Index

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

A

ABNF_REQUIRED_QUOTING - Static variable in class org.eclipse.jetty.http.QuotedCSV
ABNF from RFC 2616, RFC 822, and RFC 6455 specified characters requiring quoting.
ABNF_REQUIRED_QUOTING - Static variable in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
ABNF from RFC 2616, RFC 822, and RFC 6455 specified characters requiring quoting.
ABNORMAL - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
Abnormal Close is a synonym for StatusCode.NO_CLOSE, used to indicate a close condition where no close frame was processed from the remote side.
abort() - Method in class org.eclipse.jetty.http.HttpGenerator
 
abort() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
abort() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
 
abort() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
Issue a harsh abort of the underlying connection.
abort() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
abort() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
abort() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
abort(String, Throwable, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
abort(Throwable) - Method in interface org.eclipse.jetty.client.api.Request
Attempts to abort the send of this request.
abort(Throwable) - Method in interface org.eclipse.jetty.client.api.Response
Attempts to abort the receive of this response.
abort(Throwable) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpContentResponse
 
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpConversation
 
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpDestination
Aborts all the HttpExchanges queued in this destination.
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpExchange
 
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpRequest
 
abort(Throwable) - Method in class org.eclipse.jetty.client.HttpResponse
 
abort(Throwable) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
abort(Throwable) - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
abort(Throwable) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
abort(Throwable) - Method in class org.eclipse.jetty.server.HttpChannel
If a write or similar operation to this channel fails, then this method should be called.
abort(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
abort(Throwable) - Method in class org.eclipse.jetty.server.HttpConnection
 
abort(Throwable) - Method in interface org.eclipse.jetty.server.HttpTransport
Aborts this transport.
abort(HttpExchange, Throwable) - Method in class org.eclipse.jetty.client.HttpReceiver
 
abort(HttpExchange, Throwable) - Method in class org.eclipse.jetty.client.HttpSender
 
abort(HttpExchange, Throwable, Throwable) - Method in class org.eclipse.jetty.client.HttpChannel
 
abort(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
abort(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
abort(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
 
abort(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
ABORT_REQUEST - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
abortResponse() - Method in class org.eclipse.jetty.server.HttpChannelState
 
abortResponse(HttpExchange, Throwable) - Method in class org.eclipse.jetty.client.HttpChannel
 
AbsoluteOrdering - Class in org.eclipse.jetty.webapp
AbsoluteOrdering
AbsoluteOrdering(MetaData) - Constructor for class org.eclipse.jetty.webapp.AbsoluteOrdering
 
AbstractAuthentication - Class in org.eclipse.jetty.client.util
 
AbstractAuthentication(URI, String) - Constructor for class org.eclipse.jetty.client.util.AbstractAuthentication
 
AbstractCallbackHandler - Class in org.eclipse.jetty.jaas.callback
 
AbstractCallbackHandler() - Constructor for class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
AbstractConfiguration - Class in org.eclipse.jetty.webapp
 
AbstractConfiguration() - Constructor for class org.eclipse.jetty.webapp.AbstractConfiguration
 
AbstractConfiguration(boolean) - Constructor for class org.eclipse.jetty.webapp.AbstractConfiguration
 
AbstractConnection - Class in org.eclipse.jetty.io
A convenience base implementation of Connection.
AbstractConnection(EndPoint, Executor) - Constructor for class org.eclipse.jetty.io.AbstractConnection
 
AbstractConnectionFactory - Class in org.eclipse.jetty.server
Provides the common handling for ConnectionFactory implementations.
AbstractConnectionFactory(String) - Constructor for class org.eclipse.jetty.server.AbstractConnectionFactory
 
AbstractConnectionFactory(String...) - Constructor for class org.eclipse.jetty.server.AbstractConnectionFactory
 
AbstractConnectionPool - Class in org.eclipse.jetty.client
 
AbstractConnectionPool(HttpDestination, int, boolean, Callback) - Constructor for class org.eclipse.jetty.client.AbstractConnectionPool
 
AbstractConnectionPool(HttpDestination, Pool.StrategyType, int, boolean, Callback) - Constructor for class org.eclipse.jetty.client.AbstractConnectionPool
 
AbstractConnectionPool(HttpDestination, Pool<Connection>, Callback) - Constructor for class org.eclipse.jetty.client.AbstractConnectionPool
 
AbstractConnector - Class in org.eclipse.jetty.server
An abstract implementation of Connector that provides a ConnectionFactory mechanism for creating Connection instances for various protocols (HTTP, SSL, etc).
AbstractConnector(Server, Executor, Scheduler, ByteBufferPool, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.AbstractConnector
 
AbstractConnectorHttpClientTransport - Class in org.eclipse.jetty.client
 
AbstractConnectorHttpClientTransport(ClientConnector) - Constructor for class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
AbstractConnectorMBean - Class in org.eclipse.jetty.server.jmx
 
AbstractConnectorMBean(Object) - Constructor for class org.eclipse.jetty.server.jmx.AbstractConnectorMBean
 
AbstractContextProvider - Class in org.eclipse.jetty.osgi.boot
AbstractContextProvider Base class for DeploymentManager Providers that can deploy ContextHandlers into Jetty that have been discovered via OSGI either as bundles or services.
AbstractContextProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractContextProvider
 
AbstractContextProvider.OSGiApp - Class in org.eclipse.jetty.osgi.boot
OSGiApp
AbstractDatabaseLoginModule - Class in org.eclipse.jetty.jaas.spi
AbstractDatabaseLoginModule Abstract base class for LoginModules that interact with a database to retrieve authentication and authorization information.
AbstractDatabaseLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule
 
AbstractDatabaseLoginModule.JDBCUser - Class in org.eclipse.jetty.jaas.spi
 
AbstractDecodedMessageSink - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
AbstractDecodedMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink
 
AbstractDecodedMessageSink.Basic<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
AbstractDecodedMessageSink.Stream<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
AbstractDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
AbstractDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.AbstractDecoder
 
AbstractDiscoverableAnnotationHandler - Class in org.eclipse.jetty.annotations
DiscoverableAnnotationHandler Base class for handling the discovery of an annotation.
AbstractDiscoverableAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.AbstractDiscoverableAnnotationHandler
 
AbstractEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
 
AbstractEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.AbstractEncoder
 
AbstractEndPoint - Class in org.eclipse.jetty.io
Partial implementation of EndPoint that uses FillInterest and WriteFlusher.
AbstractEndPoint(Scheduler) - Constructor for class org.eclipse.jetty.io.AbstractEndPoint
 
AbstractExtension - Class in org.eclipse.jetty.websocket.core
 
AbstractExtension() - Constructor for class org.eclipse.jetty.websocket.core.AbstractExtension
 
AbstractFlowControlStrategy - Class in org.eclipse.jetty.http2
 
AbstractFlowControlStrategy(int) - Constructor for class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
AbstractHandler - Class in org.eclipse.jetty.server.handler
AbstractHandler.
AbstractHandler() - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
AbstractHandler() - Constructor for class org.eclipse.jetty.server.handler.AbstractHandler
 
AbstractHandler.ErrorDispatchHandler - Class in org.eclipse.jetty.server.handler
Deprecated.
This class is no longer required as ERROR dispatch is only done if there is an error page target.
AbstractHandlerContainer - Class in org.eclipse.jetty.server.handler
Abstract Handler Container.
AbstractHandlerContainer() - Constructor for class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
AbstractHandlerMBean - Class in org.eclipse.jetty.server.handler.jmx
 
AbstractHandlerMBean(Object) - Constructor for class org.eclipse.jetty.server.handler.jmx.AbstractHandlerMBean
 
AbstractHandshaker - Class in org.eclipse.jetty.websocket.core.server.internal
 
AbstractHandshaker() - Constructor for class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
AbstractHTTP2ServerConnectionFactory - Class in org.eclipse.jetty.http2.server
 
AbstractHTTP2ServerConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
AbstractHTTP2ServerConnectionFactory(HttpConfiguration, String...) - Constructor for class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer - Class in org.eclipse.jetty.http2.server
 
AbstractHTTP3ServerConnectionFactory - Class in org.eclipse.jetty.http3.server
 
AbstractHTTP3ServerConnectionFactory(HttpConfiguration, Session.Server.Listener) - Constructor for class org.eclipse.jetty.http3.server.AbstractHTTP3ServerConnectionFactory
 
AbstractHttpClientTransport - Class in org.eclipse.jetty.client
 
AbstractHttpClientTransport() - Constructor for class org.eclipse.jetty.client.AbstractHttpClientTransport
 
AbstractIntrospectableAnnotationHandler(boolean, WebAppContext) - Constructor for class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
AbstractLeakPreventer - Class in org.eclipse.jetty.util.preventers
AbstractLeakPreventer Abstract base class for code that seeks to avoid pinning of webapp classloaders by using the jetty classloader to proactively call the code that pins them (generally pinned as static data members, or as static data members that are daemon threads (which use the context classloader)).
AbstractLeakPreventer() - Constructor for class org.eclipse.jetty.util.preventers.AbstractLeakPreventer
 
AbstractLifeCycle - Class in org.eclipse.jetty.util.component
Basic implementation of the life cycle interface for components.
AbstractLifeCycle() - Constructor for class org.eclipse.jetty.util.component.AbstractLifeCycle
 
AbstractLifeCycle.AbstractLifeCycleListener - Class in org.eclipse.jetty.util.component
Deprecated.
this class is redundant now that LifeCycle.Listener has default methods.
AbstractLifeCycle.StopException - Exception Class in org.eclipse.jetty.util.component
An exception, which if thrown by doStart will immediately stop the component
AbstractLifeCycleListener() - Constructor for class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
AbstractLoginModule - Class in org.eclipse.jetty.jaas.spi
AbstractLoginModule Abstract base class for all LoginModules.
AbstractLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
AbstractLoginModule.JAASUser - Class in org.eclipse.jetty.jaas.spi
 
AbstractLoginService - Class in org.eclipse.jetty.security
AbstractLoginService Base class for LoginServices that allows subclasses to provide the user authentication and authorization information, but provides common behaviour such as handling authentication.
AbstractLoginService() - Constructor for class org.eclipse.jetty.security.AbstractLoginService
 
AbstractMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
AbstractMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.AbstractMessageSink
 
AbstractNegotiator() - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketNegotiator.AbstractNegotiator
 
AbstractNegotiator(Configuration.Customizer) - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketNegotiator.AbstractNegotiator
 
AbstractNetworkConnector - Class in org.eclipse.jetty.server
An abstract Network Connector.
AbstractNetworkConnector(Server, Executor, Scheduler, ByteBufferPool, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.AbstractNetworkConnector
 
AbstractOSGiApp - Class in org.eclipse.jetty.osgi.boot
AbstractOSGiApp Base class representing info about a webapp/ContextHandler that is deployed into Jetty.
AbstractOSGiApp(DeploymentManager, AppProvider, Bundle, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
AbstractOSGiApp(DeploymentManager, AppProvider, Bundle, Dictionary<?, ?>, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
AbstractPathSpec - Class in org.eclipse.jetty.http.pathmap
 
AbstractPathSpec() - Constructor for class org.eclipse.jetty.http.pathmap.AbstractPathSpec
 
AbstractProxyServlet - Class in org.eclipse.jetty.proxy
Abstract base class for proxy servlets.
AbstractProxyServlet() - Constructor for class org.eclipse.jetty.proxy.AbstractProxyServlet
 
AbstractProxyServlet.TransparentDelegate - Class in org.eclipse.jetty.proxy
Utility class that implement transparent proxy functionalities.
AbstractRequestContent - Class in org.eclipse.jetty.client.util
Partial implementation of Request.Content.
AbstractRequestContent(String) - Constructor for class org.eclipse.jetty.client.util.AbstractRequestContent
 
AbstractRequestContent.AbstractSubscription - Class in org.eclipse.jetty.client.util
Partial implementation of Subscription.
AbstractRequestContent.Producer - Interface in org.eclipse.jetty.client.util
 
AbstractSessionCache - Class in org.eclipse.jetty.server.session
AbstractSessionCache A base implementation of the SessionCache interface for managing a set of Session objects pertaining to a context in memory.
AbstractSessionCache(SessionHandler) - Constructor for class org.eclipse.jetty.server.session.AbstractSessionCache
 
AbstractSessionCacheFactory - Class in org.eclipse.jetty.server.session
AbstractSessionCacheFactory Base class for SessionCacheFactories.
AbstractSessionCacheFactory() - Constructor for class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
AbstractSessionDataStore - Class in org.eclipse.jetty.server.session
AbstractSessionDataStore
AbstractSessionDataStore() - Constructor for class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
AbstractSessionDataStoreFactory - Class in org.eclipse.jetty.server.session
AbstractSessionDataStoreFactory
AbstractSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.server.session.AbstractSessionDataStoreFactory
 
AbstractSubscription(Request.Content.Consumer, boolean) - Constructor for class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
 
AbstractTypedContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
AbstractTypedContentProvider(String) - Constructor for class org.eclipse.jetty.client.util.AbstractTypedContentProvider
Deprecated.
 
AbstractUserAuthentication - Class in org.eclipse.jetty.security
AbstractUserAuthentication Base class for representing an authenticated user.
AbstractUserAuthentication(String, UserIdentity) - Constructor for class org.eclipse.jetty.security.AbstractUserAuthentication
 
AbstractWebAppProvider - Class in org.eclipse.jetty.osgi.boot
AbstractWebAppProvider
AbstractWebAppProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
AbstractWebAppProvider.OSGiApp - Class in org.eclipse.jetty.osgi.boot
OSGiApp Represents a deployable webapp.
accept(int) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
accept(int) - Method in class org.eclipse.jetty.server.AbstractConnector
 
accept(int) - Method in class org.eclipse.jetty.server.LocalConnector
 
accept(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
accept(int) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
accept(ServletContext, ServerContainer) - Method in interface org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer.Configurator
 
accept(ServletContext, JettyWebSocketServerContainer) - Method in interface org.eclipse.jetty.websocket.server.config.JettyWebSocketServletContainerInitializer.Configurator
 
accept(File, String) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider.Filter
 
accept(String...) - Method in interface org.eclipse.jetty.client.api.Request
 
accept(String...) - Method in class org.eclipse.jetty.client.HttpRequest
 
accept(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
accept(SelectableChannel, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a channel to perform non-blocking read/write operations.
accept(SelectableChannel, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
accept(SocketChannel, ClientConnectionFactory, Session.Listener, Promise<Session>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
accept(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
accept(Connection) - Method in interface org.eclipse.jetty.client.ConnectionPool
Accepts the given connection to be managed by this ConnectionPool.
accept(Connection) - Method in class org.eclipse.jetty.client.HttpDestination
 
accept(Request, Response) - Method in class org.eclipse.jetty.client.ContinueProtocolHandler
 
accept(Request, Response) - Method in interface org.eclipse.jetty.client.ProtocolHandler
Inspects the given request and response to detect whether this protocol handler should handle them.
accept(Request, Response) - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
accept(Request, Response) - Method in class org.eclipse.jetty.client.RedirectProtocolHandler
 
accept(Request, Response) - Method in class org.eclipse.jetty.client.UpgradeProtocolHandler
 
accept(Request, Response) - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
accept(SslContextFactory, SocketChannel, Session.Listener, Promise<Session>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.ByteArrayMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.ByteBufferMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.DispatchedMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
accept(Frame, Callback) - Method in interface org.eclipse.jetty.websocket.core.internal.messages.MessageSink
Consume the frame payload to the message.
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.PartialByteArrayMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.PartialByteBufferMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.PartialStringMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.StringMessageSink
 
accept(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink
 
ACCEPT - Enum constant in enum org.eclipse.jetty.http.HttpHeader
Request Fields.
ACCEPT_CHARSET - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ACCEPT_ENCODING - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ACCEPT_LANGUAGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ACCEPT_RANGES - Enum constant in enum org.eclipse.jetty.http.HttpHeader
Response Fields.
accepted(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method when a channel is accepted from the ServerSocketChannel passed to SelectorManager.acceptor(SelectableChannel).
accepted(SelectableChannel) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
accepted(SelectableChannel) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
accepted(UnixSocketChannel) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
ACCEPTED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
ACCEPTED_202 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
acceptHeaders(Request, Response) - Method in class org.eclipse.jetty.client.UpgradeProtocolHandler
 
acceptor(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a server channel for accept operations.
Acceptors - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
AcceptRateLimit - Class in org.eclipse.jetty.server
A Listener that limits the rate at which new connections are accepted
AcceptRateLimit(int, long, TimeUnit, Connector...) - Constructor for class org.eclipse.jetty.server.AcceptRateLimit
 
AcceptRateLimit(int, long, TimeUnit, Server) - Constructor for class org.eclipse.jetty.server.AcceptRateLimit
 
access(long) - Method in class org.eclipse.jetty.server.session.Session
 
access(HttpSession, boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
Called by the SessionHandler when a session is first accessed by a request.
ACCESSED - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
AccessTuple(String, InetAddress, String) - Constructor for class org.eclipse.jetty.server.handler.InetAccessSet.AccessTuple
 
ACK - Static variable in interface org.eclipse.jetty.http2.Flags
 
acknowledgeLicenses() - Method in class org.eclipse.jetty.start.Licensing
 
ACL - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
ACL_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
acquire() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
acquire() - Method in class org.eclipse.jetty.util.Pool
Acquires an entry from the pool.
acquire() - Method in class org.eclipse.jetty.util.SharedBlockingCallback
 
acquire(boolean) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
Returns an idle connection, if available; if an idle connection is not available, and the given create parameter is true or AbstractConnectionPool.isMaximizeConnections() is true, then attempts to open a new connection, if possible within the configuration of this connection pool (for example, if it does not exceed the max connection count); otherwise it attempts to open a new connection, if the number of queued requests is greater than the number of pending connections; if no connection is available even after the attempts to open, return null.
acquire(boolean) - Method in interface org.eclipse.jetty.client.ConnectionPool
Returns an idle connection, if available; if an idle connection is not available, and the given create parameter is true, then schedules the opening of a new connection, if possible within the configuration of this connection pool (for example, if it does not exceed the max connection count); otherwise returns null.
acquire(int) - Method in class org.eclipse.jetty.http.GZIPContentDecoder
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
acquire(int, boolean) - Method in interface org.eclipse.jetty.io.ByteBufferPool
Requests a ByteBuffer of the given size.
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.NullByteBufferPool
 
acquire(int, boolean) - Method in interface org.eclipse.jetty.io.RetainableByteBufferPool
Acquires a memory buffer from the pool.
acquire(int, boolean) - Method in class org.eclipse.jetty.io.RetainableByteBufferPool.NotRetainedByteBufferPool
 
acquire(Function<Pool.Entry, T>) - Method in class org.eclipse.jetty.util.Pool
Acquires an entry from the pool, reserving and creating a new entry if necessary.
acquired(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
acquired(Connection) - Method in class org.eclipse.jetty.client.LeakTrackingConnectionPool
 
acquired(T) - Method in class org.eclipse.jetty.util.LeakDetector
Tracks the resource as been acquired.
acquireHttpChannel() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
acquireHttpChannel(int, Request) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
acquireWriteBlockingCallback() - Method in class org.eclipse.jetty.server.HttpOutput
 
activate() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
Adapter() - Constructor for class org.eclipse.jetty.client.api.Request.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.client.api.Response.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.fcgi.parser.ClientParser.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.fcgi.parser.ServerParser.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.http2.api.server.ServerSessionListener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.http2.parser.ServerParser.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.io.Connection.Listener.Adapter
 
Adapter() - Constructor for class org.eclipse.jetty.util.Promise.Adapter
 
AdaptiveExecutionStrategy - Class in org.eclipse.jetty.util.thread.strategy
An adaptive execution strategy that uses the Invocable status of both the task and the current thread to select an optimal strategy that prioritizes executing the task immediately in the current producing thread if it can be done so without thread starvation issues.
AdaptiveExecutionStrategy(ExecutionStrategy.Producer, Executor) - Constructor for class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
Adaptor() - Constructor for class org.eclipse.jetty.websocket.api.WriteCallback.Adaptor
Deprecated.
 
adaptTo(DatabaseMetaData) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
add(int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically adds the given deltas to the current hi and lo values.
add(int, E) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
add(int, Object) - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
add(long) - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
 
add(long) - Method in class org.eclipse.jetty.util.statistic.RateCounter
 
add(E) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
add(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
add(Object) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
add(Object, int, Object) - Static method in class org.eclipse.jetty.util.LazyList
Add an item to a LazyList
add(Object, Object) - Static method in class org.eclipse.jetty.util.LazyList
Add an item to a LazyList
add(String) - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
add(String) - Method in class org.eclipse.jetty.util.AsciiLowerCaseSet
 
add(String) - Method in class org.eclipse.jetty.util.InetAddressSet
 
add(String) - Method in class org.eclipse.jetty.util.RegexSet
 
add(String) - Method in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
add(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
add(String...) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
add(String...) - Method in class org.eclipse.jetty.webapp.Configurations
 
add(String, boolean) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
add(String, double) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
add(String, long) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
add(String, Object) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
add(String, String) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Add to or set a field.
add(String, String) - Method in class org.eclipse.jetty.util.Fields
Adds the given value to a field with the given name, creating a Fields.Field is none exists for the given name.
add(String, Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Add an entirely new session (created by the application calling Request.getSession(true)) to the cache.
add(String, Session) - Method in interface org.eclipse.jetty.server.session.SessionCache
Adds a new Session, with a never-before-used id, to the cache.
add(String, V) - Method in class org.eclipse.jetty.util.MultiMap
Add value to multi valued entry.
add(Throwable) - Method in exception class org.eclipse.jetty.util.MultiException
 
add(URI, HttpCookie) - Method in class org.eclipse.jetty.util.HttpCookieStore
 
add(URI, HttpCookie) - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
add(Connector) - Method in class org.eclipse.jetty.ant.types.Connectors
Adds a connector to the list of connectors to deploy.
add(Edge) - Method in class org.eclipse.jetty.deploy.graph.Path
 
add(HttpField) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
add(HttpField) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
add(HttpFields) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
add(HttpHeader, String) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Add to or set a field.
add(HttpHeader, HttpHeaderValue) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
add(Injection) - Method in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
add(LifeCycleCallback) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Add a Callback to the list of callbacks.
add(RunAs) - Method in class org.eclipse.jetty.plus.annotation.RunAsCollection
Deprecated.
 
add(LoginService) - Method in class org.eclipse.jetty.ant.types.LoginServices
 
add(ContextHandler) - Method in class org.eclipse.jetty.ant.types.ContextHandlers
 
add(InetAccessSet.PatternTuple) - Method in class org.eclipse.jetty.server.handler.InetAccessSet
 
add(ConfigSource) - Method in class org.eclipse.jetty.start.config.ConfigSources
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
add(ClassMatcher.Entry) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
add(Configuration) - Method in class org.eclipse.jetty.webapp.Configurations
 
add(Configuration...) - Method in class org.eclipse.jetty.webapp.Configurations
 
add(T[], T[]) - Static method in class org.eclipse.jetty.util.ArrayUtil
Add arrays
addAliasCheck(ContextHandler.AliasCheck) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Add an AliasCheck instance to possibly permit aliased resources
addAll(List<String>, Path) - Method in class org.eclipse.jetty.start.RawArgs
 
addAll(Props) - Method in class org.eclipse.jetty.start.Props
 
addAll(Attributes) - Method in class org.eclipse.jetty.util.AttributesMap
 
addAllValues(MultiMap<V>) - Method in class org.eclipse.jetty.util.MultiMap
Merge values.
addAndGetHi(int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically adds the given delta to the current hi value, returning the updated hi value.
addAndGetLo(int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically adds the given delta to the current lo value, returning the updated lo value.
addAnnotatedTypeName(String) - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
A class has been found that has an annotation of interest to this initializer.
addAnnotation(DiscoveredAnnotation) - Method in class org.eclipse.jetty.annotations.AbstractDiscoverableAnnotationHandler
 
addApp(App) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Receive an app for processing.
addApplicableTypeName(String) - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
addAppProvider(AppProvider) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
addArg(String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
Add a simple argument to the command line, quoted if necessary.
addArg(String, String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
Add a "name=value" style argument to the command line with name and value quoted if necessary.
addArg(String, String) - Method in class org.eclipse.jetty.start.RawArgs
 
addArray(Object, Object[]) - Static method in class org.eclipse.jetty.util.LazyList
Add the contents of an array to a LazyList
addAttribute(Attribute) - Method in class org.eclipse.jetty.ant.types.Attributes
 
addAttributes(Attributes) - Method in class org.eclipse.jetty.ant.AntWebAppContext
Adds a new Ant's attributes tag object if it have not been created yet.
addAuthentication(Authentication) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
 
addAuthentication(Authentication) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
addAuthenticationResult(Authentication.Result) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
 
addAuthenticationResult(Authentication.Result) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
addBean(Object) - Method in interface org.eclipse.jetty.util.component.Container
Add a bean.
addBean(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Adds the given bean, detecting whether to manage it or not.
addBean(Object, boolean) - Method in interface org.eclipse.jetty.util.component.Container
Adds the given bean, explicitly managing it or not.
addBean(Object, boolean) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Adds the given bean, explicitly managing it or not.
addBean(Object, Object) - Static method in interface org.eclipse.jetty.util.component.Container
A utility method to add a bean to a container.
addBean(Object, Object, boolean) - Static method in interface org.eclipse.jetty.util.component.Container
A utility method to add a bean to a container.
addBeanToAllConnectors(Object) - Method in class org.eclipse.jetty.server.Server
Add a bean to all connectors on the server.
addBeforeAfter(T, T) - Method in class org.eclipse.jetty.util.TopologicalSort
An alternative to TopologicalSort.addDependency(Object, Object[]), which is equivalent to addDependency(after,before) as the after item is dependent of the before item.
addBinding(Name, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Add a name to object binding to this Context.
addBinding(AppLifeCycle.Binding) - Method in class org.eclipse.jetty.deploy.AppLifeCycle
 
addBinding(AppLifeCycle.Binding) - Method in class org.eclipse.jetty.deploy.bindings.OrderedGroupBinding
 
addBindings(AppLifeCycle.Binding[]) - Method in class org.eclipse.jetty.deploy.bindings.OrderedGroupBinding
 
addBytesIn(long) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
addBytesOut(long) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
addClass(Class<?>) - Method in interface org.eclipse.jetty.util.ajax.JSON.Output
 
addClasses(Class<?>...) - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
Add classes to be passed to the ServletContainerInitializer.onStartup(Set, ServletContext) call.
addClasses(String...) - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
Add classes to be passed to the ServletContainerInitializer.onStartup(Set, ServletContext) call.
addClasses(FileSet) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
addClassName(String) - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
addClasspath(String) - Method in class org.eclipse.jetty.start.Classpath
 
addClassPath(String) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
Parse the classpath ourselves to be able to filter things.
addClassPath(String) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
addClassPath(Resource) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
addClassThatIdentifiesAJarThatMustBeRejected(Class<?>) - Static method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
addClassThatIdentifiesAJarThatMustBeRejected(String) - Static method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
addCollection(Object, Collection<?>) - Static method in class org.eclipse.jetty.util.LazyList
Add the contents of a Collection to a LazyList
addComponent(File) - Method in class org.eclipse.jetty.start.Classpath
 
addComponent(String) - Method in class org.eclipse.jetty.start.Classpath
 
addConfiguration(Configuration...) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
addConnectionFactory(ConnectionFactory) - Method in class org.eclipse.jetty.server.AbstractConnector
 
addConnector(Connector) - Method in class org.eclipse.jetty.server.Server
 
addConnectors(Connectors) - Method in class org.eclipse.jetty.ant.JettyRunTask
Adds a new Ant's connector tag object if it have not been created yet.
addConstraintMapping(ConstraintMapping) - Method in interface org.eclipse.jetty.security.ConstraintAware
Add a Constraint Mapping.
addConstraintMapping(ConstraintMapping) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
addContainerResource(Resource) - Method in class org.eclipse.jetty.webapp.MetaData
 
addContainerTldBundleDiscoverer(TldBundleDiscoverer) - Static method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
addContentHandler(String, ContentHandler) - Method in class org.eclipse.jetty.xml.XmlParser
Add a ContentHandler.
addContextHandlers(ContextHandlers) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
addConvertor(Class<?>, JSON.Convertor) - Method in class org.eclipse.jetty.util.ajax.JSON
Registers a JSON.Convertor for the given class.
addConvertorFor(String, JSON.Convertor) - Method in class org.eclipse.jetty.util.ajax.JSON
Registers a JSON.Convertor for a named class.
addCookie(Cookie) - Method in class org.eclipse.jetty.server.Response
 
addCookie(Cookie) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
addCookie(Cookie) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
addCookie(String, String, int, String, String, String) - Method in interface org.eclipse.jetty.http.CookieParser.Handler
 
addCookie(String, String, int, String, String, String) - Method in class org.eclipse.jetty.server.Cookies
 
addCookie(HttpCookie) - Method in class org.eclipse.jetty.server.Response
 
addCookieField(String) - Method in class org.eclipse.jetty.server.Cookies
 
addCSV(String, String...) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Add comma separated values, but only if not already present.
addCSV(HttpHeader, String...) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Add comma separated values, but only if not already present.
addCustomizer(HttpConfiguration.Customizer) - Method in class org.eclipse.jetty.server.HttpConfiguration
Adds a HttpConfiguration.Customizer that is invoked for every request received.
addDateField(String, long) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Sets the value of a date field.
addDateHeader(String, long) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormResponse
 
addDateHeader(String, long) - Method in class org.eclipse.jetty.server.Response
 
addDateHeader(String, long) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
addDateHeader(String, long) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
addDecorator(Decorator) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
addDependencies(Class<? extends Configuration>...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Add configuration classes that come before this configuration
addDependencies(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Add configuration classes that come before this configuration
addDependency(T, T...) - Method in class org.eclipse.jetty.util.TopologicalSort
Add a dependency to be considered in the sort.
addDependents(Class<?>...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Add configuration classes that come after this configuration
addDependents(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Add configuration classes that come after this configuration
addDescriptorProcessor(DescriptorProcessor) - Method in class org.eclipse.jetty.webapp.MetaData
 
addDirectory(Path) - Method in class org.eclipse.jetty.util.Scanner
Add a directory to be scanned.
addDirectoryScanner(DirectoryScanner) - Method in class org.eclipse.jetty.ant.types.FileMatchingConfiguration
 
addDiscoverableAnnotationHandler(AbstractDiscoverableAnnotationHandler) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
addDiscoveredAnnotation(DiscoveredAnnotation) - Method in class org.eclipse.jetty.webapp.MetaData
Add an annotation that has been discovered on a class, method or field within a resource eg a jar or dir.
addDiscoveredAnnotations(List<DiscoveredAnnotation>) - Method in class org.eclipse.jetty.webapp.MetaData
Annotations such as WebServlet, WebFilter, WebListener that can be discovered by scanning unloaded classes.
ADDED - Enum constant in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
 
addEdge(String, String) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
addEdge(Edge) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
addEncodedPaths(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Add two encoded URI path segments.
addEndpoint(ServerEndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
addEndpoint(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
addEntry(ByteBuffer, Callback) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
addEqualsArg(String, String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
addErrorPage(int, int, String) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
Adds ErrorPage mapping for a status code range.
addErrorPage(int, String) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
Adds ErrorPage mapping for a status code.
addErrorPage(Class<? extends Throwable>, String) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
Adds ErrorPage mapping for an exception class.
addErrorPage(String, String) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
Adds ErrorPage mapping for an exception class.
addEventListener(EventListener) - Method in class org.eclipse.jetty.io.AbstractConnection
 
addEventListener(EventListener) - Method in interface org.eclipse.jetty.io.Connection
Adds a listener of connection events.
addEventListener(EventListener) - Method in class org.eclipse.jetty.io.SelectorManager
 
addEventListener(EventListener) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
addEventListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Add a context event listeners.
addEventListener(EventListener) - Method in class org.eclipse.jetty.server.Request
 
addEventListener(EventListener) - Method in class org.eclipse.jetty.server.session.SessionHandler
Adds an event listener for session-related events.
addEventListener(EventListener) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Add EventListener
addEventListener(EventListener) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
addEventListener(EventListener) - Method in interface org.eclipse.jetty.util.component.Container
Add an event listener.
addEventListener(EventListener) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
addEventListener(EventListener) - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
addExclude(String) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add an exclude PathMatcher.
addExclude(PathMatcher) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add an exclude PathMatcher
addExcludeCipherSuites(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Cipher suite name or a a regular expression.
addExcludedInflationPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Adds excluded Path Specs for request filtering on request inflation.
addExcludedMethods(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Add excluded to the HTTP methods filtering.
addExcludedMimeTypes(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Adds excluded MIME types for response filtering.
addExcludedPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Adds excluded Path Specs for request filtering.
addExcludeGlobRelative(String) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add a glob: syntax pattern exclude reference in a directory relative, os neutral, pattern.
addExcludeHidden() - Method in class org.eclipse.jetty.util.PathWatcher.Config
Exclude hidden files and hidden directories
addExcludeProtocols(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Protocol name or a a regular expression.
addExcludes(List<String>) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add multiple exclude PathMatchers
addExtensions(String...) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Add WebSocket Extension Configuration(s) to request
addExtensions(String...) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
addExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
addExtensions(ExtensionConfig...) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Add WebSocket Extension Configuration(s) to Upgrade Request.
addExtensions(ExtensionConfig...) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
addFieldPart(String, ContentProvider, HttpFields) - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
Adds a field part with the given name as field name, and the given content as part content.
addFieldPart(String, Request.Content, HttpFields) - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
Adds a field part with the given name as field name, and the given content as part content.
addFile(File) - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
addFile(String) - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
addFile(Path) - Method in class org.eclipse.jetty.util.Scanner
Add a file to be scanned.
addFilePart(String, String, ContentProvider, HttpFields) - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
Adds a file part with the given name as field name, the given fileName as file name, and the given content as part content.
addFilePart(String, String, Request.Content, HttpFields) - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
Adds a file part with the given name as field name, the given fileName as file name, and the given content as part content.
addFiles(Collection<File>) - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
addFilter(Class<? extends Filter>, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a filter
addFilter(Class<? extends Filter>, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addFilter(String, Filter) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addFilter(String, Filter) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addFilter(String, Class<? extends Filter>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addFilter(String, Class<? extends Filter>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addFilter(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addFilter(String, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addFilter(String, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a filter
addFilter(String, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addFilter(FilterHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a preconstructed FilterHolder
addFilter(FilterHolder, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a filter
addFilter(FilterHolder, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addFilter(FilterHolder, FilterMapping) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter and mapping
addFilterMapping(String, XmlParser.Node, WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
addFilterMapping(FilterMapping) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a preconstructed FilterMapping
addFilterWithMapping(Class<? extends Filter>, String, int) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFilterWithMapping(Class<? extends Filter>, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFilterWithMapping(String, String, int) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFilterWithMapping(String, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFilterWithMapping(FilterHolder, String, int) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFilterWithMapping(FilterHolder, String, EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a filter.
addFirstConnectionFactory(ConnectionFactory) - Method in class org.eclipse.jetty.server.AbstractConnector
 
addFormEncodedMethod(String) - Method in class org.eclipse.jetty.server.HttpConfiguration
Adds a form encoded HTTP Method
addFragmentDescriptor(Resource, FragmentDescriptor) - Method in class org.eclipse.jetty.webapp.MetaData
Add a web-fragment.xml, and the jar it is contained in.
addGetter(String, Method) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
addHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
Adds a handler.
addHandshakeListener(SslHandshakeListener) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
addHeader(String, String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormResponse
 
addHeader(String, String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
addHeader(String, String) - Method in class org.eclipse.jetty.server.Response
 
addHeader(String, String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
addHeader(String, String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
addHeader(String, String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
addHeader(String, String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
addHeader(String, String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Add a header value to the response.
addHeader(HttpField) - Method in class org.eclipse.jetty.client.HttpRequest
 
addHeader(HttpField) - Method in class org.eclipse.jetty.client.HttpResponse
 
addIfAbsentConnectionFactory(ConnectionFactory) - Method in class org.eclipse.jetty.server.AbstractConnector
 
addInclude(String) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add an include PathMatcher
addInclude(PathMatcher) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add an include PathMatcher
addIncludeCoda(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
addIncludedInflationPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Add included Path Specs for filtering on request inflation.
addIncludedMethods(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Adds included HTTP Methods (eg: POST, PATCH, DELETE) for filtering.
addIncludedMimeTypes(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Add included MIME types for response filtering
addIncludedPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Add included Path Specs for filtering.
addIncludeGlobRelative(String) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add a glob: syntax pattern reference in a directory relative, os neutral, pattern.
addIncludePrelude(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
addIncludes(List<String>) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Add multiple include PathMatchers
addingBundle(Bundle, BundleEvent) - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider.ContextBundleTracker
 
addingBundle(Bundle, BundleEvent) - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider.WebAppTracker
 
addingService(ServiceReference) - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.JettyServerServiceTracker
 
addingService(ServiceReference) - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ContextTracker
 
addingService(ServiceReference) - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.WebAppTracker
 
addInjections(WebAppContext, Descriptor, XmlParser.Node, String, Class<?>) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Iterate over the <injection-target> entries for a node
addInput(String) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInput(String, Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInput(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInputAndExecute(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInputEOF() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInterceptor(HttpInput.Interceptor) - Method in class org.eclipse.jetty.server.HttpInput
Set the HttpInput.Interceptor, chaining it to the existing one if an HttpInput.Interceptor is already set.
addIntHeader(String, int) - Method in class org.eclipse.jetty.server.Response
 
addIntHeader(String, int) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
addIntHeader(String, int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
addJars(Resource) - Method in class org.eclipse.jetty.runner.Runner.Classpath
Deprecated.
 
addJars(Resource) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
Add elements to the class path for the context from the jar and zip files found in the specified resource.
addJSON(Appendable) - Method in interface org.eclipse.jetty.util.ajax.JSON.Generator
 
addJSON(Appendable) - Method in class org.eclipse.jetty.util.ajax.JSON.Literal
 
addJspFile(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addJspFile(String, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addJspPropertyGroup(JspPropertyGroupDescriptor) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
addLib(FileSet) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
addLifeCycleBinding(AppLifeCycle.Binding) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
addListener(AsyncListener) - Method in class org.eclipse.jetty.server.AsyncContextState
 
addListener(AsyncListener) - Method in class org.eclipse.jetty.server.HttpChannelState
 
addListener(AsyncListener, ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.server.AsyncContextState
 
addListener(Class<? extends EventListener>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
addListener(Class<? extends EventListener>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addListener(Class<? extends EventListener>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addListener(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
addListener(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addListener(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addListener(EventListener) - Method in class org.eclipse.jetty.util.PathWatcher
Add a listener for changes the watcher notices.
addListener(NamingContext.Listener) - Method in class org.eclipse.jetty.jndi.NamingContext
 
addListener(HttpChannel.Listener) - Method in class org.eclipse.jetty.server.HttpChannel
Deprecated.
addListener(ListenerHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
Add a holder for a listener
addListener(Scanner.Listener) - Method in class org.eclipse.jetty.util.Scanner
Add an added/removed/changed listener
addListener(UpgradeListener) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
addListener(T) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
addListener(T) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addListener(T) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addLocaleEncoding(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
addLoginServices(LoginServices) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
addLowResourceCheck(LowResourceMonitor.LowResourceCheck) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
addManaged(LifeCycle) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Adds a managed lifecycle.
addMapping(String...) - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
addMapping(String, Class<?>) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
addMapping(String, WebSocketNegotiator) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
addMapping(String, JettyWebSocketCreator) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
addMapping(String, JettyWebSocketCreator) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Add a WebSocket mapping to a provided JettyWebSocketCreator.
addMapping(PathSpec, WebSocketCreator, FrameHandlerFactory, Configuration.Customizer) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
Manually add a WebSocket mapping.
addMapping(PathSpec, WebSocketNegotiator) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
Manually add a WebSocket mapping.
addMapping(PathSpec, WebSocketNegotiator) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
addMappingForServletNames(EnumSet<DispatcherType>, boolean, String...) - Method in class org.eclipse.jetty.servlet.FilterHolder.Registration
 
addMappingForUrlPatterns(EnumSet<DispatcherType>, boolean, String...) - Method in class org.eclipse.jetty.servlet.FilterHolder.Registration
 
addMessageHandler(MessageHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
addMessageHandler(Class<T>, MessageHandler.Partial<T>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
addMessageHandler(Class<T>, MessageHandler.Partial<T>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
addMessageHandler(Class<T>, MessageHandler.Whole<T>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
addMessageHandler(Class<T>, MessageHandler.Whole<T>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
addMimeMapping(String, String) - Method in class org.eclipse.jetty.http.MimeTypes
Set a mime mapping
addModule(Module) - Method in class org.eclipse.jetty.start.Licensing
 
addModule(Module, Props) - Method in interface org.eclipse.jetty.start.BaseBuilder.Config
Add a module to the start environment in ${jetty.base}
addModule(Module, Props) - Method in class org.eclipse.jetty.start.builders.StartDirBuilder
 
addModule(Module, Props) - Method in class org.eclipse.jetty.start.builders.StartIniBuilder
 
addName(String) - Method in class org.eclipse.jetty.util.ssl.X509
 
addNode(Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
addOption(String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
Adds a "-OPTION" style option to the command line with no quoting, for example `--help`.
addOption(String, String, String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
Adds a "-OPTIONname=value" style option to the command line with name and value quoted if necessary, for example "-Dprop=value".
addOthers() - Method in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
addOverrideDescriptor(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
The override descriptor is a web.xml format file that is applied to the context after the standard WEB-INF/web.xml
addOverrideDescriptor(OverrideDescriptor) - Method in class org.eclipse.jetty.webapp.MetaData
Add a override-web.xml descriptor.
addParsedClass(String, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Add a class as having been parsed.
addPath(String) - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
addPath(String) - Method in class org.eclipse.jetty.util.resource.PathResource
 
addPath(String) - Method in class org.eclipse.jetty.util.resource.Resource
Returns the resource contained inside the current resource with the given name, which may or may not exist.
addPath(String) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
Add a path to the resource collection.
addPath(String) - Method in class org.eclipse.jetty.util.resource.URLResource
Returns the resource contained inside the current resource with the given name
addPath(URI, String) - Static method in class org.eclipse.jetty.util.URIUtil
 
addPath(Resource) - Method in class org.eclipse.jetty.runner.Runner.Classpath
Deprecated.
 
addPathQuery(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Add a path and a query string
addPaths(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Add two Decoded URI path segments.
addPossibleProperty(String, String) - Method in class org.eclipse.jetty.start.Props
Add a potential argument as a property.
addProgrammaticListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Apply any necessary restrictions on a programmatic added listener.
addPropertyUserStore(String, PropertyUserStore) - Method in class org.eclipse.jetty.jaas.PropertyUserStoreManager
 
addProxy(ProxyConfiguration.Proxy) - Method in class org.eclipse.jetty.client.ProxyConfiguration
Adds a proxy.
addProxyHeaders(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
addQueries(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Combine two query strings into one.
addRawArg(String) - Method in class org.eclipse.jetty.start.CommandLineBuilder
addRequestLog(RequestLog) - Method in class org.eclipse.jetty.server.HttpChannel
 
Address(String, int) - Constructor for class org.eclipse.jetty.client.Origin.Address
 
ADDRESS_TYPE_DOMAIN - Static variable in class org.eclipse.jetty.client.Socks5
The address type for domain names used in SOCKS5 connect requests and responses.
ADDRESS_TYPE_IPV4 - Static variable in class org.eclipse.jetty.client.Socks5
The address type for IPv4 used in SOCKS5 connect requests and responses.
ADDRESS_TYPE_IPV6 - Static variable in class org.eclipse.jetty.client.Socks5
The address type for IPv6 used in SOCKS5 connect requests and responses.
addRole(String) - Method in interface org.eclipse.jetty.security.ConstraintAware
Add a Role definition.
addRole(String) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
addRole(String) - Method in class org.eclipse.jetty.security.RoleInfo
 
addRoles(String...) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
delegate for ServletContext.declareRole method
addRule(Rule) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
Add a Rule
addRule(Rule) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
Add a Rule
addScannerListener(Scanner.Listener) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
addScanTargets(FileSet) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
addScopes(String...) - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
addServerClasses(Server, String...) - Static method in class org.eclipse.jetty.webapp.WebAppContext
 
addServerClassMatcher(ClassMatcher) - Method in class org.eclipse.jetty.webapp.WebAppContext
Add a ClassMatcher for server classes by combining with any existing matcher.
addServlet(Class<? extends Servlet>, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a servlet.
addServlet(Class<? extends Servlet>, String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addServlet(String, Servlet) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addServlet(String, Servlet) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addServlet(String, Class<? extends Servlet>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addServlet(String, Class<? extends Servlet>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addServlet(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
addServlet(String, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a servlet.
addServlet(String, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
addServlet(String, String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addServlet(ServletHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a pre-constructed ServletHolder.
addServlet(ServletHolder, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to add a servlet.
addServlet(ServletHolder, String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addServletContainerInitializer(ServletContainerInitializer) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to programmatically add a ServletContainerInitializer.
addServletContainerInitializer(ServletContainerInitializer, Class<?>...) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to programmatically add a ServletContainerInitializer.
addServletContainerInitializer(ServletContainerInitializerHolder...) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Convenience method to programmatically add a list of ServletContainerInitializer.
addServletContainerInitializerHolders(ServletContainerInitializerHolder...) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.ServletContainerInitializerStarter
 
addServletMapping(String, XmlParser.Node, WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
addServletMapping(ServletMapping) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a pre-constructed ServletMapping.
addServletWithMapping(Class<? extends Servlet>, String) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a servlet.
addServletWithMapping(String, String) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a servlet.
addServletWithMapping(ServletHolder, String) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a servlet.
addSessionListener(WebSocketSessionListener) - Method in interface org.eclipse.jetty.websocket.api.WebSocketContainer
Register a WebSocketSessionListener with the container
addSessionListener(WebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
addSessionListener(WebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
addSessionListener(JakartaWebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
Register a WebSocketSessionListener with the container
addSetter(String, Method) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
addStartupClasses(Class<?>...) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.DiscoveredServletContainerInitializerHolder
Classes that are listed in @HandlesTypes and found by the createServletContainerInitializerAnnotationHandlers method.
addStartupClasses(Class<?>...) - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
addStartupClasses(String...) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.DiscoveredServletContainerInitializerHolder
Classes that have annotations that are listed in @HandlesTypes are discovered by the ContainerInitializerAnnotationHandler and added here.
addStartupClasses(String...) - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
addSystemClasses(Server, String...) - Static method in class org.eclipse.jetty.webapp.WebAppContext
 
addSystemClassMatcher(ClassMatcher) - Method in class org.eclipse.jetty.webapp.WebAppContext
Add a ClassMatcher for system classes by combining with any existing matcher.
addSystemProperties(SystemProperties) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
addSystemProperty(Property) - Method in class org.eclipse.jetty.ant.types.SystemProperties
 
addTaglibDescriptor(TaglibDescriptor) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
addThrowable(Throwable) - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
addToAllConnectors(Server) - Static method in class org.eclipse.jetty.server.ServerConnectionStatistics
Deprecated.
addToArray(T[], T, Class<?>) - Static method in class org.eclipse.jetty.util.ArrayUtil
Add element to an array
addToEnvironment(String, Object) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
addToEnvironment(String, Object) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
addToEnvironment(String, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Add an environment setting to this Context
addTransformer(ClassFileTransformer) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
addUndecoratable(String...) - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
 
addUniqueLine(String) - Method in class org.eclipse.jetty.start.StartIni
 
addUniqueLine(String) - Method in class org.eclipse.jetty.start.TextFile
 
addURL(URL) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
addUrlPattern(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
addUser(String, Credential, String[]) - Method in class org.eclipse.jetty.security.UserStore
 
addValue(String) - Method in class org.eclipse.jetty.http.QuotedCSVParser
Add and parse a value string(s)
addValues(String, List<V>) - Method in class org.eclipse.jetty.util.MultiMap
Add values to multi valued entry.
addValues(String, V[]) - Method in class org.eclipse.jetty.util.MultiMap
Add values to multi valued entry.
addViaHeader(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
Adds the HTTP Via header to the proxied request, taking into account data present in the client request.
addViaHeader(Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
Adds the HTTP Via header to the proxied request.
addVirtualHost(String) - Method in class org.eclipse.jetty.rewrite.handler.VirtualHostRuleContainer
 
addVirtualHosts(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Either set virtual hosts or add to an existing set of virtual hosts.
addVirtualHosts(String[]) - Method in class org.eclipse.jetty.servlet.ServletTester
 
addWebApp(AntWebAppContext) - Method in class org.eclipse.jetty.ant.JettyRunTask
Creates a new WebApp Ant object.
addWebApplication(AntWebAppContext) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
addWebApplication(AntWebAppContext) - Method in interface org.eclipse.jetty.ant.utils.ServerProxy
Adds a new web application to this server.
addWebFragments(WebAppContext, MetaData) - Method in class org.eclipse.jetty.webapp.FragmentConfiguration
Add in fragment descriptors that have already been discovered by MetaInfConfiguration
addWebInfResource(Resource) - Method in class org.eclipse.jetty.webapp.MetaData
 
addWelcomeFiles(WebAppContext, XmlParser.Node, Descriptor) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
addXForwardedHeaders(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
After - Enum constant in enum org.eclipse.jetty.webapp.FragmentDescriptor.OtherType
 
AFTER_NAME - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.FieldState
 
AFTER_SEND - Enum constant in enum org.eclipse.jetty.http2.CloseState.Event
 
AfterContentTransformer - Class in org.eclipse.jetty.proxy
A specialized transformer for AsyncMiddleManServlet that performs the transformation when the whole content has been received.
AfterContentTransformer() - Constructor for class org.eclipse.jetty.proxy.AfterContentTransformer
 
AfterContentTransformer.Sink - Class in org.eclipse.jetty.proxy
The target to where the transformed content is written after the transformation.
AfterContentTransformer.Source - Class in org.eclipse.jetty.proxy
The source from where the original content is read to be transformed.
afterDecoding(HttpExchange) - Method in interface org.eclipse.jetty.client.ContentDecoder
Processes the exchange after the response content has been decoded.
afterDecoding(HttpExchange) - Method in class org.eclipse.jetty.client.GZIPContentDecoder
 
afterResponse(HandshakeResponse) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.EmptyConfigurator
 
afterStartup(Consumer<ServletContext>) - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
Add a optional consumer to execute once the ServletContainerInitializer.onStartup(Set, ServletContext) has been called successfully.
age(long, TimeUnit) - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
age(long, TimeUnit) - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
AGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
agent(String) - Method in interface org.eclipse.jetty.client.api.Request
 
agent(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
AHW_ATTR - Static variable in class org.eclipse.jetty.server.handler.AsyncDelayHandler
 
AliasedX509ExtendedKeyManager - Class in org.eclipse.jetty.util.ssl
An X509ExtendedKeyManager that select a key with desired alias, delegating other processing to a nested X509ExtendedKeyManager.
AliasedX509ExtendedKeyManager(X509ExtendedKeyManager, String) - Constructor for class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
ALL - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
ALL - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
ALL_INTERFACES - Static variable in class org.eclipse.jetty.util.StringUtil
 
ALL_PARTS - Static variable in class org.eclipse.jetty.start.StartArgs
 
allocate(int) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Retained
 
allocate(int) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
allocate(int) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Retained
 
allocate(int) - Static method in class org.eclipse.jetty.util.BufferUtil
Allocate ByteBuffer in flush mode.
allocate(int, boolean) - Static method in class org.eclipse.jetty.util.BufferUtil
Allocates a ByteBuffer in flush mode.
allocateDirect(int) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Retained
 
allocateDirect(int) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
allocateDirect(int) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Retained
 
allocateDirect(int) - Static method in class org.eclipse.jetty.util.BufferUtil
Allocate ByteBuffer in flush mode.
ALLOW - Enum constant in enum org.eclipse.jetty.http.HttpHeader
Entity Fields.
AllowedResourceAliasChecker - Class in org.eclipse.jetty.server
This will approve any alias to anything inside of the ContextHandlers resource base which is not protected by a protected target as defined by ContextHandler.getProtectedTargets() at start.
AllowedResourceAliasChecker(ContextHandler) - Constructor for class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
AllowedResourceAliasChecker(ContextHandler, Supplier<Resource>) - Constructor for class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
AllowedResourceAliasChecker(ContextHandler, Resource) - Constructor for class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
allowInsecureHttpDownloads() - Method in class org.eclipse.jetty.start.fileinits.DownloadFileInitializer
 
allowInsecureHttpDownloads() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
allowInsecureHttpDownloads() - Method in class org.eclipse.jetty.start.fileinits.UriFileInitializer
 
allows(ComplianceViolation) - Method in interface org.eclipse.jetty.http.ComplianceViolation.Mode
 
allows(ComplianceViolation) - Method in class org.eclipse.jetty.http.CookieCompliance
 
allows(ComplianceViolation) - Method in class org.eclipse.jetty.http.HttpCompliance
 
allows(ComplianceViolation) - Method in class org.eclipse.jetty.http.UriCompliance
 
AllowSymLinkAliasChecker - Class in org.eclipse.jetty.server.handler
Deprecated.
AllowSymLinkAliasChecker() - Constructor for class org.eclipse.jetty.server.handler.AllowSymLinkAliasChecker
Deprecated.
 
ALPHA - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
ALPNClientConnection - Class in org.eclipse.jetty.alpn.client
 
ALPNClientConnection(EndPoint, Executor, ClientConnectionFactory, SSLEngine, Map<String, Object>, List<String>) - Constructor for class org.eclipse.jetty.alpn.client.ALPNClientConnection
 
ALPNClientConnectionFactory - Class in org.eclipse.jetty.alpn.client
 
ALPNClientConnectionFactory(Executor, ClientConnectionFactory, List<String>) - Constructor for class org.eclipse.jetty.alpn.client.ALPNClientConnectionFactory
 
ALPNProcessor - Interface in org.eclipse.jetty.io.ssl
 
ALPNProcessor.Client - Interface in org.eclipse.jetty.io.ssl
Client-side interface used by ServiceLoader.
ALPNProcessor.Server - Interface in org.eclipse.jetty.io.ssl
Server-side interface used by ServiceLoader.
ALPNServerConnection - Class in org.eclipse.jetty.alpn.server
 
ALPNServerConnection(Connector, EndPoint, SSLEngine, List<String>, String) - Constructor for class org.eclipse.jetty.alpn.server.ALPNServerConnection
 
ALPNServerConnectionFactory - Class in org.eclipse.jetty.alpn.server
 
ALPNServerConnectionFactory(String) - Constructor for class org.eclipse.jetty.alpn.server.ALPNServerConnectionFactory
 
ALPNServerConnectionFactory(String...) - Constructor for class org.eclipse.jetty.alpn.server.ALPNServerConnectionFactory
 
ALT_SVC - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
AMBIGUOUS_EMPTY_SEGMENT - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow ambiguous empty segments e.g.
AMBIGUOUS_PATH_ENCODING - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow ambiguous path encoding within a URI segment e.g.
AMBIGUOUS_PATH_PARAMETER - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow ambiguous path parameters within a URI segment e.g.
AMBIGUOUS_PATH_SEGMENT - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow ambiguous path segments e.g.
AMBIGUOUS_PATH_SEPARATOR - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow ambiguous path separator within a URI segment e.g.
AnnotatedClientEndpointConfig - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
AnnotatedClientEndpointConfig(ClientEndpoint, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.AnnotatedClientEndpointConfig
 
AnnotatedServerEndpointConfig - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
AnnotatedServerEndpointConfig(JakartaWebSocketContainer, Class<?>, ServerEndpoint) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.AnnotatedServerEndpointConfig
 
AnnotatedServerEndpointConfig(JakartaWebSocketContainer, Class<?>, ServerEndpoint, EndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.AnnotatedServerEndpointConfig
 
Annotation - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
ANNOTATION - Enum constant in enum org.eclipse.jetty.servlet.Source.Origin
 
AnnotationConfiguration - Class in org.eclipse.jetty.annotations
Configuration for Annotations
AnnotationConfiguration - Class in org.eclipse.jetty.osgi.annotations
Extend the AnnotationConfiguration to support OSGi: Look for annotations inside WEB-INF/lib and also in the fragments and required bundles.
AnnotationConfiguration() - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration
 
AnnotationConfiguration() - Constructor for class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
 
AnnotationConfiguration.BundleParserTask - Class in org.eclipse.jetty.osgi.annotations
 
AnnotationConfiguration.ClassInheritanceMap - Class in org.eclipse.jetty.annotations
 
AnnotationConfiguration.DiscoveredServletContainerInitializerHolder - Class in org.eclipse.jetty.annotations
 
AnnotationConfiguration.ParserTask - Class in org.eclipse.jetty.annotations
ParserTask Task to executing scanning of a resource for annotations.
AnnotationConfiguration.ServletContainerInitializerComparator - Class in org.eclipse.jetty.annotations
ServletContainerInitializerComparator Comparator impl that orders a set of ServletContainerInitializers according to the list of classnames (optionally containing a "*" wildcard character) established in a ServletContainerInitializerOrdering.
AnnotationConfiguration.ServletContainerInitializerOrdering - Class in org.eclipse.jetty.annotations
ServletContainerInitializerOrdering
AnnotationConfiguration.TimeStatistic - Class in org.eclipse.jetty.annotations
Simple class to capture elapsed time of an operation.
AnnotationDecorator - Class in org.eclipse.jetty.annotations
AnnotationDecorator
AnnotationDecorator(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.AnnotationDecorator
 
AnnotationIntrospector - Class in org.eclipse.jetty.annotations
AnnotationIntrospector Introspects a class to find various types of annotations as defined by the servlet specification.
AnnotationIntrospector(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.AnnotationIntrospector
 
AnnotationIntrospector.AbstractIntrospectableAnnotationHandler - Class in org.eclipse.jetty.annotations
AbstractIntrospectableAnnotationHandler Base class for handlers that introspect a class to find a particular annotation.
AnnotationIntrospector.IntrospectableAnnotationHandler - Interface in org.eclipse.jetty.annotations
IntrospectableAnnotationHandler Interface for all handlers that wish to introspect a class to find a particular annotation
AnnotationParser - Class in org.eclipse.jetty.annotations
AnnotationParser
AnnotationParser - Class in org.eclipse.jetty.osgi.annotations
 
AnnotationParser() - Constructor for class org.eclipse.jetty.annotations.AnnotationParser
 
AnnotationParser(int) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser
 
AnnotationParser(int) - Constructor for class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
AnnotationParser(int, int) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser
 
AnnotationParser.AbstractHandler - Class in org.eclipse.jetty.annotations
Convenience base class to provide no-ops for all Handler methods.
AnnotationParser.ClassInfo - Class in org.eclipse.jetty.annotations
Immutable information gathered by parsing class header.
AnnotationParser.FieldInfo - Class in org.eclipse.jetty.annotations
Immutable information gathered by parsing a field on a class.
AnnotationParser.Handler - Interface in org.eclipse.jetty.annotations
Signature for all handlers that respond to parsing class files.
AnnotationParser.MethodInfo - Class in org.eclipse.jetty.annotations
Immutable information gathered by parsing a method on a class.
AnnotationParser.MyClassVisitor - Class in org.eclipse.jetty.annotations
ASM visitor for a class.
AnnotationParser.MyFieldVisitor - Class in org.eclipse.jetty.annotations
An ASM visitor for parsing Fields.
AnnotationParser.MyMethodVisitor - Class in org.eclipse.jetty.annotations
ASM Visitor for parsing a method.
AntMetaInfConfiguration - Class in org.eclipse.jetty.ant
 
AntMetaInfConfiguration() - Constructor for class org.eclipse.jetty.ant.AntMetaInfConfiguration
 
AntServletHandler() - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHandler
 
AntServletHolder() - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
AntServletHolder(Servlet) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
AntServletHolder(Class<? extends Servlet>) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
AntServletHolder(String, Servlet) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
AntServletHolder(String, Class<? extends Servlet>) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
AntURLClassLoader(AntClassLoader) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
AntWebAppContext - Class in org.eclipse.jetty.ant
Extension of WebAppContext to allow configuration via Ant environment.
AntWebAppContext(Project) - Constructor for class org.eclipse.jetty.ant.AntWebAppContext
Default constructor.
AntWebAppContext.AntServletHandler - Class in org.eclipse.jetty.ant
AntServletHandler
AntWebAppContext.AntServletHolder - Class in org.eclipse.jetty.ant
AntServletHolder
AntWebAppContext.AntURLClassLoader - Class in org.eclipse.jetty.ant
AntURLClassLoader Adapt the AntClassLoader which is not a URLClassLoader - this is needed for jsp to be able to search the classpath.
AntWebInfConfiguration - Class in org.eclipse.jetty.ant
 
AntWebInfConfiguration() - Constructor for class org.eclipse.jetty.ant.AntWebInfConfiguration
 
AntWebXmlConfiguration - Class in org.eclipse.jetty.ant
This configuration object provides additional way to inject application properties into the configured web application.
AntWebXmlConfiguration() - Constructor for class org.eclipse.jetty.ant.AntWebXmlConfiguration
 
ANY_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
ANY_REALM - Static variable in interface org.eclipse.jetty.client.api.Authentication
Constant used to indicate that any realm will match.
ANY_ROLE - Static variable in class org.eclipse.jetty.util.security.Constraint
 
APACHE - Enum constant in enum org.eclipse.jetty.servlet.ServletHolder.JspContainer
 
APACHE_SENTINEL_CLASS - Static variable in class org.eclipse.jetty.servlet.ServletHolder
 
API - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
App - Class in org.eclipse.jetty.deploy
The information about an App that is managed by the DeploymentManager
App(DeploymentManager, AppProvider, String) - Constructor for class org.eclipse.jetty.deploy.App
Create an App with specified Origin ID and archivePath
App(DeploymentManager, AppProvider, String, ContextHandler) - Constructor for class org.eclipse.jetty.deploy.App
Create an App with specified Origin ID and archivePath
AppContextLeakPreventer - Class in org.eclipse.jetty.util.preventers
AppContextLeakPreventer Cause the classloader that is pinned by AppContext.getAppContext() to be a container or system classloader, not a webapp classloader.
AppContextLeakPreventer() - Constructor for class org.eclipse.jetty.util.preventers.AppContextLeakPreventer
 
append(byte) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(byte) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
append(byte) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
append(byte) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
append(byte) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(byte[]) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(byte[]) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(byte[], int, int) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(byte[], int, int) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
append(byte[], int, int) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(byte[], int, int, int) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(char) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(char) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
append(char) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
append(char) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
append(char) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(Appendable, Object) - Method in class org.eclipse.jetty.util.ajax.JSON
Appends the given object as JSON to string buffer.
append(CharSequence, int, int) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(CharSequence, int, int) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
append(CharSequence, int, int) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
append(CharSequence, int, int) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
append(String) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(StringBuilder, byte, int) - Static method in class org.eclipse.jetty.util.StringUtil
append hex digit
append(StringBuilder, Class<?>, Method) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
append(StringBuilder, MethodType) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
append(StringBuilder, Method) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
append(StringBuilder, String, int, int) - Static method in class org.eclipse.jetty.util.StringUtil
Append substring to StringBuilder
append(String, int, int) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(ByteBuffer) - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
append(ByteBuffer) - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
append(ByteBuffer) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
append(ByteBuffer, boolean) - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
append(ByteBuffer, boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
append(ByteBuffer, byte) - Static method in class org.eclipse.jetty.util.BufferUtil
Appends a byte to a buffer
append(ByteBuffer, byte[]) - Static method in class org.eclipse.jetty.util.BufferUtil
Append bytes to a buffer.
append(ByteBuffer, byte[], int, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Append bytes to a buffer.
append(ByteBuffer, String) - Static method in class org.eclipse.jetty.util.BufferUtil
Append a string to a buffer.
append(ByteBuffer, ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Appends a buffer to a buffer
append(List<HTTP2Flusher.Entry>) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
append(HTTP2Flusher.Entry) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
append2digits(StringBuffer, int) - Static method in class org.eclipse.jetty.util.StringUtil
Append 2 digits (zero padded) to the StringBuffer
append2digits(StringBuilder, int) - Static method in class org.eclipse.jetty.util.StringUtil
Append 2 digits (zero padded) to the StringBuilder
appendArray(Appendable, Object) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendArray(Appendable, Collection<?>) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendBoolean(Appendable, Boolean) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendByte(byte) - Method in class org.eclipse.jetty.util.Utf8Appendable
 
appendJSON(Appendable, JSON.Convertible) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendJSON(Appendable, JSON.Convertor, Object) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendJSON(Appendable, JSON.Generator) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendMap(Appendable, Map<?, ?>) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendNull(Appendable) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendNumber(Appendable, Number) - Method in class org.eclipse.jetty.util.ajax.JSON
 
appendPath(StringBuffer, String) - Method in class org.eclipse.jetty.servlet.ServletHolder
Concatenate an element on to fully qualified classname.
appendSchemeHostPort(StringBuffer, String, String, int) - Static method in class org.eclipse.jetty.util.URIUtil
Append scheme, host and port URI prefix, handling IPv6 address encoding and default ports
appendSchemeHostPort(StringBuilder, String, String, int) - Static method in class org.eclipse.jetty.util.URIUtil
Append scheme, host and port URI prefix, handling IPv6 address encoding and default ports
appendString(Appendable, String) - Method in class org.eclipse.jetty.util.ajax.JSON
 
AppEntry() - Constructor for class org.eclipse.jetty.deploy.DeploymentManager.AppEntry
 
APPLICATION_JSON - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
APPLICATION_JSON_8859_1 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
APPLICATION_JSON_UTF_8 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
APPLICATION_PROTOCOLS_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
appliesTo(DispatcherType) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
appliesTo(SSLEngine) - Method in class org.eclipse.jetty.alpn.conscrypt.client.ConscryptClientALPNProcessor
 
appliesTo(SSLEngine) - Method in class org.eclipse.jetty.alpn.conscrypt.server.ConscryptServerALPNProcessor
 
appliesTo(SSLEngine) - Method in class org.eclipse.jetty.alpn.java.client.JDK9ClientALPNProcessor
 
appliesTo(SSLEngine) - Method in class org.eclipse.jetty.alpn.java.server.JDK9ServerALPNProcessor
 
appliesTo(SSLEngine) - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Tests if this processor can be applied to the given SSLEngine.
AppLifeCycle - Class in org.eclipse.jetty.deploy
The lifecycle of an App in the DeploymentManager.
AppLifeCycle() - Constructor for class org.eclipse.jetty.deploy.AppLifeCycle
 
AppLifeCycle.Binding - Interface in org.eclipse.jetty.deploy
 
apply() - Method in class org.eclipse.jetty.annotations.WebFilterAnnotation
 
apply() - Method in class org.eclipse.jetty.annotations.WebListenerAnnotation
 
apply() - Method in class org.eclipse.jetty.annotations.WebServletAnnotation
 
apply() - Method in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.CookiePatternRule
 
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Invokes this method when a match found.
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.PatternRule
Apply the rule to the request
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
 
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
 
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RewritePatternRule
 
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
Process the contained rules (called by matchAndApply)
apply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.TerminatingPatternRule
 
apply(String, HttpServletRequest, HttpServletResponse, Matcher) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
 
apply(String, HttpServletRequest, HttpServletResponse, Matcher) - Method in class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
 
apply(String, HttpServletRequest, HttpServletResponse, Matcher) - Method in class org.eclipse.jetty.rewrite.handler.RegexRule
Apply this rule to the request/response pair.
apply(String, HttpServletRequest, HttpServletResponse, Matcher) - Method in class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
 
apply(String, HttpServletRequest, HttpServletResponse, Matcher) - Method in class org.eclipse.jetty.rewrite.handler.TerminatingRegexRule
 
apply(String, String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.ForwardedSchemeHeaderRule
 
apply(String, String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
Apply the rule to the request
apply(SSLEngine, List<SNIServerName>) - Method in interface org.eclipse.jetty.util.ssl.SslContextFactory.Client.SniProvider
Provides the SNI names to send to the server.
apply(Request) - Method in interface org.eclipse.jetty.client.api.Authentication.Result
Applies the authentication result to the given request.
apply(Request) - Method in class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
apply(Request) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication.SPNEGOResult
 
apply(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
apply(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
apply(ClientConnectionFactory) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory.Decorator
Wraps the given factory.
applyMetaInfContextXml(Resource, String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
applyURI(Request, String, String) - Method in class org.eclipse.jetty.rewrite.handler.CompactPathRule
 
applyURI(Request, String, String) - Method in class org.eclipse.jetty.rewrite.handler.RewritePatternRule
This method will add _query to the requests's queryString and also combine it with existing queryStrings in the request.
applyURI(Request, String, String) - Method in class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
 
applyURI(Request, String, String) - Method in interface org.eclipse.jetty.rewrite.handler.Rule.ApplyURI
 
AppProvider - Interface in org.eclipse.jetty.deploy
Object responsible for providing Apps to the DeploymentManager
ApproveAliases() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler.ApproveAliases
Deprecated.
 
ApproveNonExistentDirectoryAliases() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler.ApproveNonExistentDirectoryAliases
Deprecated.
 
areSupported() - Static method in class org.eclipse.jetty.util.VirtualThreads
 
Arg(Class<?>) - Constructor for class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
Arg(Class<?>, String) - Constructor for class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
ARG_ALLOW_INSECURE_HTTP_DOWNLOADS - Static variable in class org.eclipse.jetty.start.StartArgs
 
ARG_PARTS - Static variable in class org.eclipse.jetty.start.StartArgs
 
ArrayByteBufferPool - Class in org.eclipse.jetty.io
A ByteBuffer pool where ByteBuffers are held in queues that are held in array elements.
ArrayByteBufferPool() - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with a default configuration.
ArrayByteBufferPool(int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int, long, long, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool.Retained - Class in org.eclipse.jetty.io
 
arrayFromString(String) - Static method in class org.eclipse.jetty.util.StringUtil
Parse the string representation of a list using StringUtil.csvSplit(List, String, int, int)
ArrayRetainableByteBufferPool - Class in org.eclipse.jetty.io
A RetainableByteBuffer pool where RetainableByteBuffers are held in Pools that are held in array elements.
ArrayRetainableByteBufferPool() - Constructor for class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
Creates a new ArrayRetainableByteBufferPool with a default configuration.
ArrayRetainableByteBufferPool(int, int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
Creates a new ArrayRetainableByteBufferPool with the given configuration.
ArrayRetainableByteBufferPool(int, int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
Creates a new ArrayRetainableByteBufferPool with the given configuration.
ArrayRetainableByteBufferPool(int, int, int, int, long, long, Function<Integer, Integer>, Function<Integer, Integer>) - Constructor for class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
ArrayRetainableByteBufferPool(int, int, int, int, IntUnaryOperator, IntUnaryOperator, long, long) - Constructor for class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
Creates a new ArrayRetainableByteBufferPool with the given configuration.
ArrayUtil - Class in org.eclipse.jetty.util
Utility methods for Array manipulation
ArrayUtil() - Constructor for class org.eclipse.jetty.util.ArrayUtil
 
artifactId - Variable in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
asArray() - Method in class org.eclipse.jetty.runner.Runner.Classpath
Deprecated.
 
asBuffer() - Method in enum org.eclipse.jetty.http.HttpMethod
 
asBuffer() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
asByteBuffer() - Method in enum org.eclipse.jetty.http.HttpScheme
 
AsciiLowerCaseSet - Class in org.eclipse.jetty.util
 
AsciiLowerCaseSet() - Constructor for class org.eclipse.jetty.util.AsciiLowerCaseSet
 
asciiToLowerCase(byte) - Static method in class org.eclipse.jetty.util.StringUtil
fast lower case conversion.
asciiToLowerCase(char) - Static method in class org.eclipse.jetty.util.StringUtil
fast lower case conversion.
asciiToLowerCase(String) - Static method in class org.eclipse.jetty.util.StringUtil
fast lower case conversion.
asciiToUpperCase(byte) - Static method in class org.eclipse.jetty.util.StringUtil
fast upper case conversion.
asciiToUpperCase(char) - Static method in class org.eclipse.jetty.util.StringUtil
fast upper case conversion.
asciiToUpperCase(String) - Static method in class org.eclipse.jetty.util.StringUtil
fast upper case conversion.
asContextListener(ServletContainerInitializer) - Static method in class org.eclipse.jetty.servlet.listener.ContainerInitializer
Utility Method to allow for manual execution of ServletContainerInitializer when using Embedded Jetty.
asImmutable() - Method in interface org.eclipse.jetty.http.HttpFields
 
asImmutable() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
asImmutable() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
asImmutable() - Method in interface org.eclipse.jetty.http.HttpURI
 
asImmutable() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
asImmutable() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
asList(T[]) - Static method in class org.eclipse.jetty.util.TypeUtil
Array to List.
asMutableList(E[]) - Static method in class org.eclipse.jetty.util.ArrayUtil
 
asPathSpec(String) - Static method in class org.eclipse.jetty.http.pathmap.PathMappings
Deprecated, for removal: This API element is subject to removal in a future version.
asPathSpec(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
asPathSpec(ConstraintMapping) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
asPayloadBuffer() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
asPayloadBuffer(int, String) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
asReadOnly() - Method in class org.eclipse.jetty.websocket.core.Frame
 
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
asRetainableByteBufferPool() - Method in interface org.eclipse.jetty.io.ByteBufferPool
Get this pool as a RetainableByteBufferPool, which supports reference counting of the buffers and possibly a more efficient lookup mechanism based on the Pool class.
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
asRetainableByteBufferPool() - Method in class org.eclipse.jetty.io.NullByteBufferPool
 
assertIsAnnotated(Method, Class<? extends Annotation>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
assertIsPublicNonStatic(Method) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
assertIsReturn(Method, Class<?>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
assertMessageNotNull(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
assertSendHandlerNotNull(SendHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
assertValidFrame(Frame, CoreSession) - Static method in class org.eclipse.jetty.websocket.core.internal.util.FrameValidation
 
assertValidIncoming(Frame, CoreSession) - Static method in class org.eclipse.jetty.websocket.core.internal.util.FrameValidation
 
assertValidOutgoing(Frame, CoreSession) - Static method in class org.eclipse.jetty.websocket.core.internal.util.FrameValidation
 
associate(HttpExchange) - Method in class org.eclipse.jetty.client.HttpChannel
Associates the given exchange to this channel in order to be sent over the network.
associate(UserIdentity) - Method in class org.eclipse.jetty.security.DefaultIdentityService
If there are roles refs present in the scope, then wrap the UserIdentity with one that uses the role references in the UserIdentity.isUserInRole(String, org.eclipse.jetty.server.UserIdentity.Scope)
associate(UserIdentity) - Method in interface org.eclipse.jetty.security.IdentityService
Associate a user identity with the current thread.
associateClassLoader(ClassLoader) - Static method in class org.eclipse.jetty.jndi.ContextFactory
 
associateContext(Context) - Static method in class org.eclipse.jetty.jndi.ContextFactory
Associate the given Context with the current thread.
associateInfo(Object) - Static method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
asString() - Method in class org.eclipse.jetty.client.HttpDestination
 
asString() - Method in class org.eclipse.jetty.client.Origin.Address
 
asString() - Method in class org.eclipse.jetty.client.Origin
 
asString() - Method in class org.eclipse.jetty.client.Origin.Protocol
 
asString() - Method in class org.eclipse.jetty.http.HttpCookie
 
asString() - Method in interface org.eclipse.jetty.http.HttpFields
 
asString() - Method in enum org.eclipse.jetty.http.HttpHeader
 
asString() - Method in enum org.eclipse.jetty.http.HttpHeaderValue
 
asString() - Method in enum org.eclipse.jetty.http.HttpMethod
 
asString() - Method in enum org.eclipse.jetty.http.HttpScheme
 
asString() - Method in interface org.eclipse.jetty.http.HttpURI
 
asString() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
asString() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
asString() - Method in enum org.eclipse.jetty.http.HttpVersion
 
asString() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
asSubConfig(Path) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Build a new config from a this configuration.
asTryExecutor(Executor) - Static method in interface org.eclipse.jetty.util.thread.TryExecutor
 
Async(Executor, Scheduler, long) - Constructor for class org.eclipse.jetty.util.SocketAddressResolver.Async
Creates a new instance with the given executor (to perform DNS resolution in a separate thread), the given scheduler (to cancel the operation if it takes too long) and the given timeout, in milliseconds.
ASYNC - Enum constant in enum org.eclipse.jetty.fcgi.parser.ContentParser.Result
The frame content has been parsed, but the application signalled that it wants to process the content asynchronously.
ASYNC - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
ASYNC_DISPATCH - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
ASYNC_ERROR - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
ASYNC_TIMEOUT - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
AsyncContentProvider - Interface in org.eclipse.jetty.client
Deprecated.
no replacement, use Request.Content instead.
AsyncContentProvider.Listener - Interface in org.eclipse.jetty.client
Deprecated.
A listener that is notified of content availability
AsyncContextEvent - Class in org.eclipse.jetty.server
 
AsyncContextEvent(ContextHandler.Context, AsyncContextState, HttpChannelState, Request, ServletRequest, ServletResponse) - Constructor for class org.eclipse.jetty.server.AsyncContextEvent
 
AsyncContextEvent(ContextHandler.Context, AsyncContextState, HttpChannelState, Request, ServletRequest, ServletResponse, HttpURI) - Constructor for class org.eclipse.jetty.server.AsyncContextEvent
 
AsyncContextState - Class in org.eclipse.jetty.server
 
AsyncContextState(HttpChannelState) - Constructor for class org.eclipse.jetty.server.AsyncContextState
 
AsyncContextState.WrappedAsyncListener - Class in org.eclipse.jetty.server
 
AsyncDelayHandler - Class in org.eclipse.jetty.server.handler
A handler wrapper that provides the framework to asynchronously delay the handling of a request.
AsyncDelayHandler() - Constructor for class org.eclipse.jetty.server.handler.AsyncDelayHandler
 
asyncError(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelState
 
AsyncJSON - Class in org.eclipse.jetty.util.ajax
A non-blocking JSON parser that can parse partial JSON strings.
AsyncJSON(AsyncJSON.Factory) - Constructor for class org.eclipse.jetty.util.ajax.AsyncJSON
 
AsyncJSON.Context - Interface in org.eclipse.jetty.util.ajax
The state of JSON parsing.
AsyncJSON.Factory - Class in org.eclipse.jetty.util.ajax
The factory that creates AsyncJSON instances.
AsyncMiddleManServlet - Class in org.eclipse.jetty.proxy
Servlet 3.1 asynchronous proxy servlet with capability to intercept and modify request/response content.
AsyncMiddleManServlet() - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
AsyncMiddleManServlet.ContentTransformer - Interface in org.eclipse.jetty.proxy
Allows applications to transform upstream and downstream content.
AsyncMiddleManServlet.GZIPContentTransformer - Class in org.eclipse.jetty.proxy
 
AsyncMiddleManServlet.ProxyReader - Class in org.eclipse.jetty.proxy
 
AsyncMiddleManServlet.ProxyResponseListener - Class in org.eclipse.jetty.proxy
 
AsyncMiddleManServlet.ProxyWriter - Class in org.eclipse.jetty.proxy
 
AsyncMiddleManServlet.Transparent - Class in org.eclipse.jetty.proxy
Convenience extension of AsyncMiddleManServlet that offers transparent proxy functionalities.
AsyncProxyServlet - Class in org.eclipse.jetty.proxy
Servlet 3.1 asynchronous proxy servlet.
AsyncProxyServlet() - Constructor for class org.eclipse.jetty.proxy.AsyncProxyServlet
 
AsyncProxyServlet.StreamReader - Class in org.eclipse.jetty.proxy
 
AsyncProxyServlet.StreamWriter - Class in org.eclipse.jetty.proxy
 
AsyncProxyServlet.Transparent - Class in org.eclipse.jetty.proxy
Convenience extension of AsyncProxyServlet that offers transparent proxy functionalities.
asyncReadFillInterested() - Method in class org.eclipse.jetty.server.HttpConnection
 
AsyncRequestContent - Class in org.eclipse.jetty.client.util
 
AsyncRequestContent(String, ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.AsyncRequestContent
 
AsyncRequestContent(ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.AsyncRequestContent
 
AsyncRequestLogWriter - Class in org.eclipse.jetty.server
An asynchronously writing RequestLogWriter
AsyncRequestLogWriter() - Constructor for class org.eclipse.jetty.server.AsyncRequestLogWriter
 
AsyncRequestLogWriter(String) - Constructor for class org.eclipse.jetty.server.AsyncRequestLogWriter
 
AsyncRequestLogWriter(String, BlockingQueue<String>) - Constructor for class org.eclipse.jetty.server.AsyncRequestLogWriter
 
atEOF() - Method in class org.eclipse.jetty.http.HttpParser
Signal that the associated data source is at EOF
AtomicBiInteger - Class in org.eclipse.jetty.util
An AtomicLong with additional methods to treat it as two hi/lo integers.
AtomicBiInteger() - Constructor for class org.eclipse.jetty.util.AtomicBiInteger
 
AtomicBiInteger(int, int) - Constructor for class org.eclipse.jetty.util.AtomicBiInteger
 
AtomicBiInteger(long) - Constructor for class org.eclipse.jetty.util.AtomicBiInteger
 
Atomics - Class in org.eclipse.jetty.util
 
Attachable - Interface in org.eclipse.jetty.util
Abstract mechanism to support attachment of miscellaneous objects.
ATTR - Static variable in class org.eclipse.jetty.util.DecoratedObjectFactory
ServletContext attribute for the active DecoratedObjectFactory
ATTR - Static variable in interface org.eclipse.jetty.webapp.Configuration
 
ATTR_JAKARTA_SERVER_CONTAINER - Static variable in class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
The ServletContext attribute key name for the ServerContainer per jakarta.websocket spec 1.0 final section 6.4 Programmatic Server Deployment
attribute(String, Object) - Method in interface org.eclipse.jetty.client.api.Request
 
attribute(String, Object) - Method in class org.eclipse.jetty.client.HttpRequest
 
Attribute - Class in org.eclipse.jetty.ant.types
 
Attribute() - Constructor for class org.eclipse.jetty.ant.types.Attribute
 
ATTRIBUTE - Static variable in class org.eclipse.jetty.cdi.CdiDecoratingListener
 
ATTRIBUTE_VALUES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
A cookie attribute value was found and its value is retained.
attributeAdded(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
attributeAdded(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.servlet.DecoratingListener
 
AttributeContainerMap - Class in org.eclipse.jetty.util.component
An Attributes implementation that holds it's values in an immutable ContainerLifeCycle
AttributeContainerMap() - Constructor for class org.eclipse.jetty.util.component.AttributeContainerMap
 
AttributeNormalizer - Class in org.eclipse.jetty.quickstart
Normalize Attribute to String.
AttributeNormalizer(Resource) - Constructor for class org.eclipse.jetty.quickstart.AttributeNormalizer
 
attributeRemoved(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
attributeRemoved(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.servlet.DecoratingListener
 
attributeReplaced(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
attributeReplaced(ServletContextAttributeEvent) - Method in class org.eclipse.jetty.servlet.DecoratingListener
 
Attributes - Class in org.eclipse.jetty.ant.types
 
Attributes - Interface in org.eclipse.jetty.util
Attributes.
Attributes() - Constructor for class org.eclipse.jetty.ant.types.Attributes
 
ATTRIBUTES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
A cookie attribute was found.
ATTRIBUTES - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
Attributes.Wrapper - Class in org.eclipse.jetty.util
A Wrapper of attributes
AttributesMap - Class in org.eclipse.jetty.util
 
AttributesMap() - Constructor for class org.eclipse.jetty.util.AttributesMap
 
AttributesMap(AttributesMap) - Constructor for class org.eclipse.jetty.util.AttributesMap
 
AUTH_METHOD_KEY - Static variable in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
AUTH_TYPE - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
authenticate(HttpServletResponse) - Method in class org.eclipse.jetty.server.Request
 
authenticate(HttpServletResponse) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
authenticate(HttpServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
authenticate(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
authenticate(ServletRequest) - Method in interface org.eclipse.jetty.server.Authentication.Deferred
Authenticate if possible without sending a challenge.
authenticate(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
authenticate(ServletRequest, ServletResponse) - Method in interface org.eclipse.jetty.server.Authentication.Deferred
Authenticate and possibly send a challenge.
authenticate(Object) - Method in class org.eclipse.jetty.security.UserPrincipal
 
authenticate(Request, ContentResponse, Authentication.HeaderInfo, Attributes) - Method in interface org.eclipse.jetty.client.api.Authentication
Executes the authentication mechanism for the given request, returning a Authentication.Result that can be used to actually authenticate the request via Authentication.Result.apply(Request).
authenticate(Request, ContentResponse, Authentication.HeaderInfo, Attributes) - Method in class org.eclipse.jetty.client.util.BasicAuthentication
 
authenticate(Request, ContentResponse, Authentication.HeaderInfo, Attributes) - Method in class org.eclipse.jetty.client.util.DigestAuthentication
 
authenticate(Request, ContentResponse, Authentication.HeaderInfo, Attributes) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
authenticate(EndPoint, Callback) - Method in interface org.eclipse.jetty.client.Socks5.Authentication
Performs the authentication send and receive bytes exchanges specific for this Socks5.Authentication.
authenticate(UserPrincipal) - Method in class org.eclipse.jetty.security.UserPrincipal
 
authenticate(Credential) - Method in class org.eclipse.jetty.security.UserPrincipal
 
Authentication - Interface in org.eclipse.jetty.client.api
Authentication represents a mechanism to authenticate requests for protected resources.
Authentication - Interface in org.eclipse.jetty.server
The Authentication state of a request.
Authentication.Challenge - Interface in org.eclipse.jetty.server
An Authentication Challenge has been sent.
Authentication.Deferred - Interface in org.eclipse.jetty.server
A deferred authentication with methods to progress the authentication process.
Authentication.Failed - Exception Class in org.eclipse.jetty.server
 
Authentication.Failure - Interface in org.eclipse.jetty.server
An Authentication Failure has been sent.
Authentication.HeaderInfo - Class in org.eclipse.jetty.client.api
Structure holding information about the WWW-Authenticate (or Proxy-Authenticate) header.
Authentication.LoginAuthentication - Interface in org.eclipse.jetty.server
An authentication that is capable of performing a programmatic login operation.
Authentication.LogoutAuthentication - Interface in org.eclipse.jetty.server
An authentication that is capable of performing a programmatic logout operation.
Authentication.NonAuthenticated - Interface in org.eclipse.jetty.server
After a logout, the authentication reverts to a state where it is possible to programmatically log in again.
Authentication.ResponseSent - Interface in org.eclipse.jetty.server
Authentication Response sent state.
Authentication.Result - Interface in org.eclipse.jetty.client.api
Authentication.SendSuccess - Interface in org.eclipse.jetty.server
 
Authentication.User - Interface in org.eclipse.jetty.server
A successful Authentication with User information.
Authentication.Wrapped - Interface in org.eclipse.jetty.server
A wrapped authentication with methods provide the wrapped request/response for use by the application
AuthenticationException(String) - Constructor for exception class org.eclipse.jetty.security.openid.OpenIdCredentials.AuthenticationException
 
AuthenticationProtocolHandler - Class in org.eclipse.jetty.client
 
AuthenticationProtocolHandler(HttpClient, int) - Constructor for class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
AuthenticationStore - Interface in org.eclipse.jetty.client.api
Authenticator - Interface in org.eclipse.jetty.security
Authenticator Interface
Authenticator.AuthConfiguration - Interface in org.eclipse.jetty.security
Authenticator Configuration
Authenticator.Factory - Interface in org.eclipse.jetty.security
Authenticator Factory
authority(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
authority(String, int) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
AUTHORITY - Static variable in class org.eclipse.jetty.http2.hpack.AuthorityHttpField
 
AuthorityHttpField - Class in org.eclipse.jetty.http2.hpack
 
AuthorityHttpField(String) - Constructor for class org.eclipse.jetty.http2.hpack.AuthorityHttpField
 
AUTHORIZATION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
AuthorizationService - Interface in org.eclipse.jetty.security.authentication
A service to query for user roles.
AUTHORIZER - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.Role
 
AUTO - Enum constant in enum org.eclipse.jetty.quickstart.QuickStartConfiguration.Mode
 
AUTO - Enum constant in enum org.eclipse.jetty.websocket.api.BatchMode
Implementers are free to decide whether to send or not frames to the network layer.
autoDemand() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
AutoLock - Class in org.eclipse.jetty.util.thread
Reentrant lock that can be used in a try-with-resources statement.
AutoLock() - Constructor for class org.eclipse.jetty.util.thread.AutoLock
 
AutoLock.WithCondition - Class in org.eclipse.jetty.util.thread
A reentrant lock with a condition that can be used in a try-with-resources statement.
available() - Method in interface org.eclipse.jetty.server.ContentProducer
Get the byte count that can immediately be read from this ContentProducer instance or the underlying HttpChannel.
available() - Method in class org.eclipse.jetty.server.HttpInput
 
available() - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
AVAILABLE - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
 
AVAILABLE_PROCESSORS - Static variable in class org.eclipse.jetty.util.ProcessorUtils
 
AvailableDecoders - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
AvailableDecoders(EndpointConfig, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
AvailableEncoders - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
 
AvailableEncoders(EndpointConfig, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
availableProcessors() - Static method in class org.eclipse.jetty.util.ProcessorUtils
Returns the number of available processors, from System Property "JETTY_AVAILABLE_PROCESSORS", or if not set then from environment variable "JETTY_AVAILABLE_PROCESSORS" or if not set then from Runtime.availableProcessors().
await() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
await() - Method in class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
await(long, TimeUnit) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
Waits for the given timeout for the whole request/response cycle to be finished, then returns the corresponding result.
await(long, TimeUnit) - Method in class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
AWTLeakPreventer - Class in org.eclipse.jetty.util.preventers
AWTLeakPreventer See https://issues.jboss.org/browse/AS7-3733 The java.awt.Toolkit class has a static field that is the default toolkit.
AWTLeakPreventer() - Constructor for class org.eclipse.jetty.util.preventers.AWTLeakPreventer
 

B

BAD_DATA - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1003 indicates that an endpoint is terminating the connection because it has received a type of data it cannot accept (e.g., an endpoint that understands only text data MAY send this if it receives a binary message).
BAD_DATA - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
BAD_GATEWAY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
BAD_GATEWAY - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
BAD_GATEWAY_502 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
BAD_PAYLOAD - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1007 indicates that an endpoint is terminating the connection because it has received data within a message that was not consistent with the type of the message (e.g., non-UTF-8 [RFC3629] data within a text message).
BAD_PAYLOAD - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
BAD_QUOTES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Quotes are not balanced or are embedded in value.
BAD_REQUEST - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
BAD_REQUEST_400 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
badMessage(BadMessageException) - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
badMessage(BadMessageException) - Method in class org.eclipse.jetty.http.HttpParser
 
badMessage(BadMessageException) - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
Called to signal that a bad HTTP message has been received.
badMessage(BadMessageException) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
badMessage(BadMessageException) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
badMessageError(int, String, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Bad Message Error body
BadMessageException - Exception Class in org.eclipse.jetty.http
Exception thrown to indicate a Bad HTTP Message has either been received or attempted to be generated.
BadMessageException() - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadMessageException(int) - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadMessageException(int, String) - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadMessageException(int, String, Throwable) - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadMessageException(String) - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadMessageException(String, Throwable) - Constructor for exception class org.eclipse.jetty.http.BadMessageException
 
BadPayloadException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Exception to terminate the connection because it has received data within a frame payload that was not consistent with the requirements of that frame payload.
BadPayloadException - Exception Class in org.eclipse.jetty.websocket.core.exception
Exception to terminate the connection because it has received data within a frame payload that was not consistent with the requirements of that frame payload.
BadPayloadException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.BadPayloadException
 
BadPayloadException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.BadPayloadException
 
BadPayloadException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.BadPayloadException
 
BadPayloadException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.BadPayloadException
 
BadPayloadException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.BadPayloadException
 
BadPayloadException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.BadPayloadException
 
BalancerServlet - Class in org.eclipse.jetty.proxy
 
BalancerServlet() - Constructor for class org.eclipse.jetty.proxy.BalancerServlet
 
BASE64_TRANSFER_ENCODING - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
BaseAuthModule - Class in org.eclipse.jetty.security.jaspi.modules
Simple abstract module implementing a Jakarta Authentication ServerAuthModule and ServerAuthContext.
BaseAuthModule() - Constructor for class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
BaseAuthModule(CallbackHandler) - Constructor for class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
BaseBuilder - Class in org.eclipse.jetty.start
Build a start configuration in ${jetty.base}, including ini files, directories, and libs.
BaseBuilder(BaseHome, StartArgs) - Constructor for class org.eclipse.jetty.start.BaseBuilder
 
BaseBuilder.Config - Interface in org.eclipse.jetty.start
 
BaseHolder<T> - Class in org.eclipse.jetty.servlet
AbstractHolder Base class for all servlet-related classes that may be lazily instantiated (eg servlet, filter, listener), and/or require metadata to be held regarding their origin (web.xml, annotation, programmatic api etc).
BaseHolder(Source) - Constructor for class org.eclipse.jetty.servlet.BaseHolder
 
BaseHome - Class in org.eclipse.jetty.start
File access for ${jetty.home}, ${jetty.base}, directories.
BaseHome() - Constructor for class org.eclipse.jetty.start.BaseHome
 
BaseHome(String[]) - Constructor for class org.eclipse.jetty.start.BaseHome
 
BaseHome(CommandLineConfigSource) - Constructor for class org.eclipse.jetty.start.BaseHome
 
BaseHome(ConfigSources) - Constructor for class org.eclipse.jetty.start.BaseHome
 
BaseHome.SearchDir - Class in org.eclipse.jetty.start
 
BaseHomeFileInitializer - Class in org.eclipse.jetty.start.fileinits
Copy a file found in BaseHome from a URI of the form "basehome:some/path" FileInitializer
BaseHomeFileInitializer(BaseHome) - Constructor for class org.eclipse.jetty.start.fileinits.BaseHomeFileInitializer
 
BASELINE_CONTROL - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
BASETEMPDIR - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
Basic(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink.Basic
 
BasicAuthentication - Class in org.eclipse.jetty.client.util
Implementation of the HTTP "Basic" authentication defined in RFC 2617.
BasicAuthentication(URI, String, String, String) - Constructor for class org.eclipse.jetty.client.util.BasicAuthentication
 
BasicAuthentication.BasicResult - Class in org.eclipse.jetty.client.util
Basic authentication result.
BasicAuthenticationAuthModule - Class in org.eclipse.jetty.security.jaspi.modules
A ServerAuthModule implementation of HTTP Basic Authentication.
BasicAuthenticationAuthModule() - Constructor for class org.eclipse.jetty.security.jaspi.modules.BasicAuthenticationAuthModule
 
BasicAuthenticationAuthModule(CallbackHandler, String) - Constructor for class org.eclipse.jetty.security.jaspi.modules.BasicAuthenticationAuthModule
 
BasicAuthenticator - Class in org.eclipse.jetty.security.authentication
 
BasicAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
BasicClientEndpointConfig - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
BasicClientEndpointConfig() - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.BasicClientEndpointConfig
 
BasicResult(URI, String, String) - Constructor for class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
BasicResult(URI, HttpHeader, String, String) - Constructor for class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
BasicResult(URI, HttpHeader, String, String, Charset) - Constructor for class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
BasicServerEndpointConfig - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
BasicServerEndpointConfig(Class<?>, String) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.BasicServerEndpointConfig
 
batch - Variable in class org.eclipse.jetty.websocket.core.internal.FrameEntry
 
batch - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
batchMode() - Element in annotation type org.eclipse.jetty.websocket.api.annotations.WebSocket
The output frame buffering mode.
BatchMode - Enum in org.eclipse.jetty.websocket.api
The possible batch modes when enqueuing outgoing frames.
beanAdded(Container, Object) - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
beanAdded(Container, Object) - Method in interface org.eclipse.jetty.util.component.Container.Listener
 
beanRemoved(Container, Object) - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
beanRemoved(Container, Object) - Method in interface org.eclipse.jetty.util.component.Container.Listener
 
Before - Enum constant in enum org.eclipse.jetty.webapp.FragmentDescriptor.OtherType
 
BEFORE_SEND - Enum constant in enum org.eclipse.jetty.http2.CloseState.Event
 
beforeDecoding(HttpExchange) - Method in interface org.eclipse.jetty.client.ContentDecoder
Processes the exchange just before the decoding of the response content.
beforeDecoding(HttpExchange) - Method in class org.eclipse.jetty.client.GZIPContentDecoder
 
beforeRequest(Map<String, List<String>>) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.EmptyConfigurator
 
BEGIN_REQUEST - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
beginInvalidate() - Method in class org.eclipse.jetty.server.session.Session
 
BeginRequestContentParser - Class in org.eclipse.jetty.fcgi.parser
Parser for the BEGIN_REQUEST frame content.
BeginRequestContentParser(HeaderParser, ServerParser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.BeginRequestContentParser
 
beginToHeaders(HttpExchange) - Method in class org.eclipse.jetty.client.HttpSender
 
Behavior - Enum in org.eclipse.jetty.websocket.core
Behavior for how the WebSocket should operate.
BINARY - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
BINARY - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Binary Frame
bind(String, Object) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
bind(String, Object) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
bind(String, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Bind a name (as a String) to an object
bind(InetSocketAddress, int) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
bind(Context, String, Object) - Static method in class org.eclipse.jetty.jndi.NamingUtil
Bind an object to a context ensuring all sub-contexts are created if necessary
bind(Name, Object) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
bind(Name, Object) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
bind(Name, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Bind a name to an object
bind(NamingContext, Binding) - Method in interface org.eclipse.jetty.jndi.NamingContext.Listener
Called by NamingContext.addBinding(Name, Object) when adding a binding.
BIND - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
bindEntry(WebAppContext, String, Class<?>) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Bind a resource with the given name from web.xml of the given type with a jndi resource from either the server or the webapp's naming environment.
bindEnvEntries(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
Bind all EnvEntries that have been declared, so that the processing of the web.xml file can potentially override them.
bindEnvEntry(String, Object) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
BindingEnumeration - Class in org.eclipse.jetty.jndi
BindingEnumeration
BindingEnumeration(Iterator<Binding>) - Constructor for class org.eclipse.jetty.jndi.BindingEnumeration
 
bindingLogin(String, Object) - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
binding authentication check This method of authentication works only if the user branch of the DIT (ldap tree) has an ACI (access control instruction) that allow the access to any user or at least for the user that logs in.
bindMessageDestinationRef(WebAppContext, String, Class<?>) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
bindResourceEnvRef(WebAppContext, String, Class<?>) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
bindResourceRef(WebAppContext, String, Class<?>) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Bind a resource reference.
bindTemplateVariables(MethodHandle, String[], Map<String, String>) - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
Bind the URI Template Variables to their provided values, converting to the type that the MethodHandle target has declared.
bindTo(MethodHandle, Object...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
Bind optional arguments to provided method handle
bindToENC() - Static method in class org.eclipse.jetty.plus.jndi.Transaction
 
bindToENC(Object, String, String) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
Link a name in a webapp's java:/comp/evn namespace to a pre-existing resource.
bindToENC(String) - Method in class org.eclipse.jetty.plus.jndi.Link
 
bindToENC(String) - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Add a java:comp/env binding for the object represented by this NamingEntry, but bind it as the name supplied
bindToENC(String) - Method in class org.eclipse.jetty.plus.jndi.Transaction
Allow other bindings of UserTransaction.
bindUserTransaction(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
bindValue(String, Object) - Method in class org.eclipse.jetty.server.session.Session
Bind value if value implements HttpSessionBindingListener (calls HttpSessionBindingListener.valueBound(HttpSessionBindingEvent))
block() - Method in class org.eclipse.jetty.util.FutureCallback
 
block() - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
Block until the Callback has succeeded or failed and after the return leave in the state to allow reuse.
block(long, TimeUnit) - Method in class org.eclipse.jetty.util.FutureCallback
 
Blocker() - Constructor for class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
 
BLOCKING - Enum constant in enum org.eclipse.jetty.util.thread.Invocable.InvocationType
Invoking the Invocable may block the invoker thread, and the invocation may be performed immediately (possibly blocking the invoker thread) or deferred to a later time, for example by submitting the Invocable to a thread pool.
BlockingArrayQueue<E> - Class in org.eclipse.jetty.util
A BlockingQueue backed by a circular array capable or growing.
BlockingArrayQueue() - Constructor for class org.eclipse.jetty.util.BlockingArrayQueue
Creates an unbounded BlockingArrayQueue with default initial capacity and grow factor.
BlockingArrayQueue(int) - Constructor for class org.eclipse.jetty.util.BlockingArrayQueue
Creates a bounded BlockingArrayQueue that does not grow.
BlockingArrayQueue(int, int) - Constructor for class org.eclipse.jetty.util.BlockingArrayQueue
Creates an unbounded BlockingArrayQueue that grows by the given parameter.
BlockingArrayQueue(int, int, int) - Constructor for class org.eclipse.jetty.util.BlockingArrayQueue
Create a bounded BlockingArrayQueue that grows by the given parameter.
body(Request.Content) - Method in interface org.eclipse.jetty.client.api.Request
 
body(Request.Content) - Method in class org.eclipse.jetty.client.HttpRequest
 
BODY_PART - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
BodyParser - Class in org.eclipse.jetty.http2.parser
The base parser for the frame body of HTTP/2 frames.
BodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.BodyParser
 
BooleanDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Boolean decoder.
BooleanDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.BooleanDecoder
 
BooleanEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Boolean to Encoder.Text Message encoder
BooleanEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.BooleanEncoder
 
BoundDelegatingInputStream - Class in org.eclipse.jetty.session.infinispan
BoundDelegatingInputStream An InputStream that delegates methods to an ObjectInput.
BoundDelegatingInputStream(ObjectInput) - Constructor for class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
BR - Static variable in class org.eclipse.jetty.http.CompressedContentFormat
 
BREAK_EVEN_GZIP_SIZE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
bucketFor(int) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
bucketFor(int) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
bucketFor(int) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
bucketFor(int, boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
buffer - Variable in class org.eclipse.jetty.client.util.DeferredContentProvider.Chunk
Deprecated.
 
BufferedResponseHandler - Class in org.eclipse.jetty.server.handler
A Handler that can apply a HttpOutput.Interceptor mechanism to buffer the entire response content until the output is closed.
BufferedResponseHandler() - Constructor for class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
BufferedResponseHandler.BufferedInterceptor - Interface in org.eclipse.jetty.server.handler
An HttpOutput.Interceptor which is created by BufferedResponseHandler.newBufferedInterceptor(HttpChannel, Interceptor) and is used by the implementation to buffer outgoing content.
BufferingFlowControlStrategy - Class in org.eclipse.jetty.http2
A flow control strategy that accumulates updates and emits window control frames when the accumulated value reaches a threshold.
BufferingFlowControlStrategy(float) - Constructor for class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
BufferingFlowControlStrategy(int, float) - Constructor for class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
BufferingResponseListener - Class in org.eclipse.jetty.client.util
Implementation of Response.Listener that buffers the content up to a maximum length specified to the constructors.
BufferingResponseListener() - Constructor for class org.eclipse.jetty.client.util.BufferingResponseListener
Creates an instance with a default maximum length of 2 MiB.
BufferingResponseListener(int) - Constructor for class org.eclipse.jetty.client.util.BufferingResponseListener
Creates an instance with the given maximum length
bufferSize - Static variable in class org.eclipse.jetty.util.IO
 
BufferUtil - Class in org.eclipse.jetty.util
Buffer utility methods.
BufferUtil() - Constructor for class org.eclipse.jetty.util.BufferUtil
 
build() - Static method in interface org.eclipse.jetty.http.HttpFields
 
build() - Static method in interface org.eclipse.jetty.http.HttpURI
 
build() - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
build() - Method in class org.eclipse.jetty.start.BaseBuilder
Build out the Base directory (if needed)
build() - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
Build the completed string and reset the buffer.
build() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
build() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
build() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
build() - Method in class org.eclipse.jetty.util.Index.Builder
Build a Index instance.
build() - Method in class org.eclipse.jetty.util.Index.Mutable.Builder
Build a Index.Mutable instance.
build(int) - Static method in interface org.eclipse.jetty.http.HttpFields
 
build(Class<?>, Class<? extends Annotation>, Method) - Static method in exception class org.eclipse.jetty.websocket.core.exception.InvalidSignatureException
 
build(Class<?>, Class<? extends Annotation>, Method...) - Static method in exception class org.eclipse.jetty.websocket.core.exception.DuplicateAnnotationException
 
build(MethodType, MethodType) - Static method in exception class org.eclipse.jetty.websocket.core.exception.InvalidSignatureException
 
build(String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
build(String, String, String) - Static method in class org.eclipse.jetty.session.infinispan.InfinispanKeyBuilder
 
build(URI) - Static method in interface org.eclipse.jetty.http.HttpURI
 
build(HttpFields) - Static method in interface org.eclipse.jetty.http.HttpFields
 
build(HttpFields, EnumSet<HttpHeader>) - Static method in interface org.eclipse.jetty.http.HttpFields
 
build(HttpFields, HttpField) - Static method in interface org.eclipse.jetty.http.HttpFields
 
build(HttpURI) - Static method in interface org.eclipse.jetty.http.HttpURI
 
build(HttpURI, String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
build(HttpURI, String, String, String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
BUILD_TIMESTAMP - Static variable in class org.eclipse.jetty.util.Jetty
a formatted build timestamp with pattern yyyy-MM-dd'T'HH:mm:ssXXX
Builder() - Constructor for class org.eclipse.jetty.util.Index.Builder
Create a new index builder instance.
buildMutableVisibleAsciiAlphabet(boolean, int) - Static method in interface org.eclipse.jetty.util.Index
A special purpose static builder for fast creation of specific Index type
bundleAdded(Bundle) - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider
 
bundleAdded(Bundle) - Method in interface org.eclipse.jetty.osgi.boot.BundleProvider
 
bundleAdded(Bundle) - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider
A bundle has been added that could be a webapp
BundleClassLoaderHelper - Interface in org.eclipse.jetty.osgi.boot.utils
BundleClassLoaderHelper
BundleClassLoaderHelperFactory - Class in org.eclipse.jetty.osgi.boot.utils
BundleClassLoaderHelperFactory Get a class loader helper adapted for the particular osgi environment.
BundleContextProvider - Class in org.eclipse.jetty.osgi.boot
BundleContextProvider
BundleContextProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.BundleContextProvider
 
BundleContextProvider.ContextBundleTracker - Class in org.eclipse.jetty.osgi.boot
 
BundleFileLocatorHelper - Interface in org.eclipse.jetty.osgi.boot.utils
BundleFileLocatorHelper
BundleFileLocatorHelperFactory - Class in org.eclipse.jetty.osgi.boot.utils
BundleFileLocatorHelperFactory Obtain a helper for locating files based on the bundle.
BundleParserTask(AnnotationParser, Set<? extends AnnotationParser.Handler>, Resource) - Constructor for class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration.BundleParserTask
 
BundleProvider - Interface in org.eclipse.jetty.osgi.boot
BundleProvider Jetty DeploymentManager Provider api for webapps or ContextHandlers that are discovered as osgi bundles.
bundleRemoved(Bundle) - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider
Bundle has been removed.
bundleRemoved(Bundle) - Method in interface org.eclipse.jetty.osgi.boot.BundleProvider
 
bundleRemoved(Bundle) - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider
Bundle has been removed.
BundleWebAppProvider - Class in org.eclipse.jetty.osgi.boot
BundleWebAppProvider
BundleWebAppProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.BundleWebAppProvider
 
BundleWebAppProvider.WebAppTracker - Class in org.eclipse.jetty.osgi.boot
 
ByClass() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
byLastModified(boolean) - Static method in class org.eclipse.jetty.util.resource.ResourceCollators
 
ByLocation() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByLocation
 
ByLocationOrModule() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
ByModule() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
byName(boolean) - Static method in class org.eclipse.jetty.util.resource.ResourceCollators
 
ByPackage() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
ByPackageOrName() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
bySize(boolean) - Static method in class org.eclipse.jetty.util.resource.ResourceCollators
 
ByteArrayDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
ByteArrayDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteArrayDecoder
 
ByteArrayEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
 
ByteArrayEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteArrayEncoder
 
ByteArrayEndPoint - Class in org.eclipse.jetty.io
ByteArrayEndPoint.
ByteArrayEndPoint() - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(byte[], int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(String, int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, byte[], int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, String, int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, ByteBuffer, ByteBuffer) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayISO8859Writer - Class in org.eclipse.jetty.util
Byte Array ISO 8859 writer.
ByteArrayISO8859Writer() - Constructor for class org.eclipse.jetty.util.ByteArrayISO8859Writer
Constructor.
ByteArrayISO8859Writer(byte[]) - Constructor for class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
ByteArrayISO8859Writer(int) - Constructor for class org.eclipse.jetty.util.ByteArrayISO8859Writer
Constructor.
ByteArrayMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
ByteArrayMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.ByteArrayMessageSink
 
ByteArrayOutputStream2 - Class in org.eclipse.jetty.util
ByteArrayOutputStream with public internals
ByteArrayOutputStream2() - Constructor for class org.eclipse.jetty.util.ByteArrayOutputStream2
 
ByteArrayOutputStream2(int) - Constructor for class org.eclipse.jetty.util.ByteArrayOutputStream2
 
ByteBufferAccumulator - Class in org.eclipse.jetty.io
Accumulates data into a list of ByteBuffers which can then be combined into a single buffer or written to an OutputStream.
ByteBufferAccumulator() - Constructor for class org.eclipse.jetty.io.ByteBufferAccumulator
 
ByteBufferAccumulator(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.io.ByteBufferAccumulator
 
ByteBufferCallbackAccumulator - Class in org.eclipse.jetty.io
This class can be used to accumulate pairs of ByteBuffer and Callback, and eventually copy these into a single ByteBuffer or byte array and succeed the callbacks.
ByteBufferCallbackAccumulator() - Constructor for class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
ByteBufferContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
ByteBufferContentProvider(String, ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.ByteBufferContentProvider
Deprecated.
 
ByteBufferContentProvider(ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.ByteBufferContentProvider
Deprecated.
 
ByteBufferDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
ByteBufferDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteBufferDecoder
 
ByteBufferEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
 
ByteBufferEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteBufferEncoder
 
ByteBufferMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
ByteBufferMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.ByteBufferMessageSink
 
ByteBufferOutputStream - Class in org.eclipse.jetty.io
Simple wrapper of a ByteBuffer as an OutputStream.
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream
 
ByteBufferOutputStream2 - Class in org.eclipse.jetty.io
This class implements an output stream in which the data is written into a list of ByteBuffer, the buffer list automatically grows as data is written to it, the buffers are taken from the supplied ByteBufferPool or freshly allocated if one is not supplied.
ByteBufferOutputStream2() - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream2
 
ByteBufferOutputStream2(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream2
 
ByteBufferPool - Interface in org.eclipse.jetty.io
A ByteBuffer pool.
ByteBufferPool.Lease - Class in org.eclipse.jetty.io
 
ByteBufferRangeWriter - Class in org.eclipse.jetty.server.resource
ByteBuffer based RangeWriter
ByteBufferRangeWriter(ByteBuffer) - Constructor for class org.eclipse.jetty.server.resource.ByteBufferRangeWriter
 
ByteBufferRequestContent - Class in org.eclipse.jetty.client.util
ByteBufferRequestContent(String, ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.ByteBufferRequestContent
 
ByteBufferRequestContent(ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.ByteBufferRequestContent
 
ByteDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Byte decoder
ByteDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteDecoder
 
ByteEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Byte to Encoder.Text Message encoder
ByteEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteEncoder
 
byteEquals(byte[], byte[]) - Static method in class org.eclipse.jetty.util.security.Credential
Utility method that replaces Arrays.equals() to avoid timing attacks.
BYTES - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
BytesContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
use BytesRequestContent instead.
BytesContentProvider(byte[]...) - Constructor for class org.eclipse.jetty.client.util.BytesContentProvider
Deprecated.
 
BytesContentProvider(String, byte[]...) - Constructor for class org.eclipse.jetty.client.util.BytesContentProvider
Deprecated.
 
BytesRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content for byte arrays.
BytesRequestContent(byte[]...) - Constructor for class org.eclipse.jetty.client.util.BytesRequestContent
 
BytesRequestContent(String, byte[]...) - Constructor for class org.eclipse.jetty.client.util.BytesRequestContent
 

C

C_AUTHORITY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
C_METHOD - Enum constant in enum org.eclipse.jetty.http.HttpHeader
HTTP2 Fields.
C_PATH - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
C_PROTOCOL - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
C_SCHEME - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
C_STATUS - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
cache(String) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
CACHE - Static variable in enum org.eclipse.jetty.http.HttpHeader
 
CACHE - Static variable in enum org.eclipse.jetty.http.HttpHeaderValue
 
CACHE - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
CACHE - Static variable in class org.eclipse.jetty.http.HttpParser
Cache of common HttpFields including: Common static combinations such as: Connection: close Accept-Encoding: gzip Content-Length: 0 Combinations of Content-Type header for common mime types by common charsets Most common headers with null values so that a lookup will at least determine the header name even if the name:value combination is not cached
CACHE - Static variable in enum org.eclipse.jetty.http.HttpScheme
 
CACHE - Static variable in enum org.eclipse.jetty.http.HttpVersion
 
CACHE - Static variable in class org.eclipse.jetty.http.MimeTypes
 
CACHE_CONTROL - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
cached(ByteBuffer) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
Attempts to return a cached string from the buffer bytes.
CACHED_CONTAINER_FRAGMENTS - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
CACHED_CONTAINER_RESOURCES - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
CACHED_CONTAINER_TLDS - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
CachedContentFactory - Class in org.eclipse.jetty.server
 
CachedContentFactory(CachedContentFactory, ResourceFactory, MimeTypes, boolean, boolean, CompressedContentFormat[]) - Constructor for class org.eclipse.jetty.server.CachedContentFactory
Constructor.
CachedContentFactory.CachedHttpContent - Class in org.eclipse.jetty.server
MetaData associated with a context Resource.
CachedContentFactory.CachedPrecompressedHttpContent - Class in org.eclipse.jetty.server
 
CachingSessionDataStore - Class in org.eclipse.jetty.server.session
CachingSessionDataStore A SessionDataStore is a mechanism for (persistently) storing data associated with sessions.
CachingSessionDataStore(SessionDataMap, SessionDataStore) - Constructor for class org.eclipse.jetty.server.session.CachingSessionDataStore
 
CachingSessionDataStoreFactory - Class in org.eclipse.jetty.server.session
CachingSessionDataStoreFactory
CachingSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
CachingWebAppClassLoader - Class in org.eclipse.jetty.webapp
A WebAppClassLoader that caches CachingWebAppClassLoader.getResource(String) results.
CachingWebAppClassLoader(ClassLoader, WebAppClassLoader.Context) - Constructor for class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
CachingWebAppClassLoader(WebAppClassLoader.Context) - Constructor for class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
calcAndSetExpiry() - Method in class org.eclipse.jetty.server.session.SessionData
 
calcAndSetExpiry(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
calcExpiry() - Method in class org.eclipse.jetty.server.session.SessionData
 
calcExpiry(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
calculateInactivityTimeout(long) - Method in class org.eclipse.jetty.server.session.Session
Calculate what the session timer setting should be based on: the time remaining before the session expires and any idle eviction time configured.
call() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
call() - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration.BundleParserTask
 
callback - Variable in class org.eclipse.jetty.client.util.DeferredContentProvider.Chunk
Deprecated.
 
callback - Variable in class org.eclipse.jetty.websocket.core.internal.FrameEntry
 
callback(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
callback(Object) - Method in class org.eclipse.jetty.plus.annotation.PostConstructCallback
 
callback(Object) - Method in class org.eclipse.jetty.plus.annotation.PreDestroyCallback
 
Callback - Interface in org.eclipse.jetty.util
A callback abstraction that handles completed/failed events of asynchronous operations.
Callback.Completable - Class in org.eclipse.jetty.util
A CompletableFuture that is also a Callback.
Callback.Completing - Class in org.eclipse.jetty.util
A Callback implementation that calls the Callback.Completing.completed() method when it either succeeds or fails.
Callback.Nested - Class in org.eclipse.jetty.util
Nested Completing Callback that completes after completing the nested callback
callbackHandler - Variable in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
callContextDestroyed(ServletContextListener, ServletContextEvent) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
callContextDestroyed(ServletContextListener, ServletContextEvent) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
callContextInitialized(ServletContextListener, ServletContextEvent) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
callContextInitialized(ServletContextListener, ServletContextEvent) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
callPostConstructCallback(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Call the method, if one exists, that is annotated with @PostConstruct or with <post-construct> in web.xml
callPreDestroyCallback(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Call the method, if one exists, that is annotated with @PreDestroy or with <pre-destroy> in web.xml
callSessionAttributeListeners(String, Object, Object) - Method in class org.eclipse.jetty.server.session.Session
Call binding and attribute listeners based on the new and old values of the attribute.
callSessionCreatedListeners(Session) - Method in class org.eclipse.jetty.server.session.SessionHandler
Call the session lifecycle listeners in the order they were added.
callSessionDestroyedListeners(Session) - Method in class org.eclipse.jetty.server.session.SessionHandler
Call the session lifecycle listeners in the reverse order they were added.
callSessionIdListeners(Session, String) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
callStartup(WebAppContext) - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
cancel() - Method in class org.eclipse.jetty.io.CyclicTimeout
Cancels this CyclicTimeout so that it won't expire.
cancel() - Method in class org.eclipse.jetty.server.session.Session.SessionInactivityTimer
 
cancel() - Method in class org.eclipse.jetty.util.component.Graceful.Shutdown
 
cancel() - Method in interface org.eclipse.jetty.util.thread.Scheduler.Task
 
cancel(boolean) - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
cancel(boolean) - Method in class org.eclipse.jetty.util.FutureCallback
 
cancel(boolean) - Method in class org.eclipse.jetty.util.FuturePromise
 
cancel(boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
CANCEL_PUSH - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
CANCEL_STREAM_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that a stream is no longer needed.
cancelDemand() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
cancelTimeout() - Method in class org.eclipse.jetty.server.HttpChannelState
 
cancelTimeout(AsyncContextEvent) - Method in class org.eclipse.jetty.server.HttpChannelState
 
cancelTimeoutTask() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
canonicalEncodedPath(String) - Static method in class org.eclipse.jetty.util.URIUtil
canonicalPath(String) - Static method in class org.eclipse.jetty.util.URIUtil
Convert a decoded URI path to a canonical form.
canonicalURI(String) - Static method in class org.eclipse.jetty.util.URIUtil
Convert a partial URI to a canonical form.
canReadDirectory(Path) - Static method in class org.eclipse.jetty.start.FS
 
canReadFile(Path) - Static method in class org.eclipse.jetty.start.FS
 
canWrite(Path) - Static method in class org.eclipse.jetty.start.FS
 
capacity() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
capacity() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
capacityFor(int) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
capacityFor(int) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
capacityFor(int) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
cappedAdd(int, int, int) - Static method in class org.eclipse.jetty.util.MathUtils
Returns the sum of its arguments, capping to maxValue.
cappedAdd(long, long) - Static method in class org.eclipse.jetty.util.MathUtils
Returns the sum of its arguments, capping to Long.MAX_VALUE if they overflow.
CASE_INSENSITIVE_METHOD - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
The HTTP RFC(s) require that method names are case sensitive, so that "Get" and "GET" are considered different methods.
CASE_SENSITIVE_FIELD_NAME - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
The HTTP RFC(s) require that field names are case-insensitive, so for example the fields "Content-Type: text/xml" and "content-type: text/xml" are considered equivalent.
caseInsensitiveHeader(String, String) - Method in class org.eclipse.jetty.http.HttpParser
 
caseSensitive(boolean) - Method in class org.eclipse.jetty.util.Index.Builder
Configure the index to be either case-sensitive or not.
cast(WatchEvent<?>) - Static method in class org.eclipse.jetty.util.PathWatcher
 
cdata(String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
CDI_INTEGRATION_ATTRIBUTE - Static variable in class org.eclipse.jetty.cdi.CdiServletContainerInitializer
 
CdiConfiguration - Class in org.eclipse.jetty.cdi
CDI Configuration
CdiConfiguration() - Constructor for class org.eclipse.jetty.cdi.CdiConfiguration
 
CdiDecoratingListener - Class in org.eclipse.jetty.cdi
A DecoratingListener that listens for "org.eclipse.jetty.cdi.decorator"
CdiDecoratingListener(ServletContextHandler) - Constructor for class org.eclipse.jetty.cdi.CdiDecoratingListener
 
CdiServletContainerInitializer - Class in org.eclipse.jetty.cdi
A ServletContainerInitializer that introspects for a CDI API implementation within a web application and applies an integration mode if CDI is found.
CdiServletContainerInitializer() - Constructor for class org.eclipse.jetty.cdi.CdiServletContainerInitializer
 
CdiSpiDecorator - Class in org.eclipse.jetty.cdi
A Decorator that invokes the CDI provider within a webapp to decorate objects created by the contexts DecoratedObjectFactory (typically Listeners, Filters and Servlets).
CdiSpiDecorator(ServletContextHandler) - Constructor for class org.eclipse.jetty.cdi.CdiSpiDecorator
 
CertificateUtils - Class in org.eclipse.jetty.util.security
 
CertificateUtils() - Constructor for class org.eclipse.jetty.util.security.CertificateUtils
 
CertificateValidator - Class in org.eclipse.jetty.util.security
Convenience class to handle validation of certificates, aliases and keystores Allows specifying Certificate Revocation List (CRL), as well as enabling CRL Distribution Points Protocol (CRLDP) certificate extension support, and also enabling On-Line Certificate Status Protocol (OCSP) support.
CertificateValidator(KeyStore, Collection<? extends CRL>) - Constructor for class org.eclipse.jetty.util.security.CertificateValidator
creates an instance of the certificate validator
changeSessionId() - Method in class org.eclipse.jetty.server.Request
 
changeSessionId() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
changeSessionId() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
CHANGING - Enum constant in enum org.eclipse.jetty.server.session.Session.IdState
 
CHANGING - Enum constant in enum org.eclipse.jetty.server.session.Session.State
 
ChannelWithAddress(SelectableChannel, SocketAddress) - Constructor for class org.eclipse.jetty.io.ClientConnector.Configurator.ChannelWithAddress
 
CharacterDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Character decoder
CharacterDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.CharacterDecoder
 
CharacterEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Character to Encoder.Text Message encoder
CharacterEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.CharacterEncoder
 
CharsetStringBuilder - Interface in org.eclipse.jetty.util
Build a string from a sequence of bytes and/or characters.
CharsetStringBuilder.DecoderStringBuilder - Class in org.eclipse.jetty.util
 
CharsetStringBuilder.Iso88591StringBuilder - Class in org.eclipse.jetty.util
 
CharsetStringBuilder.UsAsciiStringBuilder - Class in org.eclipse.jetty.util
 
check() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
check() - Method in class org.eclipse.jetty.util.component.Graceful.Shutdown
This method should be called whenever the components state has been updated.
check(byte, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FrameSequence
 
check(int) - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
Checks leases against the given number of maxThreads.
check(Object) - Method in class org.eclipse.jetty.util.security.Credential
Check a credential
check(Object) - Method in class org.eclipse.jetty.util.security.Credential.Crypt
 
check(Object) - Method in class org.eclipse.jetty.util.security.Credential.MD5
 
check(Object) - Method in class org.eclipse.jetty.util.security.Password
 
check(String, Path) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
check(String, Path) - Method in class org.eclipse.jetty.server.SymlinkAllowedResourceAliasChecker
 
check(String, Resource) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
check(String, Resource) - Method in class org.eclipse.jetty.server.handler.AllowSymLinkAliasChecker
Deprecated.
 
check(String, Resource) - Method in interface org.eclipse.jetty.server.handler.ContextHandler.AliasCheck
Check an alias
check(String, Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ApproveAliases
Deprecated.
 
check(String, Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ApproveNonExistentDirectoryAliases
Deprecated.
 
check(String, Resource) - Method in class org.eclipse.jetty.server.SameFileAliasChecker
Deprecated.
 
check(URI, String) - Method in class org.eclipse.jetty.start.FileInitializer
 
checkAlias(String, Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
checkAndPrepareUpgrade() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection.ServerHttpChannelOverHTTP2
 
checkAndPrepareUpgrade() - Method in class org.eclipse.jetty.server.HttpChannel
Checks whether the processing of the request resulted in an upgrade, and if so performs upgrade preparation steps before the upgrade response is sent back to the client.
checkAndPrepareUpgrade() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
checkAndSetAttributeName() - Method in class org.eclipse.jetty.webapp.DecoratingListener
 
checkCiphers(SSLParameters) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
checkClientTrusted(X509Certificate[], String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkConfiguration() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
checkConfiguration() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
checkConnection() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
checkConnection() - Method in class org.eclipse.jetty.util.resource.JarResource
 
checkConnection() - Method in class org.eclipse.jetty.util.resource.URLResource
 
checkContext(String, Request, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
checkContextPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
checkConverted() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionLegacyConverter
Retrieve the sessions using protobuf format and print them out to confirm they're ok.
checkCredential(Object) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
checkEnabledModules() - Method in class org.eclipse.jetty.start.Modules
 
checkEndPointIdentificationAlgorithm() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
checkError() - Method in class org.eclipse.jetty.server.ResponseWriter
 
checkExpiration(Set<String>) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
checkExpiration(Set<String>) - Method in interface org.eclipse.jetty.server.session.SessionCache
Check a list of session ids that belong to potentially expired sessions.
checkExpiry(Map<String, Object>) - Static method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
checkFrameSize(byte, int) - Method in class org.eclipse.jetty.websocket.core.internal.Parser
 
checkIdleTimeout() - Method in class org.eclipse.jetty.io.IdleTimeout
 
CHECKIN - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
checkInactiveSession(Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Check a session for being inactive and thus being able to be evicted, if eviction is enabled.
checkInactiveSession(Session) - Method in interface org.eclipse.jetty.server.session.SessionCache
Check a Session to see if it might be appropriate to evict or expire.
checkIndexes() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
Check to see if indexes are available, in which case we can do more performant queries.
checkListener(Class<? extends EventListener>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
checkListener(Class<? extends EventListener>) - Method in class org.eclipse.jetty.webapp.WebAppContext.Context
 
checkMinDataRate() - Method in interface org.eclipse.jetty.server.ContentProducer
Check if the current data rate consumption is above the minimal rate.
checkOrigin(String) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
 
CHECKOUT - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
checkParams(Class<?>[], Class<?>[], boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
checkPathsWithUncoveredHttpMethods() - Method in interface org.eclipse.jetty.security.ConstraintAware
See Servlet Spec 31, sec 13.8.4, pg 145 Container must check if there are urls with uncovered http methods
checkPathsWithUncoveredHttpMethods() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Servlet spec 3.1 pg.
checkPermission(Permission) - Static method in class org.eclipse.jetty.util.security.SecurityUtils
Checks the given permission, if the security manager is set.
checkProtocols(SSLParameters) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
checkPseudoHeader(HttpHeader, Object) - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
checkRequestedSessionId(Request, HttpServletRequest) - Method in class org.eclipse.jetty.server.session.SessionHandler
Look for a requested session ID in cookies and URI parameters
checkSecurity(Request) - Method in class org.eclipse.jetty.security.SecurityHandler
 
checkServerTrusted(X509Certificate[], String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
checkServletType() - Method in class org.eclipse.jetty.servlet.ServletHolder
Check to ensure class of servlet is acceptable.
checkStarted() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
checkState() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
checkTrustAll() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
checkUriCompliance(UriCompliance, HttpURI) - Static method in class org.eclipse.jetty.http.UriCompliance
 
checkUserDataPermissions(String, Request, Response, RoleInfo) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
checkUserDataPermissions(String, Request, Response, RoleInfo) - Method in class org.eclipse.jetty.security.SecurityHandler
 
checkValidForRead() - Method in class org.eclipse.jetty.server.session.Session
Chech that the session data can be read.
checkValidForWrite() - Method in class org.eclipse.jetty.server.session.Session
Check that the session can be modified.
checkViolation(HttpCompliance.Violation) - Method in class org.eclipse.jetty.http.HttpParser
 
checkVirtualHost(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
checkWebResourcePermissions(String, Request, Response, Object, UserIdentity) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
checkWebResourcePermissions(String, Request, Response, Object, UserIdentity) - Method in class org.eclipse.jetty.security.SecurityHandler
 
chooseClientAlias(String[], Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
chooseClientAlias(String[], Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
chooseClientAlias(String[], Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
chooseSelector() - Method in class org.eclipse.jetty.io.SelectorManager
 
chooseServerAlias(String, Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
chooseServerAlias(String, Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
chooseServerAlias(String, Principal[], Socket) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
chooseServerAlias(String, Principal[], Collection<SNIMatcher>, SSLSession) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
Chunk(ByteBuffer, Callback) - Constructor for class org.eclipse.jetty.client.util.DeferredContentProvider.Chunk
Deprecated.
 
CHUNK - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CHUNK_PARAMS - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CHUNK_SIZE - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CHUNK_SIZE - Static variable in class org.eclipse.jetty.http.HttpGenerator
 
CHUNKED - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
CHUNKED_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CHUNKED_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
 
CipherComparator() - Constructor for class org.eclipse.jetty.http2.HTTP2Cipher.CipherComparator
 
CLAIMS - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
CLASS_INHERITANCE_MAP - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
CLASS_NAME - Static variable in interface org.eclipse.jetty.osgi.boot.utils.BundleClassLoaderHelper
The name of the custom implementation for this interface in a fragment.
CLASS_NAME - Static variable in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
The name of the custom implementation for this interface in a fragment.
classifier - Variable in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
ClassInfo(Resource, String, int, int, String, String, String[]) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
ClassInheritanceHandler - Class in org.eclipse.jetty.annotations
ClassInheritanceHandler As asm scans for classes, remember the type hierarchy.
ClassInheritanceHandler(Map<String, Set<String>>) - Constructor for class org.eclipse.jetty.annotations.ClassInheritanceHandler
 
ClassInheritanceMap() - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.ClassInheritanceMap
 
ClassLoaderDump - Class in org.eclipse.jetty.server
 
ClassLoaderDump(ClassLoader) - Constructor for class org.eclipse.jetty.server.ClassLoaderDump
 
ClassLoaderThreadLocal() - Constructor for class org.eclipse.jetty.util.ClassLoadingObjectInputStream.ClassLoaderThreadLocal
 
ClassLoadingObjectInputStream - Class in org.eclipse.jetty.util
ClassLoadingObjectInputStream For re-inflating serialized objects, this class uses the thread context classloader rather than the jvm's default classloader selection.
ClassLoadingObjectInputStream() - Constructor for class org.eclipse.jetty.util.ClassLoadingObjectInputStream
 
ClassLoadingObjectInputStream(InputStream) - Constructor for class org.eclipse.jetty.util.ClassLoadingObjectInputStream
 
ClassLoadingObjectInputStream.ClassLoaderThreadLocal - Class in org.eclipse.jetty.util
 
ClassMatcher - Class in org.eclipse.jetty.webapp
A matcher for classes based on package and/or location and/or module/
ClassMatcher() - Constructor for class org.eclipse.jetty.webapp.ClassMatcher
 
ClassMatcher(String) - Constructor for class org.eclipse.jetty.webapp.ClassMatcher
 
ClassMatcher(String...) - Constructor for class org.eclipse.jetty.webapp.ClassMatcher
 
ClassMatcher(ClassMatcher) - Constructor for class org.eclipse.jetty.webapp.ClassMatcher
 
ClassMatcher.ByClass - Class in org.eclipse.jetty.webapp
 
ClassMatcher.ByLocation - Class in org.eclipse.jetty.webapp
 
ClassMatcher.ByLocationOrModule - Class in org.eclipse.jetty.webapp
 
ClassMatcher.ByModule - Class in org.eclipse.jetty.webapp
 
ClassMatcher.ByPackage - Class in org.eclipse.jetty.webapp
 
ClassMatcher.ByPackageOrName - Class in org.eclipse.jetty.webapp
 
ClassMatcher.Entry - Class in org.eclipse.jetty.webapp
 
Classpath - Class in org.eclipse.jetty.start
Class to handle CLASSPATH construction
Classpath() - Constructor for class org.eclipse.jetty.runner.Runner.Classpath
Deprecated.
 
Classpath() - Constructor for class org.eclipse.jetty.start.Classpath
 
Classpath(String) - Constructor for class org.eclipse.jetty.start.Classpath
 
ClassVisibilityChecker - Interface in org.eclipse.jetty.util
ClassVisibilityChecker Interface to be implemented by classes capable of checking class visibility for a context.
clean() - Method in class org.eclipse.jetty.server.session.SessionData
Clear all dirty flags.
cleanOrphans(long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Remove all sessions for any context that expired at or before the given time.
cleanReference(String) - Method in class org.eclipse.jetty.start.Props
 
cleanSubject(MessageInfo, Subject) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
cleanUp() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
Only remove tmp files.
cleanUp() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
Only remove tmp files.
clear() - Method in class org.eclipse.jetty.client.ProtocolHandlers
Removes all protocol handlers from this container.
clear() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
clear() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
clear() - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
clear() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
clear() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
clear() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
clear() - Method in interface org.eclipse.jetty.io.RetainableByteBufferPool
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBufferPool.NotRetainedByteBufferPool
 
clear() - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Clears all the includes, excludes, included connector names and excluded connector names.
clear() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
clear() - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
clear() - Method in class org.eclipse.jetty.util.Fields
Empties this Fields instance from all fields
clear() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
clear() - Method in interface org.eclipse.jetty.util.Index.Mutable
Remove all entries from the index.
clear() - Method in class org.eclipse.jetty.util.RegexSet
 
clear() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
clear() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
clear() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
clear() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
clear() - Method in class org.eclipse.jetty.webapp.Configurations
 
clear() - Method in class org.eclipse.jetty.webapp.MetaData
Empty ready for reuse
clear() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
clear() - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
clear(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Clears the buffer to be empty in flush mode.
clearAliasChecks() - Method in class org.eclipse.jetty.server.handler.ContextHandler
clear the list of AliasChecks
clearAllAttributes() - Method in class org.eclipse.jetty.server.session.SessionData
Remove all attributes
clearAssertionStatus() - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
clearAttributes() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
clearAttributes() - Method in class org.eclipse.jetty.server.Server
 
clearAttributes() - Method in class org.eclipse.jetty.server.ServletAttributes
 
clearAttributes() - Method in interface org.eclipse.jetty.util.Attributes
 
clearAttributes() - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
clearAttributes() - Method in class org.eclipse.jetty.util.AttributesMap
 
clearAttributes() - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
clearAuthenticationResults() - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
Removes all authentication results stored
clearAuthenticationResults() - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
clearAuthentications() - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
Removes all Authentications stored
clearAuthentications() - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
clearCache() - Method in class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
clearConnectionFactories() - Method in class org.eclipse.jetty.server.AbstractConnector
 
clearCredential() - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
clearError() - Method in class org.eclipse.jetty.server.ResponseWriter
 
clearHeaders() - Method in class org.eclipse.jetty.client.HttpResponse
 
clearLowResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
clearObject() - Method in class org.eclipse.jetty.jaas.callback.ObjectCallback
 
clearPassword() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
clearPassword() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
clearToFill(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Clear the buffer to be empty in fill mode.
clearTracking() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
clearTransitiveEnable() - Method in class org.eclipse.jetty.start.Module
 
Client() - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
Client(boolean) - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
CLIENT - Enum constant in enum org.eclipse.jetty.websocket.api.WebSocketBehavior
 
CLIENT - Enum constant in enum org.eclipse.jetty.websocket.core.Behavior
 
CLIENT_BIDIRECTIONAL - Enum constant in enum org.eclipse.jetty.quic.common.StreamType
 
CLIENT_CONNECTION_FACTORY_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
CLIENT_CONNECTOR_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
CLIENT_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http2.client.HTTP2ClientConnectionFactory
 
CLIENT_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http3.client.HTTP3Client
 
CLIENT_CONTEXT_KEY - Static variable in interface org.eclipse.jetty.io.ClientConnectionFactory
 
CLIENT_GRACEFUL - Static variable in class org.eclipse.jetty.http3.frames.GoAwayFrame
 
CLIENT_REQUEST_ATTRIBUTE - Static variable in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
CLIENT_UNIDIRECTIONAL - Enum constant in enum org.eclipse.jetty.quic.common.StreamType
 
ClientCertAuthenticator - Class in org.eclipse.jetty.security.authentication
Deprecated.
ClientCertAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
ClientConnectionFactory - Interface in org.eclipse.jetty.io
Factory for client-side Connection instances.
ClientConnectionFactory.Decorator - Interface in org.eclipse.jetty.io
Wraps another ClientConnectionFactory.
ClientConnectionFactory.Info - Class in org.eclipse.jetty.io
A holder for a list of protocol strings identifying an application protocol (for example ["h2", "h2-17", "h2-16"]) and a ClientConnectionFactory that creates connections that speak that network protocol.
ClientConnectionFactoryOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
ClientConnectionFactoryOverHTTP2(HTTP2Client) - Constructor for class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2
 
ClientConnectionFactoryOverHTTP2.HTTP2 - Class in org.eclipse.jetty.http2.client.http
Representation of the HTTP/2 application protocol used by HttpClientTransportDynamic.
ClientConnectionFactoryOverHTTP3 - Class in org.eclipse.jetty.http3.client.http
 
ClientConnectionFactoryOverHTTP3(HTTP3Client) - Constructor for class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3
 
ClientConnectionFactoryOverHTTP3.HTTP3 - Class in org.eclipse.jetty.http3.client.http
Representation of the HTTP/3 application protocol used by HttpClientTransportDynamic.
ClientConnector - Class in org.eclipse.jetty.io
The client-side component that connects to server sockets.
ClientConnector() - Constructor for class org.eclipse.jetty.io.ClientConnector
 
ClientConnector(ClientConnector.Configurator) - Constructor for class org.eclipse.jetty.io.ClientConnector
 
ClientConnector.ClientSelectorManager - Class in org.eclipse.jetty.io
 
ClientConnector.Configurator - Class in org.eclipse.jetty.io
Configures a ClientConnector.
ClientConnector.Configurator.ChannelWithAddress - Class in org.eclipse.jetty.io
A pair/record holding a SelectableChannel and a SocketAddress to connect to.
ClientEndpointConfigWrapper - Class in org.eclipse.jetty.websocket.jakarta.common
 
ClientEndpointConfigWrapper() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
ClientEndpointConfigWrapper(ClientEndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
ClientGenerator - Class in org.eclipse.jetty.fcgi.generator
 
ClientGenerator(ByteBufferPool) - Constructor for class org.eclipse.jetty.fcgi.generator.ClientGenerator
 
ClientGenerator(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.fcgi.generator.ClientGenerator
 
ClientHTTP2StreamEndPoint - Class in org.eclipse.jetty.http2.client.http
 
ClientHTTP2StreamEndPoint(IStream) - Constructor for class org.eclipse.jetty.http2.client.http.ClientHTTP2StreamEndPoint
 
ClientParser - Class in org.eclipse.jetty.fcgi.parser
 
ClientParser(ClientParser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.ClientParser
 
ClientParser.Listener - Interface in org.eclipse.jetty.fcgi.parser
 
ClientParser.Listener.Adapter - Class in org.eclipse.jetty.fcgi.parser
 
ClientProtocolSession - Class in org.eclipse.jetty.quic.client
Client specific implementation of ProtocolSession.
ClientProtocolSession(ClientQuicSession) - Constructor for class org.eclipse.jetty.quic.client.ClientProtocolSession
 
ClientQuicConnection - Class in org.eclipse.jetty.quic.client
The client specific implementation of QuicConnection.
ClientQuicConnection(ClientConnector, EndPoint, Map<String, Object>) - Constructor for class org.eclipse.jetty.quic.client.ClientQuicConnection
 
ClientQuicSession - Class in org.eclipse.jetty.quic.client
The client specific implementation of QuicSession.
ClientQuicSession(Executor, Scheduler, ByteBufferPool, QuicheConnection, QuicConnection, InetSocketAddress, Map<String, Object>) - Constructor for class org.eclipse.jetty.quic.client.ClientQuicSession
 
clientRequestStatus(Throwable) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
ClientSelectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
ClientUpgradeRequest - Class in org.eclipse.jetty.websocket.client
Client based UpgradeRequest API
ClientUpgradeRequest() - Constructor for class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
ClientUpgradeRequest(URI) - Constructor for class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Deprecated.
clone() - Method in class org.eclipse.jetty.util.security.Constraint
 
clone(Object) - Static method in class org.eclipse.jetty.util.LazyList
 
cloneConfigure(WebAppContext, WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
cloneConfigure(WebAppContext, WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
cloneConfigure(WebAppContext, WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
cloneConfigure(WebAppContext, WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
close() - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
close() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
close() - Method in interface org.eclipse.jetty.client.api.Connection
 
close() - Method in interface org.eclipse.jetty.client.ConnectionPool
 
close() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
close() - Method in class org.eclipse.jetty.client.HttpDestination
 
close() - Method in class org.eclipse.jetty.client.LeakTrackingConnectionPool
 
close() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
close() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
No more content will be added to this content provider and notifies the listener that no more content is available.
close() - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
close() - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
close() - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
 
close() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
close() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
close() - Method in class org.eclipse.jetty.http.HttpParser
Request that the associated data source be closed
close() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
close() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
close() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
close() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
close() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
close() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
close() - Method in interface org.eclipse.jetty.http2.IStream
Forcibly closes this stream.
close() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection.ServerHttpChannelOverHTTP2
 
close() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
close() - Method in class org.eclipse.jetty.io.AbstractConnection
 
close() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
close() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
close() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
close() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
close() - Method in interface org.eclipse.jetty.io.Connection
Performs a logical close of this connection.
close() - Method in interface org.eclipse.jetty.io.EndPoint
Close any backing stream associated with the endpoint
close() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
close() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
close() - Method in class org.eclipse.jetty.io.WriterOutputStream
 
close() - Method in class org.eclipse.jetty.jndi.BindingEnumeration
 
close() - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
close() - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
close() - Method in class org.eclipse.jetty.jndi.NameEnumeration
 
close() - Method in class org.eclipse.jetty.jndi.NamingContext
Do nothing
close() - Method in class org.eclipse.jetty.logging.StacklessLogging
 
close() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
close() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
close() - Method in class org.eclipse.jetty.server.HttpOutput
 
close() - Method in class org.eclipse.jetty.server.HttpWriter
 
close() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
close() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
close() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
close() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
close() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
close() - Method in interface org.eclipse.jetty.server.NetworkConnector
Performs the activities needed to close the network communication (for example, to stop accepting network connections).
close() - Method in class org.eclipse.jetty.server.resource.ByteBufferRangeWriter
 
close() - Method in class org.eclipse.jetty.server.resource.InputStreamRangeWriter
 
close() - Method in class org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter
 
close() - Method in class org.eclipse.jetty.server.ResponseWriter
 
close() - Method in class org.eclipse.jetty.server.ServerConnector
 
close() - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
close() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
close() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
close() - Method in class org.eclipse.jetty.util.compression.CompressionPool.Entry
 
close() - Method in class org.eclipse.jetty.util.IteratingCallback
Method to invoke to forbid further invocations to IteratingCallback.iterate() and IteratingCallback.reset().
close() - Method in class org.eclipse.jetty.util.MultiPartOutputStream
End the current part.
close() - Method in class org.eclipse.jetty.util.MultiPartWriter
End the current part.
close() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
 
close() - Method in class org.eclipse.jetty.util.Pool
 
close() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
close() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
close() - Method in class org.eclipse.jetty.util.resource.JarResource
 
close() - Method in class org.eclipse.jetty.util.resource.PathResource
 
close() - Method in class org.eclipse.jetty.util.resource.Resource
Release any temporary resources held by the resource.
close() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
close() - Method in class org.eclipse.jetty.util.resource.URLResource
Release any resources held by the resource.
close() - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
close() - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
Check the Callback has succeeded or failed and after the return leave in the state to allow reuse.
close() - Method in class org.eclipse.jetty.util.thread.AutoLock
 
close() - Method in class org.eclipse.jetty.util.thread.ThreadClassLoaderScope
 
close() - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget.Leased
 
close() - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
close() - Method in interface org.eclipse.jetty.websocket.api.Session
Request a close of the current conversation with a normal status code and no reason phrase.
close() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
close() - Method in interface org.eclipse.jetty.websocket.core.Extension
Used to clean up any resources after connection close.
close() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageWriter
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.Parser.ParsedFrame
 
close() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
close() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
close() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
close() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
close(int, String) - Method in interface org.eclipse.jetty.websocket.api.Session
Send a websocket Close frame, with status code.
close(int, String) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
close(int, String, Callback) - Method in interface org.eclipse.jetty.http2.api.Session
Closes the session by sending a GOAWAY frame with the given error code and payload.
close(int, String, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
Invoked internally and by applications to send a GO_AWAY frame to the other peer.
close(int, String, Callback) - Method in interface org.eclipse.jetty.websocket.core.CoreSession
Initiate close handshake with provide status code and optional reason phrase.
close(int, String, Callback) - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
close(int, String, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Send Close Frame with specified Status Code and optional Reason
close(int, String, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.Session
Send a websocket Close frame, with status code.
close(int, String, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
close(long, Throwable) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
close(CloseReason) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
close(Closeable) - Static method in class org.eclipse.jetty.start.FS
 
close(Closeable) - Static method in class org.eclipse.jetty.util.IO
Closes an arbitrary closable, and logs exceptions at ignore level
close(InputStream) - Static method in class org.eclipse.jetty.util.IO
closes an input stream, and logs exceptions
close(OutputStream) - Static method in class org.eclipse.jetty.util.IO
closes an output stream, and logs exceptions
close(Reader) - Static method in class org.eclipse.jetty.util.IO
closes a reader, and logs exceptions
close(Writer) - Static method in class org.eclipse.jetty.util.IO
closes a writer, and logs exceptions
close(Throwable) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
close(Throwable) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
close(Throwable) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
close(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
close(Throwable) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
close(Throwable) - Method in interface org.eclipse.jetty.io.EndPoint
Close any backing stream associated with the endpoint, passing a cause
close(Throwable) - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
close(Throwable) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
close(Callback) - Method in interface org.eclipse.jetty.websocket.core.CoreSession
Initiate close handshake, no payload (no declared status code or reason phrase)
close(Callback) - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
close(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Send Close Frame with no payload.
close(CloseStatus) - Method in interface org.eclipse.jetty.websocket.api.Session
Request Close the current conversation, giving a reason for the closure.
close(CloseStatus) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
CLOSE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
CLOSE - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CLOSE - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
CLOSE - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Close Frame
closeByHTTP(HttpFields) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
closed(Throwable) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
closed(Socket) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when a connection to a remote client has been closed.
CLOSED - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CLOSED - Enum constant in enum org.eclipse.jetty.http2.CloseState
Fully closed.
CloseException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
 
CloseException - Exception Class in org.eclipse.jetty.websocket.core.exception
 
CloseException(int, String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.CloseException
 
CloseException(int, String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.CloseException
 
CloseException(int, String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.CloseException
 
CloseException(int, String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.CloseException
 
CloseException(int, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.CloseException
 
CloseException(int, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.CloseException
 
closeFlusher() - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
Used to close this flusher when there is no explicit failure.
closeFlusher() - Method in class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
Used to close this flusher when there is no explicit failure.
CloseInfo - Class in org.eclipse.jetty.quic.common
A record that captures error code and error reason.
CloseInfo(long, String) - Constructor for class org.eclipse.jetty.quic.common.CloseInfo
 
closeOutput() - Method in class org.eclipse.jetty.server.Response
 
CloseState - Enum in org.eclipse.jetty.http2
The set of close states for a stream or a session.
CloseState.Event - Enum in org.eclipse.jetty.http2
 
CloseStatus - Class in org.eclipse.jetty.websocket.api
 
CloseStatus - Class in org.eclipse.jetty.websocket.core
Representation of a WebSocket Close (status code & reason)
CloseStatus() - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
Creates a reason for closing a web socket connection with the no given status code.
CloseStatus(int) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
Creates a reason for closing a web socket connection with the given status code and no reason phrase.
CloseStatus(int, String) - Constructor for class org.eclipse.jetty.websocket.api.CloseStatus
Creates a reason for closing a web socket connection with the given code and reason phrase.
CloseStatus(int, String) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
Creates a reason for closing a web socket connection with the given status code and reason phrase.
CloseStatus(int, String, Throwable) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
Creates a reason for closing a web socket connection with the given status code and reason phrase.
CloseStatus(int, Throwable) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
Creates a reason for closing a web socket connection with the given status code and reason phrase.
CloseStatus(ByteBuffer) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
 
CloseStatus(Frame) - Constructor for class org.eclipse.jetty.websocket.core.CloseStatus
 
CloseStatus.Supplier - Interface in org.eclipse.jetty.websocket.core
 
closeTag() - Method in class org.eclipse.jetty.xml.XmlAppendable
 
CLOSING - Enum constant in enum org.eclipse.jetty.http2.CloseState
A half-close frame has been received and a half-close frame has been generated, but not yet sent.
CNTL - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
code - Variable in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
code - Variable in enum org.eclipse.jetty.fcgi.FCGI.Role
 
code - Variable in enum org.eclipse.jetty.http2.ErrorCode
 
codeString(int) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
collectFragmentsAndRequiredBundles(Bundle, PackageAdmin, Map<String, Bundle>, boolean) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
Returns the fragments and the required-bundles.
Collection(RequestLog...) - Constructor for class org.eclipse.jetty.server.RequestLog.Collection
 
collectRequiredBundles(Bundle, PackageAdmin, Map<String, Bundle>, boolean) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
A simplistic but good enough parser for the Require-Bundle header.
COLON - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
combine(RoleInfo) - Method in class org.eclipse.jetty.security.RoleInfo
 
combine(UserDataConstraint) - Method in enum org.eclipse.jetty.security.UserDataConstraint
 
combine(Callback, Callback) - Static method in interface org.eclipse.jetty.util.Callback
 
combine(Invocable.InvocationType, Invocable.InvocationType) - Static method in interface org.eclipse.jetty.util.thread.Invocable
 
COMMA_NOT_VALID_OCTET - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Deprecated.
Use SPECIAL_CHARS_IN_QUOTES
COMMA_SEPARATOR - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
A comma was found as separator between cookies.
COMMAND_CONNECT - Static variable in class org.eclipse.jetty.client.Socks5
The SOCKS5 CONNECT command used in SOCKS5 connect requests.
CommandLineBuilder - Class in org.eclipse.jetty.start
 
CommandLineBuilder() - Constructor for class org.eclipse.jetty.start.CommandLineBuilder
 
CommandLineBuilder(boolean) - Constructor for class org.eclipse.jetty.start.CommandLineBuilder
 
CommandLineBuilder(String) - Constructor for class org.eclipse.jetty.start.CommandLineBuilder
Deprecated.
CommandLineConfigSource - Class in org.eclipse.jetty.start.config
Configuration Source representing the Command Line arguments.
CommandLineConfigSource(String[]) - Constructor for class org.eclipse.jetty.start.config.CommandLineConfigSource
 
commit() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
commit() - Method in interface org.eclipse.jetty.http2.IStream
Marks this stream as committed.
commit() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
commit() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
 
commit(HttpSession) - Method in class org.eclipse.jetty.server.session.SessionHandler
Called when a response is about to be committed.
commit(ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
commit(MetaData.Response) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
commit(MetaData.Response) - Method in class org.eclipse.jetty.server.HttpChannel
 
commit(Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
A response that has accessed this session is about to be returned to the client.
commit(Session) - Method in interface org.eclipse.jetty.server.session.SessionCache
Called when a response is about to be committed.
commitResponse() - Method in class org.eclipse.jetty.server.HttpChannelState
 
COMMITTED - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.State
 
compact(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Compact the buffer
compactPath(String) - Static method in class org.eclipse.jetty.util.URIUtil
Convert a path to a compact form.
CompactPathRule - Class in org.eclipse.jetty.rewrite.handler
Rewrite the URI by compacting to remove //
CompactPathRule() - Constructor for class org.eclipse.jetty.rewrite.handler.CompactPathRule
 
COMPARATOR - Static variable in class org.eclipse.jetty.http2.HTTP2Cipher
 
compare(ServletContainerInitializer, ServletContainerInitializer) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerComparator
 
compare(File, File) - Method in class org.eclipse.jetty.start.NaturalSort.Files
 
compare(String, String) - Method in class org.eclipse.jetty.http2.HTTP2Cipher.CipherComparator
 
compare(String, String) - Method in class org.eclipse.jetty.start.NaturalSort.Strings
 
compare(Path, Path) - Method in class org.eclipse.jetty.start.NaturalSort.Paths
 
compareAndSet(int, int, int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the hi and lo values to the given updated values only if the current hi and lo values == the expected hi and lo values.
compareAndSet(long, int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the values to the given updated values only if the current encoded value == the expected encoded value.
compareAndSetHi(int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the hi value to the given updated value only if the current value == the expected value.
compareAndSetLo(int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the lo value to the given updated value only if the current value == the expected value.
compareTo(MappedResource<E>) - Method in class org.eclipse.jetty.http.pathmap.MappedResource
Comparison is based solely on the pathSpec
compareTo(PathSpec) - Method in class org.eclipse.jetty.http.pathmap.AbstractPathSpec
 
compareTo(PathSpec) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
compareTo(ServletHolder) - Method in class org.eclipse.jetty.servlet.ServletHolder
Comparator by init order.
compareTo(Module) - Method in class org.eclipse.jetty.start.Module
 
compareTo(Version) - Method in class org.eclipse.jetty.start.Version
 
compile(byte[]) - Static method in class org.eclipse.jetty.util.SearchPattern
Produces a SearchPattern instance which can be used to find matches of the pattern in data
compile(String) - Static method in class org.eclipse.jetty.util.SearchPattern
Produces a SearchPattern instance which can be used to find matches of the pattern in data
Completable() - Constructor for class org.eclipse.jetty.util.Callback.Completable
 
Completable() - Constructor for class org.eclipse.jetty.util.Promise.Completable
 
Completable(Invocable.InvocationType) - Constructor for class org.eclipse.jetty.util.Callback.Completable
 
complete() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
complete() - Method in class org.eclipse.jetty.http3.api.Stream.Data
The method that applications must invoke to signal that the data bytes have been processed.
complete() - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamWriter
 
complete() - Method in class org.eclipse.jetty.server.AsyncContextState
 
complete() - Method in class org.eclipse.jetty.server.HttpChannelState
 
complete() - Method in class org.eclipse.jetty.server.session.Session
 
complete() - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
Signals to the parser that the parse data is complete, and returns the object parsed from the JSON chunks passed to the parse() methods.
complete(HttpSession) - Method in class org.eclipse.jetty.server.session.SessionHandler
Called when a request is finally leaving a session.
complete(String, JSON.Source) - Static method in class org.eclipse.jetty.util.ajax.JSON
 
complete(Callback) - Method in class org.eclipse.jetty.server.HttpOutput
 
complete(Callback) - Method in class org.eclipse.jetty.server.HttpWriter
 
complete(Callback) - Method in class org.eclipse.jetty.server.ResponseWriter
 
COMPLETE - Enum constant in enum org.eclipse.jetty.fcgi.parser.ContentParser.Result
The frame content parsing is complete, and the parser can now parse the padding bytes.
COMPLETE - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
completed() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
completed() - Method in class org.eclipse.jetty.util.Callback.Completing
 
completed(String) - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
completed(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelState
 
completed(Throwable) - Method in class org.eclipse.jetty.server.HttpOutput
Called to indicate that the request cycle has been completed.
completeOutput() - Method in class org.eclipse.jetty.server.Response
Deprecated.
completeOutput(Callback) - Method in class org.eclipse.jetty.server.Response
 
completeResponse() - Method in class org.eclipse.jetty.server.HttpChannelState
 
completeWith(CompletableFuture<?>) - Method in interface org.eclipse.jetty.util.Callback
Completes this callback with the given CompletableFuture.
completeWith(CompletableFuture<C>) - Method in interface org.eclipse.jetty.util.Promise
 
completeWrite() - Method in class org.eclipse.jetty.io.WriteFlusher
Complete a write that has not completed and that called WriteFlusher.onIncompleteFlush() to request a call to this method when a call to EndPoint.flush(ByteBuffer...) is likely to be able to progress.
completing() - Method in class org.eclipse.jetty.server.HttpChannelState
 
Completing() - Constructor for class org.eclipse.jetty.util.Callback.Completing
 
Completing(Invocable.InvocationType) - Constructor for class org.eclipse.jetty.util.Callback.Completing
 
COMPLETING - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.State
 
COMPLETING_1XX - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.State
 
ComplianceViolation - Interface in org.eclipse.jetty.http
A Compliance Violation represents a requirement of an RFC, specification or Jetty implementation that may be allowed to be violated if it is included in a ComplianceViolation.Mode.
ComplianceViolation.Listener - Interface in org.eclipse.jetty.http
A listener that can be notified of violations.
ComplianceViolation.Mode - Interface in org.eclipse.jetty.http
A Mode is a set of ComplianceViolations that are allowed.
compliesWith(CookieCompliance) - Method in class org.eclipse.jetty.http.CookieCompliance
 
components - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
components - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
composeName(String, String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
composeName(String, String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
composeName(String, String) - Method in class org.eclipse.jetty.jndi.NamingContext
Join two names together.
composeName(Name, Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
composeName(Name, Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
composeName(Name, Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Join two names together.
CompressedContentFormat - Class in org.eclipse.jetty.http
 
CompressedContentFormat(String, String) - Constructor for class org.eclipse.jetty.http.CompressedContentFormat
 
COMPRESSION_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates inability to maintain the HPACK compression context.
CompressionException(String, Object...) - Constructor for exception class org.eclipse.jetty.http2.hpack.HpackException.CompressionException
 
CompressionPool<T> - Class in org.eclipse.jetty.util.compression
 
CompressionPool(int) - Constructor for class org.eclipse.jetty.util.compression.CompressionPool
Create a Pool of CompressionPool instances.
CompressionPool.Entry - Class in org.eclipse.jetty.util.compression
 
computeField(String, BiFunction<String, List<HttpField>, HttpField>) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Computes a single field for the given HTTP header name and for existing fields with the same name.
computeField(HttpHeader, BiFunction<HttpHeader, List<HttpField>, HttpField>) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Computes a single field for the given HttpHeader and for existing fields with the same header.
concat(Iterator<T>, Iterator<T>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
Confidential - Enum constant in enum org.eclipse.jetty.security.UserDataConstraint
 
config - Variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
config(Props) - Method in class org.eclipse.jetty.start.ModuleGraphWriter
 
Config() - Constructor for class org.eclipse.jetty.servlet.ServletHolder.Config
 
Config(Path) - Constructor for class org.eclipse.jetty.util.PathWatcher.Config
 
Config(Path, PathWatcher.Config) - Constructor for class org.eclipse.jetty.util.PathWatcher.Config
 
ConfigSource - Interface in org.eclipse.jetty.start.config
A Configuration Source
ConfigSources - Class in org.eclipse.jetty.start.config
Weighted List of ConfigSources.
ConfigSources() - Constructor for class org.eclipse.jetty.start.config.ConfigSources
 
ConfigurableSpnegoAuthenticator - Class in org.eclipse.jetty.security.authentication
A LoginAuthenticator that uses SPNEGO and the GSS API to authenticate requests.
ConfigurableSpnegoAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
 
ConfigurableSpnegoAuthenticator(String) - Constructor for class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
Allow for a custom authMethod value to be set for instances where SPNEGO may not be appropriate
ConfigurableSpnegoLoginService - Class in org.eclipse.jetty.security
A configurable (as opposed to using system properties) SPNEGO LoginService.
ConfigurableSpnegoLoginService(String, AuthorizationService) - Constructor for class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
Configuration - Interface in org.eclipse.jetty.webapp
A pluggable Configuration for WebAppContexts.
Configuration - Interface in org.eclipse.jetty.websocket.core
 
Configuration.ConfigurationCustomizer - Class in org.eclipse.jetty.websocket.core
 
Configuration.Customizer - Interface in org.eclipse.jetty.websocket.core
 
Configuration.Wrapper - Class in org.eclipse.jetty.webapp
 
Configuration.WrapperFunction - Interface in org.eclipse.jetty.webapp
Experimental Wrapper mechanism for WebApp Configuration components.
ConfigurationCustomizer() - Constructor for class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
ConfigurationManager - Interface in org.eclipse.jetty.deploy
ConfigurationManager Type for allow injection of property values for replacement in jetty xml files during deployment.
ConfigurationProcessor - Interface in org.eclipse.jetty.xml
A ConfigurationProcessor for non XmlConfiguration format files.
ConfigurationProcessorFactory - Interface in org.eclipse.jetty.xml
 
Configurations - Class in org.eclipse.jetty.webapp
An ordered list of Configuration instances.
Configurations() - Constructor for class org.eclipse.jetty.webapp.Configurations
 
Configurations(String...) - Constructor for class org.eclipse.jetty.webapp.Configurations
 
Configurations(List<String>) - Constructor for class org.eclipse.jetty.webapp.Configurations
 
Configurations(Configurations) - Constructor for class org.eclipse.jetty.webapp.Configurations
 
Configurator() - Constructor for class org.eclipse.jetty.io.ClientConnector.Configurator
 
configure() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
configure() - Method in interface org.eclipse.jetty.xml.ConfigurationProcessor
 
configure() - Method in class org.eclipse.jetty.xml.XmlConfiguration
Applies the XML configuration script.
configure(Object) - Method in interface org.eclipse.jetty.xml.ConfigurationProcessor
 
configure(Object) - Method in class org.eclipse.jetty.xml.XmlConfiguration
Applies the XML configuration script to the given object.
configure(String[]) - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
Configure a jetty instance and deploy the webapps presented as args
configure(SelectableChannel) - Method in class org.eclipse.jetty.io.ClientConnector
 
configure(SSLEngine, Connection) - Method in class org.eclipse.jetty.alpn.conscrypt.client.ConscryptClientALPNProcessor
 
configure(SSLEngine, Connection) - Method in class org.eclipse.jetty.alpn.conscrypt.server.ConscryptServerALPNProcessor
 
configure(SSLEngine, Connection) - Method in class org.eclipse.jetty.alpn.java.client.JDK9ClientALPNProcessor
 
configure(SSLEngine, Connection) - Method in class org.eclipse.jetty.alpn.java.server.JDK9ServerALPNProcessor
 
configure(SSLEngine, Connection) - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Configures the given SSLEngine and the given Connection for ALPN.
configure(AbstractConnection, Connector, EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
configure(AbstractConnection, Connector, EndPoint) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
configure(EndPoint) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
configure(QuickStartGeneratorConfiguration, WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
configure(Connector) - Method in interface org.eclipse.jetty.server.ConnectionFactory.Configuring
Called during LifeCycle.start().
configure(Connector) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
configure(Server, List<URL>, Dictionary<String, Object>) - Static method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
configure(ServletContextHandler, JakartaWebSocketServletContainerInitializer.Configurator) - Static method in class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
Configure the ServletContextHandler to call JakartaWebSocketServletContainerInitializer.onStartup(Set, ServletContext) during the ServletContext initialization phase.
configure(ServletContextHandler, JettyWebSocketServletContainerInitializer.Configurator) - Static method in class org.eclipse.jetty.websocket.server.config.JettyWebSocketServletContainerInitializer
Configure the ServletContextHandler to call the JettyWebSocketServletContainerInitializer during the ServletContext initialization phase.
configure(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.ant.AntWebInfConfiguration
Adds classpath files into web application classloader, and sets web.xml and base directory for the configured web application.
configure(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
Allow fragments to supply some resources that are added to the baseResource of the webapp.
configure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
configure(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
Configure WebApp.
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configurations
 
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
Configure Apply web-jetty.xml configuration
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
configure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebXmlConfiguration
Process web-default.xml, web.xml, override-web.xml
configure(JettyWebSocketServletFactory) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServlet
Configure the JettyWebSocketServletFactory for this servlet instance by setting default configuration (which may be overriden by annotations) and mapping JettyWebSocketCreators.
configureCallbacks() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
configureContextHandler() - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
ConfiguredEndpoint - Class in org.eclipse.jetty.websocket.jakarta.common
Associate a JSR Endpoint with its optional EndpointConfig
ConfiguredEndpoint(Object, EndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.ConfiguredEndpoint
 
configureForSubject(Subject) - Method in class org.eclipse.jetty.security.RolePrincipal
 
configureMode(Server, String) - Static method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
Configure the server for the quickstart mode.
configureRoleInfo(RoleInfo, ConstraintMapping) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Initialize or update the RoleInfo from the constraint
configureSubject(Subject) - Method in class org.eclipse.jetty.security.UserPrincipal
 
configureTempDirectory(File, WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
configureWebApp() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
Configuring Connection Factories - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
CONFLICT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
CONFLICT_409 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
connect() - Method in class org.eclipse.jetty.server.LocalConnector
 
connect(Object, URI) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
connect(Object, URI, ClientUpgradeRequest) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
Connect to remote websocket endpoint
connect(Object, URI, ClientUpgradeRequest, JettyUpgradeListener) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
Connect to remote websocket endpoint
connect(InetSocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
connect(InetSocketAddress, Map<String, Object>) - Method in interface org.eclipse.jetty.client.HttpClientTransport
connect(InetSocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
connect(InetSocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
connect(InetSocketAddress, ClientConnectionFactory, Session.Listener, Promise<Session>, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
connect(SocketAddress, Map<String, Object>) - Method in interface org.eclipse.jetty.client.HttpClientTransport
Establishes a physical connection to the given address.
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
connect(SocketAddress, Session.Listener) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(SocketAddress, Session.Listener, Promise<Session>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(SocketAddress, Session.Client.Listener) - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
connect(SocketAddress, Session.Client.Listener, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
connect(SocketAddress, ClientConnectionFactory, Session.Listener, Promise<Session>, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
connect(SocketAddress, ClientConnectionFactory, Session.Listener, Promise<Session>, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(SelectableChannel, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a channel to perform a non-blocking connect.
connect(SslContextFactory, SocketAddress, Session.Listener) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(SslContextFactory, SocketAddress, Session.Listener, Promise<Session>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(SslContextFactory, SocketAddress, Session.Listener, Promise<Session>, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
connect(CoreClientUpgradeRequest) - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
connect(FrameHandler, URI) - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
CONNECT - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
ConnectContext(HttpServletRequest, HttpServletResponse, AsyncContext, EndPoint) - Constructor for class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
connectDatabase() - Method in class org.eclipse.jetty.security.JDBCLoginService
Connect to database with parameters setup by loadConfig()
connectFailed(Throwable, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
connectFailed(Map<String, Object>, Throwable) - Method in class org.eclipse.jetty.client.AbstractHttpClientTransport
 
ConnectHandler - Class in org.eclipse.jetty.proxy
Implementation of a Handler that supports HTTP CONNECT.
ConnectHandler() - Constructor for class org.eclipse.jetty.proxy.ConnectHandler
 
ConnectHandler(Handler) - Constructor for class org.eclipse.jetty.proxy.ConnectHandler
 
ConnectHandler.ConnectContext - Class in org.eclipse.jetty.proxy
 
ConnectHandler.ConnectManager - Class in org.eclipse.jetty.proxy
 
ConnectHandler.DownstreamConnection - Class in org.eclipse.jetty.proxy
 
ConnectHandler.UpstreamConnection - Class in org.eclipse.jetty.proxy
 
Connection - Interface in org.eclipse.jetty.client.api
Connection represent a connection to a Destination and allow applications to send requests via Connection.send(Request, Response.CompleteListener).
Connection - Interface in org.eclipse.jetty.io
A Connection is associated to an EndPoint so that I/O events happening on the EndPoint can be processed by the Connection.
CONNECTION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
General Fields.
CONNECTION_CLOSE - Static variable in class org.eclipse.jetty.server.HttpConnection
 
CONNECTION_PROMISE_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
Connection.Listener - Interface in org.eclipse.jetty.io
A Listener for connection events.
Connection.Listener.Adapter - Class in org.eclipse.jetty.io
 
Connection.UpgradeFrom - Interface in org.eclipse.jetty.io
Connection implementations implement this interface when they can upgrade from the protocol they speak (for example HTTP/1.1) to a different protocol (e.g.
Connection.UpgradeTo - Interface in org.eclipse.jetty.io
Connection implementations implement this interface when they can be upgraded to the protocol they speak (e.g.
connectionClosed(Connection, Throwable) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a connection is closed.
Connection Factories - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
Connection Factories - Search tag in class org.eclipse.jetty.server.ServerConnector
Section
ConnectionFactory - Interface in org.eclipse.jetty.server
A Factory to create Connection instances for Connectors.
ConnectionFactory.Configuring - Interface in org.eclipse.jetty.server
A ConnectionFactory that can configure the connector.
ConnectionFactory.Detecting - Interface in org.eclipse.jetty.server
Connections created by this factory MUST implement Connection.UpgradeTo.
ConnectionFactory.Detecting.Detection - Enum in org.eclipse.jetty.server
The possible outcomes of the ConnectionFactory.Detecting.detect(ByteBuffer) method.
ConnectionFactory.Upgrading - Interface in org.eclipse.jetty.server
 
Connection Factory Operation - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
connectionFailed(SelectableChannel, Throwable, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
connectionFailed(SelectableChannel, Throwable, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a non-blocking connect cannot be completed.
connectionFailed(SelectableChannel, Throwable, Object) - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectManager
 
connectionFailure(ByteBuffer, int, String) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
ConnectionLimit - Class in org.eclipse.jetty.server
A Listener that limits the number of Connections.
ConnectionLimit(int, Connector...) - Constructor for class org.eclipse.jetty.server.ConnectionLimit
 
ConnectionLimit(int, Server) - Constructor for class org.eclipse.jetty.server.ConnectionLimit
 
connectionOpened(Connection, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
connectionOpened(Connection, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a connection is opened.
ConnectionPool - Interface in org.eclipse.jetty.client
Client-side connection pool abstraction.
ConnectionPool.Factory - Interface in org.eclipse.jetty.client
Factory for ConnectionPool instances.
ConnectionPool.MaxUsable - Interface in org.eclipse.jetty.client
Marks a connection as being usable for a maximum number of requests.
ConnectionPool.Multiplexable - Interface in org.eclipse.jetty.client
Marks a connection as supporting multiplexed requests.
ConnectionSet() - Constructor for class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
ConnectionStatistics - Class in org.eclipse.jetty.io
A Connection.Listener that tracks connection statistics.
ConnectionStatistics() - Constructor for class org.eclipse.jetty.io.ConnectionStatistics
 
ConnectionStatistics.Stats - Class in org.eclipse.jetty.io
 
ConnectionStatisticsMBean - Class in org.eclipse.jetty.io.jmx
 
ConnectionStatisticsMBean(Object) - Constructor for class org.eclipse.jetty.io.jmx.ConnectionStatisticsMBean
 
ConnectManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.proxy.ConnectHandler.ConnectManager
 
Connector - Class in org.eclipse.jetty.ant.types
Connector
Connector - Interface in org.eclipse.jetty.server
A Connector accept connections and data from remote peers, and allows applications to send data to remote peers, by setting up the machinery needed to handle such tasks.
Connector() - Constructor for class org.eclipse.jetty.ant.types.Connector
 
Connector(int, int) - Constructor for class org.eclipse.jetty.ant.types.Connector
 
Connectors - Class in org.eclipse.jetty.ant.types
Specifies a jetty configuration <connectors/> element for Ant build file.
Connectors() - Constructor for class org.eclipse.jetty.ant.types.Connectors
Default constructor.
Connectors(int, int) - Constructor for class org.eclipse.jetty.ant.types.Connectors
Constructor.
ConnectorServer - Class in org.eclipse.jetty.jmx
LifeCycle wrapper for JMXConnectorServer.
ConnectorServer(JMXServiceURL, String) - Constructor for class org.eclipse.jetty.jmx.ConnectorServer
Constructs a ConnectorServer
ConnectorServer(JMXServiceURL, Map<String, ?>, String) - Constructor for class org.eclipse.jetty.jmx.ConnectorServer
Constructs a ConnectorServer
ConnectorServer(JMXServiceURL, Map<String, ?>, String, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.jmx.ConnectorServer
Constructs a ConnectorServer
Connector Services - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
ConnectorsThreadPoolLowResourceCheck() - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck
 
ConnectRequest(long, String, HostPortHttpField, String, HttpFields, String) - Constructor for class org.eclipse.jetty.http.MetaData.ConnectRequest
 
ConnectRequest(long, HttpScheme, HostPortHttpField, String, HttpFields, String) - Constructor for class org.eclipse.jetty.http.MetaData.ConnectRequest
 
ConnectRequest(String, HostPortHttpField, String, HttpFields, String) - Constructor for class org.eclipse.jetty.http.MetaData.ConnectRequest
 
ConnectRequest(HttpScheme, HostPortHttpField, String, HttpFields, String) - Constructor for class org.eclipse.jetty.http.MetaData.ConnectRequest
 
connectToServer(HttpServletRequest, String, int, Promise<SocketChannel>) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
connectToServer(Endpoint, ClientEndpointConfig, URI) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
connectToServer(Class<?>, URI) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
connectToServer(Class<? extends Endpoint>, ClientEndpointConfig, URI) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
connectToServer(Object, URI) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
ConscryptClientALPNProcessor - Class in org.eclipse.jetty.alpn.conscrypt.client
 
ConscryptClientALPNProcessor() - Constructor for class org.eclipse.jetty.alpn.conscrypt.client.ConscryptClientALPNProcessor
 
ConscryptServerALPNProcessor - Class in org.eclipse.jetty.alpn.conscrypt.server
 
ConscryptServerALPNProcessor() - Constructor for class org.eclipse.jetty.alpn.conscrypt.server.ConscryptServerALPNProcessor
 
ConstantThrowable - Exception Class in org.eclipse.jetty.util
A Throwable that may be used in static contexts.
ConstantThrowable() - Constructor for exception class org.eclipse.jetty.util.ConstantThrowable
 
ConstantThrowable(String) - Constructor for exception class org.eclipse.jetty.util.ConstantThrowable
 
Constraint - Class in org.eclipse.jetty.util.security
Constraint Describe an auth and/or data constraint.
Constraint() - Constructor for class org.eclipse.jetty.util.security.Constraint
Constructor.
Constraint(String, String) - Constructor for class org.eclipse.jetty.util.security.Constraint
Convenience Constructor.
ConstraintAware - Interface in org.eclipse.jetty.security
 
ConstraintMapping - Class in org.eclipse.jetty.security
 
ConstraintMapping() - Constructor for class org.eclipse.jetty.security.ConstraintMapping
 
ConstraintSecurityHandler - Class in org.eclipse.jetty.security
ConstraintSecurityHandler
ConstraintSecurityHandler() - Constructor for class org.eclipse.jetty.security.ConstraintSecurityHandler
 
constraintsExist(List<ServletMapping>, List<ConstraintMapping>) - Method in class org.eclipse.jetty.annotations.ServletSecurityAnnotationHandler
Check if there are already <security-constraint> elements defined that match the url-patterns for the servlet.
consumeAll() - Method in interface org.eclipse.jetty.server.ContentProducer
Fail all content currently available in this ContentProducer instance as well as in the underlying HttpChannel.
consumeAll() - Method in class org.eclipse.jetty.server.HttpInput
 
consumeInput() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
container - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
Container - Interface in org.eclipse.jetty.util.component
A Container
CONTAINER_BUNDLE_PATTERN - Static variable in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
Regex of symbolic names of bundles that should be considered to be on the container classpath
CONTAINER_INCLUDE_JAR_PATTERN - Static variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
CONTAINER_INITIALIZER_STARTER - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
CONTAINER_INITIALIZERS - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
CONTAINER_JAR_PATTERN - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
Container.InheritedListener - Interface in org.eclipse.jetty.util.component
Inherited Listener.
Container.Listener - Interface in org.eclipse.jetty.util.component
A listener for Container events.
ContainerDefaultConfigurator - Class in org.eclipse.jetty.websocket.jakarta.server.config
The "Container Default Configurator" per the JSR-356 spec.
ContainerDefaultConfigurator() - Constructor for class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
Default Constructor required, as jakarta.websocket.server.ServerEndpointConfig$Configurator.fetchContainerDefaultConfigurator() will be the one that instantiates this class in most cases.
ContainerInitializer - Class in org.eclipse.jetty.plus.annotation
Deprecated.
ContainerInitializer - Class in org.eclipse.jetty.servlet.listener
Utility Methods for manual execution of ServletContainerInitializer when using Embedded Jetty.
ContainerInitializer() - Constructor for class org.eclipse.jetty.servlet.listener.ContainerInitializer
 
ContainerInitializer(ServletContainerInitializer, Class<?>[]) - Constructor for class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
ContainerInitializer(ClassLoader, String) - Constructor for class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
ContainerInitializer.ServletContainerInitializerServletContextListener - Class in org.eclipse.jetty.servlet.listener
 
ContainerInitializerAnnotationHandler - Class in org.eclipse.jetty.annotations
ContainerInitializerAnnotationHandler
ContainerInitializerAnnotationHandler(ContainerInitializer, Class<?>) - Constructor for class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
Deprecated.
ContainerInitializerAnnotationHandler(ServletContainerInitializerHolder, Class<?>) - Constructor for class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
 
ContainerLifeCycle - Class in org.eclipse.jetty.util.component
A ContainerLifeCycle is an LifeCycle implementation for a collection of contained beans.
ContainerLifeCycle() - Constructor for class org.eclipse.jetty.util.component.ContainerLifeCycle
 
ContainerPathNameMatcher(WebAppContext, String) - Constructor for class org.eclipse.jetty.webapp.MetaInfConfiguration.ContainerPathNameMatcher
 
contains(Object) - Method in class org.eclipse.jetty.util.AsciiLowerCaseSet
 
contains(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
contains(Object, Object) - Static method in class org.eclipse.jetty.util.LazyList
 
contains(String) - Method in class org.eclipse.jetty.http.HttpField
Look for a value in a possible multi valued field
contains(String) - Method in interface org.eclipse.jetty.http.HttpFields
 
contains(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Check to see if this cache contains an entry for the session corresponding to the session id.
contains(String) - Method in interface org.eclipse.jetty.server.session.SessionCache
Check to see if a Session is in the cache.
contains(String, String) - Method in interface org.eclipse.jetty.http.HttpFields
 
contains(EnumSet<HttpHeader>) - Method in interface org.eclipse.jetty.http.HttpFields
 
contains(HttpField) - Method in interface org.eclipse.jetty.http.HttpFields
 
contains(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
 
contains(HttpHeader, String) - Method in interface org.eclipse.jetty.http.HttpFields
 
containsFilterHolder(FilterHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
containsHeader(String) - Method in class org.eclipse.jetty.server.Response
 
containsHeader(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
containsHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
containsKey(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
containsKey(String) - Method in class org.eclipse.jetty.start.Props
 
containsPathSpec(String) - Method in class org.eclipse.jetty.servlet.ServletMapping
Test if the list of path specs contains a particular one.
containsSameFieldName(Field, Class<?>, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
containsSameMethodSignature(Method, Class<?>, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
containsServletHolder(ServletHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
containsSimpleValue(V) - Method in class org.eclipse.jetty.util.MultiMap
Test for a specific single value in the map.
containsValue(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
content(String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
content(ByteBuffer) - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
content(ByteBuffer) - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
 
content(ByteBuffer) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
content(ByteBuffer) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
content(ByteBuffer, boolean) - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
content(ByteBuffer, Callback) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
content(ContentProvider) - Method in interface org.eclipse.jetty.client.api.Request
Deprecated.
content(ContentProvider) - Method in class org.eclipse.jetty.client.HttpRequest
 
content(ContentProvider, String) - Method in interface org.eclipse.jetty.client.api.Request
Deprecated.
content(ContentProvider, String) - Method in class org.eclipse.jetty.client.HttpRequest
 
Content(ByteBuffer) - Constructor for class org.eclipse.jetty.server.HttpInput.Content
 
CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CONTENT_ENCODING - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_END - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
CONTENT_LANGUAGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_LENGTH - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_LENGTH - Enum constant in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
 
CONTENT_LENGTH - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
CONTENT_LENGTH_0 - Static variable in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
CONTENT_LOCATION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_MD5 - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_RANGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_TYPE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
CONTENT_TYPE - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
contentComplete() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
contentComplete() - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
 
contentComplete() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
contentComplete() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
ContentDecoder - Interface in org.eclipse.jetty.client
ContentDecoder decodes content bytes of a response.
ContentDecoder.Factory - Class in org.eclipse.jetty.client
Factory for ContentDecoders; subclasses must implement ContentDecoder.Factory.newContentDecoder().
ContentParser - Class in org.eclipse.jetty.fcgi.parser
Parser for FastCGI frame content.
ContentParser(HeaderParser) - Constructor for class org.eclipse.jetty.fcgi.parser.ContentParser
 
ContentParser.Result - Enum in org.eclipse.jetty.fcgi.parser
The result of the frame content parsing.
ContentProducer - Interface in org.eclipse.jetty.server
ContentProducer is the bridge between HttpInput and HttpChannel.
ContentProvider - Interface in org.eclipse.jetty.client.api
Deprecated.
ContentProvider.Typed - Interface in org.eclipse.jetty.client.api
Deprecated.
use Request.Content instead
ContentResponse - Interface in org.eclipse.jetty.client.api
A specialized Response that can hold a limited content in memory.
Context() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler.Context
 
Context() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
Context() - Constructor for class org.eclipse.jetty.webapp.WebAppContext.Context
 
CONTEXT_INIT - Static variable in class org.eclipse.jetty.servlet.DefaultServlet
 
CONTEXT_KEY - Static variable in class org.eclipse.jetty.quic.common.QuicConfiguration
 
ContextBundleTracker(BundleContext, String) - Constructor for class org.eclipse.jetty.osgi.boot.BundleContextProvider.ContextBundleTracker
 
contextDestroyed() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Call the ServletContextListeners with contextDestroyed.
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.server.DebugListener
 
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
 
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.ELContextCleaner
Deprecated.
 
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.IntrospectorCleaner
 
contextDestroyed(ServletContextEvent) - Method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketShutdownContainer
 
ContextFactory - Class in org.eclipse.jetty.jndi
ContextFactory
ContextFactory() - Constructor for class org.eclipse.jetty.jndi.ContextFactory
 
contextFor(String) - Method in class org.eclipse.jetty.util.ajax.JSON
Every time a JSON object field representation {"name": value} is parsed, this method is called to (possibly) return a different JSON instance (for example configured with different converters) to parse the object field.
contextForArray() - Method in class org.eclipse.jetty.util.ajax.JSON
Every time a JSON array representation [...] is parsed, this method is called to (possibly) return a different JSON instance (for example configured with different converters) to parse the array items.
ContextHandler - Class in org.eclipse.jetty.server.handler
ContextHandler.
ContextHandler() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(String) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(ContextHandler.Context) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(ContextHandler.Context, HandlerContainer, String) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(HandlerContainer, String) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler.AliasCheck - Interface in org.eclipse.jetty.server.handler
Interface to check aliases
ContextHandler.ApproveAliases - Class in org.eclipse.jetty.server.handler
Deprecated.
ContextHandler.ApproveNonExistentDirectoryAliases - Class in org.eclipse.jetty.server.handler
Deprecated.
ContextHandler.Availability - Enum in org.eclipse.jetty.server.handler
 
ContextHandler.Context - Class in org.eclipse.jetty.server.handler
Context.
ContextHandler.ContextScopeListener - Interface in org.eclipse.jetty.server.handler
Listener for all threads entering context scope, including async IO callbacks
ContextHandler.ContextStatus - Enum in org.eclipse.jetty.server.handler
 
ContextHandler.StaticContext - Class in org.eclipse.jetty.server.handler
A simple implementation of ServletContext that is used when there is no ContextHandler.
ContextHandlerCollection - Class in org.eclipse.jetty.server.handler
This HandlerCollection is creates a Map of contexts to it's contained handlers based on the context path and virtual hosts of any contained ContextHandlers.
ContextHandlerCollection() - Constructor for class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
ContextHandlerCollection(ContextHandler...) - Constructor for class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
ContextHandlerMBean - Class in org.eclipse.jetty.server.handler.jmx
 
ContextHandlerMBean(Object) - Constructor for class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
ContextHandlers - Class in org.eclipse.jetty.ant.types
Specifies <contextHandlers/> element in web app configuration.
ContextHandlers() - Constructor for class org.eclipse.jetty.ant.types.ContextHandlers
 
contextInitialized() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Call the ServletContextListeners contextInitialized methods.
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.server.DebugListener
 
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
 
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.ELContextCleaner
Deprecated.
 
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.servlet.listener.IntrospectorCleaner
 
contextInitialized(ServletContextEvent) - Method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketShutdownContainer
 
CONTEXTPATH - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
ContextTracker(BundleContext, Filter) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ContextTracker
 
CONTINUATION - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
CONTINUATION - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
CONTINUATION - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Continuation Frame
ContinuationBodyParser - Class in org.eclipse.jetty.http2.parser
 
ContinuationBodyParser(HeaderParser, Parser.Listener, HeaderBlockParser, HeaderBlockFragments) - Constructor for class org.eclipse.jetty.http2.parser.ContinuationBodyParser
 
ContinuationFrame - Class in org.eclipse.jetty.http2.frames
 
ContinuationFrame(int, boolean) - Constructor for class org.eclipse.jetty.http2.frames.ContinuationFrame
 
CONTINUE - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
CONTINUE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
CONTINUE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
CONTINUE_100 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
CONTINUE_100_INFO - Static variable in class org.eclipse.jetty.http.HttpGenerator
 
continue100(int) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
If the associated response has the Expect header set to 100 Continue, then accessing the input stream indicates that the handler/servlet is ready for the request body and thus a 100 Continue response is sent.
continue100(int) - Method in class org.eclipse.jetty.server.HttpChannel
If the associated response has the Expect header set to 100 Continue, then accessing the input stream indicates that the handler/servlet is ready for the request body and thus a 100 Continue response is sent.
continue100(int) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
If the associated response has the Expect header set to 100 Continue, then accessing the input stream indicates that the handler/servlet is ready for the request body and thus a 100 Continue response is sent.
ContinueListener() - Constructor for class org.eclipse.jetty.client.ContinueProtocolHandler.ContinueListener
 
ContinueProtocolHandler - Class in org.eclipse.jetty.client
A protocol handler that handles the 100 response code.
ContinueProtocolHandler() - Constructor for class org.eclipse.jetty.client.ContinueProtocolHandler
 
ContinueProtocolHandler.ContinueListener - Class in org.eclipse.jetty.client
 
control(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.Generator
 
convert() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionLegacyConverter
Convert all sessions to protobuf format sessions.
convert(Fields) - Static method in class org.eclipse.jetty.client.util.FormContentProvider
Deprecated.
 
convert(Fields) - Static method in class org.eclipse.jetty.client.util.FormRequestContent
 
convert(Fields, Charset) - Static method in class org.eclipse.jetty.client.util.FormContentProvider
Deprecated.
 
convert(Fields, Charset) - Static method in class org.eclipse.jetty.client.util.FormRequestContent
 
convertCause(Throwable) - Static method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
convertCause(Throwable) - Static method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
convertCredentialLdapToJetty(String) - Static method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
 
convertHexDigit(byte) - Static method in class org.eclipse.jetty.util.TypeUtil
 
convertHexDigit(char) - Static method in class org.eclipse.jetty.util.TypeUtil
 
convertHexDigit(int) - Static method in class org.eclipse.jetty.util.TypeUtil
 
convertible() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
convertIdentifier(String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
Convert a camel case identifier into either upper or lower depending on the way the db stores identifiers.
convertTo(Class<?>, Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSON
 
cookie(HttpCookie) - Method in interface org.eclipse.jetty.client.api.Request
 
cookie(HttpCookie) - Method in class org.eclipse.jetty.client.HttpRequest
 
COOKIE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
Other Fields.
CookieCompliance - Class in org.eclipse.jetty.http
The compliance mode for Cookie handling.
CookieCompliance(String, Set<CookieCompliance.Violation>) - Constructor for class org.eclipse.jetty.http.CookieCompliance
 
CookieCompliance.Violation - Enum in org.eclipse.jetty.http
 
CookieConfig() - Constructor for class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
CookieCutter - Class in org.eclipse.jetty.http
Deprecated.
CookieCutter(CookieParser.Handler, CookieCompliance, ComplianceViolation.Listener) - Constructor for class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
CookieParser - Interface in org.eclipse.jetty.http
Cookie parser.
CookieParser.Handler - Interface in org.eclipse.jetty.http
The handler of parsed cookies.
CookieParser.InvalidCookieException - Exception Class in org.eclipse.jetty.http
The exception thrown when a cookie cannot be parsed and CookieCompliance.Violation.INVALID_COOKIES is not allowed.
CookiePatternRule - Class in org.eclipse.jetty.rewrite.handler
Sets the cookie in the response whenever the rule finds a match.
CookiePatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.CookiePatternRule
 
CookiePatternRule(String, String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.CookiePatternRule
 
Cookies - Class in org.eclipse.jetty.server
Cookie parser
Cookies() - Constructor for class org.eclipse.jetty.server.Cookies
 
Cookies(CookieCompliance, ComplianceViolation.Listener) - Constructor for class org.eclipse.jetty.server.Cookies
 
cookieSet() - Method in class org.eclipse.jetty.server.session.Session
 
COOKIESETTIME - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
Coordinates() - Constructor for class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
copy(File, File) - Static method in class org.eclipse.jetty.util.IO
Copy files or directories
copy(InputStream, OutputStream) - Static method in class org.eclipse.jetty.util.IO
Copy Stream in to Stream out until EOF or exception.
copy(InputStream, OutputStream, long) - Static method in class org.eclipse.jetty.util.IO
Copy Stream in to Stream for byteCount bytes or until EOF or exception.
copy(Reader, Writer) - Static method in class org.eclipse.jetty.util.IO
Copy Reader to Writer out until EOF or exception.
copy(Reader, Writer, long) - Static method in class org.eclipse.jetty.util.IO
Copy Reader to Writer for byteCount bytes or until EOF or exception.
copy(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Deep copy of a buffer
copy(SessionData) - Method in class org.eclipse.jetty.server.session.SessionData
Copy the info from the given sessiondata
copy(Frame) - Static method in class org.eclipse.jetty.websocket.core.Frame
 
COPY - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
copyBuffer(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
copyBytes(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
copyDir(File, File) - Static method in class org.eclipse.jetty.util.IO
 
copyDirectory(Path, Path) - Method in class org.eclipse.jetty.start.FileInitializer
 
copyFile(File, File) - Static method in class org.eclipse.jetty.util.IO
 
copyHeaders(Frame) - Method in class org.eclipse.jetty.websocket.core.Frame
 
copyOf(JakartaWebSocketMessageMetadata) - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
copyRequest(HttpRequest, URI) - Method in class org.eclipse.jetty.client.HttpClient
 
copyRequestHeaders(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
copyTo(File) - Method in class org.eclipse.jetty.util.resource.JarResource
 
copyTo(File) - Method in class org.eclipse.jetty.util.resource.PathResource
 
copyTo(File) - Method in class org.eclipse.jetty.util.resource.Resource
Copy the Resource to the new destination file.
copyTo(File) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
copyWithoutPayload(Frame) - Static method in class org.eclipse.jetty.websocket.core.Frame
 
copyZipContents(Path, Path) - Static method in class org.eclipse.jetty.start.FS
 
coreClient - Variable in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
coreClientFactory - Variable in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
CoreClientUpgradeRequest - Class in org.eclipse.jetty.websocket.core.client
 
CoreClientUpgradeRequest(WebSocketCoreClient, URI) - Constructor for class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
CoreSession - Interface in org.eclipse.jetty.websocket.core
Represents the outgoing Frames.
CoreSession.Empty - Class in org.eclipse.jetty.websocket.core
 
count() - Method in class org.eclipse.jetty.start.Classpath
 
COUNTER - Static variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
CounterStatistic - Class in org.eclipse.jetty.util.statistic
Statistics on a counter value.
CounterStatistic() - Constructor for class org.eclipse.jetty.util.statistic.CounterStatistic
 
CountingCallback - Class in org.eclipse.jetty.util
A callback wrapper that succeeds the wrapped callback when the count is reached, or on first failure.
CountingCallback(Callback, int) - Constructor for class org.eclipse.jetty.util.CountingCallback
 
countTokens() - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
Not implemented.
CR - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
CR - Enum constant in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
 
CR - Static variable in class org.eclipse.jetty.util.TypeUtil
 
CR_LINE_TERMINATION - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
create(String) - Static method in class org.eclipse.jetty.util.PidFile
 
create(URI, String) - Method in class org.eclipse.jetty.start.FileInitializer
Initialize a file resource
create(URI, String) - Method in class org.eclipse.jetty.start.fileinits.BaseHomeFileInitializer
 
create(URI, String) - Method in class org.eclipse.jetty.start.fileinits.LocalFileInitializer
 
create(URI, String) - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
create(URI, String) - Method in class org.eclipse.jetty.start.fileinits.TestFileInitializer
 
create(URI, String) - Method in class org.eclipse.jetty.start.fileinits.UriFileInitializer
 
createAnnotationParser(int) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
createAnnotationParser(int) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
This parser scans the bundles using the OSGi APIs instead of assuming a jar.
createApp(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
Called by the Scanner.DiscreteListener to create a new App object.
createConnection(Promise<Connection>) - Method in class org.eclipse.jetty.client.HttpDestination
 
createConnector(boolean) - Method in class org.eclipse.jetty.servlet.ServletTester
Create a port based connector.
createConstraint() - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
createConstraint(String, boolean, String[], int) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Create a security constraint
createConstraint(String, HttpConstraintElement) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Create a Constraint
createConstraint(String, String[], ServletSecurity.EmptyRoleSemantic, ServletSecurity.TransportGuarantee) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Create Constraint
createConstraint(Constraint) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
createConstraintsWithMappingsForPath(String, String, ServletSecurityElement) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Generate Constraints and ContraintMappings for the given url pattern and ServletSecurityElement
createContext(String) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
createContext(String, HttpHandler) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
createContextHandler() - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
createContextHandler() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
createContextHandler(App) - Method in interface org.eclipse.jetty.deploy.AppProvider
Create a ContextHandler for an App
createContextHandler(App) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
createContextHandler(App) - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider
 
createContextHandler(App) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
CREATED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
CREATED_201 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
createEndpointMetadata(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
createEnvContext(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
createFile() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
createFile() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
createFilter(Class<T>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
createFilter(Class<T>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
createFilter(BundleContext, String, String) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
Create an osgi filter for the given classname and server name.
createHttpClient() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
Creates a HttpClient instance, configured with init parameters of this servlet.
createHttpServer(InetSocketAddress, int) - Method in class org.eclipse.jetty.http.spi.JettyHttpServerProvider
 
createHttpsServer(InetSocketAddress, int) - Method in class org.eclipse.jetty.http.spi.JettyHttpServerProvider
 
createInstance() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
createInstance() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
createInstance() - Method in class org.eclipse.jetty.servlet.ListenerHolder
 
createInstance() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
createInstance(Class<T>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
createInstance(Class<T>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
createInstance(Class<T>) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
createInstance(BaseHolder<T>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
createLibEtcClassLoader(File, ClassLoader) - Static method in class org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper
 
createLibExtClassLoader(List<File>, List<URL>, ClassLoader) - Static method in class org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper
 
createListener(Class<T>) - Method in class org.eclipse.jetty.server.AsyncContextState
 
createListener(Class<T>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
createListener(Class<T>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
createLocalConnector() - Method in class org.eclipse.jetty.servlet.ServletTester
 
createLocalStream(int, MetaData.Request, Consumer<Throwable>) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
createLogger() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
createMessageSink(MethodHandle, Class<? extends MessageSink>, Executor, WebSocketSession) - Static method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
createMessageSink(JakartaWebSocketSession, JakartaWebSocketMessageMetadata) - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
createMetadata(Class<?>) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
createNewFile(Path) - Static method in class org.eclipse.jetty.start.FS
 
createOrigin(HttpRequest, Origin.Protocol) - Method in class org.eclipse.jetty.client.HttpClient
 
createProtocolSession() - Method in class org.eclipse.jetty.quic.client.ClientQuicSession
 
createProtocolSession() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
createProtocolSession() - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
createRemoteStream(int, MetaData.Request) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
createServlet(Class<T>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
createServlet(Class<T>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
createServletContainerInitializerAnnotationHandlers(WebAppContext, List<ServletContainerInitializer>) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
createSession(SocketAddress, ByteBuffer) - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
createSession(SocketAddress, ByteBuffer) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
createSession(SocketAddress, ByteBuffer) - Method in class org.eclipse.jetty.quic.server.ServerQuicConnection
 
createSubcontext(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
createSubcontext(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
createSubcontext(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Create a Context as a child of this one
createSubcontext(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
createSubcontext(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
createSubcontext(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Create a context as a child of this one
CREATETIME - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
createWebApp() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
createWebSocket(ServerUpgradeRequest, ServerUpgradeResponse) - Method in interface org.eclipse.jetty.websocket.core.server.WebSocketCreator
Create a websocket from the incoming request.
createWebSocket(ServerUpgradeRequest, ServerUpgradeResponse) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
createWebSocket(JettyServerUpgradeRequest, JettyServerUpgradeResponse) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketCreator
Create a websocket from the incoming request.
createWebSocketConnection(Request, WebSocketCoreSession) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
createWebSocketConnection(Request, WebSocketCoreSession) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
createWebSocketConnection(Request, WebSocketCoreSession) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
CreatorNegotiator - Class in org.eclipse.jetty.websocket.core.server.internal
 
CreatorNegotiator(WebSocketCreator, FrameHandlerFactory) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.CreatorNegotiator
 
CreatorNegotiator(WebSocketCreator, FrameHandlerFactory, Configuration.Customizer) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.CreatorNegotiator
 
Credential - Class in org.eclipse.jetty.util.security
Credentials.
Credential() - Constructor for class org.eclipse.jetty.util.security.Credential
 
Credential.Crypt - Class in org.eclipse.jetty.util.security
Unix Crypt Credentials
Credential.MD5 - Class in org.eclipse.jetty.util.security
MD5 Credentials
credentialLogin(Object) - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
password supplied authentication check
CredentialProvider - Interface in org.eclipse.jetty.util.security
Provider of credentials, it converts a String into a credential if it starts with a given prefix
CredentialValidationCallback - Class in org.eclipse.jetty.security.jaspi.callback
CredentialValidationCallback Store a jetty Credential for a user so that it can be validated by jaspi
CredentialValidationCallback(Subject, String, Credential) - Constructor for class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
CRLF - Enum constant in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
 
CRLF - Static variable in class org.eclipse.jetty.util.IO
 
CRLF - Static variable in class org.eclipse.jetty.util.StringUtil
 
CRLF_BYTES - Static variable in class org.eclipse.jetty.util.IO
 
crypt(String, String) - Static method in class org.eclipse.jetty.util.security.Credential.Crypt
 
crypt(String, String) - Static method in class org.eclipse.jetty.util.security.UnixCrypt
Encrypts String into crypt (Unix) code.
CSRF_TOKEN - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
Deprecated.
csvSplit(String) - Static method in class org.eclipse.jetty.util.StringUtil
csvSplit(String, int, int) - Static method in class org.eclipse.jetty.util.StringUtil
csvSplit(List<String>, String, int, int) - Static method in class org.eclipse.jetty.util.StringUtil
Split a quoted comma separated string to a list
customize(Socket, Class<? extends Connection>, boolean) - Method in class org.eclipse.jetty.server.SocketCustomizationListener
This method may be extended to configure a socket on open events.
customize(SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
customize(SSLEngine) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Customize an SslEngine instance with the configuration of this factory, by calling SslContextFactory.customize(SSLParameters)
customize(SSLEngine, Request) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Customizes the request attributes to be set for SSL requests.
customize(SSLParameters) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Customize an SslParameters instance with the configuration of this factory.
customize(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
customize(Connection, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory
 
customize(Connection, Map<String, Object>) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
customize(EndPoint) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
Allow for overridden customization of endpoint (such as special transport level properties: e.g.
customize(Connector, HttpConfiguration, Request) - Method in class org.eclipse.jetty.rewrite.RewriteCustomizer
 
customize(Connector, HttpConfiguration, Request) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
customize(Connector, HttpConfiguration, Request) - Method in class org.eclipse.jetty.server.HostHeaderCustomizer
 
customize(Connector, HttpConfiguration, Request) - Method in interface org.eclipse.jetty.server.HttpConfiguration.Customizer
 
customize(Connector, HttpConfiguration, Request) - Method in class org.eclipse.jetty.server.ProxyCustomizer
 
customize(Connector, HttpConfiguration, Request) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
customize(Configuration) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
customize(Configuration) - Method in interface org.eclipse.jetty.websocket.core.Configuration.Customizer
 
customize(Configuration) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiator.AbstractNegotiator
 
customize(Configuration) - Method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
customizeFastCGIHeaders(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
customizeSecure(Request) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Customizes the request attributes for general secure settings.
CustomRequestLog - Class in org.eclipse.jetty.server
A flexible RequestLog, which produces log strings in a customizable format.
CustomRequestLog() - Constructor for class org.eclipse.jetty.server.CustomRequestLog
 
CustomRequestLog(String) - Constructor for class org.eclipse.jetty.server.CustomRequestLog
 
CustomRequestLog(String, String) - Constructor for class org.eclipse.jetty.server.CustomRequestLog
 
CustomRequestLog(RequestLog.Writer, String) - Constructor for class org.eclipse.jetty.server.CustomRequestLog
 
CyclicTimeout - Class in org.eclipse.jetty.io
An abstract implementation of a timeout.
CyclicTimeout(Scheduler) - Constructor for class org.eclipse.jetty.io.CyclicTimeout
 
CyclicTimeouts<T> - Class in org.eclipse.jetty.io
An implementation of a timeout that manages many expirable entities whose timeouts are mostly cancelled or re-scheduled.
CyclicTimeouts(Scheduler) - Constructor for class org.eclipse.jetty.io.CyclicTimeouts
 
CyclicTimeouts.Expirable - Interface in org.eclipse.jetty.io
An entity that may expire.

D

data(byte[], int, int, Callback) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamWriter
 
data(DataFrame) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given DATA frame.
data(DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given DATA frame.
data(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
data(IStream, Callback, DataFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
data(IStream, Callback, DataFrame) - Method in interface org.eclipse.jetty.http2.ISession
Enqueues the given DATA frame to be written to the connection.
data(DataFrame) - Method in interface org.eclipse.jetty.http3.api.Stream
Sends the given DATA frame containing some or all the bytes of the request content or of the response content.
data(ByteBufferPool.Lease, DataFrame, int) - Method in class org.eclipse.jetty.http2.generator.Generator
 
Data(DataFrame, Runnable) - Constructor for class org.eclipse.jetty.http3.api.Stream.Data
 
DATA - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
DATA - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
DATA - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
DatabaseAdaptor - Class in org.eclipse.jetty.server.session
DatabaseAdaptor Handles differences between databases.
DatabaseAdaptor() - Constructor for class org.eclipse.jetty.server.session.DatabaseAdaptor
 
DataBodyParser - Class in org.eclipse.jetty.http2.parser
 
DataBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.DataBodyParser
 
DataFrame - Class in org.eclipse.jetty.http2.frames
 
DataFrame - Class in org.eclipse.jetty.http3.frames
 
DataFrame(int, ByteBuffer, boolean) - Constructor for class org.eclipse.jetty.http2.frames.DataFrame
 
DataFrame(int, ByteBuffer, boolean, int) - Constructor for class org.eclipse.jetty.http2.frames.DataFrame
 
DataFrame(ByteBuffer, boolean) - Constructor for class org.eclipse.jetty.http2.frames.DataFrame
 
DataFrame(ByteBuffer, boolean) - Constructor for class org.eclipse.jetty.http3.frames.DataFrame
 
DataGenerator - Class in org.eclipse.jetty.http2.generator
 
DataGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.DataGenerator
 
DatagramChannelEndPoint - Class in org.eclipse.jetty.io
An EndPoint implementation based on DatagramChannel.
DatagramChannelEndPoint(DatagramChannel, ManagedSelector, SelectionKey, Scheduler) - Constructor for class org.eclipse.jetty.io.DatagramChannelEndPoint
 
dataSize() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
dataSize() - Method in interface org.eclipse.jetty.http2.IStream
 
DataSourceCloser - Class in org.eclipse.jetty.jndi
Close a DataSource.
DataSourceCloser(DataSource) - Constructor for class org.eclipse.jetty.jndi.DataSourceCloser
 
DataSourceCloser(DataSource, String) - Constructor for class org.eclipse.jetty.jndi.DataSourceCloser
 
DataSourceLoginModule - Class in org.eclipse.jetty.jaas.spi
DataSourceLoginModule A LoginModule that uses a DataSource to retrieve user authentication and authorisation information.
DataSourceLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.DataSourceLoginModule
 
DataSourceLoginService - Class in org.eclipse.jetty.plus.security
DataSourceLoginService
DataSourceLoginService() - Constructor for class org.eclipse.jetty.plus.security.DataSourceLoginService
 
DataSourceLoginService(String) - Constructor for class org.eclipse.jetty.plus.security.DataSourceLoginService
 
DataSourceLoginService(String, IdentityService) - Constructor for class org.eclipse.jetty.plus.security.DataSourceLoginService
 
DataSourceLoginService.DBUserPrincipal - Class in org.eclipse.jetty.plus.security
DBUser
dataType - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
DATE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
DateCache - Class in org.eclipse.jetty.util
Computes String representations of Dates then caches the results so that subsequent requests within the same second will be fast.
DateCache() - Constructor for class org.eclipse.jetty.util.DateCache
Make a DateCache that will use a default format.
DateCache(String) - Constructor for class org.eclipse.jetty.util.DateCache
Make a DateCache that will use the given format.
DateCache(String, Locale) - Constructor for class org.eclipse.jetty.util.DateCache
 
DateCache(String, Locale, String) - Constructor for class org.eclipse.jetty.util.DateCache
 
DateCache(String, Locale, TimeZone) - Constructor for class org.eclipse.jetty.util.DateCache
 
DateCache(String, Locale, TimeZone, boolean) - Constructor for class org.eclipse.jetty.util.DateCache
 
DateCache.Tick - Class in org.eclipse.jetty.util
 
DateGenerator - Class in org.eclipse.jetty.http
ThreadLocal Date formatters for HTTP style dates.
DateGenerator() - Constructor for class org.eclipse.jetty.http.DateGenerator
 
DateParser - Class in org.eclipse.jetty.http
ThreadLocal data parsers for HTTP style dates
DateParser() - Constructor for class org.eclipse.jetty.http.DateParser
 
DBUserPrincipal(String, Credential, int) - Constructor for class org.eclipse.jetty.plus.security.DataSourceLoginService.DBUserPrincipal
 
DC_CONFIDENTIAL - Static variable in class org.eclipse.jetty.util.security.Constraint
 
DC_FORBIDDEN - Static variable in class org.eclipse.jetty.util.security.Constraint
 
DC_INTEGRAL - Static variable in class org.eclipse.jetty.util.security.Constraint
 
DC_NONE - Static variable in class org.eclipse.jetty.util.security.Constraint
 
DC_UNSET - Static variable in class org.eclipse.jetty.util.security.Constraint
 
deactivate(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
debug() - Method in class org.eclipse.jetty.start.CommandLineBuilder
 
debug(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
debug(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
debug(String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(String, long) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Formats and logs at debug level.
debug(String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(String, Object...) - Static method in class org.eclipse.jetty.start.StartLog
 
debug(String, Object...) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Formats and logs at debug level.
debug(String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(String, Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given message at debug level, with Throwable information.
debug(Throwable) - Static method in class org.eclipse.jetty.start.StartLog
 
debug(Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given Throwable information at debug level
debug(Marker, String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(Marker, String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(Marker, String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(Marker, String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
debug(Marker, String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
DEBUG - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
DebugBinding - Class in org.eclipse.jetty.deploy.bindings
 
DebugBinding(String) - Constructor for class org.eclipse.jetty.deploy.bindings.DebugBinding
 
DebugBinding(String...) - Constructor for class org.eclipse.jetty.deploy.bindings.DebugBinding
 
DebugHandler - Class in org.eclipse.jetty.server.handler
Debug Handler.
DebugHandler() - Constructor for class org.eclipse.jetty.server.handler.DebugHandler
 
DebugListener - Class in org.eclipse.jetty.server
A Context Listener that produces additional debug.
DebugListener() - Constructor for class org.eclipse.jetty.server.DebugListener
 
DebugListener(boolean, boolean, boolean) - Constructor for class org.eclipse.jetty.server.DebugListener
 
DebugListener(OutputStream, boolean, boolean, boolean) - Constructor for class org.eclipse.jetty.server.DebugListener
 
DebugListenerBinding - Class in org.eclipse.jetty.deploy.bindings
A Deployment binding that installs a DebugListener in all deployed contexts
DebugListenerBinding() - Constructor for class org.eclipse.jetty.deploy.bindings.DebugListenerBinding
 
DebugListenerBinding(DebugListener) - Constructor for class org.eclipse.jetty.deploy.bindings.DebugListenerBinding
 
declaredRolesContains(String) - Method in class org.eclipse.jetty.security.AbstractUserAuthentication
 
declareRoles(String...) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
declareRoles(String...) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
declareRoles(String...) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
DeclareRolesAnnotationHandler - Class in org.eclipse.jetty.annotations
DeclaresRolesAnnotationHandler
DeclareRolesAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.DeclareRolesAnnotationHandler
 
decode(long, ByteBuffer, QpackDecoder.Handler) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
Decode a buffer into a MetaData object given a HTTP/3 stream ID.
decode(InputStream) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.InputStreamDecoder
 
decode(Reader) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ReaderDecoder
 
decode(String) - Static method in class org.eclipse.jetty.security.openid.JwtDecoder
Decodes a JSON Web Token (JWT) into a Map of claims.
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.BooleanDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.CharacterDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.DoubleDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.FloatDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.IntegerDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.LongDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ShortDecoder
 
decode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.StringDecoder
 
decode(ByteBuffer) - Method in interface org.eclipse.jetty.client.ContentDecoder
Decodes the bytes in the given buffer and returns decoded bytes, if any.
decode(ByteBuffer) - Method in class org.eclipse.jetty.http.compression.HuffmanDecoder
 
decode(ByteBuffer) - Method in class org.eclipse.jetty.http.compression.NBitStringDecoder
Decode a string from the buffer.
decode(ByteBuffer) - Method in class org.eclipse.jetty.http.GZIPContentDecoder
Inflates compressed data from a buffer.
decode(ByteBuffer) - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
decode(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteArrayDecoder
 
decode(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteBufferDecoder
 
decode88591To(InputStream, MultiMap<String>, int, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to MultiMap, using ISO8859-1 encodings.
decodeChunks(ByteBuffer) - Method in class org.eclipse.jetty.http.GZIPContentDecoder
Inflates compressed data.
DecodedBinaryMessageSink<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
DecodedBinaryMessageSink(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedBinaryMessageSink
 
DecodedBinaryStreamMessageSink<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
DecodedBinaryStreamMessageSink(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedBinaryStreamMessageSink
 
decodedChunk(ByteBuffer) - Method in class org.eclipse.jetty.client.GZIPContentDecoder
 
decodedChunk(ByteBuffer) - Method in class org.eclipse.jetty.http.GZIPContentDecoder
Called when a chunk of data is inflated.
decodedPath(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
DecodedTextMessageSink<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
DecodedTextMessageSink(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedTextMessageSink
 
DecodedTextStreamMessageSink<T> - Class in org.eclipse.jetty.websocket.jakarta.common.messages
 
DecodedTextStreamMessageSink(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedTextStreamMessageSink
 
decodeInt(ByteBuffer) - Method in class org.eclipse.jetty.http.compression.NBitIntegerDecoder
Decode an integer from the buffer.
decodeLong(ByteBuffer) - Method in class org.eclipse.jetty.http.compression.NBitIntegerDecoder
Decode a long from the buffer.
decodeName(String) - Static method in class org.eclipse.jetty.nosql.mongodb.MongoUtils
 
decodePath(String) - Static method in class org.eclipse.jetty.util.URIUtil
 
decodePath(String, int, int) - Static method in class org.eclipse.jetty.util.URIUtil
 
decoder - Variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
DecoderStringBuilder(CharsetDecoder) - Constructor for class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
decodeSpecific(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Decode a raw String and convert any specific URI encoded sequences into characters.
decodeString(String) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decode String with % encoding.
decodeString(String, int, int, Charset) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decode String with % encoding.
decodeTo(InputStream, MultiMap<String>, String, int, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
Deprecated, for removal: This API element is subject to removal in a future version.
decodeTo(InputStream, MultiMap<String>, Charset, int, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to Map.
decodeTo(String, MultiMap<String>, String) - Static method in class org.eclipse.jetty.util.UrlEncoded
Deprecated, for removal: This API element is subject to removal in a future version.
decodeTo(String, MultiMap<String>, Charset) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to Map.
decodeTo(String, MultiMap<String>, Charset, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to Map.
decodeUtf16To(InputStream, MultiMap<String>, int, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
 
decodeUtf8To(InputStream, MultiMap<String>, int, int) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to Map.
decodeUtf8To(String, int, int, MultiMap<String>) - Static method in class org.eclipse.jetty.util.UrlEncoded
Decoded parameters to Map.
decodeUtf8To(String, MultiMap<String>) - Static method in class org.eclipse.jetty.util.UrlEncoded
 
decodeValue(Object) - Static method in class org.eclipse.jetty.nosql.mongodb.MongoUtils
 
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
Remove jndi setup from start
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
deconfigure(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
DeConfigure WebApp.
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
deconfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebXmlConfiguration
 
deconfigureSubject(Subject) - Method in class org.eclipse.jetty.security.UserPrincipal
 
decorate(Object) - Method in class org.eclipse.jetty.annotations.AnnotationDecorator
 
decorate(Object) - Method in class org.eclipse.jetty.plus.webapp.PlusDecorator
 
decorate(T) - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
Decorate an object.
decorate(T) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
decorate(T) - Method in interface org.eclipse.jetty.util.Decorator
 
decorate(T) - Method in class org.eclipse.jetty.util.DeprecationWarning
 
DecoratedObjectFactory - Class in org.eclipse.jetty.util
An ObjectFactory enhanced by Decorator instances.
DecoratedObjectFactory() - Constructor for class org.eclipse.jetty.util.DecoratedObjectFactory
 
DecoratingListener - Class in org.eclipse.jetty.servlet
A ServletContextAttributeListener that listens for a context attribute to obtain a decorator instance.
DecoratingListener - Class in org.eclipse.jetty.webapp
An extended org.eclipse.jetty.servlet.DecoratingListener.
DecoratingListener() - Constructor for class org.eclipse.jetty.webapp.DecoratingListener
 
DecoratingListener(String) - Constructor for class org.eclipse.jetty.webapp.DecoratingListener
 
DecoratingListener(ServletContextHandler) - Constructor for class org.eclipse.jetty.webapp.DecoratingListener
 
DecoratingListener(ServletContextHandler, String) - Constructor for class org.eclipse.jetty.servlet.DecoratingListener
 
DecoratingListener(ServletContextHandler, String) - Constructor for class org.eclipse.jetty.webapp.DecoratingListener
 
Decorator - Interface in org.eclipse.jetty.util
Interface to decorate objects created by the DecoratedObjectFactory
DECORATOR_ATTRIBUTE - Static variable in class org.eclipse.jetty.webapp.DecoratingListener
 
decrement() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
Decrements the value by one.
decrementCount() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
decrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
Deprecated.
decrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Deprecated.
decrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
Deprecated.
decrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
Deprecated.
DecryptedEndPoint() - Constructor for class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
deduceKeyLength(String) - Static method in class org.eclipse.jetty.util.ssl.SslContextFactory
Given the name of a TLS/SSL cipher suite, return an int representing it effective stream cipher key strength.
DEEP_BINDING - Static variable in class org.eclipse.jetty.jndi.NamingContext
 
DEFAULT - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
The default spec for accessing the Default path behavior.
DEFAULT - Static variable in class org.eclipse.jetty.http.UriCompliance
The default compliance mode that extends RFC3986 compliance with additional violations to avoid most ambiguous URIs.
DEFAULT - Static variable in interface org.eclipse.jetty.osgi.boot.utils.BundleClassLoaderHelper
The default instance supports felix and equinox
DEFAULT - Static variable in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
The default instance supports felix and equinox
DEFAULT - Static variable in class org.eclipse.jetty.servlet.FilterMapping
Dispatch types
DEFAULT_AUTO_FRAGMENT - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
Whether frames are automatically fragmented to respect the maximum frame size.
DEFAULT_BACKOFF_MS - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
DEFAULT_BUFFER_SIZE - Static variable in class org.eclipse.jetty.client.GZIPContentDecoder
 
DEFAULT_CAPACITY - Static variable in class org.eclipse.jetty.util.BlockingArrayQueue
Default initial capacity, 128.
DEFAULT_CAPACITY - Static variable in class org.eclipse.jetty.util.compression.CompressionPool
 
DEFAULT_CONNECT_TIMEOUT - Static variable in class org.eclipse.jetty.io.SelectorManager
 
DEFAULT_CONTAINER_INCLUDE_JAR_PATTERN - Static variable in class org.eclipse.jetty.ant.AntWebAppContext
 
DEFAULT_CONTEXT_PATH - Static variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
DEFAULT_DATE_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
DEFAULT_DELIMS - Static variable in class org.eclipse.jetty.util.StringUtil
 
DEFAULT_FACTOR - Static variable in class org.eclipse.jetty.io.ArrayByteBufferPool
 
DEFAULT_FACTOR - Static variable in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
DEFAULT_FACTOR - Static variable in class org.eclipse.jetty.io.MappedByteBufferPool
 
DEFAULT_FACTOR - Static variable in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
DEFAULT_FILENAME - Static variable in class org.eclipse.jetty.jaas.spi.PropertyFileLoginModule
 
DEFAULT_FORMAT - Static variable in class org.eclipse.jetty.util.DateCache
 
DEFAULT_GRACE_PERIOD_SEC - Static variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
DEFAULT_GROWTH - Static variable in class org.eclipse.jetty.util.BlockingArrayQueue
Default growth factor, 64.
DEFAULT_HOST - Static variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
DEFAULT_IDLE_TIMEOUT - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default duration that a websocket connection may be idle before being closed by the implementation.
DEFAULT_INPUT_BUFFER_SIZE - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default input buffer size used to read from network/transport layer.
DEFAULT_JETTY_ETC_FILES - Static variable in class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
Set of config files to apply to a jetty Server instance if none are supplied by SYS_PROP_JETTY_ETC_FILES
DEFAULT_JETTYHOME - Static variable in class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
Default location within bundle of a jetty home dir.
DEFAULT_KEYMANAGERFACTORY_ALGORITHM - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory
 
DEFAULT_LISTENER_TYPE_INDEX - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
DEFAULT_MAX_BINARY_MESSAGE_SIZE - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default maximum size of a binary message that can be received.
DEFAULT_MAX_CAPACITY_BY_FACTOR - Static variable in class org.eclipse.jetty.io.ArrayByteBufferPool
 
DEFAULT_MAX_CAPACITY_BY_FACTOR - Static variable in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
DEFAULT_MAX_CAPACITY_BY_FACTOR - Static variable in class org.eclipse.jetty.io.MappedByteBufferPool
 
DEFAULT_MAX_CAPACITY_BY_FACTOR - Static variable in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
DEFAULT_MAX_CONTENT_LENGTH - Static variable in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
DEFAULT_MAX_FORM_CONTENT_SIZE - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
DEFAULT_MAX_FORM_KEYS - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
DEFAULT_MAX_FRAME_SIZE - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default maximum payload size of any WebSocket frame that can be received.
DEFAULT_MAX_KEYS - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
DEFAULT_MAX_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.Frame
 
DEFAULT_MAX_OUTGOING_FRAMES - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default maximum number of data frames allowed to be waiting to be sent at any one time.
DEFAULT_MAX_QUERY_RESULTS - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
DEFAULT_MAX_RETRIES - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
DEFAULT_MAX_SCAN_WAIT - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
DEFAULT_MAX_TABLE_CAPACITY - Static variable in class org.eclipse.jetty.http2.hpack.HpackContext
 
DEFAULT_MAX_TEXT_MESSAGE_SIZE - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default maximum size of a text message that can be received.
DEFAULT_MIN_GZIP_SIZE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
DEFAULT_MULTI_THREADED - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
DEFAULT_NAMESPACE - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
DEFAULT_ORIGIN_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
DEFAULT_OUTPUT_BUFFER_SIZE - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default output buffer size used to write to the network/transport layer.
DEFAULT_PERIOD_MS - Static variable in class org.eclipse.jetty.server.session.HouseKeeper
 
DEFAULT_PORT - Static variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
DEFAULT_PORT - Static variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
DEFAULT_PROTECTED_OSGI_TARGETS - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Set of extra dirs that must not be served by osgi webapps
DEFAULT_ROLE_CLASS_NAME - Static variable in class org.eclipse.jetty.jaas.JAASLoginService
 
DEFAULT_ROLE_CLASS_NAMES - Static variable in class org.eclipse.jetty.jaas.JAASLoginService
 
DEFAULT_SAVE_PERIOD_SEC - Static variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
DEFAULT_SCAN_DEPTH - Static variable in class org.eclipse.jetty.util.Scanner
When walking a directory, a depth of 1 ensures that the directory's descendants are visited, not just the directory itself (as a file).
DEFAULT_SESSION_TRACKING_MODES - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
DEFAULT_TRACKING - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
DEFAULT_TRUSTMANAGERFACTORY_ALGORITHM - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory
 
DEFAULT_USE_CONTAINER_METAINF_CACHE - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
DEFAULT_WINDOW_SIZE - Static variable in interface org.eclipse.jetty.http2.FlowControlStrategy
 
DEFAULT_WRITE_TIMEOUT - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
The default maximum time a frame may be waiting to be sent.
Default404Servlet() - Constructor for class org.eclipse.jetty.servlet.ServletHandler.Default404Servlet
 
DefaultAuthConfigFactory - Class in org.eclipse.jetty.security.jaspi
A very basic AuthConfigFactory that allows for registering providers programmatically.
DefaultAuthConfigFactory() - Constructor for class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
DefaultAuthenticatorFactory - Class in org.eclipse.jetty.security
The Default Authenticator Factory.
DefaultAuthenticatorFactory() - Constructor for class org.eclipse.jetty.security.DefaultAuthenticatorFactory
 
DefaultBundleClassLoaderHelper - Class in org.eclipse.jetty.osgi.boot.utils.internal
DefaultBundleClassLoaderHelper
DefaultBundleClassLoaderHelper() - Constructor for class org.eclipse.jetty.osgi.boot.utils.internal.DefaultBundleClassLoaderHelper
 
DefaultCallbackHandler - Class in org.eclipse.jetty.jaas.callback
DefaultCallbackHandler An implementation of the JAAS CallbackHandler.
DefaultCallbackHandler() - Constructor for class org.eclipse.jetty.jaas.callback.DefaultCallbackHandler
 
defaultCustomizer - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
DefaultFileLocatorHelper - Class in org.eclipse.jetty.osgi.boot.utils.internal
DefaultFileLocatorHelper
DefaultFileLocatorHelper() - Constructor for class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
 
DefaultHandler - Class in org.eclipse.jetty.server.handler
Default Handler.
DefaultHandler() - Constructor for class org.eclipse.jetty.server.handler.DefaultHandler
 
DefaultIdentityService - Class in org.eclipse.jetty.security
Default Identity Service implementation.
DefaultIdentityService() - Constructor for class org.eclipse.jetty.security.DefaultIdentityService
 
DefaultImpl() - Constructor for class org.eclipse.jetty.util.Uptime.DefaultImpl
 
DefaultJettyAtJettyHomeHelper - Class in org.eclipse.jetty.osgi.boot.internal.serverfactory
DefaultJettyAtJettyHomeHelper
DefaultJettyAtJettyHomeHelper() - Constructor for class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
 
DefaultParser() - Constructor for class org.eclipse.jetty.jndi.InitialContextFactory.DefaultParser
 
DefaultsDescriptor - Class in org.eclipse.jetty.webapp
DefaultsDescriptor
DefaultsDescriptor(Resource) - Constructor for class org.eclipse.jetty.webapp.DefaultsDescriptor
 
DefaultServlet - Class in org.eclipse.jetty.servlet
The default servlet.
DefaultServlet() - Constructor for class org.eclipse.jetty.servlet.DefaultServlet
 
DefaultServlet(ResourceService) - Constructor for class org.eclipse.jetty.servlet.DefaultServlet
 
DefaultSessionCache - Class in org.eclipse.jetty.server.session
DefaultSessionCache A session store that keeps its sessions in memory within a concurrent map
DefaultSessionCache(SessionHandler) - Constructor for class org.eclipse.jetty.server.session.DefaultSessionCache
 
DefaultSessionCache(SessionHandler, ConcurrentMap<String, Session>) - Constructor for class org.eclipse.jetty.server.session.DefaultSessionCache
 
DefaultSessionCacheFactory - Class in org.eclipse.jetty.server.session
DefaultSessionCacheFactory Factory for creating new DefaultSessionCaches.
DefaultSessionCacheFactory() - Constructor for class org.eclipse.jetty.server.session.DefaultSessionCacheFactory
 
DefaultSessionIdManager - Class in org.eclipse.jetty.server.session
DefaultSessionIdManager Manages session ids to ensure each session id within a context is unique, and that session ids can be shared across contexts (but not session contents).
DefaultSessionIdManager(Server) - Constructor for class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
DefaultSessionIdManager(Server, Random) - Constructor for class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
DefaultUserIdentity - Class in org.eclipse.jetty.security
The default implementation of UserIdentity.
DefaultUserIdentity(Subject, Principal, String[]) - Constructor for class org.eclipse.jetty.security.DefaultUserIdentity
 
DeferredAuthentication - Class in org.eclipse.jetty.security.authentication
 
DeferredAuthentication(LoginAuthenticator) - Constructor for class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
DeferredContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
use AsyncRequestContent instead.
DeferredContentProvider(ByteBuffer...) - Constructor for class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
Creates a new DeferredContentProvider with the given initial content
DeferredContentProvider.Chunk - Class in org.eclipse.jetty.client.util
Deprecated.
 
definePackage(String, String, String, String, String, String, String, URL) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
definePackage(String, Manifest, URL) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
DEFLATE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
DeflaterPool - Class in org.eclipse.jetty.util.compression
 
DeflaterPool(int, int, boolean) - Constructor for class org.eclipse.jetty.util.compression.DeflaterPool
Create a Pool of Deflater instances.
delayHandling(Request, AsyncContext) - Method in class org.eclipse.jetty.server.handler.AsyncDelayHandler
Called to indicate that a requests handling is being delayed/ The implementation should arrange for context.dispatch() to be called when the request should be handled.
DELEGATE - Static variable in interface org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager.SniSelector
 
DelegatedJettyClientUpgradeRequest - Class in org.eclipse.jetty.websocket.client.impl
Representing the Jetty HttpClient's HttpRequest in the UpgradeRequest interface.
DelegatedJettyClientUpgradeRequest(CoreClientUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
DelegatedJettyClientUpgradeResponse - Class in org.eclipse.jetty.websocket.client.impl
Representing the Jetty HttpClient's HttpResponse in the UpgradeResponse interface.
DelegatedJettyClientUpgradeResponse(HttpResponse) - Constructor for class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
DelegatedServerUpgradeRequest - Class in org.eclipse.jetty.websocket.server.internal
 
DelegatedServerUpgradeRequest(ServerUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
DelegatedServerUpgradeResponse - Class in org.eclipse.jetty.websocket.server.internal
 
DelegatedServerUpgradeResponse(ServerUpgradeResponse) - Constructor for class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
DelegatingThreadPool - Class in org.eclipse.jetty.http.spi
 
DelegatingThreadPool(Executor) - Constructor for class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
delete() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
Remove the file, whether or not Part.write() was called on it (ie no longer temporary)
delete() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
Remove the file, whether or not Part.write() was called on it (ie no longer temporary)
delete() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
delete() - Method in class org.eclipse.jetty.util.resource.PathResource
 
delete() - Method in class org.eclipse.jetty.util.resource.Resource
Deletes the given resource
delete() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
delete() - Method in class org.eclipse.jetty.util.resource.URLResource
Deletes the given resource
delete(File) - Static method in class org.eclipse.jetty.util.IO
Delete File.
delete(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
delete(String) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
delete(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
delete(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Remove a session object from this store and from any backing store.
delete(String) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
delete(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Delete a session
delete(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
delete(String) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
delete(String) - Method in interface org.eclipse.jetty.server.session.SessionCache
Remove a Session completely: from both this cache and the SessionDataStore.
delete(String) - Method in interface org.eclipse.jetty.server.session.SessionDataMap
Delete session data
delete(String) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
DELETE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
DELETED - Enum constant in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
 
deleteFile(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Delete the file associated with a session
deleteOrphanSessions(long) - Method in interface org.eclipse.jetty.session.infinispan.QueryManager
 
deleteParts() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Delete any tmp storage for parts, and clear out the parts list.
deleteParts() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Delete any tmp storage for parts, and clear out the parts list.
DELIMITER - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
DELIMITER_CLOSE - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
DELIMITER_PADDING - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
demand() - Method in interface org.eclipse.jetty.client.api.Request.Content.Subscription
Demands more content, which eventually results in Request.Content.Consumer.onContent(ByteBuffer, boolean, Callback) to be invoked.
demand() - Method in class org.eclipse.jetty.client.HttpReceiver
 
demand() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
demand() - Method in class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
 
demand() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
demand() - Method in interface org.eclipse.jetty.http3.api.Stream
Causes Stream.Client.Listener.onDataAvailable(Stream.Client) on the client, or Stream.Server.Listener.onDataAvailable(Stream.Server) on the server, to be invoked, possibly at a later time, when the stream has data to be read.
demand(long) - Method in interface org.eclipse.jetty.http2.api.Stream
Demands n more DATA frames for this stream.
demand(long) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
demand(long) - Method in interface org.eclipse.jetty.websocket.core.CoreSession
Manage flow control by indicating demand for handling Frames.
demand(long) - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
demand(long) - Method in interface org.eclipse.jetty.websocket.core.internal.DemandChain
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
demand(long) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
DemandChain - Interface in org.eclipse.jetty.websocket.core.internal
This is extended by an Extension so it can intercept demand calls.
DemandingFlusher - Class in org.eclipse.jetty.websocket.core.internal
This flusher can be used to mutated and fragment Frames and forwarded them on towards the application using the IncomingFrames provided in the constructor.
DemandingFlusher(IncomingFrames) - Constructor for class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
 
demask() - Method in class org.eclipse.jetty.websocket.core.Frame
 
deobfuscate(String) - Static method in class org.eclipse.jetty.util.security.Password
 
DEPLOYED - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
DEPLOYED_EVENT - Static variable in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
deployHandler(Handler, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Thread safe deploy of a Handler.
DEPLOYING - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
DEPLOYING_EVENT - Static variable in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
DeploymentManager - Class in org.eclipse.jetty.deploy
The Deployment Manager.
DeploymentManager() - Constructor for class org.eclipse.jetty.deploy.DeploymentManager
 
DeploymentManager.AppEntry - Class in org.eclipse.jetty.deploy
Represents a single tracked app within the deployment manager.
DeploymentManagerMBean - Class in org.eclipse.jetty.deploy.jmx
 
DeploymentManagerMBean(Object) - Constructor for class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
DeprecationWarning - Class in org.eclipse.jetty.util
 
DeprecationWarning() - Constructor for class org.eclipse.jetty.util.DeprecationWarning
 
depth() - Method in interface org.eclipse.jetty.util.ajax.AsyncJSON.Context
 
deregister(LifeCycle) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
deregister(LifeCycle) - Static method in class org.eclipse.jetty.util.thread.ShutdownThread
 
deregisterAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
deregisterAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ServiceApp
 
deregisterAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.ServiceApp
 
description() - Element in annotation type org.eclipse.jetty.util.annotation.Name
the description of the parameter
Descriptor - Class in org.eclipse.jetty.webapp
 
Descriptor(Resource) - Constructor for class org.eclipse.jetty.webapp.Descriptor
 
DESCRIPTOR - Enum constant in enum org.eclipse.jetty.servlet.Source.Origin
 
DescriptorProcessor - Interface in org.eclipse.jetty.webapp
DescriptorProcessor
deserialize(byte[]) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap.SessionDataTranscoder
 
deserializeAttributes() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
deserializeAttributes(SessionData, ObjectInputStream) - Static method in class org.eclipse.jetty.server.session.SessionData
De-serialize the attribute map of a session.
Destination - Interface in org.eclipse.jetty.client.api
Destination represents the triple made of the Destination.getScheme(), the Destination.getHost() and the Destination.getPort().
destroy() - Method in class org.eclipse.jetty.client.HttpChannel
 
destroy() - Method in class org.eclipse.jetty.client.HttpConnection
 
destroy() - Method in class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
destroy() - Method in class org.eclipse.jetty.http.GZIPContentDecoder
 
destroy() - Method in class org.eclipse.jetty.io.CyclicTimeout
Destroys this CyclicTimeout.
destroy() - Method in class org.eclipse.jetty.io.CyclicTimeouts
 
destroy() - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
destroy() - Method in class org.eclipse.jetty.jndi.DataSourceCloser
 
destroy() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
destroy() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
destroy() - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
destroy() - Method in interface org.eclipse.jetty.server.Handler
 
destroy() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpInputInterceptor
 
destroy() - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
destroy() - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
destroy() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
destroy() - Method in class org.eclipse.jetty.server.session.Session.SessionInactivityTimer
 
destroy() - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
destroy() - Method in class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
destroy() - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
destroy() - Method in class org.eclipse.jetty.start.Main
 
destroy() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
destroy() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Destroys the managed Destroyable beans in the reverse order they were added.
destroy() - Method in interface org.eclipse.jetty.util.component.Destroyable
 
destroy() - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
destroy() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AbstractDecoder
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.InputStreamDecoder
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ReaderDecoder
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AbstractEncoder
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteArrayEncoder
 
destroy() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteBufferEncoder
 
destroy() - Method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
 
destroy(Object) - Method in class org.eclipse.jetty.annotations.AnnotationDecorator
 
destroy(Object) - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
Destroy a decorated object.
destroy(Object) - Method in class org.eclipse.jetty.plus.webapp.PlusDecorator
 
destroy(Object) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
destroy(Object) - Method in interface org.eclipse.jetty.util.Decorator
 
destroy(Object) - Method in class org.eclipse.jetty.util.DeprecationWarning
 
destroy(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
Remove all jndi setup
destroy(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
destroy(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
Destroy WebApp.
destroy(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
Destroyable - Interface in org.eclipse.jetty.util.component
A Destroyable is an object which can be destroyed.
DESTROYED - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.ContextStatus
 
destroyFilter(T) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
destroyInstance() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
destroyInstance() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
destroyInstance(Object) - Method in class org.eclipse.jetty.servlet.FilterHolder
 
destroyInstance(Object) - Method in class org.eclipse.jetty.servlet.Holder
 
destroyInstance(Object) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
destroyServlet(T) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
destroySubcontext(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
destroySubcontext(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
destroySubcontext(String) - Method in class org.eclipse.jetty.jndi.NamingContext
 
destroySubcontext(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
destroySubcontext(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
destroySubcontext(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
 
detachListener(RegistrationListener, String, String) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
detect(ByteBuffer) - Method in interface org.eclipse.jetty.server.ConnectionFactory.Detecting
Check the bytes in the given buffer to figure out if this ConnectionFactory.Detecting instance can work with them or not.
detect(ByteBuffer) - Method in class org.eclipse.jetty.server.DetectorConnectionFactory
Performs a detection using multiple ConnectionFactory.Detecting instances and returns the aggregated outcome.
detect(ByteBuffer) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
DetectorConnectionFactory - Class in org.eclipse.jetty.server
A ConnectionFactory combining multiple ConnectionFactory.Detecting instances that will upgrade to the first one recognizing the bytes in the buffer.
DetectorConnectionFactory(ConnectionFactory.Detecting...) - Constructor for class org.eclipse.jetty.server.DetectorConnectionFactory
When the first bytes are not recognized by the detectingConnectionFactories, the default behavior is to upgrade to the protocol returned by AbstractConnectionFactory.findNextProtocol(Connector).
DGRAM - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Protocol
 
didActivate() - Method in class org.eclipse.jetty.server.session.Session
Call the activation listeners.
digest(String) - Static method in class org.eclipse.jetty.util.security.Credential.MD5
Used only by Command Line Password utility
DigestAuthentication - Class in org.eclipse.jetty.client.util
Implementation of the HTTP "Digest" authentication defined in RFC 2617.
DigestAuthentication(URI, String, String, String) - Constructor for class org.eclipse.jetty.client.util.DigestAuthentication
Construct a DigestAuthentication with a SecureRandom nonce.
DigestAuthentication(URI, String, String, String, Random) - Constructor for class org.eclipse.jetty.client.util.DigestAuthentication
 
DigestAuthenticator - Class in org.eclipse.jetty.security.authentication
The nonce max age in ms can be set with the SecurityHandler.setInitParameter(String, String) using the name "maxNonceAge".
DigestAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
DIGIT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
DirConfigSource - Class in org.eclipse.jetty.start.config
A Directory based ConfigSource.
DirConfigSource(String, Path, int, boolean) - Constructor for class org.eclipse.jetty.start.config.DirConfigSource
Create DirConfigSource with specified identifier and directory.
directUpgrade() - Method in class org.eclipse.jetty.http2.parser.PrefaceParser
Advances this parser after the PrefaceFrame.PREFACE_PREAMBLE_BYTES.
directUpgrade() - Method in class org.eclipse.jetty.http2.parser.ServerParser
A direct upgrade is an unofficial upgrade from HTTP/1.1 to HTTP/2.0.
directUpgrade() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
disassociate(Object) - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
disassociate(Object) - Method in interface org.eclipse.jetty.security.IdentityService
Disassociate the user identity from the current thread and restore previous identity.
disassociate(HttpExchange) - Method in class org.eclipse.jetty.client.HttpChannel
 
disassociateClassLoader() - Static method in class org.eclipse.jetty.jndi.ContextFactory
 
disassociateContext(Context) - Static method in class org.eclipse.jetty.jndi.ContextFactory
 
disassociateInfo() - Static method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
disconnect() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
disconnect() - Method in interface org.eclipse.jetty.websocket.api.Session
Issue a harsh disconnect of the underlying connection.
disconnect() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
DISCONNECT - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
DisconnectFrame - Class in org.eclipse.jetty.http2.frames
 
DisconnectFrame() - Constructor for class org.eclipse.jetty.http2.frames.DisconnectFrame
 
DiscoveredAnnotation - Class in org.eclipse.jetty.webapp
DiscoveredAnnotation Represents an annotation that has been discovered by scanning source code of WEB-INF/classes and WEB-INF/lib jars.
DiscoveredAnnotation(WebAppContext, String) - Constructor for class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
DiscoveredAnnotation(WebAppContext, String, Resource) - Constructor for class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
DiscoveredServletContainerInitializerHolder(Source, ServletContainerInitializer, Class<?>...) - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.DiscoveredServletContainerInitializerHolder
 
discoverJakartaFrameHandlerMetadata(Class<?>, JakartaWebSocketFrameHandlerMetadata) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
dispatch() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
dispatch() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
dispatch() - Method in class org.eclipse.jetty.server.AsyncContextState
 
dispatch() - Method in interface org.eclipse.jetty.util.thread.ExecutionStrategy
Initiates (or resumes) the task production and consumption.
dispatch() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
dispatch() - Method in class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
dispatch() - Method in class org.eclipse.jetty.util.thread.strategy.ProduceConsume
 
dispatch() - Method in class org.eclipse.jetty.util.thread.strategy.ProduceExecuteConsume
 
dispatch(int) - Static method in class org.eclipse.jetty.servlet.FilterMapping
Dispatch type from name
dispatch(DispatcherType) - Static method in class org.eclipse.jetty.servlet.FilterMapping
Dispatch type from name
dispatch(ServletContext, String) - Method in class org.eclipse.jetty.server.AsyncContextState
 
dispatch(ServletContext, String) - Method in class org.eclipse.jetty.server.HttpChannelState
 
dispatch(String) - Method in class org.eclipse.jetty.server.AsyncContextState
 
dispatch(String) - Static method in class org.eclipse.jetty.servlet.FilterMapping
Dispatch type from name
DISPATCH - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
DispatchedMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
Centralized logic for Dispatched Message Handling.
DispatchedMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.DispatchedMessageSink
 
Dispatcher - Class in org.eclipse.jetty.server
 
Dispatcher(ContextHandler, String) - Constructor for class org.eclipse.jetty.server.Dispatcher
 
Dispatcher(ContextHandler, HttpURI, String) - Constructor for class org.eclipse.jetty.server.Dispatcher
 
dispose() - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
dispose() - Method in class org.eclipse.jetty.client.HttpReceiver
Disposes the state of this HttpReceiver.
dispose() - Method in class org.eclipse.jetty.client.HttpSender
 
DO_NOT_HUFFMAN - Static variable in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
DO_NOT_INDEX - Static variable in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
doAccept(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
doAccept(SelectableChannel) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Implemented by subclasses to resolve which sessions in this context that are being managed by this node that should be expired.
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Check to see which sessions have expired.
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doCheckExpired(Set<String>, long) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Implemented by subclasses to delete sessions for other contexts that expired at or before the timeLimit.
doCleanOrphans(long) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doCleanOrphans(long) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doClientStart() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
doClientStart() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
doClientStop() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
doClientStop() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
doClose() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
doComputeIfAbsent(String, Function<String, Session>) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Compute the mappingFunction to create a Session object iff the session with the given id isn't already in the map, otherwise return the existing Session.
doComputeIfAbsent(String, Function<String, Session>) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
doComputeIfAbsent(String, Function<String, Session>) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
DOCUMENT_ROOT - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
DOCUMENT_URI - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
doDelete(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Remove the session with this identity from the store
doDelete(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
doDelete(String) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
doError(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.AbstractHandler
Deprecated.
doExists(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doExists(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doExists(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Check if a session for the given id exists.
doExists(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doExists(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doExists(String) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doExists(String) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doFetchRoles() - Method in class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule.JDBCUser
 
doFetchRoles() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
doFetchRoles() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule.LDAPBindingUser
 
doFetchRoles() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule.LDAPUser
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.eclipse.jetty.servlet.FilterHolder
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
doFilter(ServletRequest, ServletResponse, FilterChain) - Method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
 
doFinishConnect(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
doFinishConnect(SelectableChannel) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
doFormat(long, DateTimeFormatter) - Method in class org.eclipse.jetty.util.DateCache
Format a date according to supplied formatter.
doFormatCookieDate(StringBuilder, long) - Method in class org.eclipse.jetty.http.DateGenerator
Format "EEE, dd-MMM-yy HH:mm:ss 'GMT'" for cookies
doFormatDate(long) - Method in class org.eclipse.jetty.http.DateGenerator
Format HTTP date "EEE, dd MMM yyyy HH:mm:ss 'GMT'"
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.ResourceService
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.NoJspServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHandler.Default404Servlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.StatisticsServlet
 
doGet(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Get the session matching the key from the cache.
doGet(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
doGet(String) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
doGetExpired(long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doGetExpired(long) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doGetExpired(long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Implemented by subclasses to find sessions for this context in the store that expired at or before the time limit and thus not being actively managed by any node.
doGetExpired(long) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doGetExpired(long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doGetExpired(long) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doGetExpired(long) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.DeclareRolesAnnotationHandler
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.MultiPartConfigAnnotationHandler
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.PostConstructAnnotationHandler
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.PreDestroyAnnotationHandler
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.RunAsAnnotationHandler
 
doHandle(Class) - Method in class org.eclipse.jetty.annotations.ServletSecurityAnnotationHandler
 
doHandle(Class<?>) - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
doHandle(Class<?>) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
Class level Resource annotations declare a name in the environment that will be looked up at runtime.
doHandle(Class<?>) - Method in class org.eclipse.jetty.annotations.ResourcesAnnotationHandler
 
doHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
doHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ScopedHandler
Do the handler work within the scope.
doHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
doHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
doHead(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
doInsert(String, SessionData) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Load the session from persistent store.
doLoad(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doLoad(String) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
DONE - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
doNonErrorHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.AbstractHandler.ErrorDispatchHandler
Deprecated.
doOptions(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.StatisticsServlet
 
doPrivileged(PrivilegedAction<T>) - Static method in class org.eclipse.jetty.util.security.SecurityUtils
Runs the given action with the calling context restricted to just the calling frame, not all the frames in the stack.
doProcessBinding(Node, App) - Method in class org.eclipse.jetty.osgi.boot.OSGiDeployer
 
doPutIfAbsent(String, Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Put the session into the map if it wasn't already there
doPutIfAbsent(String, Session) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
doPutIfAbsent(String, Session) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
doReplace(String, Session, Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Replace the mapping from id to oldValue with newValue
doReplace(String, Session, Session) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
doReplace(String, Session, Session) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
doRFC2254Encoding(String) - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
 
doScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.http.spi.HttpSpiContextHandler
 
doScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
doScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ScopedHandler
Scope the handler
doScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
doScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
doSessionAttributeListeners(Session, String, Object, Object) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
doShutdown(Request, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
doShutdownInput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.unixsocket.common.UnixSocketEndPoint
Deprecated.
 
doStart() - Method in class org.eclipse.jetty.annotations.ServletContainerInitializersStarter
Deprecated.
 
doStart() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
doStart() - Method in class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
doStart() - Method in class org.eclipse.jetty.client.HttpClient
 
doStart() - Method in class org.eclipse.jetty.client.HttpDestination
 
doStart() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
doStart() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
doStart() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
doStart() - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
doStart() - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
doStart() - Method in class org.eclipse.jetty.http3.server.HTTP3ServerConnector
 
doStart() - Method in class org.eclipse.jetty.io.ClientConnector
 
doStart() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
doStart() - Method in class org.eclipse.jetty.io.ManagedSelector
 
doStart() - Method in class org.eclipse.jetty.io.SelectorManager
 
doStart() - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
doStart() - Method in class org.eclipse.jetty.jaas.PropertyUserStoreManager
 
doStart() - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
doStart() - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider
 
doStart() - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider
 
doStart() - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider
 
doStart() - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider
 
doStart() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
doStart() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
doStart() - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
doStart() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
doStart() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
doStart() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
doStart() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
doStart() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
doStart() - Method in class org.eclipse.jetty.security.HashLoginService
 
doStart() - Method in class org.eclipse.jetty.security.JDBCLoginService
 
doStart() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
doStart() - Method in class org.eclipse.jetty.security.PropertyUserStore
Depending on the value of the refresh interval, this method will either start up a scanner thread that will monitor the properties file for changes after it has initially loaded it.
doStart() - Method in class org.eclipse.jetty.security.SecurityHandler
 
doStart() - Method in class org.eclipse.jetty.server.AbstractConnector
 
doStart() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
doStart() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
doStart() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
doStart() - Method in class org.eclipse.jetty.server.AsyncRequestLogWriter
 
doStart() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
doStart() - Method in class org.eclipse.jetty.server.CustomRequestLog
Set up request logging and open log file.
doStart() - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ScopedHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
doStart() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
doStart() - Method in class org.eclipse.jetty.server.RequestLogWriter
 
doStart() - Method in class org.eclipse.jetty.server.Server
 
doStart() - Method in class org.eclipse.jetty.server.ServerConnector
 
doStart() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
doStart() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
doStart() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.server.session.HouseKeeper
 
doStart() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
doStart() - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
doStart() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
doStart() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
doStart() - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
doStart() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
doStart() - Method in class org.eclipse.jetty.servlet.ListenerHolder
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Initializer
Deprecated.
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.ServletContainerInitializerStarter
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
doStart() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
doStart() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doStart() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
doStart() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
Method to override to start the lifecycle
doStart() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Starts the managed lifecycle beans in the order they were added.
doStart() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
doStart() - Method in class org.eclipse.jetty.util.LeakDetector
 
doStart() - Method in class org.eclipse.jetty.util.PathWatcher
 
doStart() - Method in class org.eclipse.jetty.util.preventers.AbstractLeakPreventer
 
doStart() - Method in class org.eclipse.jetty.util.Scanner
Start the scanning action.
doStart() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Creates the SSLContext object and starts the lifecycle
doStart() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
doStart() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
doStart() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
doStart() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
doStart() - Method in class org.eclipse.jetty.util.thread.Sweeper
 
doStart() - Method in class org.eclipse.jetty.util.thread.TimerScheduler
 
doStart() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
doStart() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
doStart() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
doStart() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
doStart() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
doStop() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
doStop() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
doStop() - Method in class org.eclipse.jetty.client.HttpClient
 
doStop() - Method in class org.eclipse.jetty.client.HttpDestination
 
doStop() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
doStop() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
doStop() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doStop() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
doStop() - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
doStop() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
doStop() - Method in class org.eclipse.jetty.io.ClientConnector
 
doStop() - Method in class org.eclipse.jetty.io.ManagedSelector
 
doStop() - Method in class org.eclipse.jetty.io.SelectorManager
 
doStop() - Method in class org.eclipse.jetty.jaas.PropertyUserStoreManager
 
doStop() - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
doStop() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
doStop() - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider
 
doStop() - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider
 
doStop() - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider
 
doStop() - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider
 
doStop() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
doStop() - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
doStop() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
doStop() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
doStop() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
doStop() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
doStop() - Method in class org.eclipse.jetty.security.HashLoginService
 
doStop() - Method in class org.eclipse.jetty.security.JDBCLoginService
 
doStop() - Method in class org.eclipse.jetty.security.PropertyUserStore
 
doStop() - Method in class org.eclipse.jetty.security.SecurityHandler
 
doStop() - Method in class org.eclipse.jetty.server.AbstractConnector
 
doStop() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
doStop() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
doStop() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
doStop() - Method in class org.eclipse.jetty.server.AsyncRequestLogWriter
 
doStop() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
doStop() - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
doStop() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
doStop() - Method in class org.eclipse.jetty.server.RequestLogWriter
 
doStop() - Method in class org.eclipse.jetty.server.Server
 
doStop() - Method in class org.eclipse.jetty.server.ServerConnector
 
doStop() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
doStop() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
doStop() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
doStop() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doStop() - Method in class org.eclipse.jetty.server.session.HouseKeeper
 
doStop() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doStop() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
doStop() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
doStop() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
doStop() - Method in class org.eclipse.jetty.servlet.ListenerHolder
 
doStop() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
doStop() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.ServletContainerInitializerStarter
 
doStop() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
doStop() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
doStop() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
doStop() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
Method to override to stop the lifecycle
doStop() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Stops the managed lifecycle beans in the reverse order they were added.
doStop() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
doStop() - Method in class org.eclipse.jetty.util.LeakDetector
 
doStop() - Method in class org.eclipse.jetty.util.PathWatcher
 
doStop() - Method in class org.eclipse.jetty.util.Scanner
Stop the scanning.
doStop() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
doStop() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
doStop() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
doStop() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
doStop() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
doStop() - Method in class org.eclipse.jetty.util.thread.Sweeper
 
doStop() - Method in class org.eclipse.jetty.util.thread.TimerScheduler
 
doStop() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
doStop() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
doStop() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
doStop() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
Store the session data persistently.
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
doStore(String, SessionData, long) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
doTrace(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
DoubleDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Double to decoder
DoubleDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.DoubleDecoder
 
DoubleEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Double to Encoder.Text Message encoder
DoubleEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.DoubleEncoder
 
doUpdate(String, SessionData) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
download(URI, Path) - Method in class org.eclipse.jetty.start.fileinits.DownloadFileInitializer
 
download(URI, Path) - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
protected only for testing purpose
download(MavenLocalRepoFileInitializer.Coordinates, Path) - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
DownloadFileInitializer - Class in org.eclipse.jetty.start.fileinits
 
DownloadFileInitializer(BaseHome, String...) - Constructor for class org.eclipse.jetty.start.fileinits.DownloadFileInitializer
 
DownstreamConnection(EndPoint, Executor, ByteBufferPool, ConcurrentMap<String, Object>) - Constructor for class org.eclipse.jetty.proxy.ConnectHandler.DownstreamConnection
 
drainTo(Collection<? super E>) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
drainTo(Collection<? super E>, int) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
DriverManagerLeakPreventer - Class in org.eclipse.jetty.util.preventers
DriverManagerLeakPreventer Cause DriverManager.getCallerClassLoader() to be called, which will pin the classloader.
DriverManagerLeakPreventer() - Constructor for class org.eclipse.jetty.util.preventers.DriverManagerLeakPreventer
 
dump() - Method in class org.eclipse.jetty.client.ProtocolHandlers
 
dump() - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
dump() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
dump() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
dump() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
dump() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
dump() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
dump() - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
dump() - Method in class org.eclipse.jetty.jndi.NamingContext
 
dump() - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
dump() - Method in class org.eclipse.jetty.server.ClassLoaderDump
 
dump() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
dump() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
dump() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
dump() - Method in class org.eclipse.jetty.servlet.Holder
 
dump() - Method in class org.eclipse.jetty.util.AttributesMap
 
dump() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
dump() - Method in interface org.eclipse.jetty.util.component.Dumpable
 
dump() - Method in class org.eclipse.jetty.util.component.DumpableCollection
 
dump() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
dump() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
dump() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
dump() - Method in class org.eclipse.jetty.webapp.Configurations
 
dump() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
dump() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
dump() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
dump(PrintStream) - Method in class org.eclipse.jetty.start.Classpath
 
dump(Appendable) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Dump this object to an Appendable with no indent.
dump(Appendable, String) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.client.HttpClient
 
dump(Appendable, String) - Method in class org.eclipse.jetty.client.HttpDestination
 
dump(Appendable, String) - Method in class org.eclipse.jetty.client.ProtocolHandlers
 
dump(Appendable, String) - Method in class org.eclipse.jetty.client.ValidatingConnectionPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
dump(Appendable, String) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ManagedSelector
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
dump(Appendable, String) - Static method in class org.eclipse.jetty.jndi.ContextFactory
 
dump(Appendable, String) - Method in class org.eclipse.jetty.jndi.NamingContext
 
dump(Appendable, String) - Method in class org.eclipse.jetty.plus.jndi.NamingDump
 
dump(Appendable, String) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
dump(Appendable, String) - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.ClassLoaderDump
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.Server
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.FilterHolder
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
dump(Appendable, String) - Method in class org.eclipse.jetty.servlet.ServletMapping
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.AttributesMap
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
dump(Appendable, String) - Method in interface org.eclipse.jetty.util.component.Dumpable
Dump this object (and children) into an Appendable using the provided indent after any new lines.
dump(Appendable, String) - Method in class org.eclipse.jetty.util.component.DumpableCollection
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.Pool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
dump(Appendable, String) - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.webapp.Configurations
 
dump(Appendable, String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
 
dump(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
dump(ClassLoader) - Static method in class org.eclipse.jetty.ant.AntWebAppContext
 
dump(ClassLoader) - Static method in class org.eclipse.jetty.util.TypeUtil
 
dump(TimeUnit) - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
dump(Dumpable) - Static method in interface org.eclipse.jetty.util.component.Dumpable
Utility method to implement Dumpable.dump() by calling Dumpable.dump(Appendable, String)
Dumpable - Interface in org.eclipse.jetty.util.component
 
Dumpable.DumpableContainer - Interface in org.eclipse.jetty.util.component
DumpableContainer A Dumpable that is a container of beans can implement this interface to allow it to refine which of its beans can be dumped.
DumpableCollection - Class in org.eclipse.jetty.util.component
 
DumpableCollection(String, Collection<?>) - Constructor for class org.eclipse.jetty.util.component.DumpableCollection
 
dumpActiveXmls(PrintStream) - Method in class org.eclipse.jetty.start.StartArgs
 
dumpContainer(Appendable, String, Container, boolean) - Static method in interface org.eclipse.jetty.util.component.Dumpable
 
dumpEnvironment(PrintStream) - Method in class org.eclipse.jetty.start.StartArgs
 
dumpIterable(Appendable, String, Iterable<?>, boolean) - Static method in interface org.eclipse.jetty.util.component.Dumpable
 
dumpJvmArgs(PrintStream) - Method in class org.eclipse.jetty.start.StartArgs
 
dumpMapEntries(Appendable, String, Map<?, ?>, boolean) - Static method in interface org.eclipse.jetty.util.component.Dumpable
 
dumpObject(Appendable, Object) - Static method in interface org.eclipse.jetty.util.component.Dumpable
Dump just an Object (but not it's contained items) to an Appendable.
dumpObjects(Appendable, String, Object...) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Dump this object, it's contained beans and additional items to an Appendable
dumpObjects(Appendable, String, Object, Object...) - Static method in interface org.eclipse.jetty.util.component.Dumpable
Dump an Object, it's contained items and additional items to an Appendable.
dumpProperties(PrintStream) - Method in class org.eclipse.jetty.start.StartArgs
 
dumpSelf() - Method in interface org.eclipse.jetty.util.component.Dumpable
The description of this/self found in the dump.
dumpSelf() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
dumpSelf() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
dumpStdErr() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Dumps to System.err.
dumpSystemProperties(PrintStream) - Method in class org.eclipse.jetty.start.StartArgs
 
dumpThread(long) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
DuplexConnectionPool - Class in org.eclipse.jetty.client
 
DuplexConnectionPool(HttpDestination, int, boolean, Callback) - Constructor for class org.eclipse.jetty.client.DuplexConnectionPool
 
DuplexConnectionPool(HttpDestination, int, Callback) - Constructor for class org.eclipse.jetty.client.DuplexConnectionPool
 
DuplexConnectionPool(HttpDestination, Pool<Connection>, Callback) - Constructor for class org.eclipse.jetty.client.DuplexConnectionPool
Deprecated.
DuplexHttpDestination - Class in org.eclipse.jetty.client
A destination for those network transports that are duplex (e.g.
DuplexHttpDestination(HttpClient, Origin) - Constructor for class org.eclipse.jetty.client.DuplexHttpDestination
 
DuplexHttpDestination(HttpClient, Origin, boolean) - Constructor for class org.eclipse.jetty.client.DuplexHttpDestination
 
DUPLICATE_HOST_HEADERS - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230: Section 5.4, the HTTP protocol says that a Server must reject a request duplicate host headers.
DuplicateAnnotationException - Exception Class in org.eclipse.jetty.websocket.core.exception
 
DuplicateAnnotationException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.DuplicateAnnotationException
 
DuplicateAnnotationException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.DuplicateAnnotationException
 
dynamicHolderAdded(ServletHolder) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
notification that a ServletRegistration has been created so we can track the annotations

E

EARLY_HINT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
EARLY_HINT_103 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
earlyEOF() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
earlyEOF() - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
Called to signal that an EOF was received unexpectedly during the parsing of an HTTP message
earlyEOF() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
earlyEOF() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
earlyEOF() - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
EatWhatYouKill - Class in org.eclipse.jetty.util.thread.strategy
Deprecated, for removal: This API element is subject to removal in a future version.
This class has been renamed to AdaptiveExecutionStrategy
EatWhatYouKill(ExecutionStrategy.Producer, Executor) - Constructor for class org.eclipse.jetty.util.thread.strategy.EatWhatYouKill
Deprecated.
 
Edge - Class in org.eclipse.jetty.deploy.graph
Basic Graph Edge
Edge(Node, Node) - Constructor for class org.eclipse.jetty.deploy.graph.Edge
 
edges() - Method in class org.eclipse.jetty.deploy.graph.Path
 
EITHER - Enum constant in enum org.eclipse.jetty.util.thread.Invocable.InvocationType
Invoking the Invocable may block the invoker thread, but the invocation cannot be deferred to a later time, differently from Invocable.InvocationType.BLOCKING.
elapsed(long, long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the nanoseconds elapsed between two nanoTimes.
ELContextCleaner - Class in org.eclipse.jetty.servlet.listener
Deprecated.
ELContextCleaner() - Constructor for class org.eclipse.jetty.servlet.listener.ELContextCleaner
Deprecated.
 
element() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
EMBEDDED - Enum constant in enum org.eclipse.jetty.servlet.Source.Origin
 
EMBEDDED - Static variable in class org.eclipse.jetty.servlet.Source
 
emit(HttpField) - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
emit(JettyLogger, Level, long, String, Throwable, String, Object...) - Method in interface org.eclipse.jetty.logging.JettyAppender
 
emit(JettyLogger, Level, long, String, Throwable, String, Object...) - Method in class org.eclipse.jetty.logging.StdErrAppender
 
emitFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
This is used within an implementation of DemandingFlusher.handle(Frame, Callback, boolean) to forward a frame onto the next layer of processing.
empty(boolean) - Static method in interface org.eclipse.jetty.util.Index
 
Empty() - Constructor for class org.eclipse.jetty.util.HttpCookieStore.Empty
 
Empty() - Constructor for class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
EMPTY - Static variable in interface org.eclipse.jetty.http.HttpFields
A constant for an immutable and empty HttpFields.
EMPTY - Static variable in interface org.eclipse.jetty.http.pathmap.MatchedPath
 
EMPTY_ARRAY - Static variable in class org.eclipse.jetty.http2.frames.Frame
 
EMPTY_BUFFER - Static variable in class org.eclipse.jetty.util.BufferUtil
 
EMPTY_MAP - Static variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
emptyBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
emptyBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.ContinuationBodyParser
 
emptyBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.DataBodyParser
 
emptyBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.HeadersBodyParser
 
emptyBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
EmptyConfigurator - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
EmptyConfigurator() - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.EmptyConfigurator
 
EmptyLoginService - Class in org.eclipse.jetty.security
LoginService implementation which always denies any attempt to login.
EmptyLoginService() - Constructor for class org.eclipse.jetty.security.EmptyLoginService
 
EmptyResource - Class in org.eclipse.jetty.util.resource
EmptyResource Represents a resource that does does not refer to any file, url, jar etc.
enable(String, boolean) - Method in class org.eclipse.jetty.start.Module
 
enable(String, String) - Method in class org.eclipse.jetty.start.Modules
Enable a module
enable(T, boolean) - Method in class org.eclipse.jetty.util.Pool.Entry
Enables this, previously reserved, Entry.
ENABLE_CONNECT_PROTOCOL - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
ENABLE_KEY - Static variable in class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
 
ENABLE_PUSH - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
enableDebug() - Static method in class org.eclipse.jetty.start.StartLog
 
enableLowOnResources(boolean, boolean) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
encode(byte[]) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteArrayEncoder
 
encode(int, int) - Static method in class org.eclipse.jetty.util.AtomicBiInteger
Encodes hi and lo values into a long.
encode(Boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.BooleanEncoder
 
encode(Byte) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteEncoder
 
encode(Character) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.CharacterEncoder
 
encode(Double) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.DoubleEncoder
 
encode(Float) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.FloatEncoder
 
encode(Integer) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.IntegerEncoder
 
encode(Long) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.LongEncoder
 
encode(Short) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ShortEncoder
 
encode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.StringEncoder
 
encode(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteBufferEncoder
 
encode(ByteBuffer, int, long) - Static method in class org.eclipse.jetty.http.compression.NBitIntegerEncoder
 
encode(ByteBuffer, int, String, boolean) - Static method in class org.eclipse.jetty.http.compression.NBitStringEncoder
 
encode(ByteBuffer, long, MetaData) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
Encodes a MetaData object into the supplied ByteBuffer for a specific HTTP/s stream.
encode(ByteBuffer, String) - Static method in class org.eclipse.jetty.http.compression.HuffmanEncoder
 
encode(ByteBuffer, HttpField) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
encode(ByteBuffer, MetaData) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
encode(HpackEncoder, ByteBufferPool.Lease, MetaData, int) - Method in class org.eclipse.jetty.http2.generator.FrameGenerator
 
encode(ByteBufferPool.Lease) - Method in interface org.eclipse.jetty.http3.qpack.Instruction
 
encode(MultiMap<String>, Charset, boolean) - Static method in class org.eclipse.jetty.util.UrlEncoded
Encode MultiMap with % encoding.
EncodeFailedFuture - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
A Future&lt;Void&gt; that is already failed as a result of an Encode error
EncodeFailedFuture(Object, Encoder, Class<?>, Throwable) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
encodeHi(long, int) - Static method in class org.eclipse.jetty.util.AtomicBiInteger
Sets the hi value into the given encoded value.
encodeLo(long, int) - Static method in class org.eclipse.jetty.util.AtomicBiInteger
Sets the lo value into the given encoded value.
encodeLowerCase(ByteBuffer, String) - Static method in class org.eclipse.jetty.http.compression.HuffmanEncoder
 
encodeMaxDynamicTableSize(ByteBuffer, int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
encodeName(Object) - Static method in class org.eclipse.jetty.nosql.mongodb.MongoUtils
 
encodeName(String) - Static method in class org.eclipse.jetty.nosql.mongodb.MongoUtils
 
encodePath(String) - Static method in class org.eclipse.jetty.util.URIUtil
Encode a URI path.
encodePath(StringBuilder, String) - Static method in class org.eclipse.jetty.util.URIUtil
Encode a URI path.
encoder - Variable in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
encodeRedirectUrl(String) - Method in class org.eclipse.jetty.server.Response
Deprecated.
encodeRedirectUrl(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
Deprecated.
encodeRedirectUrl(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
encodeRedirectURL(String) - Method in class org.eclipse.jetty.server.Response
 
encodeRedirectURL(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
encodeRedirectURL(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
encodeSpaces(String) - Static method in class org.eclipse.jetty.util.URIUtil
Encode a raw URI String and convert any raw spaces to their "%20" equivalent.
encodeSpecific(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Encode a raw String and convert any specific characters to their URI encoded equivalent.
encodeString(String) - Static method in class org.eclipse.jetty.util.UrlEncoded
Perform URL encoding.
encodeString(StringBuilder, String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Encode a URI path.
encodeString(String, Charset) - Static method in class org.eclipse.jetty.util.UrlEncoded
Perform URL encoding.
encodeUrl(String) - Method in class org.eclipse.jetty.server.Response
Deprecated.
encodeUrl(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
Deprecated.
encodeUrl(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
encodeURL(String) - Method in class org.eclipse.jetty.server.Response
 
encodeURL(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
encodeURL(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
ENCODING - Static variable in class org.eclipse.jetty.util.UrlEncoded
 
EncodingException - Exception Class in org.eclipse.jetty.http.compression
 
EncodingException(String) - Constructor for exception class org.eclipse.jetty.http.compression.EncodingException
 
EncodingHttpWriter - Class in org.eclipse.jetty.server
 
EncodingHttpWriter(HttpOutput, String) - Constructor for class org.eclipse.jetty.server.EncodingHttpWriter
 
end() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
end(int) - Method in class org.eclipse.jetty.fcgi.parser.ResponseContentParser
 
end(int) - Method in class org.eclipse.jetty.fcgi.parser.StreamContentParser
 
end(Deflater) - Method in class org.eclipse.jetty.util.compression.DeflaterPool
 
end(Inflater) - Method in class org.eclipse.jetty.util.compression.InflaterPool
 
end(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
end(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 
end(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
 
end(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
end(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
end(T) - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
END - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.State
 
END - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
END - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
END_HEADERS - Static variable in interface org.eclipse.jetty.http2.Flags
 
END_REQUEST - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
END_STREAM - Static variable in interface org.eclipse.jetty.http2.Flags
 
endHandling(Request) - Method in class org.eclipse.jetty.server.handler.AsyncDelayHandler
Called to indicated the handling of the request is ending.
endPart() - Method in class org.eclipse.jetty.util.MultiPartWriter
end creation of the next Content.
EndPoint - Interface in org.eclipse.jetty.io
EndPoint is the abstraction for an I/O channel that transports bytes.
EndPoint.Wrapper - Interface in org.eclipse.jetty.io
Marks an EndPoint that wraps another EndPoint.
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.io.ManagedSelector
 
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when an endpoint is closed.
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
EndpointConfigWrapper - Class in org.eclipse.jetty.websocket.jakarta.common
 
EndpointConfigWrapper() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
EndpointConfigWrapper(EndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.io.ManagedSelector
 
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when an endpoint is opened.
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
EndRequestContentParser - Class in org.eclipse.jetty.fcgi.parser
Parser for the END_REQUEST frame content.
EndRequestContentParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.EndRequestContentParser
 
endStartLog() - Static method in class org.eclipse.jetty.start.StartLog
 
endsWith(byte[], int, int) - Method in class org.eclipse.jetty.util.SearchPattern
Search for a partial match of the pattern at the end of the data.
endsWithIgnoreCase(String, String) - Static method in class org.eclipse.jetty.util.StringUtil
 
endsWithTail(ByteBuffer) - Static method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
ENHANCE_YOUR_CALM - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
ENHANCE_YOUR_CALM_420 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
ENHANCE_YOUR_CALM_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that the other peer might be generating excessive load.
enqueue(Queue<HttpExchange>, HttpExchange) - Method in class org.eclipse.jetty.client.HttpDestination
 
enqueue(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
Enqueue a Frame to be written to the endpoint.
ensureBuffer(int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Get the last buffer of the accumulator, this can be written to directly to avoid copying into the accumulator.
ensureBuffer(int, int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Get the last buffer of the accumulator, this can be written to directly to avoid copying into the accumulator.
ensureCapacity(ByteBuffer, int) - Static method in class org.eclipse.jetty.util.BufferUtil
 
ensureConsumeAllOrNotPersistent() - Method in class org.eclipse.jetty.server.HttpChannel
 
ensureContainer(ServletContext) - Static method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
ensureContainer(ServletContext) - Static method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
ensureDirectoryExists(Path) - Static method in class org.eclipse.jetty.start.FS
 
ensureDirectoryWritable(Path) - Static method in class org.eclipse.jetty.start.FS
 
ensureField(HttpField) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Ensure that specific HttpField exists when the field may not exist or may exist and be multi valued.
ensureFilter(ServletContext) - Static method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
Ensure a WebSocketUpgradeFilter is available on the provided ServletContext, a new filter will added if one does not already exist.
ensureIndexes() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
ensureMappings(ServletContext) - Static method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
ensurePool(Container) - Static method in class org.eclipse.jetty.util.compression.DeflaterPool
 
ensurePool(Container) - Static method in class org.eclipse.jetty.util.compression.InflaterPool
 
ensureSize(Object, int) - Static method in class org.eclipse.jetty.util.LazyList
Ensure the capacity of the underlying list.
ensureSpareCapacity(int) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
ensureWebSocketComponents(Server, ServletContext) - Static method in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
This ensures a WebSocketComponents is available at the ServletContext attribute WebSocketServerComponents.WEBSOCKET_COMPONENTS_ATTRIBUTE.
ENTER - Enum constant in enum org.eclipse.jetty.util.PathWatcher.DirAction
 
enterScope(ContextHandler.Context, Request, Object) - Method in interface org.eclipse.jetty.server.handler.ContextHandler.ContextScopeListener
 
enterScope(Request, Object) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
enterSession(HttpSession) - Method in class org.eclipse.jetty.server.Request
Remember a session that this request has just entered.
EntityDataModel() - Constructor for class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
entityFromSession(SessionData, Key) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
Generate a gcloud datastore Entity from SessionData
Entry() - Constructor for class org.eclipse.jetty.util.Pool.Entry
 
Entry(String, boolean) - Constructor for class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
Entry(Frame, IStream, Callback) - Constructor for class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
entrySet() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
ENV_ENTRY_TYPES - Static variable in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
 
EnvConfiguration - Class in org.eclipse.jetty.plus.webapp
EnvConfiguration
EnvConfiguration() - Constructor for class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
EnvEntry - Class in org.eclipse.jetty.plus.jndi
EnvEntry
EnvEntry(Object, String, Object, boolean) - Constructor for class org.eclipse.jetty.plus.jndi.EnvEntry
 
EnvEntry(String, Object) - Constructor for class org.eclipse.jetty.plus.jndi.EnvEntry
 
EnvEntry(String, Object, boolean) - Constructor for class org.eclipse.jetty.plus.jndi.EnvEntry
 
eof() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
eof() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
eof() - Method in class org.eclipse.jetty.server.HttpChannel
Mark the channel's input as EOF.
eof() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
EOF - Enum constant in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
 
EOF - Static variable in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
EOF_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
EOF_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
 
EofContent() - Constructor for class org.eclipse.jetty.server.HttpInput.EofContent
 
EofException - Exception Class in org.eclipse.jetty.io
A Jetty specialization of EOFException.
EofException() - Constructor for exception class org.eclipse.jetty.io.EofException
 
EofException(String) - Constructor for exception class org.eclipse.jetty.io.EofException
 
EofException(Throwable) - Constructor for exception class org.eclipse.jetty.io.EofException
 
EPILOGUE - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
equals(int) - Method in enum org.eclipse.jetty.http.HttpStatus.Code
 
equals(Object) - Method in class org.eclipse.jetty.client.ContentDecoder.Factory
 
equals(Object) - Method in class org.eclipse.jetty.client.Origin.Address
 
equals(Object) - Method in class org.eclipse.jetty.client.Origin
 
equals(Object) - Method in class org.eclipse.jetty.client.Origin.Protocol
 
equals(Object) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
equals(Object) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
equals(Object) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.TLV
 
equals(Object) - Method in class org.eclipse.jetty.deploy.graph.Edge
 
equals(Object) - Method in class org.eclipse.jetty.deploy.graph.Node
 
equals(Object) - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
equals(Object) - Method in class org.eclipse.jetty.http.HttpField
 
equals(Object) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
equals(Object) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
equals(Object) - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
equals(Object) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
equals(Object) - Method in class org.eclipse.jetty.http.pathmap.AbstractPathSpec
 
equals(Object) - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
equals(Object) - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
equals(Object) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
equals(Object) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
equals(Object) - Method in class org.eclipse.jetty.jaas.JAASPrincipal
 
equals(Object) - Method in class org.eclipse.jetty.jaas.JAASRole
 
equals(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
equals(Object) - Method in class org.eclipse.jetty.plus.annotation.PostConstructCallback
 
equals(Object) - Method in class org.eclipse.jetty.plus.annotation.PreDestroyCallback
 
equals(Object) - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
equals(Object) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
equals(Object) - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
equals(Object) - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
equals(Object) - Method in class org.eclipse.jetty.start.FileArg
 
equals(Object) - Method in class org.eclipse.jetty.start.Module
 
equals(Object) - Method in class org.eclipse.jetty.util.Fields
 
equals(Object) - Method in class org.eclipse.jetty.util.Fields.Field
 
equals(Object) - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
equals(Object) - Method in class org.eclipse.jetty.util.resource.PathResource
 
equals(Object) - Method in class org.eclipse.jetty.util.resource.URLResource
 
equals(Object) - Method in class org.eclipse.jetty.util.security.Credential.Crypt
 
equals(Object) - Method in class org.eclipse.jetty.util.security.Credential.MD5
 
equals(Object) - Method in class org.eclipse.jetty.util.security.Password
 
equals(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
equals(Object) - Method in class org.eclipse.jetty.websocket.core.Frame
 
equals(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
 
equals(Object) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
equals(String, char[], int, int) - Static method in class org.eclipse.jetty.util.StringUtil
 
equals(Fields.Field, boolean) - Method in class org.eclipse.jetty.util.Fields.Field
 
equalsIgnoreEncodings(String, String) - Static method in class org.eclipse.jetty.util.URIUtil
 
equalsIgnoreEncodings(URI, URI) - Static method in class org.eclipse.jetty.util.URIUtil
 
ERR_BAD_ARG - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_BAD_GRAPH - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_BAD_STOP_PROPS - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_INVOKE_MAIN - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_LOGGING - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_NOT_STOPPED - Static variable in exception class org.eclipse.jetty.start.UsageException
 
ERR_UNKNOWN - Static variable in exception class org.eclipse.jetty.start.UsageException
 
error() - Method in class org.eclipse.jetty.quic.common.CloseInfo
 
error(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.server.Dispatcher
 
error(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
error(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
error(String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(String, Object...) - Static method in class org.eclipse.jetty.start.StartLog
 
error(String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(Marker, String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(Marker, String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(Marker, String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(Marker, String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
error(Marker, String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
ERROR - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
ERROR - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
ERROR_CHARSET - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_CONTEXT - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_PAGE - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
ERROR_PAGE - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_PAGE - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
ERROR_PARAMETER - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
errorClose() - Method in class org.eclipse.jetty.server.Response
 
ErrorCode - Enum in org.eclipse.jetty.http2
Standard HTTP/2 error codes.
ErrorContent(Throwable) - Constructor for class org.eclipse.jetty.server.HttpInput.ErrorContent
 
ErrorDispatchHandler() - Constructor for class org.eclipse.jetty.server.handler.AbstractHandler.ErrorDispatchHandler
Deprecated.
 
ErrorHandler - Class in org.eclipse.jetty.server.handler
Handler for Error pages An ErrorHandler is registered with ContextHandler.setErrorHandler(ErrorHandler) or Server.setErrorHandler(ErrorHandler).
ErrorHandler() - Constructor for class org.eclipse.jetty.server.handler.ErrorHandler
 
ErrorHandler.ErrorPageMapper - Interface in org.eclipse.jetty.server.handler
 
ErrorPageErrorHandler - Class in org.eclipse.jetty.servlet
An ErrorHandler that maps exceptions and status codes to URIs for dispatch using the internal ERROR style of dispatch.
ErrorPageErrorHandler() - Constructor for class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
errorPageForMethod(String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
ESCAPE_IN_QUOTES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
A backslash was found in a quoted cookie value.
escapeString(Appendable, String) - Method in class org.eclipse.jetty.util.ajax.JSON
Escapes the characters of the given input string into the given buffer.
escapeUnicode(Appendable, char) - Method in class org.eclipse.jetty.util.ajax.JSON
Per JSON specification, unicode characters are by default NOT escaped.
etag(String) - Method in class org.eclipse.jetty.http.CompressedContentFormat
Get an etag with suffix that represents this compressed type.
ETAG - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ETAG_HEADERS - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
ETAG_SEPARATOR - Static variable in class org.eclipse.jetty.http.CompressedContentFormat
The separator within an etag used to indicate a compressed variant.
Event(Object) - Constructor for class org.eclipse.jetty.io.ssl.SslHandshakeListener.Event
 
EventSender - Class in org.eclipse.jetty.osgi.boot.utils
Utility class for emitting OSGi EventAdmin events
evict() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Determines whether to evict the current thread from the pool.
EVICT_ON_INACTIVITY - Static variable in interface org.eclipse.jetty.server.session.SessionCache
 
EVICT_ON_SESSION_EXIT - Static variable in interface org.eclipse.jetty.server.session.SessionCache
 
EXACT - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
For exactly defined path specs, no glob.
EXCEPTION - Static variable in class org.eclipse.jetty.util.log.Log
Deprecated.
exchangeTerminated(HttpExchange, Result) - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
exchangeTerminated(HttpExchange, Result) - Method in class org.eclipse.jetty.client.HttpChannel
 
exchangeTerminated(HttpExchange, Result) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
exchangeTerminated(HttpExchange, Result) - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
exchangeTerminating(HttpExchange, Result) - Method in class org.eclipse.jetty.client.HttpChannel
 
exclude(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
exclude(String) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
exclude(String) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Excludes an InetAccess entry pattern with an optional connector name, address and URI mapping.
exclude(String) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
exclude(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
exclude(String...) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Excludes InetAccess patterns
exclude(String...) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
exclude(String, String, PathSpec) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Excludes an InetAccess entry.
exclude(T) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
exclude(T...) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
excludeConnector(String) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Deprecated.
excludeConnectors(String...) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Deprecated.
excludeHidden - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
EXECUTABLE_COMPARATOR - Static variable in class org.eclipse.jetty.xml.XmlConfiguration
 
execute() - Method in class org.eclipse.jetty.ant.JettyRunTask
Executes this Ant task.
execute() - Method in class org.eclipse.jetty.ant.JettyStopTask
 
execute(Runnable) - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
execute(Runnable) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
execute(Runnable) - Method in class org.eclipse.jetty.io.SelectorManager
Executes the given task in a different thread.
execute(Runnable) - Method in class org.eclipse.jetty.server.HttpChannel
 
execute(Runnable) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.SerializedExecutor
 
execute(Runnable) - Method in interface org.eclipse.jetty.util.thread.TryExecutor
 
execute(Runnable) - Method in class org.eclipse.jetty.util.thread.TryExecutor.NoTryExecutor
 
executeOnVirtualThread(Runnable) - Static method in class org.eclipse.jetty.util.VirtualThreads
Deprecated, for removal: This API element is subject to removal in a future version.
ExecuteProduceConsume - Class in org.eclipse.jetty.util.thread.strategy
A strategy where the thread that produces will always run the resulting task.
ExecuteProduceConsume(ExecutionStrategy.Producer, Executor) - Constructor for class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
executeRequest(String) - Method in class org.eclipse.jetty.server.LocalConnector
Execute a request and return the EndPoint through which multiple responses can be received or more input provided.
ExecutionStrategy - Interface in org.eclipse.jetty.util.thread
An ExecutionStrategy executes Runnable tasks produced by a ExecutionStrategy.Producer.
ExecutionStrategy.Producer - Interface in org.eclipse.jetty.util.thread
A producer of Runnable tasks to run.
ExecutorThreadPool - Class in org.eclipse.jetty.util.thread
ExecutorThreadPool() - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(int) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(int, int) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(int, int, BlockingQueue<Runnable>) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(ThreadPoolExecutor) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(ThreadPoolExecutor, int) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
ExecutorThreadPool(ThreadPoolExecutor, int, ThreadGroup) - Constructor for class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
exists() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
exists() - Method in class org.eclipse.jetty.util.resource.JarFileResource
Returns true if the represented resource exists.
exists() - Method in class org.eclipse.jetty.util.resource.JarResource
Returns true if the represented resource exists.
exists() - Method in class org.eclipse.jetty.util.resource.PathResource
 
exists() - Method in class org.eclipse.jetty.util.resource.Resource
 
exists() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
exists() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns true if the represented resource exists.
exists(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
exists(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Check to see if a session corresponding to the id exists.
exists(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
exists(String) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
exists(String) - Method in interface org.eclipse.jetty.server.session.SessionCache
Check to see if a session exists: WILL consult the SessionDataStore.
exists(String) - Method in interface org.eclipse.jetty.server.session.SessionDataStore
Test if data exists for a given session id.
exists(String) - Method in class org.eclipse.jetty.util.Scanner
 
exists(Path) - Static method in class org.eclipse.jetty.start.FS
 
exists(SessionContext, String) - Method in interface org.eclipse.jetty.session.infinispan.QueryManager
 
exitScope(ContextHandler.Context, Request) - Method in interface org.eclipse.jetty.server.handler.ContextHandler.ContextScopeListener
 
exitScope(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
expand(String) - Method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
expand(String) - Method in class org.eclipse.jetty.start.Props
 
expand(String, Stack<String>) - Method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
expandChildren(List<Handler>, Class<?>) - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
expandChildren(List<Handler>, Class<?>) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
expandChildren(List<Handler>, Class<?>) - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
expandChildren(List<Handler>, Class<?>) - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
expandDependencies(Props) - Method in class org.eclipse.jetty.start.Module
 
expandHandler(Handler, List<Handler>, Class<?>) - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
expandLibs() - Method in class org.eclipse.jetty.start.StartArgs
Expand any command line added --lib lib references.
expandModules(List<Module>) - Method in class org.eclipse.jetty.start.StartArgs
Build up the Classpath and XML file references based on enabled Module list.
expandSystemProperties() - Method in class org.eclipse.jetty.start.StartArgs
Expand any command line added --lib lib references.
EXPECT - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
EXPECTATION_FAILED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
EXPECTATION_FAILED_417 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
expects100Continue(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
expects100Continue(Request) - Method in class org.eclipse.jetty.client.HttpSender
 
expireAll(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Remove an id from use by telling all contexts to remove a session with this id.
expireAll(String) - Method in interface org.eclipse.jetty.server.SessionIdManager
Expire all sessions on all contexts that share the same id.
EXPIRES - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
EXPIRY - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
ExpiryInfo(String, String, long, String, String) - Constructor for class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
expose(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Expose classes to the web application by adding them as exclusions to the AbstractConfiguration.getServerClasses()
EXTENDED_LISTENER_TYPE_INDEX - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
EXTENDED_NCSA_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
Extension - Interface in org.eclipse.jetty.websocket.core
Interface for WebSocket Extensions.
EXTENSION_ERROR - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
ExtensionConfig - Class in org.eclipse.jetty.websocket.core
Represents an Extension Configuration, as seen during the connection Handshake process.
ExtensionConfig - Interface in org.eclipse.jetty.websocket.api
Represents an Extension Configuration, as seen during the connection Handshake process.
ExtensionConfig(String) - Constructor for class org.eclipse.jetty.websocket.core.ExtensionConfig
 
ExtensionConfig(String, Map<String, String>) - Constructor for class org.eclipse.jetty.websocket.core.ExtensionConfig
 
ExtensionConfig(ExtensionConfig) - Constructor for class org.eclipse.jetty.websocket.core.ExtensionConfig
Copy constructor
ExtensionConfig.Parser - Interface in org.eclipse.jetty.websocket.api
 
ExtensionConfigParser - Class in org.eclipse.jetty.websocket.common
 
ExtensionConfigParser() - Constructor for class org.eclipse.jetty.websocket.common.ExtensionConfigParser
 
ExtensionStack - Class in org.eclipse.jetty.websocket.core.internal
Represents the stack of Extensions.
ExtensionStack(WebSocketComponents, Behavior) - Constructor for class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
extract(Path, Path) - Static method in class org.eclipse.jetty.start.FS
 
extractFormParameters(MultiMap<String>) - Method in class org.eclipse.jetty.server.Request
 
extractRedirectURI(Response) - Method in class org.eclipse.jetty.client.HttpRedirector
Extracts and sanitizes (by making it absolute and escaping paths and query parameters) the redirect URI of the given response.
extractZip(Path, Path) - Static method in class org.eclipse.jetty.start.FS
 
ExtraXmlDescriptorProcessor - Class in org.eclipse.jetty.quickstart
ExtraXmlDescriptorProcessor Saves literal XML snippets from web.xml.
ExtraXmlDescriptorProcessor() - Constructor for class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 

F

Factory() - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder.Factory
 
Factory() - Constructor for class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
Factory(int) - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder.Factory
 
Factory(int) - Constructor for class org.eclipse.jetty.http2.parser.WindowRateControl.Factory
 
Factory(String) - Constructor for class org.eclipse.jetty.client.ContentDecoder.Factory
 
Factory(ByteBufferPool) - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder.Factory
 
Factory(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder.Factory
 
fail(Throwable) - Method in interface org.eclipse.jetty.client.api.Request.Content
Fails this request content, possibly failing and discarding accumulated content that was not demanded.
fail(Throwable) - Method in interface org.eclipse.jetty.client.api.Request.Content.Subscription
Fails the subscription, notifying the content producer to stop producing content.
fail(Throwable) - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
fail(Throwable) - Method in class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
 
fail(Throwable) - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
fail(Throwable) - Method in class org.eclipse.jetty.client.util.InputStreamRequestContent
 
fail(Throwable) - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
 
fail(Throwable) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
fail(Throwable) - Method in class org.eclipse.jetty.util.SharedBlockingCallback
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.AbstractMessageSink
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.ByteArrayMessageSink
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.ByteBufferMessageSink
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.DispatchedMessageSink
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
fail(Throwable) - Method in interface org.eclipse.jetty.websocket.core.internal.messages.MessageSink
Fail the message sink.
fail(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.messages.StringMessageSink
 
fail(Throwable) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink
 
fail(Request, Throwable, Response) - Method in class org.eclipse.jetty.client.HttpRedirector
 
fail(Request, Response, Throwable) - Method in class org.eclipse.jetty.client.HttpRedirector
 
failAllContent(Throwable) - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
failAllContent(Throwable) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
failAllContent(Throwable) - Method in class org.eclipse.jetty.server.HttpChannel
Fail all content that is currently stored within the channel.
failAllContent(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
failAllData(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
failAllData(Throwable) - Method in interface org.eclipse.jetty.http2.IStream
Fail all data queued in the stream and reset demand to 0.
failed(Throwable) - Method in class org.eclipse.jetty.client.HttpDestination
 
failed(Throwable) - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
failed(Throwable) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
failed(Throwable) - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
failed(Throwable) - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
failed(Throwable) - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
failed(Throwable) - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
failed(Throwable) - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
failed(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
failed(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
failed(Throwable) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
failed(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
failed(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
failed(Throwable) - Method in class org.eclipse.jetty.server.HttpChannel
Fail the channel's input.
failed(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
failed(Throwable) - Method in class org.eclipse.jetty.server.HttpInput.WrappingContent
 
failed(Throwable) - Method in class org.eclipse.jetty.util.Callback.Completable
 
failed(Throwable) - Method in class org.eclipse.jetty.util.Callback.Completing
 
failed(Throwable) - Method in interface org.eclipse.jetty.util.Callback
Callback invoked when the operation fails.
failed(Throwable) - Method in class org.eclipse.jetty.util.Callback.Nested
 
failed(Throwable) - Method in class org.eclipse.jetty.util.CountingCallback
 
failed(Throwable) - Method in class org.eclipse.jetty.util.FutureCallback
 
failed(Throwable) - Method in class org.eclipse.jetty.util.FuturePromise
 
failed(Throwable) - Method in class org.eclipse.jetty.util.IteratingCallback
Method to invoke when the asynchronous sub-task fails, or to fail the overall asynchronous task and therefore terminate the iteration.
failed(Throwable) - Method in class org.eclipse.jetty.util.Promise.Adapter
 
failed(Throwable) - Method in class org.eclipse.jetty.util.Promise.Completable
 
failed(Throwable) - Method in interface org.eclipse.jetty.util.Promise
Callback invoked when the operation fails.
failed(Throwable) - Method in class org.eclipse.jetty.util.Promise.Wrapper
 
failed(Throwable) - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
 
failed(Throwable) - Method in class org.eclipse.jetty.websocket.jakarta.common.SendHandlerCallback
 
Failed(String) - Constructor for exception class org.eclipse.jetty.server.Authentication.Failed
 
FAILED - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
FAILED - Static variable in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
FAILED_DEPENDENCY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
FAILED_DEPENDENCY_424 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
FAILED_EVENT - Static variable in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
FAILED_TLS_HANDSHAKE - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1015 is a reserved value and MUST NOT be set as a status code in a Close control frame by an endpoint.
FAILED_TLS_HANDSHAKE - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
failedCallback(Callback, Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
 
failFlusher(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
Used to fail this flusher possibly from an external event such as a callback.
failFlusher(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
Used to fail this flusher possibly from an external event such as a callback.
failure - Variable in class org.eclipse.jetty.client.SendFailure
 
FAILURE - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
FailureFrame - Class in org.eclipse.jetty.http2.frames
 
FailureFrame(int, String, Throwable) - Constructor for class org.eclipse.jetty.http2.frames.FailureFrame
 
FakeURLClassLoader - Class in org.eclipse.jetty.osgi.boot.utils
FakeURLClassLoader
FakeURLClassLoader(ClassLoader, URL[]) - Constructor for class org.eclipse.jetty.osgi.boot.utils.FakeURLClassLoader
 
fallback(HttpServletRequest, HttpServletResponse, FilterChain, String) - Method in class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
False - Enum constant in enum org.eclipse.jetty.webapp.MetaData.Complete
 
FASTCGI_ENV_NAMES_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
FASTCGI_HTTPS_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
FastCGIProxyServlet - Class in org.eclipse.jetty.fcgi.server.proxy
Specific implementation of AsyncProxyServlet.Transparent for FastCGI.
FastCGIProxyServlet() - Constructor for class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
fatal(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
fatal(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
FCGI - Class in org.eclipse.jetty.fcgi
 
FCGI.FrameType - Enum in org.eclipse.jetty.fcgi
 
FCGI.Headers - Class in org.eclipse.jetty.fcgi
 
FCGI.Role - Enum in org.eclipse.jetty.fcgi
 
FCGI.StreamType - Enum in org.eclipse.jetty.fcgi
 
fetchOpenIdConnectMetadata() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
Obtain the JSON metadata from OpenID Connect Discovery Configuration Endpoint.
fetchRoles() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
Field(String, String) - Constructor for class org.eclipse.jetty.util.Fields.Field
 
FIELD - Enum constant in enum org.eclipse.jetty.http.HttpParser.FieldState
 
FIELD - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.FieldState
 
FieldInfo(AnnotationParser.ClassInfo, String, int, String, String, Object) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
Fields - Class in org.eclipse.jetty.util
A container for name/value pairs, known as fields.
Fields() - Constructor for class org.eclipse.jetty.util.Fields
Creates an empty, modifiable, case insensitive Fields instance.
Fields(boolean) - Constructor for class org.eclipse.jetty.util.Fields
Creates an empty, modifiable, case insensitive Fields instance.
Fields(Fields, boolean) - Constructor for class org.eclipse.jetty.util.Fields
Creates a Fields instance by copying the fields from the given Fields and making it (im)mutable depending on the given immutable parameter
Fields.Field - Class in org.eclipse.jetty.util
A named list of string values.
file(Path) - Method in interface org.eclipse.jetty.client.api.Request
Shortcut method to specify a file as a content for this request, with the default content type of "application/octet-stream".
file(Path) - Method in class org.eclipse.jetty.client.HttpRequest
 
file(Path, String) - Method in interface org.eclipse.jetty.client.api.Request
Shortcut method to specify a file as a content for this request, with the given content type.
file(Path, String) - Method in class org.eclipse.jetty.client.HttpRequest
 
fileAdded(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
fileAdded(String) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
fileAdded(String) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is added.
fileAdded(String) - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
FileArg - Class in org.eclipse.jetty.start
 
FileArg(String) - Constructor for class org.eclipse.jetty.start.FileArg
 
FileArg(Module, String) - Constructor for class org.eclipse.jetty.start.FileArg
 
FileBufferedResponseHandler - Class in org.eclipse.jetty.server.handler
A Handler that can apply a HttpOutput.Interceptor mechanism to buffer the entire response content until the output is closed.
FileBufferedResponseHandler() - Constructor for class org.eclipse.jetty.server.handler.FileBufferedResponseHandler
 
fileChanged(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
fileChanged(String) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
fileChanged(String) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is changed.
fileChanged(String) - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
FileDestroyable - Class in org.eclipse.jetty.util.component
 
FileDestroyable() - Constructor for class org.eclipse.jetty.util.component.FileDestroyable
 
FileDestroyable(File) - Constructor for class org.eclipse.jetty.util.component.FileDestroyable
 
FileDestroyable(String) - Constructor for class org.eclipse.jetty.util.component.FileDestroyable
 
FileID - Class in org.eclipse.jetty.deploy.util
Simple, yet surprisingly common utility methods for identifying various file types commonly seen and worked with in a deployment scenario.
FileID() - Constructor for class org.eclipse.jetty.deploy.util.FileID
 
FileInitializer - Class in org.eclipse.jetty.start
Interface for initializing a file resource.
FileInitializer(BaseHome, String...) - Constructor for class org.eclipse.jetty.start.FileInitializer
 
FileMatchingConfiguration - Class in org.eclipse.jetty.ant.types
Describes set of files matched by <fileset/> elements in ant configuration file.
FileMatchingConfiguration() - Constructor for class org.eclipse.jetty.ant.types.FileMatchingConfiguration
 
fileNamesAsURLs(String, String) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
Treating the string as a separated list of filenames, convert and return the list of urls.
FileNoticeLifeCycleListener - Class in org.eclipse.jetty.util.component
Deprecated.
use org.eclipse.jetty.server.StateLifeCycleListener instead
FileNoticeLifeCycleListener(String) - Constructor for class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
fileRemoved(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
fileRemoved(String) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
fileRemoved(String) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is removed.
fileRemoved(String) - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
Files() - Constructor for class org.eclipse.jetty.start.NaturalSort.Files
 
FILES_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
filesChanged(Set<String>) - Method in class org.eclipse.jetty.ant.ServerProxyImpl.WebAppScannerListener
 
filesChanged(Set<String>) - Method in interface org.eclipse.jetty.util.Scanner.BulkListener
 
FileSessionDataStore - Class in org.eclipse.jetty.server.session
FileSessionDataStore A file-based store of session data.
FileSessionDataStore() - Constructor for class org.eclipse.jetty.server.session.FileSessionDataStore
 
FileSessionDataStoreFactory - Class in org.eclipse.jetty.server.session
FileSessionDataStoreFactory
FileSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
fill(long, ByteBuffer) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
fill(ByteBuffer) - Method in interface org.eclipse.jetty.io.EndPoint
Fill the passed buffer with data from this endpoint.
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
fill(ByteBuffer, byte[], int, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Like append, but does not throw BufferOverflowException
fillable() - Method in class org.eclipse.jetty.io.FillInterest
Call to signal that a read is now possible.
fillBuffer() - Method in class org.eclipse.jetty.http.HttpTester.Input
 
FillInterest - Class in org.eclipse.jetty.io
A Utility class to help implement EndPoint.fillInterested(Callback) by keeping state and calling the context and callback objects.
FillInterest() - Constructor for class org.eclipse.jetty.io.FillInterest
 
fillInterested() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
fillInterested() - Method in class org.eclipse.jetty.io.AbstractConnection
Utility method to be called to register read interest.
fillInterested() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
fillInterested(Callback) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
fillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
fillInterested(Callback) - Method in interface org.eclipse.jetty.io.EndPoint
Requests callback methods to be invoked when a call to EndPoint.fill(ByteBuffer) would return data or EOF.
fillInterested(Callback) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
fillInterested(Callback) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
Filter() - Constructor for class org.eclipse.jetty.deploy.providers.WebAppProvider.Filter
 
FILTER - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.Role
 
FilterHolder - Class in org.eclipse.jetty.servlet
 
FilterHolder() - Constructor for class org.eclipse.jetty.servlet.FilterHolder
Constructor
FilterHolder(Filter) - Constructor for class org.eclipse.jetty.servlet.FilterHolder
Constructor for existing filter.
FilterHolder(Class<? extends Filter>) - Constructor for class org.eclipse.jetty.servlet.FilterHolder
Constructor
FilterHolder(Source) - Constructor for class org.eclipse.jetty.servlet.FilterHolder
Constructor
FilterHolder.Registration - Class in org.eclipse.jetty.servlet
 
FilterHolder.WrapFunction - Interface in org.eclipse.jetty.servlet
Experimental Wrapper mechanism for Filter objects.
FilterHolder.Wrapper - Class in org.eclipse.jetty.servlet
 
FilterMapping - Class in org.eclipse.jetty.servlet
 
FilterMapping() - Constructor for class org.eclipse.jetty.servlet.FilterMapping
 
FilterMappingMBean - Class in org.eclipse.jetty.servlet.jmx
 
FilterMappingMBean(Object) - Constructor for class org.eclipse.jetty.servlet.jmx.FilterMappingMBean
 
filterReturnType(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
Access for MethodHandle implementations to filter the return value of user provided TEXT/BINARY based message handling methods.
filterServerResponseHeader(HttpServletRequest, Response, String, String) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
filterServerResponseHeader(HttpServletRequest, Response, String, String) - Method in class org.eclipse.jetty.proxy.BalancerServlet
 
find(Request, Response) - Method in class org.eclipse.jetty.client.ProtocolHandlers
Finds the first protocol handler that accepts the given request and response.
findAndFilterContainerPaths(WebAppContext) - Method in class org.eclipse.jetty.ant.AntMetaInfConfiguration
 
findAndFilterContainerPaths(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Find jars and directories that are on the container's classpath and apply an optional filter.
findAndFilterWebAppPaths(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Finds the jars that are either physically or virtually in WEB-INF/lib, and applies an optional filter to their full pathnames.
findAnnotatedMethod(Class<?>, Class<? extends Annotation>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
findAnnotatedMethods(Class<?>, Class<? extends Annotation>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
findAuthentication(String, URI, String) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
Returns the authentication that matches the given type (for example, "Basic" or "Digest"), the given request URI and the given realm.
findAuthentication(String, URI, String) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
findAuthenticationResult(URI) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
Returns an Authentication.Result that matches the given URI, or null if no Authentication.Results match the given URI.
findAuthenticationResult(URI) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
findBean(ObjectName) - Method in class org.eclipse.jetty.jmx.MBeanContainer
Lookup an instance by object name
findClass(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
findClass(String) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
findClass(String) - Method in class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
 
findClass(String) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
findClassDirs(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
findConnectionHeaders(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
findContainerOf(HandlerContainer, Class<T>, Handler) - Static method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
findContentParser(FCGI.FrameType) - Method in class org.eclipse.jetty.fcgi.parser.ClientParser
 
findContentParser(FCGI.FrameType) - Method in class org.eclipse.jetty.fcgi.parser.Parser
 
findContentParser(FCGI.FrameType) - Method in class org.eclipse.jetty.fcgi.parser.ServerParser
 
findContextName(ServletContext) - Method in class org.eclipse.jetty.server.DebugListener
 
findDir(Bundle, String) - Static method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
Get a resource representing a directory inside a bundle.
findEdges(Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
Find all edges that are connected to the specific node, both as an outgoing Edge.getFrom() or incoming Edge.getTo() end point.
findEdgesFrom(Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
Find all edges that are connected Edge.getFrom() the specific node.
findEntries(Bundle, String) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
Helper method equivalent to Bundle#getEntry(String entryPath) except that it searches for entries in the fragments by using the findEntries method.
findEntries(Bundle, String) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
Helper method equivalent to Bundle#getEntry(String entryPath) except that it searches for entries in the fragments by using the Bundle#findEntries method.
findExecutable(File, String) - Static method in class org.eclipse.jetty.start.CommandLineBuilder
 
findExtraClasspathDirs(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Get class dirs from WebAppContext.getExtraClasspath as resources
findExtraClasspathJars(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Get jars from WebAppContext.getExtraClasspath as resources
findField(Class<?>, String, Class<?>, boolean, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
findFile(String, String, String, Bundle) - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
findGenericClassFor(Class<?>, Class<?>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
Given a Base (concrete) Class, find the interface specified, and return its concrete Generic class declaration.
findIdentityService() - Method in class org.eclipse.jetty.security.SecurityHandler
 
findInheritedField(Package, Class<?>, String, Class<?>, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
findInheritedMethod(Package, Class<?>, String, Class<?>[], boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
findJars(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
Consider the fragment bundles associated with the bundle of the webapp being deployed.
findJars(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Look for jars that should be treated as if they are in WEB-INF/lib
findJavaBin() - Static method in class org.eclipse.jetty.start.CommandLineBuilder
 
findLibrary(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
findLoginService() - Method in class org.eclipse.jetty.security.SecurityHandler
 
findMavenLocalRepoDir() - Method in class org.eclipse.jetty.start.StartArgs
 
findMBean(Object) - Method in class org.eclipse.jetty.jmx.MBeanContainer
Lookup an object name by instance
findMethod(Class<?>, String, Class<?>...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
findMethod(Class<?>, String, Class<?>[], boolean, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
findMethod(Package, Class<?>, String, boolean) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
Find a method of the given name either directly in the given class, or inherited.
findNextProtocol(Connector) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
findNextProtocol(Connector, String) - Static method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
findProtocolHandler(Request, Response) - Method in class org.eclipse.jetty.client.HttpClient
 
findRequestName(ServletRequest) - Method in class org.eclipse.jetty.server.DebugListener
 
findResource(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
findResource(String) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
findResources(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
findServerName(ServletContext, Server) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
Find a servername.
findServiceSubject(Server) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
Find a service Subject.
findWebInfClassesDir(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Get WEB-INF/classes dir
findWebInfLibJars(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Look for jars in WEB-INF/lib
findWebXml(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebXmlConfiguration
 
finishInvalidate() - Method in class org.eclipse.jetty.server.session.Session
Call HttpSessionAttributeListeners as part of invalidating a Session.
finRsvOp - Variable in class org.eclipse.jetty.websocket.core.Frame
Combined FIN + RSV1 + RSV2 + RSV3 + OpCode byte.
FIRST - Enum constant in enum org.eclipse.jetty.util.Pool.StrategyType
A strategy that looks for an entry always starting from the first entry.
FIRST_OCTETS - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
firstEdge() - Method in class org.eclipse.jetty.deploy.graph.Path
 
firstNode() - Method in class org.eclipse.jetty.deploy.graph.Path
 
Flags - Interface in org.eclipse.jetty.http2
 
flattenBindings(Context, String) - Static method in class org.eclipse.jetty.jndi.NamingUtil
Do a deep listing of the bindings for a context.
flipToFill(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Flip the buffer to fill mode.
flipToFlush(ByteBuffer, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Flip the buffer to Flush mode.
FloatDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Text Message to Float decoder
FloatDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.FloatDecoder
 
FloatEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Float to Encoder.Text Message encoder
FloatEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.FloatEncoder
 
FLOW_CONTROL_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates an HTTP/2 flow control violation.
FlowControlStrategy - Interface in org.eclipse.jetty.http2
 
FlowControlStrategy.Factory - Interface in org.eclipse.jetty.http2
 
flush() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
flush() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
flush() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
flush() - Method in class org.eclipse.jetty.io.WriterOutputStream
 
flush() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
flush() - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
flush() - Method in class org.eclipse.jetty.server.HttpOutput
 
flush() - Method in class org.eclipse.jetty.server.HttpWriter
 
flush() - Method in class org.eclipse.jetty.server.ResponseWriter
 
flush() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
flush() - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
flush() - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Flushes messages that may have been batched by the implementation.
flush() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
flush() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
flush() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageWriter
 
flush(long, ByteBuffer, boolean) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
flush(SocketAddress, ByteBuffer[]) - Method in class org.eclipse.jetty.io.WriteFlusher
Flushes the buffers iteratively until no progress is made.
flush(ByteBuffer...) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
flush(ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Flush data from the passed header/buffer to this endpoint.
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
flush(Generator.Result...) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
flush(Generator.Result...) - Method in class org.eclipse.jetty.fcgi.generator.Flusher
 
flush(Callback) - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
flush(Callback) - Method in interface org.eclipse.jetty.websocket.core.CoreSession
If using BatchMode.ON or BatchMode.AUTO, trigger a flush of enqueued / batched frames.
flush(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
FLUSH - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
FLUSH_FRAME - Static variable in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
flushBatch() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
flushBuffer() - Method in class org.eclipse.jetty.server.Response
 
flushBuffer() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
flushCache() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
Flusher - Class in org.eclipse.jetty.fcgi.generator
 
Flusher(EndPoint) - Constructor for class org.eclipse.jetty.fcgi.generator.Flusher
 
FOLLOW_LINKS - Static variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
followRedirects(boolean) - Method in interface org.eclipse.jetty.client.api.Request
 
followRedirects(boolean) - Method in class org.eclipse.jetty.client.HttpRequest
 
FORBIDDEN - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
FORBIDDEN_403 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
FORCED - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
ForceRequestHeaderValueRule - Class in org.eclipse.jetty.rewrite.handler
 
ForceRequestHeaderValueRule() - Constructor for class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
forCharset(Charset) - Static method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
forkPath() - Method in class org.eclipse.jetty.deploy.graph.Path
 
FORM(String, Fields) - Method in class org.eclipse.jetty.client.HttpClient
Performs a POST request to the specified URI with the given form parameters.
FORM(URI, Fields) - Method in class org.eclipse.jetty.client.HttpClient
Performs a POST request to the specified URI with the given form parameters.
FORM_ENCODED - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
format(long) - Method in class org.eclipse.jetty.util.DateCache
Format a date according to our stored formatter.
format(long) - Method in class org.eclipse.jetty.util.DateCache.Tick
 
format(String, Object...) - Method in class org.eclipse.jetty.server.ResponseWriter
 
format(Date) - Method in class org.eclipse.jetty.util.DateCache
Format a date according to our stored formatter.
format(Locale, String, Object...) - Method in class org.eclipse.jetty.server.ResponseWriter
 
formatAddrOrHost(String) - Method in class org.eclipse.jetty.server.HttpChannel
Format the address or host returned from Request methods
formatCookieDate(long) - Static method in class org.eclipse.jetty.http.DateGenerator
Format "EEE, dd-MMM-yyyy HH:mm:ss 'GMT'" for cookies
formatCookieDate(StringBuilder, long) - Static method in class org.eclipse.jetty.http.DateGenerator
Format "EEE, dd-MMM-yyyy HH:mm:ss 'GMT'" for cookies
formatDate(long) - Static method in class org.eclipse.jetty.http.DateGenerator
Format HTTP date "EEE, dd MMM yyyy HH:mm:ss 'GMT'"
formatNow(long) - Method in class org.eclipse.jetty.util.DateCache
Deprecated.
formatTick(long) - Method in class org.eclipse.jetty.util.DateCache
 
FormAuthentication(String, UserIdentity) - Constructor for class org.eclipse.jetty.security.authentication.FormAuthenticator.FormAuthentication
 
FormAuthenticator - Class in org.eclipse.jetty.security.authentication
FORM Authenticator.
FormAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.FormAuthenticator
 
FormAuthenticator(String, String, boolean) - Constructor for class org.eclipse.jetty.security.authentication.FormAuthenticator
 
FormAuthenticator.FormAuthentication - Class in org.eclipse.jetty.security.authentication
This Authentication represents a just completed Form authentication.
FormAuthenticator.FormRequest - Class in org.eclipse.jetty.security.authentication
 
FormAuthenticator.FormResponse - Class in org.eclipse.jetty.security.authentication
 
FormContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
use FormRequestContent instead.
FormContentProvider(Fields) - Constructor for class org.eclipse.jetty.client.util.FormContentProvider
Deprecated.
 
FormContentProvider(Fields, Charset) - Constructor for class org.eclipse.jetty.client.util.FormContentProvider
Deprecated.
 
FormRequest(HttpServletRequest) - Constructor for class org.eclipse.jetty.security.authentication.FormAuthenticator.FormRequest
 
FormRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content for form uploads with the "application/x-www-form-urlencoded" content type.
FormRequestContent(Fields) - Constructor for class org.eclipse.jetty.client.util.FormRequestContent
 
FormRequestContent(Fields, Charset) - Constructor for class org.eclipse.jetty.client.util.FormRequestContent
 
FormResponse(HttpServletResponse) - Constructor for class org.eclipse.jetty.security.authentication.FormAuthenticator.FormResponse
 
forUnixDomain(Path) - Static method in class org.eclipse.jetty.io.ClientConnector
Creates a ClientConnector configured to connect via Unix-Domain sockets to the given Unix-Domain path
forward(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.server.Dispatcher
 
forward(ServletRequest, ServletResponse, DispatcherType) - Method in class org.eclipse.jetty.server.Dispatcher
 
FORWARD - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
FORWARDED - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
FORWARDED - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
ForwardedRequestCustomizer - Class in org.eclipse.jetty.server
Customize Requests for Proxy Forwarding.
ForwardedRequestCustomizer() - Constructor for class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
ForwardedRequestCustomizer.Source - Enum in org.eclipse.jetty.server
Ordered Source Enum.
ForwardedSchemeHeaderRule - Class in org.eclipse.jetty.rewrite.handler
Set the scheme for the request
ForwardedSchemeHeaderRule() - Constructor for class org.eclipse.jetty.rewrite.handler.ForwardedSchemeHeaderRule
 
forwardFailure(List<Response.ResponseListener>, Response, Throwable) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
forwardFailureComplete(List<Response.ResponseListener>, Request, Throwable, Response, Throwable) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
forwardSuccess(List<Response.ResponseListener>, Response) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
forwardSuccessComplete(List<Response.ResponseListener>, Request, Response) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
FOUND - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
FOUND_302 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
foundClass(String, URL) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
fragment(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
FRAGMENT_AND_REQUIRED_BUNDLES - Static variable in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
FRAGMENT_AND_REQUIRED_RESOURCES - Static variable in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
FRAGMENT_RESOURCES - Static variable in class org.eclipse.jetty.webapp.FragmentConfiguration
 
FragmentConfiguration - Class in org.eclipse.jetty.webapp
FragmentConfiguration
FragmentConfiguration() - Constructor for class org.eclipse.jetty.webapp.FragmentConfiguration
 
FragmentDescriptor - Class in org.eclipse.jetty.webapp
Fragment A web-fragment.xml descriptor.
FragmentDescriptor(Resource) - Constructor for class org.eclipse.jetty.webapp.FragmentDescriptor
 
FragmentDescriptor.OtherType - Enum in org.eclipse.jetty.webapp
 
FragmentExtension - Class in org.eclipse.jetty.websocket.core.internal
Fragment Extension
FragmentExtension() - Constructor for class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
FragmentExtension.FragmentingDemandingFlusher - Class in org.eclipse.jetty.websocket.core.internal
 
FragmentingDemandingFlusher() - Constructor for class org.eclipse.jetty.websocket.core.internal.FragmentExtension.FragmentingDemandingFlusher
 
FragmentingFlusher - Class in org.eclipse.jetty.websocket.core.internal
Used to split large data frames into multiple frames below the maxFrameSize.
FragmentingFlusher(Configuration) - Constructor for class org.eclipse.jetty.websocket.core.internal.FragmentingFlusher
 
frame - Variable in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
frame - Variable in class org.eclipse.jetty.websocket.core.internal.FrameEntry
 
Frame - Class in org.eclipse.jetty.http2.frames
 
Frame - Class in org.eclipse.jetty.http3.frames
 
Frame - Class in org.eclipse.jetty.websocket.core
A Base Frame as seen in RFC 6455.
Frame - Interface in org.eclipse.jetty.websocket.api
An immutable websocket frame.
Frame() - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(byte) - Constructor for class org.eclipse.jetty.websocket.core.Frame
Construct form opcode
Frame(byte, boolean, String) - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(byte, boolean, ByteBuffer) - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(byte, byte[], ByteBuffer) - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(byte, String) - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(byte, ByteBuffer) - Constructor for class org.eclipse.jetty.websocket.core.Frame
 
Frame(FrameType) - Constructor for class org.eclipse.jetty.http2.frames.Frame
 
Frame(FrameType) - Constructor for class org.eclipse.jetty.http3.frames.Frame
 
FRAME_SIZE_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that a frame has an invalid length.
Frame.Type - Enum in org.eclipse.jetty.websocket.api
 
FrameCaptureExtension - Class in org.eclipse.jetty.websocket.core.internal
 
FrameCaptureExtension() - Constructor for class org.eclipse.jetty.websocket.core.internal.FrameCaptureExtension
 
FrameEntry - Class in org.eclipse.jetty.websocket.core.internal
 
FrameEntry(Frame, Callback, boolean) - Constructor for class org.eclipse.jetty.websocket.core.internal.FrameEntry
 
FrameFlusher - Class in org.eclipse.jetty.websocket.core.internal
 
FrameFlusher(ByteBufferPool, Scheduler, Generator, EndPoint, int, int) - Constructor for class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
FrameGenerator - Class in org.eclipse.jetty.http2.generator
 
FrameGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.FrameGenerator
 
FrameHandler - Interface in org.eclipse.jetty.websocket.core
Interface for local WebSocket Endpoint Frame handling.
FrameHandlerFactory - Interface in org.eclipse.jetty.websocket.core.server
Factory for FrameHandler instances
FrameList(HeadersFrame) - Constructor for class org.eclipse.jetty.http2.IStream.FrameList
Creates a frame list of just the given HEADERS frame.
FrameList(HeadersFrame, DataFrame, HeadersFrame) - Constructor for class org.eclipse.jetty.http2.IStream.FrameList
Creates a frame list of the given frames.
frames(IStream, List<? extends Frame>, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
frames(IStream, List<? extends Frame>, Callback) - Method in interface org.eclipse.jetty.http2.ISession
Enqueues the given frames to be written to the connection.
FrameSequence - Class in org.eclipse.jetty.websocket.core.internal
 
FrameSequence() - Constructor for class org.eclipse.jetty.websocket.core.internal.FrameSequence
 
FrameType - Enum in org.eclipse.jetty.http2.frames
 
FrameType - Enum in org.eclipse.jetty.http3.frames
 
FrameValidation - Class in org.eclipse.jetty.websocket.core.internal.util
Some static utility methods for validating a Frame based on the state of its CoreSession.
FrameValidation() - Constructor for class org.eclipse.jetty.websocket.core.internal.util.FrameValidation
 
frameworkHasCompletedAutostarts() - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
 
from(byte) - Static method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
from(int) - Static method in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
from(int) - Static method in enum org.eclipse.jetty.fcgi.FCGI.Role
 
from(int) - Static method in enum org.eclipse.jetty.http2.ErrorCode
 
from(int) - Static method in enum org.eclipse.jetty.http2.frames.FrameType
 
from(long) - Static method in enum org.eclipse.jetty.http3.frames.FrameType
 
from(long) - Static method in enum org.eclipse.jetty.quic.common.StreamType
 
from(InputStream) - Static method in class org.eclipse.jetty.http.HttpTester
 
from(Runnable) - Static method in interface org.eclipse.jetty.util.Callback
Creates a callback that runs completed when it succeeds or fails
from(Runnable, Consumer<Throwable>) - Static method in interface org.eclipse.jetty.util.Callback
Creates a callback from the given success and failure lambdas.
from(Runnable, Callback) - Static method in interface org.eclipse.jetty.util.Callback
Creates a nested callback that runs completed before completing the nested callback.
from(String) - Static method in class org.eclipse.jetty.http.CookieCompliance
Create compliance set from string.
from(String) - Static method in class org.eclipse.jetty.http.HttpCompliance
Create compliance mode from a String description.
from(String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
from(String) - Static method in interface org.eclipse.jetty.http.pathmap.PathSpec
 
from(String) - Static method in class org.eclipse.jetty.http.UriCompliance
Create compliance set from string.
from(String) - Static method in class org.eclipse.jetty.server.handler.InetAccessSet.PatternTuple
 
from(String) - Static method in class org.eclipse.jetty.util.InetAddressPattern
 
from(String, Object...) - Static method in class org.eclipse.jetty.util.component.DumpableCollection
 
from(String, String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
from(String, String) - Static method in interface org.eclipse.jetty.http.pathmap.MatchedPath
 
from(String, String, int, String) - Static method in interface org.eclipse.jetty.http.HttpURI
 
from(String, Collection<?>) - Static method in class org.eclipse.jetty.util.component.DumpableCollection
 
from(URI) - Static method in interface org.eclipse.jetty.http.HttpURI
 
from(ByteBuffer) - Static method in class org.eclipse.jetty.http.HttpTester
 
from(ReadableByteChannel) - Static method in class org.eclipse.jetty.http.HttpTester
 
from(CompletableFuture<?>) - Static method in interface org.eclipse.jetty.util.Callback
Creates a non-blocking callback from the given incomplete CompletableFuture.
from(CompletableFuture<?>, Invocable.InvocationType) - Static method in interface org.eclipse.jetty.util.Callback
Creates a callback from the given incomplete CompletableFuture, with the given blocking characteristic.
from(CompletableFuture<? super T>) - Static method in interface org.eclipse.jetty.util.Promise
Creates a promise from the given incomplete CompletableFuture.
from(Consumer<String>, Consumer<ByteBuffer>) - Static method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
from(Consumer<T>, Consumer<Throwable>) - Static method in interface org.eclipse.jetty.util.Promise
Creates a Promise from the given success and failure consumers.
from(Function<WebSocketNegotiation, FrameHandler>) - Static method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
from(Function<WebSocketNegotiation, FrameHandler>, Configuration.Customizer) - Static method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
from(Set<UriCompliance.Violation>) - Static method in class org.eclipse.jetty.http.UriCompliance
Create compliance set from a set of allowed Violations.
from(HttpField...) - Static method in interface org.eclipse.jetty.http.HttpFields
 
from(ByteBufferPool) - Static method in interface org.eclipse.jetty.io.RetainableByteBufferPool
 
from(LoginService, Object) - Static method in interface org.eclipse.jetty.security.authentication.AuthorizationService
Wraps a LoginService as an AuthorizationService
from(Callback) - Static method in class org.eclipse.jetty.util.Callback.Completable
Creates a completable future given a callback.
from(Callback, Runnable) - Static method in interface org.eclipse.jetty.util.Callback
Creates a nested callback that runs completed after completing the nested callback.
from(Callback, Throwable) - Static method in interface org.eclipse.jetty.util.Callback
Creates a nested callback which always fails the nested callback on completion.
from(Callback, Callback) - Static method in interface org.eclipse.jetty.util.Callback
Creates a callback which combines two other callbacks and will succeed or fail them both.
from(Invocable.InvocationType, Runnable) - Static method in interface org.eclipse.jetty.util.Callback
Creates a Callback with the given invocationType, that runs the given Runnable when it succeeds or fails.
from(Invocable.InvocationType, Runnable) - Static method in interface org.eclipse.jetty.util.thread.Invocable
Creates a Invocable.Task from the given InvocationType and Runnable.
from(Invocable.InvocationType, Runnable, Consumer<Throwable>) - Static method in interface org.eclipse.jetty.util.Callback
Creates a callback with the given InvocationType from the given success and failure lambdas.
from(WebSocketCoreClient, URI, FrameHandler) - Static method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
from(ExtensionStack) - Static method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
from(WebSocketCreator, FrameHandlerFactory) - Static method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
from(WebSocketCreator, FrameHandlerFactory, Configuration.Customizer) - Static method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
FROM - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
fromArray(String, Object[]) - Static method in class org.eclipse.jetty.util.component.DumpableCollection
 
fromEventsPerSecond(int) - Static method in class org.eclipse.jetty.http2.parser.WindowRateControl
 
fromHexString(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
fromHexString(String) - Static method in class org.eclipse.jetty.util.TypeUtil
fromJSON(Reader) - Method in class org.eclipse.jetty.util.ajax.JSON
Parses the JSON from the given Reader into an object.
fromJSON(String) - Method in class org.eclipse.jetty.util.ajax.JSON
Parses the given JSON string into an object.
fromJSON(Map<String, Object>) - Method in interface org.eclipse.jetty.util.ajax.JSON.Convertible
 
fromJSON(Map<String, Object>) - Method in interface org.eclipse.jetty.util.ajax.JSON.Convertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONCollectionConvertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONEnumConvertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
fromJSON(Map<String, Object>) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertorFactory
 
fromLevel(Level) - Static method in enum org.eclipse.jetty.logging.JettyLevel
 
fromList(String, boolean) - Static method in class org.eclipse.jetty.util.resource.Resource
Parse a list of String delimited resources and return the List of Resources instances it represents.
fromList(String, boolean, ResourceFactory) - Static method in class org.eclipse.jetty.util.resource.Resource
Parse a delimited String of resource references and return the List of Resources instances it represents.
fromName(String) - Static method in class org.eclipse.jetty.util.TypeUtil
Class from a canonical name for a type.
fromString(ClassLoader, String) - Static method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
Re-inflate a stringified ServletContainerInitializerHolder.
fromString(String) - Static method in enum org.eclipse.jetty.http.HttpMethod
Converts the given String parameter to an HttpMethod.
fromString(String) - Static method in enum org.eclipse.jetty.http.HttpVersion
Case insensitive fromString() conversion
fromVersion(int) - Static method in enum org.eclipse.jetty.http.HttpVersion
 
FS - Class in org.eclipse.jetty.start
 
FS() - Constructor for class org.eclipse.jetty.start.FS
 
FutureCallback - Class in org.eclipse.jetty.util
 
FutureCallback() - Constructor for class org.eclipse.jetty.util.FutureCallback
 
FutureCallback(boolean) - Constructor for class org.eclipse.jetty.util.FutureCallback
 
FutureCallback(Throwable) - Constructor for class org.eclipse.jetty.util.FutureCallback
 
futureCoreSession - Variable in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
FuturePromise<C> - Class in org.eclipse.jetty.util
 
FuturePromise() - Constructor for class org.eclipse.jetty.util.FuturePromise
 
FuturePromise(C) - Constructor for class org.eclipse.jetty.util.FuturePromise
 
FuturePromise(C, Throwable) - Constructor for class org.eclipse.jetty.util.FuturePromise
 
FutureResponseListener - Class in org.eclipse.jetty.client.util
A BufferingResponseListener that is also a Future, to allow applications to block (indefinitely or for a timeout) until FutureResponseListener.onComplete(Result) is called, or to abort the request/response conversation.
FutureResponseListener(Request) - Constructor for class org.eclipse.jetty.client.util.FutureResponseListener
 
FutureResponseListener(Request, int) - Constructor for class org.eclipse.jetty.client.util.FutureResponseListener
 

G

GATEWAY_INTERFACE - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
GATEWAY_TIMEOUT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
GATEWAY_TIMEOUT_504 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
GCloudSessionDataStore - Class in org.eclipse.jetty.gcloud.session
GCloudSessionDataStore
GCloudSessionDataStore() - Constructor for class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
GCloudSessionDataStore.EntityDataModel - Class in org.eclipse.jetty.gcloud.session
EntityDataModel Names of type of Entity and Entity properties for sessions.
GCloudSessionDataStore.ExpiryInfo - Class in org.eclipse.jetty.gcloud.session
ExpiryInfo Information related to session expiry
GCloudSessionDataStoreFactory - Class in org.eclipse.jetty.gcloud.session
GCloudSessionDataStoreFactory
GCloudSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
generate() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
generate(ByteBufferPool.Lease) - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
generate(ByteBufferPool.Lease, DataFrame, int) - Method in class org.eclipse.jetty.http2.generator.DataGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.FrameGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.GoAwayGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.HeadersGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.NoOpGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.PingGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.PrefaceGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.PriorityGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.PushPromiseGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.ResetGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.SettingsGenerator
 
generate(ByteBufferPool.Lease, Frame) - Method in class org.eclipse.jetty.http2.generator.WindowUpdateGenerator
 
generate(ByteBufferPool.Lease, FrameType, int, int, int, int) - Method in class org.eclipse.jetty.http2.generator.HeaderGenerator
 
GENERATE - Enum constant in enum org.eclipse.jetty.quickstart.QuickStartConfiguration.Mode
 
generateAcceptableResponse(Request, HttpServletRequest, HttpServletResponse, int, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Generate an acceptable error response.
generateAcceptableResponse(Request, HttpServletRequest, HttpServletResponse, int, String, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Generate an acceptable error response for a mime type.
generateContent(int, ByteBuffer, boolean, boolean, Callback, FCGI.FrameType) - Method in class org.eclipse.jetty.fcgi.generator.Generator
 
generateData(ByteBufferPool.Lease, int, ByteBuffer, boolean, int) - Method in class org.eclipse.jetty.http2.generator.DataGenerator
 
generateGoAway(ByteBufferPool.Lease, int, int, byte[]) - Method in class org.eclipse.jetty.http2.generator.GoAwayGenerator
 
generateHeader(ByteBufferPool.Lease, FrameType, int, int, int) - Method in class org.eclipse.jetty.http2.generator.FrameGenerator
 
generateHeader(Frame, ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.Generator
Generate the header bytes of a frame into a single ByteBuffer.
generateHeaders(ByteBufferPool.Lease, int, MetaData, PriorityFrame, boolean) - Method in class org.eclipse.jetty.http2.generator.HeadersGenerator
 
generatePayload(Frame, ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.Generator
Generate the payload of a frame into a single ByteBuffer, if the frame has a mask the payload will be masked as it is copied to the output buffer.
generatePing(ByteBufferPool.Lease, byte[], boolean) - Method in class org.eclipse.jetty.http2.generator.PingGenerator
 
generatePriority(ByteBufferPool.Lease, int, int, int, boolean) - Method in class org.eclipse.jetty.http2.generator.PriorityGenerator
 
generatePriorityBody(ByteBuffer, int, int, int, boolean) - Method in class org.eclipse.jetty.http2.generator.PriorityGenerator
 
generatePushPromise(ByteBufferPool.Lease, int, int, MetaData) - Method in class org.eclipse.jetty.http2.generator.PushPromiseGenerator
 
generateQuickStartWebXml(WebAppContext, OutputStream) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
Perform the generation of the xml file
generateRequest(MetaData.Request, ByteBuffer, ByteBuffer, ByteBuffer, boolean) - Method in class org.eclipse.jetty.http.HttpGenerator
 
generateRequestContent(int, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.generator.ClientGenerator
 
generateRequestHeaders(int, HttpFields, Callback) - Method in class org.eclipse.jetty.fcgi.generator.ClientGenerator
 
generateReset(ByteBufferPool.Lease, int, int) - Method in class org.eclipse.jetty.http2.generator.ResetGenerator
 
generateResponse(MetaData.Response, boolean, ByteBuffer, ByteBuffer, ByteBuffer, boolean) - Method in class org.eclipse.jetty.http.HttpGenerator
 
generateResponseContent(int, ByteBuffer, boolean, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.generator.ServerGenerator
 
generateResponseContent(ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
generateResponseHeaders(int, int, String, HttpFields, Callback) - Method in class org.eclipse.jetty.fcgi.generator.ServerGenerator
 
generateResponseHeaders(MetaData.Response, Callback) - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
generateSettings(ByteBufferPool.Lease, Map<Integer, Integer>, boolean) - Method in class org.eclipse.jetty.http2.generator.SettingsGenerator
 
generateWholeFrame(Frame, ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.Generator
Generate the whole frame (header + payload copy) into a single ByteBuffer.
generateWindowUpdate(ByteBufferPool.Lease, int, int) - Method in class org.eclipse.jetty.http2.generator.WindowUpdateGenerator
 
Generator - Class in org.eclipse.jetty.fcgi.generator
 
Generator - Class in org.eclipse.jetty.http2.generator
 
Generator - Class in org.eclipse.jetty.websocket.core.internal
Generating a frame in WebSocket land.
Generator() - Constructor for class org.eclipse.jetty.websocket.core.internal.Generator
 
Generator(ByteBufferPool) - Constructor for class org.eclipse.jetty.http2.generator.Generator
 
Generator(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.fcgi.generator.Generator
 
Generator(ByteBufferPool, boolean, int) - Constructor for class org.eclipse.jetty.http2.generator.Generator
 
Generator(ByteBufferPool, boolean, int, int) - Constructor for class org.eclipse.jetty.http2.generator.Generator
Deprecated.
Generator(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.http2.generator.Generator
 
Generator(ByteBufferPool, int, int) - Constructor for class org.eclipse.jetty.http2.generator.Generator
Deprecated.
Generator.Result - Class in org.eclipse.jetty.fcgi.generator
 
get() - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
get() - Method in class org.eclipse.jetty.util.compression.CompressionPool.Entry
 
get() - Method in class org.eclipse.jetty.util.FutureCallback
 
get() - Method in class org.eclipse.jetty.util.FuturePromise
 
get() - Static method in interface org.eclipse.jetty.websocket.core.client.internal.HttpClientProvider
 
get() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
get(byte[], int, int) - Method in class org.eclipse.jetty.server.HttpInput.Content
Read the wrapped byte buffer.
get(byte[], int, int) - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
get(int) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
get(int) - Static method in enum org.eclipse.jetty.security.UserDataConstraint
 
get(int) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
get(int) - Method in class org.eclipse.jetty.webapp.Configurations
 
get(int) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get the ith child node or content.
get(long, TimeUnit) - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
get(long, TimeUnit) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
Waits for the given timeout for the response to be available, then returns it.
get(long, TimeUnit) - Method in class org.eclipse.jetty.util.FutureCallback
 
get(long, TimeUnit) - Method in class org.eclipse.jetty.util.FuturePromise
 
get(long, TimeUnit) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
get(Class<? extends T>) - Method in class org.eclipse.jetty.webapp.Configurations
 
get(Object) - Method in class org.eclipse.jetty.util.HostMap
 
get(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
get(Object, int) - Static method in class org.eclipse.jetty.util.LazyList
Get item from the list
get(String) - Method in interface org.eclipse.jetty.http.HttpFields
 
get(String) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
get(String) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
get(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Get a session object.
get(String) - Method in interface org.eclipse.jetty.server.session.SessionCache
Get an existing Session.
get(String) - Method in class org.eclipse.jetty.start.Modules
 
get(String) - Method in class org.eclipse.jetty.util.Fields
 
get(String) - Method in interface org.eclipse.jetty.util.Index
Get an exact match from a String key
get(String) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get the first child node with the tag.
get(String, int, int) - Method in interface org.eclipse.jetty.util.Index
Get an exact match from a String key
get(URI) - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
get(URI) - Method in class org.eclipse.jetty.util.HttpCookieStore
 
get(ByteBuffer) - Method in interface org.eclipse.jetty.util.Index
Get an exact match from a segment of a ByteBuffer as key
get(ByteBuffer, int, int) - Method in interface org.eclipse.jetty.util.Index
Get an exact match from a segment of a ByteBuffer as key
get(HttpField) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
get(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
 
get(HttpHeader) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
get(HttpHeader) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
get(PathSpec) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
GET - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
GET(String) - Method in class org.eclipse.jetty.client.HttpClient
Performs a GET request to the specified URI.
GET(URI) - Method in class org.eclipse.jetty.client.HttpClient
Performs a GET request to the specified URI.
GET_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
GET_VALUES - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
GET_VALUES_RESULT - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
getAbortCause() - Method in interface org.eclipse.jetty.client.api.Request
 
getAbortCause() - Method in class org.eclipse.jetty.client.HttpRequest
 
getAcceptableWriter(Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Deprecated.
getAcceptedIssuers() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
getAcceptedReceiveBufferSize() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptedSendBufferSize() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptedSubProtocol() - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the accepted WebSocket protocol.
getAcceptedSubProtocol() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getAcceptedSubProtocol() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getAcceptedSubProtocol() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getAcceptedTcpNoDelay() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptEncodingField() - Method in class org.eclipse.jetty.client.HttpClient
 
getAcceptorPriorityDelta() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getAcceptors() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getAcceptQueueSize() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptQueueSize() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
getAcceptRateLimit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getAccess() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getAccess() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getAccess() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getAccessed() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getAccessed() - Method in class org.eclipse.jetty.server.session.SessionData
 
getAccessTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getActiveConnectionCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getActualValue(Number) - Method in interface org.eclipse.jetty.util.ajax.JSONPojoConvertor.NumberType
 
getAddress() - Method in class org.eclipse.jetty.client.Origin
 
getAddress() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
getAddress() - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
getAddress() - Method in class org.eclipse.jetty.server.handler.InetAccessSet.AccessTuple
 
getAddressResolutionTimeout() - Method in class org.eclipse.jetty.client.HttpClient
 
getAfter() - Method in class org.eclipse.jetty.start.Module
 
getAfters() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
getAgent() - Method in interface org.eclipse.jetty.client.api.Request
 
getAgent() - Method in class org.eclipse.jetty.client.HttpRequest
 
getAlias() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getAlias() - Method in class org.eclipse.jetty.util.resource.Resource
 
getAlias() - Method in class org.eclipse.jetty.util.ssl.X509
 
getAliasChecks() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAliases() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getAliasMapper() - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
getAliasPath() - Method in class org.eclipse.jetty.util.resource.PathResource
The Alias as a Path.
getAllAttributeNames() - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
getAllAttributes() - Method in class org.eclipse.jetty.server.session.SessionData
 
getAllContainerJars(WebAppContext) - Method in class org.eclipse.jetty.ant.AntMetaInfConfiguration
 
getAllContainerJars(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
getAllLines() - Method in class org.eclipse.jetty.start.TextFile
 
getAllModules() - Method in class org.eclipse.jetty.start.StartArgs
 
getAllowed() - Method in interface org.eclipse.jetty.http.ComplianceViolation.Mode
 
getAllowed() - Method in class org.eclipse.jetty.http.CookieCompliance
 
getAllowed() - Method in class org.eclipse.jetty.http.HttpCompliance
 
getAllowed() - Method in class org.eclipse.jetty.http.UriCompliance
Get the set of UriCompliance.Violations allowed by this compliance mode.
getAllowNullPathInfo() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAllResources() - Method in class org.eclipse.jetty.util.resource.Resource
 
getAlterTableForMaxIntervalAsString() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getAltSvcHttpField() - Method in class org.eclipse.jetty.http3.server.HTTP3ServerConnector
 
getAlwaysSaveUri() - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
getAndEnter(String, boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Get a session object.
getAndSetHi(int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the hi value without changing the lo value.
getAndSetLo(int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Atomically sets the lo value without changing the hi value.
getAnnotatedTypeNames() - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
getApp() - Method in class org.eclipse.jetty.deploy.DeploymentManager.AppEntry
 
getAppByOriginId(String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getAppContext() - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
getAppender() - Method in class org.eclipse.jetty.logging.JettyLogger
 
getAppEntries() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getApplicableTypeNames() - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
getApplicationData() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketPongMessage
 
getApplicationMethodHandleLookup(Class<?>) - Static method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
Gives a MethodHandles.Lookup instance to be used to find public methods in application classes.
getApplicationMethodHandleLookup(Class<?>) - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
Gives a MethodHandles.Lookup instance to be used to find public methods in application classes.
getAppProvider() - Method in class org.eclipse.jetty.deploy.App
 
getAppProviders() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getAppProviders() - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
getApps() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getApps() - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
getApps(String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getApps(String) - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
getApps(Node) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Get Set of Apps by Node
getAppsWithSameContext(App) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getArgs() - Method in class org.eclipse.jetty.start.CommandLineBuilder
 
getArgs() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getArgs() - Method in interface org.eclipse.jetty.start.config.ConfigSource
The list of Arguments for this ConfigSource
getArgs() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getArrayConverter() - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
getArrayConverter() - Method in class org.eclipse.jetty.util.ajax.JSON
 
getArtifactId() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getAssociate() - Method in class org.eclipse.jetty.util.resource.Resource
 
getAssociatedInfo() - Static method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
getAssumedEncodings() - Static method in class org.eclipse.jetty.http.MimeTypes
Access a mutable map of mime type to the charset assumed for that content type.
getAsyncContext() - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
getAsyncContext() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getAsyncContext() - Method in class org.eclipse.jetty.server.Request
 
getAsyncContext() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getAsyncContextEvent() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getAsyncDispatches() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getAsyncRemote() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getAsyncRequests() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getAsyncRequestsWaiting() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getAsyncRequestsWaitingMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getAttachment() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getAttachment() - Method in class org.eclipse.jetty.client.HttpConnection
 
getAttachment() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
getAttachment() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getAttachment() - Method in interface org.eclipse.jetty.util.Attachable
 
getAttribute(String) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getAttribute(String) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getAttribute(String) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getAttribute(String) - Method in interface org.eclipse.jetty.http2.api.Stream
 
getAttribute(String) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getAttribute(String) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
getAttribute(String) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttribute(String) - Method in class org.eclipse.jetty.server.HttpChannelState
 
getAttribute(String) - Method in class org.eclipse.jetty.server.Request
Get Request Attribute.
getAttribute(String) - Method in class org.eclipse.jetty.server.Server
 
getAttribute(String) - Method in class org.eclipse.jetty.server.ServletAttributes
 
getAttribute(String) - Method in class org.eclipse.jetty.server.session.Session
 
getAttribute(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
getAttribute(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getAttribute(String) - Method in interface org.eclipse.jetty.util.Attributes
 
getAttribute(String) - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
getAttribute(String) - Method in class org.eclipse.jetty.util.AttributesMap
 
getAttribute(String) - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
getAttribute(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getAttribute(String) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get an element attribute.
getAttribute(String, String) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get an element attribute.
getAttributeEntrySet() - Method in class org.eclipse.jetty.util.AttributesMap
 
getAttributeName() - Method in class org.eclipse.jetty.servlet.DecoratingListener
 
getAttributeNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getAttributeNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttributeNames() - Method in class org.eclipse.jetty.server.Request
 
getAttributeNames() - Method in class org.eclipse.jetty.server.Server
 
getAttributeNames() - Method in class org.eclipse.jetty.server.session.Session
 
getAttributeNames() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getAttributeNames() - Method in interface org.eclipse.jetty.util.Attributes
 
getAttributeNames() - Method in class org.eclipse.jetty.util.AttributesMap
 
getAttributeNames() - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
getAttributeNames() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getAttributeNamesCopy(Attributes) - Static method in class org.eclipse.jetty.util.AttributesMap
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.Server
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.ServletAttributes
 
getAttributeNameSet() - Method in interface org.eclipse.jetty.util.Attributes
 
getAttributeNameSet() - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
getAttributeNameSet() - Method in class org.eclipse.jetty.util.AttributesMap
 
getAttributeNameSet() - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
getAttributes() - Method in class org.eclipse.jetty.ant.types.Attributes
 
getAttributes() - Method in interface org.eclipse.jetty.client.api.Request
 
getAttributes() - Method in class org.eclipse.jetty.client.HttpRequest
 
getAttributes() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getAttributes() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getAttributes() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttributes() - Method in class org.eclipse.jetty.server.Request
 
getAttributes() - Method in class org.eclipse.jetty.server.session.Session
 
getAttributes() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getAttributes() - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
getAttributes() - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get an array of element attributes.
getAttributes(String[]) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
getAttributes(String[]) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getAttributeValue() - Method in enum org.eclipse.jetty.http.HttpCookie.SameSite
 
getAuthContext(String, Subject, Map) - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
getAuthContextID(MessageInfo) - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
getAuthEndpoint() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getAuthenticate() - Method in class org.eclipse.jetty.util.security.Constraint
 
getAuthenticateHeader() - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getAuthenticateHeader() - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
getAuthenticateHeader() - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
getAuthentication() - Method in class org.eclipse.jetty.server.Request
Get the authentication.
getAuthentication(Request, boolean) - Static method in class org.eclipse.jetty.server.CustomRequestLog
Extract the user authentication
getAuthenticationAttribute() - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getAuthenticationAttribute() - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
getAuthenticationAttribute() - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
getAuthenticationDuration() - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
 
getAuthenticationStore() - Method in class org.eclipse.jetty.client.HttpClient
 
getAuthenticationURI(Request) - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getAuthenticationURI(Request) - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
getAuthenticationURI(Request) - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
getAuthenticator() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getAuthenticator() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getAuthenticator(Server, ServletContext, Authenticator.AuthConfiguration, IdentityService, LoginService) - Method in interface org.eclipse.jetty.security.Authenticator.Factory
 
getAuthenticator(Server, ServletContext, Authenticator.AuthConfiguration, IdentityService, LoginService) - Method in class org.eclipse.jetty.security.DefaultAuthenticatorFactory
 
getAuthenticator(Server, ServletContext, Authenticator.AuthConfiguration, IdentityService, LoginService) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
getAuthenticator(Server, ServletContext, Authenticator.AuthConfiguration, IdentityService, LoginService) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticatorFactory
 
getAuthenticatorFactory() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getAuthMethod() - Method in class org.eclipse.jetty.security.AbstractUserAuthentication
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
getAuthMethod() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
 
getAuthMethod() - Method in interface org.eclipse.jetty.security.Authenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
getAuthMethod() - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
getAuthMethod() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getAuthMethod() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getAuthMethod() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getAuthMethod() - Method in interface org.eclipse.jetty.server.Authentication.User
 
getAuthority() - Method in interface org.eclipse.jetty.http.HttpURI
 
getAuthority() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getAuthority() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getAuthorizationHeader() - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getAuthorizationHeader() - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
getAuthorizationHeader() - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
getAuthType() - Method in class org.eclipse.jetty.server.Request
 
getAuthType() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getAuthType() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getAvailable() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
getAvailableDecoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getAvailableDirectByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getAvailableDirectMemory() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getAvailableEncoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getAvailableExtensionNames() - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
getAvailableExtensionNames() - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Get the names of all available WebSocket Extensions.
getAvailableExtensions() - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
getAvailableHeapByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getAvailableHeapMemory() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getAvailableReservedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getAverageQueueLatency() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getAverageSelectedKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getAverageTaskLatency() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getBackoffMs() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getBackoffMs() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getBase() - Method in class org.eclipse.jetty.start.BaseHome
 
getBase64() - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getBaseDir() - Method in class org.eclipse.jetty.start.StartIni
 
getBaseDirectories() - Method in class org.eclipse.jetty.ant.types.FileMatchingConfiguration
 
getBaseHome() - Method in class org.eclipse.jetty.start.BaseBuilder
 
getBaseHome() - Method in class org.eclipse.jetty.start.Main
 
getBasePath() - Method in class org.eclipse.jetty.start.BaseHome
 
getBasePath() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getBasePath(String) - Method in class org.eclipse.jetty.start.BaseHome
Create a Path reference to some content in "${jetty.base}"
getBaseRequest() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getBaseRequest() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getBaseRequest(ServletRequest) - Static method in class org.eclipse.jetty.server.Request
Obtain the base Request instance of a ServletRequest, by coercion, unwrapping or special attribute.
getBaseResource() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getBaseResource() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getBaseResource() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getBaseType() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
getBaseURI() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getBasicRemote() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getBatchingAllowed() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
getBatchMode() - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
 
getBatchMode() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
getBatchMode() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getBatchMode() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
getBean(Class<T>) - Method in interface org.eclipse.jetty.util.component.Container
 
getBean(Class<T>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
getBeans() - Method in interface org.eclipse.jetty.util.component.Container
 
getBeans() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
getBeans(Class<T>) - Method in interface org.eclipse.jetty.util.component.Container
 
getBeans(Class<T>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
getBefore() - Method in class org.eclipse.jetty.start.Module
 
getBefores() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
getBeginNanoTime() - Method in class org.eclipse.jetty.http.HttpParser
 
getBeginNanoTime() - Method in class org.eclipse.jetty.http.MetaData.Request
 
getBeginNanoTime() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getBeginNanoTime() - Method in class org.eclipse.jetty.server.HttpConnection
 
getBeginNanoTime() - Method in class org.eclipse.jetty.server.Request
Get the nanoTime at which the request arrived to a connector, obtained via System.nanoTime().
getBehavior() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
 
getBehavior() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getBehavior() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getBehavior() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getBehavior() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
getBehavior() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getBehavior() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getBehavior() - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
 
getBest(byte[]) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a byte array.
getBest(byte[], int, int) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a byte array.
getBest(String) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a String, which may be a prefix match or an exact match.
getBest(String, int, int) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a String.
getBest(ByteBuffer) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a byte buffer.
getBest(ByteBuffer, int, int) - Method in interface org.eclipse.jetty.util.Index
Get the best match from key in a byte buffer.
getBidirectionalStreamRecvWindow() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getBinaryDecoders(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getBinaryHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getBinaryMetadata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getBinaryMetadata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getBinarySink() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getBinaryStreamDecoders(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getBindAddress() - Method in class org.eclipse.jetty.client.HttpClient
 
getBindAddress() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getBindAddress() - Method in class org.eclipse.jetty.io.ClientConnector
 
getBindAddress() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getBinding(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Get a name to object binding from this Context
getBinding(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Get a name to object binding from this Context
getBindings() - Method in class org.eclipse.jetty.deploy.AppLifeCycle
Get all Node bound objects.
getBindings(String) - Method in class org.eclipse.jetty.deploy.AppLifeCycle
Get all objects bound to a specific Node
getBindings(Node) - Method in class org.eclipse.jetty.deploy.AppLifeCycle
Get all objects bound to a specific Node
getBindingTargets() - Method in interface org.eclipse.jetty.deploy.AppLifeCycle.Binding
Get a list of targets that this implementation should bind to.
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.DebugBinding
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.GlobalWebappConfigBinding
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.OrderedGroupBinding
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.StandardDeployer
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.StandardStarter
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.StandardStopper
 
getBindingTargets() - Method in class org.eclipse.jetty.deploy.bindings.StandardUndeployer
 
getBlackListHosts() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getBlackListHosts() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getBlobInputStream(ResultSet, String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getBlobType() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getBody() - Method in interface org.eclipse.jetty.client.api.Request
 
getBody() - Method in class org.eclipse.jetty.client.HttpRequest
 
getBodyLength() - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
getBoolean(String, boolean) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
 
getBoundary() - Method in class org.eclipse.jetty.util.MultiPartOutputStream
 
getBoundary() - Method in class org.eclipse.jetty.util.MultiPartWriter
 
getBuf() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
getBuf() - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
getBuffer() - Method in class org.eclipse.jetty.http.HttpTester.Input
 
getBuffer() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
getBuffer() - Method in class org.eclipse.jetty.server.HttpOutput
 
getBuffer() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getBufferPool() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getBufferPool() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getBufferPool() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getBufferPool() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getBufferPool() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getBufferRatio() - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
getBufferSize() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getBufferSize() - Method in class org.eclipse.jetty.server.HttpOutput
 
getBufferSize() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
 
getBufferSize() - Method in class org.eclipse.jetty.server.Response
 
getBufferSize() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getBuilder() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
getBundle() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getBundle() - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
Returns the Bundle that defined this web-application.
getBundle(Resource) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
getBundleClassLoader(Bundle) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleClassLoaderHelper
 
getBundleClassLoader(Bundle) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultBundleClassLoaderHelper
Assuming the bundle is started.
getBundleInstallLocation(Bundle) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
Works with equinox, felix, nuxeo and probably more.
getBundleInstallLocation(Bundle) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
Works with equinox, felix, nuxeo and probably more.
getBundlePath() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
getBundleSymbolicName() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getBundleVersionAsString() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getBusyThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The number of threads executing internal and transient jobs.
getByte() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
getByteArray() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
getByteBuffer() - Method in class org.eclipse.jetty.http3.api.Stream.Data
 
getByteBuffer() - Method in class org.eclipse.jetty.http3.frames.DataFrame
 
getByteBuffer() - Method in class org.eclipse.jetty.server.HttpInput.Content
Get the wrapped byte buffer.
getByteBuffer() - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
getByteBufferPool() - Method in class org.eclipse.jetty.client.HttpClient
 
getByteBufferPool() - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
getByteBufferPool() - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
getByteBufferPool() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getByteBufferPool() - Method in class org.eclipse.jetty.http2.generator.Generator
 
getByteBufferPool() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
getByteBufferPool() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
getByteBufferPool() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
getByteBufferPool() - Method in class org.eclipse.jetty.io.ClientConnector
 
getByteBufferPool() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getByteBufferPool() - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
getByteBufferPool() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
getByteBufferPool() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getByteBufferPool() - Method in interface org.eclipse.jetty.server.Connector
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.HttpChannel
 
getByteBufferPool() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getByteBufferPool() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
getByteBufferPool() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getByteBuffers() - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
getByteBuffers() - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
getBytes() - Method in enum org.eclipse.jetty.http.HttpHeader
 
getBytes() - Method in enum org.eclipse.jetty.http.HttpMethod
 
getBytes() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getBytes() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getBytes(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
getBytes(String, String) - Static method in class org.eclipse.jetty.util.StringUtil
 
getBytesColonSpace() - Method in enum org.eclipse.jetty.http.HttpHeader
 
getBytesIn() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getBytesIn() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
getBytesIn() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getBytesIn() - Method in interface org.eclipse.jetty.io.Connection
 
getBytesIn() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getBytesIn() - Method in class org.eclipse.jetty.server.HttpConnection
 
getBytesIn() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getBytesOut() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getBytesOut() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
getBytesOut() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getBytesOut() - Method in interface org.eclipse.jetty.io.Connection
 
getBytesOut() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getBytesOut() - Method in class org.eclipse.jetty.server.HttpConnection
 
getBytesOut() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
getBytesOut() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getBytesWritten() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getBytesWritten() - Method in interface org.eclipse.jetty.http2.ISession
 
getBytesWritten() - Method in class org.eclipse.jetty.server.HttpChannel
 
getCache() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
Get the clustered cache instance.
getCache() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
Get the clustered cache instance.
getCacheControl() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Get the cacheControl.
getCacheControl() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getCacheControl() - Method in class org.eclipse.jetty.server.ResourceService
 
getCachedBeans(Class<T>) - Method in interface org.eclipse.jetty.util.component.Container
 
getCachedFiles() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getCachedSize() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getCacheKey(String) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
getCacheLineBytes() - Static method in class org.eclipse.jetty.util.MemoryUtils
 
getCallback() - Method in class org.eclipse.jetty.util.Callback.Nested
 
getCallbackHandler() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
getCallbackInvocationType() - Method in class org.eclipse.jetty.io.FillInterest
 
getCallbackInvocationType() - Method in class org.eclipse.jetty.io.WriteFlusher
 
getCanonicalContextPath() - Method in class org.eclipse.jetty.server.session.SessionContext
 
getCanonicalNameForWebAppTmpDir(WebAppContext) - Static method in class org.eclipse.jetty.webapp.WebInfConfiguration
Create a canonical name for a webapp temp directory.
getCapacity() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
getCapacity() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
getCapacity() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
getCapacityFactor() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getCapacityFactor() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getCapacityFactor() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getCapacityFactor() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getCatalogName() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCause() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
getCertAlias() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getCertChain(SSLSession) - Static method in class org.eclipse.jetty.util.ssl.SslContextFactory
Obtain the X509 Certificate Chain from the provided SSLSession using the default CertificateFactory behaviors
getCertificate() - Method in class org.eclipse.jetty.util.ssl.X509
 
getCertificateChain(String) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
getCertificateChain(String) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
getCertificateChain(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
getCertificateFactoryInstance(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getCertificates() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getCertificates() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getCertificates() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getCertStoreInstance(Collection<? extends CRL>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getChallengeUri(Request) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
getChannel() - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
getChannel() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getChannel() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
getChannel() - Method in class org.eclipse.jetty.unixsocket.common.UnixSocketEndPoint
Deprecated.
 
getChar() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
getCharacterEncoding() - Method in interface org.eclipse.jetty.http.HttpContent
 
getCharacterEncoding() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getCharacterEncoding() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getCharacterEncoding() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getCharacterEncoding() - Method in class org.eclipse.jetty.server.Request
 
getCharacterEncoding() - Method in class org.eclipse.jetty.server.Response
 
getCharacterEncoding() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getCharacterEncoding() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getCharset() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
getCharset() - Method in class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
getCharsetAssumedFromContentType(String) - Static method in class org.eclipse.jetty.http.MimeTypes
 
getCharsetFromContentType(String) - Static method in class org.eclipse.jetty.http.MimeTypes
 
getCharsetInferredFromContentType(String) - Static method in class org.eclipse.jetty.http.MimeTypes
 
getCharsetString() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
getCheckSessionExistsStatement(Connection, SessionContext) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getChildHandlerByClass(Class<T>) - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
getChildHandlerByClass(Class<T>) - Method in interface org.eclipse.jetty.server.HandlerContainer
 
getChildHandlers() - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
getChildHandlers() - Method in interface org.eclipse.jetty.server.HandlerContainer
 
getChildHandlersByClass(Class<?>) - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
getChildHandlersByClass(Class<?>) - Method in interface org.eclipse.jetty.server.HandlerContainer
 
getCipherComparator() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getClaims() - Method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
getClasses() - Method in class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
 
getClassifier() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata.Snapshot
 
getClassInfo() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getClassInfo() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getClassLoader() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getClassLoader() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getClassLoader() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getClassLoader() - Method in class org.eclipse.jetty.start.Classpath
 
getClassLoader() - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
getClassLoader() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getClassLoaderLocation(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
getClassLoaderLocation(Class<?>, ClassLoader) - Static method in class org.eclipse.jetty.util.TypeUtil
 
getClassLoadingLock(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getClassName() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getClassName() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getClassName() - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
getClassName() - Method in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
getClassNameForJsp(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getClassNames() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
getClasspath() - Method in class org.eclipse.jetty.start.StartArgs
 
getClassPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Make best effort to extract a file classpath from the context classloader
getClassPathFiles() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getCleanOrphansStatement(Connection, long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getClientAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
getClientAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
getClientAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
getClientAuthConfig(String, String, CallbackHandler) - Method in class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.client.HttpDestination
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.io.NegotiatingClientConnectionFactory
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
getClientConnector() - Method in class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
getClientConnector() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getClientConnector() - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
getClientId() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getClientSecret() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getClosedCount() - Method in class org.eclipse.jetty.util.Pool
 
getClosedStream() - Static method in class org.eclipse.jetty.util.IO
 
getCloseHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getCloseHandle() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getCloseState() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getCloseStatus() - Method in interface org.eclipse.jetty.websocket.core.CloseStatus.Supplier
 
getCloseStatus() - Method in class org.eclipse.jetty.websocket.core.internal.Parser.ParsedFrame
 
getCloseStatus() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
getCloseStatus(Frame) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
getCode() - Method in exception class org.eclipse.jetty.http.BadMessageException
 
getCode() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
 
getCode() - Method in class org.eclipse.jetty.websocket.api.CloseStatus
 
getCode() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
getCode(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Get the HttpStatusCode for a specific code
getCodeSourceLocation(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
getCollectionName() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getCommand() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getCommandLineSource() - Method in class org.eclipse.jetty.start.config.ConfigSources
 
getComment() - Method in class org.eclipse.jetty.http.HttpCookie
 
getComment() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
getCommentWithAttributes(String, boolean, HttpCookie.SameSite) - Static method in class org.eclipse.jetty.http.HttpCookie
 
getCommentWithAttributes(String, boolean, HttpCookie.SameSite, boolean) - Static method in class org.eclipse.jetty.http.HttpCookie
 
getCommentWithoutAttributes(String) - Static method in class org.eclipse.jetty.http.HttpCookie
 
getCommittedMetaData() - Method in class org.eclipse.jetty.server.HttpChannel
 
getCommittedMetaData() - Method in class org.eclipse.jetty.server.Response
Get the MetaData.Response committed for this response.
getComplianceViolationListener() - Method in class org.eclipse.jetty.server.Request
 
getComponentType() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
getConfig() - Method in class org.eclipse.jetty.security.HashLoginService
 
getConfig() - Method in class org.eclipse.jetty.security.JDBCLoginService
 
getConfig() - Method in class org.eclipse.jetty.security.PropertyUserStore
Get the config (as a string)
getConfig() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
getConfig() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getConfig() - Method in interface org.eclipse.jetty.websocket.core.Extension
The active configuration for this extension.
getConfig() - Method in class org.eclipse.jetty.websocket.jakarta.common.ConfiguredEndpoint
 
getConfigPath() - Method in class org.eclipse.jetty.security.PropertyUserStore
Get the Config Path reference.
getConfigProvider(String, String, RegistrationListener) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
getConfigResource() - Method in class org.eclipse.jetty.security.PropertyUserStore
 
getConfigs() - Method in class org.eclipse.jetty.util.PathWatcher
 
getConfigSources() - Method in class org.eclipse.jetty.start.BaseHome
 
getConfiguration() - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
getConfiguration() - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
getConfiguration() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getConfiguration() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
getConfiguration(Class<? extends T>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getConfigurationClasses() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
getConfigurationClasses() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getConfigurationManager() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
getConfigurationProcessor(String, String) - Method in interface org.eclipse.jetty.xml.ConfigurationProcessorFactory
 
getConfigurations() - Method in class org.eclipse.jetty.webapp.Configurations
 
getConfigurations() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getConfigurations(Class<? extends T>) - Method in class org.eclipse.jetty.webapp.Configurations
 
getConfigurator() - Method in class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
getConfigurator() - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
getConnectAddress() - Method in class org.eclipse.jetty.client.HttpDestination
 
getConnectedEndPoints() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getConnectedEndPoints() - Method in interface org.eclipse.jetty.server.Connector
 
getConnection() - Method in interface org.eclipse.jetty.client.api.Request
Returns the connection associated with this request.
getConnection() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getConnection() - Method in class org.eclipse.jetty.client.HttpChannel
 
getConnection() - Method in class org.eclipse.jetty.client.HttpRequest
 
getConnection() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
getConnection() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getConnection() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getConnection() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
getConnection() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getConnection() - Method in interface org.eclipse.jetty.io.EndPoint
 
getConnection() - Method in class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule
 
getConnection() - Method in class org.eclipse.jetty.jaas.spi.DataSourceLoginModule
Get a connection from the DataSource
getConnection() - Method in class org.eclipse.jetty.jaas.spi.JDBCLoginModule
Get a connection from the DriverManager
getConnection() - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
getConnection() - Method in class org.eclipse.jetty.server.HttpChannel
 
getConnection() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getConnection() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
Get a connection from the driver or datasource.
getConnection() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getConnectionCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getConnectionDurationMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionDurationMean() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationMean() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionDurationStdDev() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationStdDev() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionFactories() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getConnectionFactories() - Method in interface org.eclipse.jetty.server.Connector
 
getConnectionFactory(Class<T>) - Method in class org.eclipse.jetty.server.AbstractConnector
 
getConnectionFactory(Class<T>) - Method in interface org.eclipse.jetty.server.Connector
 
getConnectionFactory(String) - Method in class org.eclipse.jetty.server.AbstractConnector
 
getConnectionFactory(String) - Method in interface org.eclipse.jetty.server.Connector
 
getConnectionId() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getConnectionPool() - Method in class org.eclipse.jetty.client.HttpDestination
 
getConnectionPoolFactory() - Method in class org.eclipse.jetty.client.AbstractHttpClientTransport
 
getConnectionPoolFactory() - Method in interface org.eclipse.jetty.client.HttpClientTransport
 
getConnections() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnections() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnections() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getConnectionsMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionsMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionStatisticsGroups() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionStatisticsGroups() - Method in class org.eclipse.jetty.io.jmx.ConnectionStatisticsMBean
 
getConnectionsTotal() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionsTotal() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionString() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getConnectionUrl() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getConnector() - Method in class org.eclipse.jetty.server.handler.InetAccessSet.AccessTuple
 
getConnector() - Method in class org.eclipse.jetty.server.HttpChannel
 
getConnector() - Method in class org.eclipse.jetty.server.HttpConnection
 
getConnector() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getConnector() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getConnectors() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getConnectors() - Method in class org.eclipse.jetty.ant.types.Connectors
Returns the list of known connectors to deploy.
getConnectors() - Method in class org.eclipse.jetty.server.Server
 
getConnectTimeout() - Method in class org.eclipse.jetty.client.HttpClient
 
getConnectTimeout() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getConnectTimeout() - Method in class org.eclipse.jetty.io.ClientConnector
 
getConnectTimeout() - Method in class org.eclipse.jetty.io.SelectorManager
Get the connect timeout
getConnectTimeout() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getConnectTimeout() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getConstraint() - Method in class org.eclipse.jetty.security.ConstraintMapping
 
getConstraintMappings() - Method in interface org.eclipse.jetty.security.ConstraintAware
 
getConstraintMappings() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
getConstraintMappingsForPath(String, List<ConstraintMapping>) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
getContainedBeans(Class<T>) - Method in interface org.eclipse.jetty.util.component.Container
 
getContainedBeans(Class<T>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
getContainedBeans(Class<T>, Collection<T>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
getContainer() - Method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketClientContainerProvider
Used by ContainerProvider.getWebSocketContainer() to get a NEW INSTANCE of the Client WebSocketContainer.
getContainer() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getContainer(ServletContext) - Static method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
getContainer(ServletContext) - Static method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getContainer(HttpClient) - Static method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketClientContainerProvider
Get a new instance of a client WebSocketContainer which uses a supplied HttpClient.
getContainerImpl() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getContainerInitializer() - Method in class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
Deprecated.
getContainerResources() - Method in class org.eclipse.jetty.webapp.MetaData
 
getContainerTldBundleDiscoverers() - Static method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
getContainingResource() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getContent() - Method in interface org.eclipse.jetty.client.api.ContentResponse
 
getContent() - Method in interface org.eclipse.jetty.client.api.Request
Deprecated.
use Request.getBody() instead
getContent() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getContent() - Method in class org.eclipse.jetty.client.HttpRequest
 
getContent() - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getContent() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
getContent(String, int) - Method in interface org.eclipse.jetty.http.HttpContent.ContentFactory
 
getContent(String, int) - Method in class org.eclipse.jetty.server.CachedContentFactory
Returns an entry from the cache, or creates a new one.
getContent(String, int) - Method in class org.eclipse.jetty.server.ResourceContentFactory
 
getContentAsInputStream() - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getContentAsString() - Method in interface org.eclipse.jetty.client.api.ContentResponse
 
getContentAsString() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getContentAsString() - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getContentAsString(String) - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getContentAsString(Charset) - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getContentBytes() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
getContentConsumed() - Method in class org.eclipse.jetty.server.HttpInput
 
getContentCount() - Method in class org.eclipse.jetty.server.Response
 
getContentDecoderFactories() - Method in class org.eclipse.jetty.client.HttpClient
Returns a non thread-safe set of ContentDecoder.Factorys that can be modified before performing requests.
getContentDispositionFilename() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
Get the filename from the content-disposition.
getContentDispositionFilename() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
Get the filename from the content-disposition.
getContentEncoding() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
getContentEncoding() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentEncoding() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentEncoding() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentEncoding() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentEncodingValue() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentEncodingValue() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentEncodingValue() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentEncodingValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentFactory() - Method in class org.eclipse.jetty.server.ResourceService
 
getContentLength() - Method in class org.eclipse.jetty.fcgi.parser.ContentParser
 
getContentLength() - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
 
getContentLength() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentLength() - Method in class org.eclipse.jetty.http.HttpParser
 
getContentLength() - Method in class org.eclipse.jetty.http.MetaData
 
getContentLength() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentLength() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentLength() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentLength() - Method in class org.eclipse.jetty.server.Request
 
getContentLength() - Method in class org.eclipse.jetty.server.Response
 
getContentLength() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getContentLengthLong() - Method in class org.eclipse.jetty.server.Request
 
getContentLengthLong() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getContentLengthValue() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentLengthValue() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentLengthValue() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentLengthValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentPrepared() - Method in class org.eclipse.jetty.http.HttpGenerator
 
getContentProvider() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
getContentRead() - Method in class org.eclipse.jetty.http.HttpParser
 
getContentRead() - Method in class org.eclipse.jetty.server.Request
 
getContentReceived() - Method in class org.eclipse.jetty.server.HttpInput
 
getContentType() - Method in interface org.eclipse.jetty.client.api.ContentProvider.Typed
Deprecated.
 
getContentType() - Method in interface org.eclipse.jetty.client.api.Request.Content
 
getContentType() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
getContentType() - Method in class org.eclipse.jetty.client.util.AbstractRequestContent
 
getContentType() - Method in class org.eclipse.jetty.client.util.AbstractTypedContentProvider
Deprecated.
 
getContentType() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
getContentType() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentType() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentType() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentType() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentType() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getContentType() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getContentType() - Method in class org.eclipse.jetty.server.Request
 
getContentType() - Method in class org.eclipse.jetty.server.Response
 
getContentType() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getContentType() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getContentTypeField() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
getContentTypeValue() - Method in interface org.eclipse.jetty.http.HttpContent
 
getContentTypeValue() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getContentTypeValue() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getContentTypeValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getContentTypeWithoutCharset(String) - Static method in class org.eclipse.jetty.http.MimeTypes
 
getContext() - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
getContext() - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
getContext() - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
getContext() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getContext() - Method in interface org.eclipse.jetty.server.MultiParts
 
getContext() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
getContext() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
getContext() - Method in class org.eclipse.jetty.server.Request
 
getContext() - Method in class org.eclipse.jetty.server.session.SessionContext
 
getContext() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getContext() - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
getContext(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getContext(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getContext(String) - Method in class org.eclipse.jetty.webapp.WebAppContext.Context
 
getContextAttribute(String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Get a contextAttribute that will be set for every Context deployed by this provider.
getContextAttributes() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getContextAttributes() - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
getContextFile() - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
getContextForClassLoader(ClassLoader) - Method in class org.eclipse.jetty.jndi.ContextFactory
Find the naming Context for the given classloader
getContextForNamingEntries(Object) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
getContextForScope(Object) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
getContextFromFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
getContextHandler() - Method in class org.eclipse.jetty.deploy.App
Get ContextHandler for the App.
getContextHandler() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
getContextHandler() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getContextHandler() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getContextHandler() - Method in interface org.eclipse.jetty.server.UserIdentity.Scope
 
getContextHandler() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getContextHandler(ServletContext) - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContextHandlerCollection() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
getContextHandlers() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getContextHandlers() - Method in class org.eclipse.jetty.ant.types.ContextHandlers
 
getContextId() - Method in class org.eclipse.jetty.deploy.App
Deprecated.
Use getContextPath instead.
getContextName(ContextHandler) - Method in class org.eclipse.jetty.server.handler.jmx.AbstractHandlerMBean
 
getContextPath() - Method in class org.eclipse.jetty.deploy.App
The context path App relating to how it is installed on the jetty server side.
getContextPath() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getContextPath() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
getContextPath() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
getContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getContextPath() - Method in class org.eclipse.jetty.server.Request
 
getContextPath() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getContextPath() - Method in class org.eclipse.jetty.server.session.Session
 
getContextPath() - Method in class org.eclipse.jetty.server.session.SessionData
 
getContextPath() - Method in interface org.eclipse.jetty.server.UserIdentity.Scope
 
getContextPath() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getContextPath() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getContextPath() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getContextPathColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getContextPathEncoded() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContexts() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getContexts() - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
getContexts() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getContextXml() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getConversation() - Method in class org.eclipse.jetty.client.HttpExchange
 
getConversation() - Method in class org.eclipse.jetty.client.HttpRequest
 
getConvertedType() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
getConvertor(Class<?>) - Method in class org.eclipse.jetty.util.ajax.JSON
Looks up a convertor for a class.
getConvertor(String) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
Returns the JSON.Convertor associated with the given class name, if any.
getConvertorFor(String) - Method in class org.eclipse.jetty.util.ajax.JSON
Looks up a convertor for a class name.
getCookies() - Method in interface org.eclipse.jetty.client.api.Request
 
getCookies() - Method in class org.eclipse.jetty.client.HttpRequest
 
getCookies() - Method in class org.eclipse.jetty.server.Cookies
 
getCookies() - Method in class org.eclipse.jetty.server.Request
 
getCookies() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getCookies() - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
getCookies() - Method in class org.eclipse.jetty.util.HttpCookieStore
 
getCookies() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the list of Cookies on the Upgrade request
getCookies() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getCookies() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getCookies() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getCookies() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getCookies() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getCookieSet() - Method in class org.eclipse.jetty.server.session.SessionData
 
getCookieSetTime() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getCookieSetTime() - Method in class org.eclipse.jetty.server.session.Session
 
getCookieStore() - Method in class org.eclipse.jetty.client.HttpClient
 
getCookieStore() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getCookieTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCoordinates(URI) - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
getCoreConfig() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getCoreSession() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getCoreSession() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getCoreSession() - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
getCoreSession() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getCount() - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
getCount() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getCount() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getCreated() - Method in class org.eclipse.jetty.server.session.SessionData
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getCreatedTimeStamp() - Method in interface org.eclipse.jetty.io.Connection
 
getCreatedTimeStamp() - Method in interface org.eclipse.jetty.io.EndPoint
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getCreateIndexOverExpiryStatementAsString(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCreateIndexOverSessionStatementAsString(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCreateStatementAsString() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCreateTables() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getCreateTime() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getCreateTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getCreationTime() - Method in class org.eclipse.jetty.server.session.Session
 
getCredential() - Method in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
getCredential() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
getCredential() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
getCredential() - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
getCredential(String) - Static method in class org.eclipse.jetty.util.security.Credential
Get a credential from a String.
getCredential(String) - Method in interface org.eclipse.jetty.util.security.CredentialProvider
Get a credential from a String
getCredentials() - Method in class org.eclipse.jetty.security.openid.OpenIdUserPrincipal
 
getCrlPath() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Get the crlPath.
getCrlPath() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getCrls() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
getCSV(String, boolean) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name as a QuotedCSV
getCSV(HttpHeader, boolean) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name, split as a QuotedCSV
getCurrent() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
 
getCurrentConnection() - Static method in class org.eclipse.jetty.server.HttpConnection
Get the current connection that this thread is dispatched to.
getCurrentContext() - Static method in class org.eclipse.jetty.server.handler.ContextHandler
Get the current ServletContext implementation.
getCurrentSecurityHandler() - Static method in class org.eclipse.jetty.security.SecurityHandler
 
getCurrentUser() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
getCurrentWebAppContext() - Static method in class org.eclipse.jetty.webapp.WebAppContext
 
getCustomizer(Class<T>) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getCustomizers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getData() - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
getDataBytesRemaining() - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
getDataConstraint() - Method in class org.eclipse.jetty.util.security.Constraint
 
getDatasource() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getDatasourceName() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getDatedFilename() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve the file name of the request log with the expanded date wildcard if the output is written to the disk using RolloverFileOutputStream.
getDatedFilename() - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
getDateField() - Method in class org.eclipse.jetty.server.Server
 
getDateField(String) - Method in interface org.eclipse.jetty.http.HttpFields
Get a header as a date value.
getDateHeader(String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormRequest
 
getDateHeader(String) - Method in class org.eclipse.jetty.server.Request
 
getDateHeader(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getDateHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getDBCollection() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
getDbName() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getDBName() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getDebugListener() - Method in class org.eclipse.jetty.deploy.bindings.DebugListenerBinding
 
getDeclaration() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
The as-provided path spec.
getDeclaration() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getDeclaration() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getDeclaration() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getDecodedPath() - Method in interface org.eclipse.jetty.http.HttpURI
 
getDecodedPath() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getDecodedPath() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getDecoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
getDecoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getDecorators() - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
getDecryptedEndPoint() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getDefaultAsyncSendTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getDefaultConfig() - Method in class org.eclipse.jetty.start.Module
 
getDefaultConnectionFactory() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getDefaultConnectionFactory() - Method in interface org.eclipse.jetty.server.Connector
 
getDefaultConnectors() - Method in class org.eclipse.jetty.ant.types.Connectors
Gets the default list of connectors to deploy when no connectors were explicitly added to the list.
getDefaultContentType() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getDefaultLifeCycleGoal() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getDefaultMaxBinaryMessageBufferSize() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getDefaultMaxSessionIdleTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getDefaultMaxTextMessageBufferSize() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getDefaultMimeByExtension(String) - Static method in class org.eclipse.jetty.http.MimeTypes
Get the MIME type by filename extension.
getDefaultPort() - Method in enum org.eclipse.jetty.http.HttpScheme
 
getDefaultPort(String) - Static method in enum org.eclipse.jetty.http.HttpScheme
 
getDefaultProtocol() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getDefaultProtocol() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getDefaultProtocol() - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
getDefaultRequestCharacterEncoding() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getDefaultRequestContentType() - Method in class org.eclipse.jetty.client.HttpClient
 
getDefaultResponseCharacterEncoding() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getDefaultsDescriptor() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Get the defaultsDescriptor.
getDefaultsDescriptor() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
Get the defaultsDescriptor.
getDefaultsDescriptor() - Method in class org.eclipse.jetty.webapp.MetaData
 
getDefaultsDescriptor() - Method in class org.eclipse.jetty.webapp.WebAppContext
The default descriptor is a web.xml format file that is applied to the context before the standard WEB-INF/web.xml
getDefaultSecurityHandlerClass() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Get the defaultSecurityHandlerClass.
getDefaultSessionTrackingModes() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getDefaultSessionTrackingModes() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getDefaultSessionTrackingModes() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getDefaultStylesheet() - Static method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getDefaultUseCaches() - Static method in class org.eclipse.jetty.util.resource.Resource
 
getDefaultVirtualThreadsExecutor() - Static method in class org.eclipse.jetty.util.VirtualThreads
 
getDeferredSyntaxAllowedAsLiteral() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getDeflater() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
getDeflaterEntry(Request, long) - Method in interface org.eclipse.jetty.server.handler.gzip.GzipFactory
 
getDeflaterEntry(Request, long) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
getDeflaterPool() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the DeflaterPool being used.
getDeflaterPool() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getDeflaterPool() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getDeflaterPoolCapacity() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Deprecated.
for custom DeflaterPool settings use GzipHandler.setDeflaterPool(DeflaterPool).
getDelegate() - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
getDeleteStatement(Connection, String, SessionContext) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getDependencies() - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
getDependencies() - Method in interface org.eclipse.jetty.webapp.Configuration
Get known Configuration Dependencies.
getDependents() - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
getDependents() - Method in interface org.eclipse.jetty.webapp.Configuration
Get known Configuration Dependents.
getDepends() - Method in class org.eclipse.jetty.start.Module
 
getDeployedApps() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
getDeploymentManager() - Method in class org.eclipse.jetty.deploy.App
 
getDeploymentManager() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
Get the deploymentManager.
getDeploymentManager() - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider
 
getDeploymentManager() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
getDeploymentManager() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
getDeprecated() - Method in class org.eclipse.jetty.start.Module
 
getDesc() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getDescription() - Method in interface org.eclipse.jetty.http.ComplianceViolation
 
getDescription() - Method in enum org.eclipse.jetty.http.CookieCompliance.Violation
 
getDescription() - Method in enum org.eclipse.jetty.http.HttpCompliance.Violation
 
getDescription() - Method in enum org.eclipse.jetty.http.UriCompliance.Violation
 
getDescription() - Method in class org.eclipse.jetty.start.Module
 
getDescriptor() - Method in class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
getDescriptor() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getDestination(URI, String) - Method in class org.eclipse.jetty.start.FileInitializer
 
getDestinationAddress() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
getDestinationAddress() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getDestinationIdleTimeout() - Method in class org.eclipse.jetty.client.HttpClient
The default value is 0
getDestinationPort() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
getDestinationPort() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getDestinations() - Method in class org.eclipse.jetty.client.HttpClient
 
getDigest() - Method in class org.eclipse.jetty.util.security.Credential.MD5
 
getDir() - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
getDir() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getDirectBuffer() - Method in interface org.eclipse.jetty.http.HttpContent
 
getDirectBuffer() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getDirectBuffer() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getDirectBuffer() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getDirectBuffer(Resource) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getDirectByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getDirectByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getDirectByteBufferCount() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getDirectMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getDirectMemory() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getDirectMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getDirectMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getDirectMemory() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getDirMatcher() - Method in class org.eclipse.jetty.start.PathFinder
 
getDispatchContext() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getDispatched() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedActive() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedActiveMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedTimeMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedTimeMean() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedTimeStdDev() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatchedTimeTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getDispatcherType() - Method in class org.eclipse.jetty.server.Request
 
getDispatcherType() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getDispatcherTypes() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
getDispatcherTypes() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the Set of DispatcherType that this Filter will operate on.
getDispatcherTypes() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
getDispatchPath() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getDisplayName() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getDisplayName() - Method in class org.eclipse.jetty.servlet.Holder
 
getDomain() - Method in class org.eclipse.jetty.http.HttpCookie
 
getDomain() - Method in class org.eclipse.jetty.jmx.MBeanContainer
Retrieve domain name used to add MBeans
getDomain() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
getDouble() - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
getDriver() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getDriverClassName() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getDryRunParts() - Method in class org.eclipse.jetty.start.StartArgs
 
getDTD() - Method in class org.eclipse.jetty.xml.XmlParser
 
getDynamicTableSize() - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
getEdge(int) - Method in class org.eclipse.jetty.deploy.graph.Path
 
getEdges() - Method in class org.eclipse.jetty.deploy.graph.Graph
 
getEdges() - Method in class org.eclipse.jetty.deploy.graph.Path
 
getEffectiveMajorVersion() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getEffectiveMinorVersion() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getEffectiveSessionTrackingModes() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getEffectiveSessionTrackingModes() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getEffectiveSessionTrackingModes() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getElapsedNanos() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
getElements() - Method in class org.eclipse.jetty.start.Classpath
 
getElIgnored() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getEnabled() - Method in class org.eclipse.jetty.start.Modules
 
getEnabledModules() - Method in class org.eclipse.jetty.start.StartArgs
Deprecated.
getEnableSources() - Method in class org.eclipse.jetty.start.Module
 
getEncodedField() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.StaticEntry
 
getEncodedField(HttpHeader, String, String) - Method in class org.eclipse.jetty.http.Http1FieldPreEncoder
 
getEncodedField(HttpHeader, String, String) - Method in interface org.eclipse.jetty.http.HttpFieldPreEncoder
 
getEncodedField(HttpHeader, String, String) - Method in class org.eclipse.jetty.http2.hpack.HpackFieldPreEncoder
 
getEncodedField(HttpHeader, String, String) - Method in class org.eclipse.jetty.http3.qpack.QpackFieldPreEncoder
 
getEncodedLength(HttpVersion) - Method in class org.eclipse.jetty.http.PreEncodedHttpField
 
getEncodedToken() - Method in class org.eclipse.jetty.security.SpnegoUserPrincipal
 
getEncoderFor(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
getEncoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
getEncoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getEncoding() - Method in interface org.eclipse.jetty.client.api.ContentResponse
 
getEncoding() - Method in class org.eclipse.jetty.client.ContentDecoder.Factory
 
getEncoding() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getEncoding() - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getEncoding() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
getEncodingCacheSize() - Method in class org.eclipse.jetty.server.ResourceService
 
getEndpoint() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getEndpoint() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getEndPoint() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getEndPoint() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getEndPoint() - Method in interface org.eclipse.jetty.io.Connection
 
getEndPoint() - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
getEndPoint() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
getEndPoint() - Method in class org.eclipse.jetty.server.HttpChannel
 
getEndpointClass() - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
getEndpointConfig() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getEndpointIdentificationAlgorithm() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getEndpointInstance(Class<T>) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
 
getEndSessionEndpoint() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getEntityDataModel() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getEntityDataModel() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getEntry(String) - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
Get a versioned resource entry by name
getEnvironment() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
get the context for connection
getEnvironment() - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
getEnvironment() - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getEnvironment() - Method in class org.eclipse.jetty.jndi.NamingContext
Get the environment of this Context.
getEPCTasksConsumed() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
getError() - Method in class org.eclipse.jetty.http2.frames.FailureFrame
 
getError() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
getError() - Method in class org.eclipse.jetty.http2.frames.ResetFrame
 
getError() - Method in class org.eclipse.jetty.server.HttpInput.Content
Get the reported error.
getError() - Method in class org.eclipse.jetty.server.HttpInput.ErrorContent
 
getErrorCode() - Method in exception class org.eclipse.jetty.http3.qpack.QpackException
 
getErrorContext() - Method in class org.eclipse.jetty.server.Request
 
getErrorHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getErrorHandle() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getErrorHandler() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getErrorHandler() - Method in class org.eclipse.jetty.server.Server
 
getErrorHandler(Server, ContextHandler) - Static method in class org.eclipse.jetty.server.handler.ErrorHandler
 
getErrorOnUndeclaredNamespace() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getErrorPage(HttpServletRequest) - Method in interface org.eclipse.jetty.server.handler.ErrorHandler.ErrorPageMapper
 
getErrorPage(HttpServletRequest) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
getErrorPages() - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
getErrors() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getETag() - Method in interface org.eclipse.jetty.http.HttpContent
 
getETag() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getETag() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getETag() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getETag() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedPrecompressedHttpContent
 
getEtagSuffix() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
getETagValue() - Method in interface org.eclipse.jetty.http.HttpContent
 
getETagValue() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getETagValue() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getETagValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getETagValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedPrecompressedHttpContent
 
getEventListeners() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
getEventListeners() - Method in interface org.eclipse.jetty.util.component.Container
Get the beans added to the container that are EventListeners.
getEventsPerSecond() - Method in class org.eclipse.jetty.http2.parser.WindowRateControl
 
getEvictionPolicy() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
getEvictionPolicy() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
getEvictionPolicy() - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
getEvictionPolicy() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
getExceptions() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getExchanges() - Method in class org.eclipse.jetty.client.HttpConversation
 
getExcludeCipherSuites() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getExcluded() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
getExcludedAddresses() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getExcludedInflationPaths() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of excluded Path Specs for request inflation.
getExcludedMethodList() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the excluded filter list of HTTP methods in CSV format
getExcludedMethods() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of excluded HTTP methods
getExcludedMimeTypes() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of excluded MIME types
getExcludedPaths() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of excluded Path Specs
getExcludeProtocols() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getExclusions() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
getExecutor() - Method in class org.eclipse.jetty.client.HttpClient
 
getExecutor() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
getExecutor() - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
getExecutor() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getExecutor() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getExecutor() - Method in class org.eclipse.jetty.io.ClientConnector
 
getExecutor() - Method in class org.eclipse.jetty.io.SelectorManager
 
getExecutor() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getExecutor() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getExecutor() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getExecutor() - Method in interface org.eclipse.jetty.server.Connector
 
getExecutor() - Method in class org.eclipse.jetty.util.SocketAddressResolver.Async
 
getExecutor() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
getExecutor() - Method in interface org.eclipse.jetty.websocket.api.WebSocketContainer
The Container provided Executor.
getExecutor() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getExecutor() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getExecutor() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getExecutor() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getExecutor() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
getExecutor() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getExecutor() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getExitCode() - Method in exception class org.eclipse.jetty.start.UsageException
 
getExpired(Set<String>) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
getExpired(Set<String>) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
getExpired(Set<String>) - Method in interface org.eclipse.jetty.server.session.SessionDataStore
Called periodically, this method should search the data store for sessions that have been expired for a 'reasonable' amount of time.
getExpiredSessionsStatement(Connection, String, String, long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getExpireNanoTime() - Method in class org.eclipse.jetty.client.HttpChannel
 
getExpireNanoTime() - Method in class org.eclipse.jetty.client.HttpExchange
 
getExpireNanoTime() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getExpireNanoTime() - Method in interface org.eclipse.jetty.io.CyclicTimeouts.Expirable
Returns the expiration time in nanoseconds.
getExpireNanoTime() - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
getExpires() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
getExpires() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getExpiry() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getExpiry() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
getExpiry() - Method in class org.eclipse.jetty.server.session.SessionData
 
getExpiryFromFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
getExpirySec() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
Expiry time for memached entries.
getExpirySec() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
getExpiryTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getExtendedId() - Method in class org.eclipse.jetty.server.session.Session
 
getExtendedId(HttpSession) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getExtendedId(String, HttpServletRequest) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Get the session ID with any worker ID.
getExtendedId(String, HttpServletRequest) - Method in interface org.eclipse.jetty.server.SessionIdManager
Get an extended id for a session.
getExtension() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
getExtension() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata.Snapshot
 
getExtension(String) - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
getExtensionRegistry() - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
getExtensionRegistry() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getExtensionRegistry() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getExtensions() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the list of WebSocket Extension Configurations for this Upgrade Request.
getExtensions() - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the list of extensions that should be used for the websocket.
getExtensions() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getExtensions() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getExtensions() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getExtensions() - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
getExtensions() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getExtensions() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
getExtensions() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getExtensions() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getExtensions() - Method in class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
getExtensions() - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
getExtensions() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getExtensions() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getExtensionStack() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getExtraClasspath() - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
 
getExtraClasspath() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getFactories(SslContextFactory.Server, ConnectionFactory...) - Static method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getFactory() - Static method in class org.eclipse.jetty.osgi.boot.utils.BundleClassLoaderHelperFactory
 
getFactory() - Static method in class org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelperFactory
 
getFactory(ServletContext) - Static method in class org.eclipse.jetty.websocket.server.internal.JettyServerFrameHandlerFactory
 
getFailure() - Method in class org.eclipse.jetty.client.api.Result
 
getFailure() - Method in class org.eclipse.jetty.http2.frames.FailureFrame
 
getFamily() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
getFamily() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getField(int) - Method in interface org.eclipse.jetty.http.HttpFields
Get a Field by index.
getField(int) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
getField(int) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Get a Field by index.
getField(Class<?>) - Method in class org.eclipse.jetty.servlet.listener.ELContextCleaner
Deprecated.
 
getField(String) - Method in interface org.eclipse.jetty.http.HttpFields
 
getField(String) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
getField(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
 
getField(HttpHeader) - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
getFieldCache() - Method in class org.eclipse.jetty.http.HttpParser
 
getFieldName() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getFieldNames() - Method in interface org.eclipse.jetty.http.HttpFields
Get enumeration of header _names.
getFieldNamesCollection() - Method in interface org.eclipse.jetty.http.HttpFields
Get Set of header names.
getFields() - Method in class org.eclipse.jetty.http.MetaData
 
getFields(String) - Method in interface org.eclipse.jetty.http.HttpFields
 
getFields(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple fields of the same header
getFieldType() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getFile() - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
getFile() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
Get the file
getFile() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
Get the file
getFile() - Method in class org.eclipse.jetty.start.TextFile
 
getFile() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
getFile() - Method in class org.eclipse.jetty.util.resource.JarResource
 
getFile() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getFile() - Method in class org.eclipse.jetty.util.resource.Resource
File representing the given resource.
getFile() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
getFile() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns an File representing the given resource or NULL if this is not possible.
getFileAsResource(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getFileAsResource(String, String) - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getFileInBundle(Bundle, String) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
Locate a file inside a bundle.
getFileInBundle(Bundle, String) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
Locate a file inside a bundle.
getFileMatcher() - Method in class org.eclipse.jetty.start.PathFinder
 
getFilename() - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
getFileName() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve the output file name of the request log.
getFilenameDateFormat() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve the file name date format string.
getFilenameFilter() - Method in class org.eclipse.jetty.util.Scanner
Deprecated.
getFilePath() - Method in class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
getFiles() - Method in class org.eclipse.jetty.start.Module
 
getFiles() - Method in class org.eclipse.jetty.start.StartArgs
 
getFileURL(URL) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
Only useful for equinox: on felix we get the file:// url already.
getFileURL(URL) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
Only useful for equinox: on felix we get the file:// url already.
getFillInterest() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getFilter() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
getFilter(ServletContext) - Static method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
Return the default WebSocketUpgradeFilter if present on the ServletContext.
getFilter(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getFilterChain(Request, String, ServletHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getFilterMappings() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getFilterName() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
getFilterRegistration(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getFilterRegistration(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getFilterRegistrations() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getFilterRegistrations() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getFilters() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getFilters() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getFirst() - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
getFirstRegisteredDecoder(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getFlags() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
Returns the raw value of the header flag bits.
getFlowControlStrategy() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getFlowControlStrategyFactory() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getFlowControlStrategyFactory() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getFlusher() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
getForcedHost() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForcedPath() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getForcedValue() - Method in class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
getFormatString() - Method in class org.eclipse.jetty.server.CustomRequestLog
Retrieve the format string.
getFormatString() - Method in class org.eclipse.jetty.util.DateCache
 
getFormEncodedMethods() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getForwardedCipherSuiteHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedForHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedHostHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedHttpsHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedPortAsAuthority() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedPortHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedProtoHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Get the forwardedProtoHeader.
getForwardedServerHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getForwardedSslSessionIdHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getFragment() - Method in interface org.eclipse.jetty.http.HttpURI
 
getFragment() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getFragment() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getFragmentDescriptor(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
getFragmentDescriptor(Resource) - Method in class org.eclipse.jetty.webapp.MetaData
 
getFragmentDescriptorForJar(Resource) - Method in class org.eclipse.jetty.webapp.MetaData
Get the web-fragment.xml related to a jar
getFragments(Bundle) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
Helper to access the PackageAdmin and return the fragments hosted by a bundle.
getFragmentsAndRequiredBundles(Bundle) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
Returns the fragments and the required-bundles of a bundle.
getFrameBytesGenerated() - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
getFrameFlusher() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getFrameHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getFrameHandler() - Method in class org.eclipse.jetty.websocket.client.impl.JettyClientUpgradeRequest
 
getFrameHandler() - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
getFrameHandler() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaClientUpgradeRequest
 
getFrameHandler() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
getFrameHandlerFactory() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
getFrameHandlerFactory() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getFrameHandlerFactory() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
getFrameQueueSize() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
getFrames() - Method in class org.eclipse.jetty.http2.IStream.FrameList
 
getFrameType() - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
 
getFrameType() - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
getFrameType() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
getFrameType() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getFrameType() - Method in class org.eclipse.jetty.http3.frames.Frame
 
getFrom() - Method in class org.eclipse.jetty.deploy.graph.Edge
 
getGenerator() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getGenerator() - Method in class org.eclipse.jetty.server.HttpConnection
 
getGenerator() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getGracefulShutdownWaitsForRequests() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getGracePeriodSec() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
getGracePeriodSec() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStoreFactory
 
getGroup() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
The spec group.
getGroup() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getGroup() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getGroup() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getGroupId() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getGroups(Subject) - Method in class org.eclipse.jetty.jaas.JAASLoginService
Get all of the groups for the user.
getGzipEquivalentFileExtensions() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getGzipEquivalentFileExtensions() - Method in class org.eclipse.jetty.server.ResourceService
 
getHandler() - Method in class org.eclipse.jetty.http.HttpParser
 
getHandler() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getHandler() - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
getHandler() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
getHandler() - Method in class org.eclipse.jetty.server.MultiPartParser
 
getHandler() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getHandlers() - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
getHandlers() - Method in class org.eclipse.jetty.server.handler.HandlerCollection.Handlers
 
getHandlers() - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
getHandlers() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
getHandlers() - Method in interface org.eclipse.jetty.server.HandlerContainer
 
getHandlerType() - Method in class org.eclipse.jetty.websocket.jakarta.common.RegisteredMessageHandler
 
getHandshaker() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
getHeader() - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getHeader() - Method in class org.eclipse.jetty.http.HttpField
 
getHeader() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
getHeader(String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormRequest
 
getHeader(String) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getHeader(String) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getHeader(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getHeader(String) - Method in class org.eclipse.jetty.server.Request
 
getHeader(String) - Method in class org.eclipse.jetty.server.Response
 
getHeader(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getHeader(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
getHeader(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get a specific Header value from Upgrade Request
getHeader(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get a header value
getHeader(String) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHeader(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getHeaderCacheSize() - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
getHeaderCacheSize() - Method in class org.eclipse.jetty.http.HttpParser
 
getHeaderCacheSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getHeaderInfo(String) - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getHeaderInt(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the specific Header value, as an int, from the Upgrade Request.
getHeaderInt(String) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHeaderInt(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHeaderInt(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHeaderInt(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHeaderLength() - Method in class org.eclipse.jetty.http.HttpParser
 
getHeaderName() - Method in class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
getHeaderNames() - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormRequest
 
getHeaderNames() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getHeaderNames() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getHeaderNames() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getHeaderNames() - Method in class org.eclipse.jetty.server.Request
 
getHeaderNames() - Method in class org.eclipse.jetty.server.Response
 
getHeaderNames() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getHeaderNames() - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
getHeaderNames() - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the header names
getHeaderNames() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getHeaderNames() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getHeaderNames() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getHeaderNames() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getHeaderNames() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getHeaders() - Method in interface org.eclipse.jetty.client.api.Request
 
getHeaders() - Method in interface org.eclipse.jetty.client.api.Response
Returns the headers of this response.
getHeaders() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getHeaders() - Method in class org.eclipse.jetty.client.HttpRequest
 
getHeaders() - Method in class org.eclipse.jetty.client.HttpResponse
 
getHeaders() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the headers as a Map of keys to value lists.
getHeaders() - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the headers map
getHeaders() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHeaders() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHeaders() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getHeaders() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getHeaders() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getHeaders() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeResponse
 
getHeaders() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHeaders() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getHeaders(String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getHeaders(String) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getHeaders(String) - Method in class org.eclipse.jetty.server.Request
 
getHeaders(String) - Method in class org.eclipse.jetty.server.Response
 
getHeaders(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getHeaders(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
getHeaders(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the specific header values (for multi-value headers)
getHeaders(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the multi-value header value
getHeaders(String) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHeaders(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getHeadersMap() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHeadersMap() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getHeaderValue() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
getHeapByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getHeapByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getHeapByteBufferCount() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getHeapMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getHeapMemory() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getHeapMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getHeapMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getHeapMemory() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getHeldClass() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getHelper() - Method in class org.eclipse.jetty.osgi.boot.utils.BundleClassLoaderHelperFactory
 
getHelper() - Method in class org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelperFactory
 
getHexDigit() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
getHi() - Method in class org.eclipse.jetty.util.AtomicBiInteger
 
getHi(long) - Static method in class org.eclipse.jetty.util.AtomicBiInteger
Gets a hi value from the given encoded value.
getHideStacks(String) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
 
getHitList() - Method in class org.eclipse.jetty.start.PathFinder
 
getHits() - Method in class org.eclipse.jetty.start.PathFinder
 
getHolderEntry(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
getHome() - Method in class org.eclipse.jetty.start.BaseHome
 
getHomePath() - Method in class org.eclipse.jetty.start.BaseHome
 
getHomePath() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getHost() - Method in interface org.eclipse.jetty.client.api.Destination
 
getHost() - Method in interface org.eclipse.jetty.client.api.Request
 
getHost() - Method in class org.eclipse.jetty.client.HttpDestination
 
getHost() - Method in class org.eclipse.jetty.client.HttpRequest
 
getHost() - Method in class org.eclipse.jetty.client.Origin.Address
 
getHost() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getHost() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getHost() - Method in class org.eclipse.jetty.http.HostPortHttpField
Get the host.
getHost() - Method in interface org.eclipse.jetty.http.HttpURI
 
getHost() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getHost() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getHost() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getHost() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
getHost() - Method in interface org.eclipse.jetty.server.NetworkConnector
 
getHost() - Method in class org.eclipse.jetty.util.HostPort
Get the host.
getHost() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
The host of the Upgrade Request URI
getHost() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHost() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHost() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHost() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHostField() - Method in class org.eclipse.jetty.client.HttpDestination
 
getHostHeader() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getHostHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getHostName() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
getHostnameVerifier() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getHostPort() - Method in class org.eclipse.jetty.http.HostPortHttpField
 
getHosts() - Method in class org.eclipse.jetty.util.ssl.X509
 
getHpackContext() - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
getHpackContext() - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
getHpackDecoder() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getHpackEncoder() - Method in class org.eclipse.jetty.http2.generator.Generator
 
getHTTP2Client() - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
getHTTP3Client() - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
getHTTP3Configuration() - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
getHTTP3Configuration() - Method in class org.eclipse.jetty.http3.server.AbstractHTTP3ServerConnectionFactory
 
getHttpChannel() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getHttpChannel() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
getHttpChannel() - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
getHttpChannel() - Method in class org.eclipse.jetty.client.HttpReceiver
 
getHttpChannel() - Method in class org.eclipse.jetty.client.HttpSender
 
getHttpChannel() - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
getHttpChannel() - Method in class org.eclipse.jetty.fcgi.client.http.HttpSenderOverFCGI
 
getHttpChannel() - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
getHttpChannel() - Method in class org.eclipse.jetty.http2.client.http.HttpSenderOverHTTP2
 
getHttpChannel() - Method in class org.eclipse.jetty.server.AsyncContextState
 
getHttpChannel() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getHttpChannel() - Method in class org.eclipse.jetty.server.HttpConnection
 
getHttpChannel() - Method in class org.eclipse.jetty.server.HttpOutput
 
getHttpChannel() - Method in class org.eclipse.jetty.server.Request
 
getHttpChannel() - Method in class org.eclipse.jetty.server.Response
 
getHttpChannelListeners() - Method in class org.eclipse.jetty.server.AbstractConnector
Get the HttpChannel.Listeners added to the connector as a single combined Listener.
getHttpChannels() - Method in class org.eclipse.jetty.client.HttpConnection
 
getHttpChannels() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
getHttpChannelState() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getHttpChannelState() - Method in class org.eclipse.jetty.server.AsyncContextState
 
getHttpChannelState() - Method in class org.eclipse.jetty.server.Request
 
getHttpClient() - Method in class org.eclipse.jetty.client.AbstractHttpClientTransport
 
getHttpClient() - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getHttpClient() - Method in class org.eclipse.jetty.client.HttpConnection
 
getHttpClient() - Method in class org.eclipse.jetty.client.HttpDestination
 
getHttpClient() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getHttpClient() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getHttpClient() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getHttpClient() - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
getHttpClient() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
getHttpCompliance() - Method in class org.eclipse.jetty.client.HttpClient
Gets the http compliance mode for parsing http responses.
getHttpCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getHttpConfiguration() - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
getHttpConfiguration() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getHttpConfiguration() - Method in class org.eclipse.jetty.http3.server.AbstractHTTP3ServerConnectionFactory
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.HttpChannel
 
getHttpConfiguration() - Method in interface org.eclipse.jetty.server.HttpConfiguration.ConnectionFactory
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.HttpConnection
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
getHttpConnection() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getHttpConnection() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getHttpContext() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getHttpContext() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getHttpContext() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getHttpCookie() - Method in class org.eclipse.jetty.http.HttpCookie.SetCookieHttpField
 
getHttpDestination() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getHttpDestination() - Method in class org.eclipse.jetty.client.HttpChannel
 
getHttpDestination() - Method in class org.eclipse.jetty.client.HttpConnection
 
getHttpDestination() - Method in class org.eclipse.jetty.client.HttpExchange
 
getHttpDestination() - Method in class org.eclipse.jetty.client.HttpReceiver
 
getHttpDestination() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
getHttpExchange() - Method in class org.eclipse.jetty.client.HttpChannel
 
getHttpExchange() - Method in class org.eclipse.jetty.client.HttpReceiver
 
getHttpExchange() - Method in class org.eclipse.jetty.client.HttpSender
 
getHttpExchanges() - Method in class org.eclipse.jetty.client.HttpDestination
 
getHttpField() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.Entry
 
getHttpFields() - Method in class org.eclipse.jetty.server.Request
 
getHttpFields() - Method in class org.eclipse.jetty.server.Response
 
getHttpHandler() - Method in class org.eclipse.jetty.http.spi.HttpSpiContextHandler
 
getHttpInput() - Method in class org.eclipse.jetty.server.Request
 
getHttpOnly() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getHttpOutput() - Method in class org.eclipse.jetty.server.Response
 
getHttpParser() - Method in class org.eclipse.jetty.http.HttpTester.Input
 
getHttpReceiver() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getHttpReceiver() - Method in class org.eclipse.jetty.client.HttpChannel
 
getHttpReceiver() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
getHttpReceiver() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getHttpSender() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getHttpSender() - Method in class org.eclipse.jetty.client.HttpChannel
 
getHttpSender() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
getHttpSender() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getHttpServletMapping() - Method in class org.eclipse.jetty.server.Request
 
getHttpServletRequest() - Method in interface org.eclipse.jetty.server.Authentication.Wrapped
 
getHttpServletRequest() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getHttpServletRequest() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHttpServletRequest() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getHttpServletRequest() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getHttpServletResponse() - Method in interface org.eclipse.jetty.server.Authentication.Wrapped
 
getHttpSession() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getHttpSession(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Returns the HttpSession with the given session id
getHttpTransport() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
getHttpTransport() - Method in class org.eclipse.jetty.server.HttpChannel
 
getHttpURI() - Method in class org.eclipse.jetty.server.Request
 
getHttpVersion() - Method in class org.eclipse.jetty.http.Http1FieldPreEncoder
 
getHttpVersion() - Method in interface org.eclipse.jetty.http.HttpFieldPreEncoder
The major version this encoder is for.
getHttpVersion() - Method in class org.eclipse.jetty.http.MetaData
 
getHttpVersion() - Method in class org.eclipse.jetty.http2.hpack.HpackFieldPreEncoder
 
getHttpVersion() - Method in class org.eclipse.jetty.http3.qpack.QpackFieldPreEncoder
 
getHttpVersion() - Method in class org.eclipse.jetty.server.Request
 
getHttpVersion() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
The HTTP version used for this Upgrade Request
getHttpVersion() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getHttpVersion() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getHttpVersion() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getHttpVersion() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getId() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getId() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
getId() - Method in interface org.eclipse.jetty.http2.api.Stream
 
getId() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getId() - Method in interface org.eclipse.jetty.http3.api.Stream
 
getId() - Method in class org.eclipse.jetty.server.session.Session
 
getId() - Method in class org.eclipse.jetty.server.session.SessionData
 
getId() - Method in exception class org.eclipse.jetty.server.session.UnreadableSessionDataException
 
getId() - Method in exception class org.eclipse.jetty.server.session.UnwriteableSessionDataException
 
getId() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getId() - Method in interface org.eclipse.jetty.start.config.ConfigSource
The identifier for this source.
getId() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getId() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getId(HttpSession) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getId(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Get the session ID without any worker ID.
getId(String) - Method in interface org.eclipse.jetty.server.SessionIdManager
Get just the session id from an id that includes the worker name as a suffix.
getIdColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getIdentityService() - Method in class org.eclipse.jetty.jaas.JAASLoginService
Get the identityService.
getIdentityService() - Method in class org.eclipse.jetty.security.AbstractLoginService
 
getIdentityService() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
 
getIdentityService() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
getIdentityService() - Method in class org.eclipse.jetty.security.EmptyLoginService
 
getIdentityService() - Method in interface org.eclipse.jetty.security.LoginService
Get the IdentityService associated with this Login Service.
getIdentityService() - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
getIdentityService() - Method in class org.eclipse.jetty.security.SecurityHandler
Get the identityService.
getIdentityService() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getIdentityService() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getIdFromFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
getIdle() - Method in class org.eclipse.jetty.client.HttpDestination
 
getIdleConnectionCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getIdleCount() - Method in class org.eclipse.jetty.util.Pool
 
getIdleFor() - Method in class org.eclipse.jetty.io.IdleTimeout
 
getIdleThreads() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
getIdleThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getIdleThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The number of idle threads, but without including reserved threads.
getIdleThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPool
 
getIdleTimeout() - Method in interface org.eclipse.jetty.client.api.Request
 
getIdleTimeout() - Method in class org.eclipse.jetty.client.HttpClient
 
getIdleTimeout() - Method in class org.eclipse.jetty.client.HttpRequest
 
getIdleTimeout() - Method in interface org.eclipse.jetty.http2.api.Stream
 
getIdleTimeout() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getIdleTimeout() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getIdleTimeout() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getIdleTimeout() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
getIdleTimeout() - Method in class org.eclipse.jetty.io.ClientConnector
 
getIdleTimeout() - Method in interface org.eclipse.jetty.io.EndPoint
Get the max idle time in ms.
getIdleTimeout() - Method in class org.eclipse.jetty.io.IdleTimeout
 
getIdleTimeout() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getIdleTimeout() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getIdleTimeout() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getIdleTimeout() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getIdleTimeout() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getIdleTimeout() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getIdleTimeout() - Method in interface org.eclipse.jetty.server.Connector
 
getIdleTimeout() - Method in class org.eclipse.jetty.server.HttpChannel
Get the idle timeout.
getIdleTimeout() - Method in class org.eclipse.jetty.server.HttpConfiguration
The max idle time is applied to an HTTP request for IO operations and delayed dispatch.
getIdleTimeout() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getIdleTimeout() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getIdleTimeout() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getIdleTimeout() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The duration that a websocket may be idle before being closed by the implementation
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getIdleTimeout() - Method in interface org.eclipse.jetty.websocket.core.Configuration
Get the Idle Timeout
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
getIdleTimeout() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getIdleTimeoutMs() - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
getIdleTimeoutMs() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
getIdMap() - Method in class org.eclipse.jetty.xml.XmlConfiguration
Get the map of ID String to Objects that is used to hold and lookup any objects by ID.
getIdWithContext(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Get the session id with its context.
getIdWithContextAndExpiry(SessionData) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Get the session id with its context and its expiry time
getIdWithContextFromFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Extract the session id and context from the filename
getIgnorePaths() - Method in class org.eclipse.jetty.server.CustomRequestLog
Retrieve the request paths that will not be logged.
getImpl() - Method in class org.eclipse.jetty.util.Uptime
 
getImplementationConfiguration() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getIncludeCipherSuites() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getIncludeCodas() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getIncluded() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
getIncludedAddresses() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getIncludedInflationPaths() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of included Path Specs for request inflation.
getIncludedMethodList() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the included filter list of HTTP methods in CSV format
getIncludedMethods() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of included HTTP Methods
getIncludedMimeTypes() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of included MIME types
getIncludedPaths() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the current filter list of included Path Specs
getIncludePreludes() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getIncludeProtocols() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getInclusions() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
getIndexOf(String) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
Get the order index of the given classname
getIndirectBuffer() - Method in interface org.eclipse.jetty.http.HttpContent
 
getIndirectBuffer() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getIndirectBuffer() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getIndirectBuffer() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getIndirectBuffer(Resource) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getInferredEncodings() - Static method in class org.eclipse.jetty.http.MimeTypes
Access a mutable map of mime type to the charset inferred from that content type.
getInfinispanIdleTimeoutSec() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
getInfinispanIdleTimeoutSec() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
getInflateBufferSize() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the size (in bytes) of the Inflater buffer used to inflate compressed requests.
getInflater() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
getInflaterPool() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the InflaterPool being used.
getInflaterPool() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getInflaterPool() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getInflaterPoolCapacity() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Deprecated.
for custom InflaterPool settings use GzipHandler.setInflaterPool(InflaterPool).
getInfo() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
getInfo() - Method in class org.eclipse.jetty.http.HttpTester.Request
 
getInfo() - Method in class org.eclipse.jetty.http.HttpTester.Response
 
getIniTemplate() - Method in class org.eclipse.jetty.start.Module
 
getInitialContext(Hashtable) - Method in class org.eclipse.jetty.jndi.InitialContextFactory
Get Context that has access to default Namespace.
getInitializerOrdering(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Jetty-specific extension that allows an ordering to be applied across ALL ServletContainerInitializers.
getInitialSessionRecvWindow() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getInitialSessionRecvWindow() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getInitialSessionRecvWindow() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getInitialStreamRecvWindow() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
getInitialStreamRecvWindow() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getInitialStreamRecvWindow() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getInitialStreamSendWindow() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
getInitOrder() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getInitOrder() - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
getInitParameter(String) - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
Get a SecurityHandler init parameter
getInitParameter(String) - Method in class org.eclipse.jetty.security.SecurityHandler
 
getInitParameter(String) - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getInitParameter(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getInitParameter(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getInitParameter(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.Holder
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.Holder.HolderConfig
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getInitParameter(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getInitParameterNames() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
Get a SecurityHandler init parameter names
getInitParameterNames() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getInitParameterNames() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getInitParameterNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getInitParameterNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getInitParameterNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getInitParameterNames() - Method in class org.eclipse.jetty.servlet.Holder
 
getInitParameterNames() - Method in class org.eclipse.jetty.servlet.Holder.HolderConfig
 
getInitParameterNames() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getInitParameters() - Method in class org.eclipse.jetty.servlet.Holder
 
getInitParameters() - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
getInitParams() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getInitParams() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getInjection(String, Class<?>, Field) - Method in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
getInjection(String, Class<?>, Method, Class<?>) - Method in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
getInjections(String) - Method in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
getInputBufferSize() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getInputBufferSize() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getInputBufferSize() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getInputBufferSize() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
getInputBufferSize() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getInputBufferSize() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The input (read from network layer) buffer size.
getInputBufferSize() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getInputBufferSize() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getInputBufferSize() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getInputBufferSize() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
getInputBufferSize() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getInputBufferSize() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getInputFilePrefix() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
getInputState() - Method in class org.eclipse.jetty.server.Request
 
getInputStream() - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
Returns an InputStream providing the response content bytes.
getInputStream() - Method in interface org.eclipse.jetty.http.HttpContent
 
getInputStream() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getInputStream() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getInputStream() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer.Source
 
getInputStream() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getInputStream() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getInputStream() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getInputStream() - Method in class org.eclipse.jetty.server.Request
 
getInputStream() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
getInputStream() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
getInputStream() - Method in class org.eclipse.jetty.util.resource.JarResource
 
getInputStream() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getInputStream() - Method in class org.eclipse.jetty.util.resource.Resource
Input stream to the resource
getInputStream() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
getInputStream() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns an input stream to the resource.
getInputStream() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getInputStream(boolean) - Method in class org.eclipse.jetty.util.resource.URLResource
Returns an input stream to the resource, optionally nulling out the underlying url connection.
getInsertSessionStatementAsString() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getInstalledExtensions() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
getInstance() - Static method in class org.eclipse.jetty.osgi.boot.JettyBootstrapActivator
 
getInstance() - Static method in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
getInstance() - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
getInstance() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getInstance() - Static method in class org.eclipse.jetty.start.StartLog
 
getInstance() - Static method in class org.eclipse.jetty.util.thread.ShutdownThread
Returns the instance of the singleton
getInstance() - Static method in class org.eclipse.jetty.util.Uptime
 
getInstance() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
getInstance(String) - Static method in class org.eclipse.jetty.apache.jsp.JuliLog
 
getInstanceFor(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
getInt(String, int) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
 
getIntegersPerCacheLine() - Static method in class org.eclipse.jetty.util.MemoryUtils
 
getInterceptor() - Method in interface org.eclipse.jetty.server.ContentProducer
getInterceptor() - Method in class org.eclipse.jetty.server.HttpInput
 
getInterceptor() - Method in class org.eclipse.jetty.server.HttpOutput
 
getInterestedTypes() - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
getInterfaces() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getInternalParameters() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getIntervalSec() - Method in class org.eclipse.jetty.server.session.HouseKeeper
Get the period between scavenge cycles.
getIntHeader(String) - Method in class org.eclipse.jetty.server.Request
 
getIntHeader(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getIntHeader(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getIntValue() - Method in class org.eclipse.jetty.http.HttpField
 
getIntValue() - Method in class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
getIntValue() - Method in class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
getInUseCount() - Method in class org.eclipse.jetty.util.Pool
 
getInvocationType() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
getInvocationType() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
getInvocationType() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
getInvocationType() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
getInvocationType() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getInvocationType() - Method in class org.eclipse.jetty.server.HttpInput.Content
 
getInvocationType() - Method in class org.eclipse.jetty.server.HttpInput.WrappingContent
 
getInvocationType() - Method in class org.eclipse.jetty.util.Callback.Completable
 
getInvocationType() - Method in class org.eclipse.jetty.util.Callback.Completing
 
getInvocationType() - Method in class org.eclipse.jetty.util.Callback.Nested
 
getInvocationType() - Method in class org.eclipse.jetty.util.IteratingNestedCallback
 
getInvocationType() - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
 
getInvocationType() - Method in interface org.eclipse.jetty.util.thread.Invocable
 
getInvocationType() - Method in class org.eclipse.jetty.util.thread.Invocable.ReadyTask
 
getInvocationType(Object) - Static method in interface org.eclipse.jetty.util.thread.Invocable
Get the invocation type of an Object.
getIssuer() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getIsXml() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getJarFile() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
getJarFor(ServletContainerInitializer) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
getJarFor(ServletContainerInitializer) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
 
getJarForFragmentName(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
getJarSource(String) - Static method in class org.eclipse.jetty.util.URIUtil
 
getJarSource(URI) - Static method in class org.eclipse.jetty.util.URIUtil
 
getJavaClass() - Method in class org.eclipse.jetty.session.infinispan.SessionDataMarshaller
 
getJettyContextHandler() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getJettyEnvXml() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getJettyLogger(String) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
Get a JettyLogger instance, creating if not yet existing.
getJettyLoggerFactory() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
getJettyXml() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getJettyXml() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getJettyXml() - Method in class org.eclipse.jetty.deploy.bindings.GlobalWebappConfigBinding
 
getJndiName() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getJndiName() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Get the unique name of the object relative to the scope
getJndiName() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getJndiNameInScope() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Get the name of the object, fully qualified with the scope
getJPMS() - Method in class org.eclipse.jetty.start.Module
 
getJspConfigDescriptor() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getJspConfigDescriptor() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getJspConfigDescriptor() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getJspPackagePrefix() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getJspPropertyGroups() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
getJvmArgs() - Method in class org.eclipse.jetty.start.Module
 
getJvmArgs() - Method in class org.eclipse.jetty.start.StartArgs
Deprecated.
use StartArgs.getJvmArgSources() instead, as it will return source references with each arg.
getJvmArgSources() - Method in class org.eclipse.jetty.start.StartArgs
Return ordered Map of JVM arguments to Source (locations)
getKey() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService.DBUserPrincipal
 
getKey() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getKey() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
getKey() - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Negotiation
 
getKeyManagerFactoryAlgorithm() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyManagerFactoryInstance() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyManagerPassword() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyManagers(KeyStore) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyManagers(KeyStore) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
getKeys() - Method in class org.eclipse.jetty.server.session.SessionData
 
getKeyStore() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyStore(String, String, String, String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Loads keystore using an input stream or a file path in the same order of precedence.
getKeyStore(Resource, String, String, String) - Static method in class org.eclipse.jetty.util.security.CertificateUtils
 
getKeyStorePassword() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyStorePath() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyStoreProvider() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyStoreResource() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyStoreType() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getKeyTabPath() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
getKind() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getKnown() - Method in interface org.eclipse.jetty.http.ComplianceViolation.Mode
 
getKnown() - Method in class org.eclipse.jetty.http.CookieCompliance
 
getKnown() - Method in class org.eclipse.jetty.http.HttpCompliance
 
getKnown() - Method in class org.eclipse.jetty.http.UriCompliance
 
getKnown() - Static method in class org.eclipse.jetty.webapp.Configurations
 
getKnownAuthenticatorFactories() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getKnownMimeTypes() - Static method in class org.eclipse.jetty.http.MimeTypes
 
getLast() - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
getLastAccessed() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getLastAccessed() - Method in class org.eclipse.jetty.server.session.SessionData
 
getLastAccessedTime() - Method in class org.eclipse.jetty.server.session.Session
 
getLastAccessTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getLastId() - Method in class org.eclipse.jetty.http3.frames.GoAwayFrame
 
getLastModified() - Method in interface org.eclipse.jetty.http.HttpContent
 
getLastModified() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getLastModified() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getLastModified() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getLastModifiedValue() - Method in interface org.eclipse.jetty.http.HttpContent
 
getLastModifiedValue() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getLastModifiedValue() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getLastModifiedValue() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getLastNode() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getLastNode() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
getLastNode() - Method in class org.eclipse.jetty.server.session.SessionData
 
getLastNodeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getLastRemoteStreamId() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getLastSaved() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getLastSaved() - Method in class org.eclipse.jetty.server.session.SessionData
 
getLastSavedTimeColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getLastStreamId() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
getLastUpdate() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
getLastUpdated() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getLazyMatches(String) - Method in class org.eclipse.jetty.util.HostMap
Retrieve a lazy list of map entries associated with specified hostname by taking into account the domain suffix matches.
getLeakedAcquires() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
getLeakedReleases() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
getLeakedRemoves() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
getLeakedResources() - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
getLeasedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The fundamental value that represents the number of threads that are leased to internal components, and therefore cannot be used to execute transient jobs.
getLeasedThreads() - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
 
getLeftMost(String) - Static method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getLegacyMajor() - Method in class org.eclipse.jetty.start.Version
 
getLength() - Method in interface org.eclipse.jetty.client.api.ContentProvider
Deprecated.
 
getLength() - Method in interface org.eclipse.jetty.client.api.Request.Content
 
getLength() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
getLength() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
getLength() - Method in class org.eclipse.jetty.client.util.ByteBufferContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.ByteBufferRequestContent
 
getLength() - Method in class org.eclipse.jetty.client.util.BytesContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.BytesRequestContent
 
getLength() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
 
getLength() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
getLength() - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
getLength() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
getLength() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Get the amount of bytes which have been accumulated.
getLength() - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
getLength() - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyInputStreamRequestContent
 
getLength() - Method in class org.eclipse.jetty.util.SearchPattern
 
getLength(String) - Static method in class org.eclipse.jetty.util.StringUtil
Get the length of a string where a null string is length 0.
getLevel() - Method in class org.eclipse.jetty.logging.JettyLogger
 
getLevel(String) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
Returns the Logging Level for the provided log name.
getLibraries() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getLibrariesConfiguration() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getLibs() - Method in class org.eclipse.jetty.start.Module
 
getLicense() - Method in class org.eclipse.jetty.start.Module
 
getLifeCycle() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getLifeCycleBindings() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getLifecyleNode() - Method in class org.eclipse.jetty.deploy.DeploymentManager.AppEntry
 
getLine() - Method in class org.eclipse.jetty.start.RawArgs.Entry
 
getLineMatches(Pattern) - Method in class org.eclipse.jetty.start.TextFile
 
getLines() - Method in class org.eclipse.jetty.start.TextFile
 
getLineTerminations() - Method in class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
getLink() - Method in class org.eclipse.jetty.plus.jndi.Link
 
getList(Object) - Static method in class org.eclipse.jetty.util.LazyList
Get the real List from a LazyList.
getList(Object, boolean) - Static method in class org.eclipse.jetty.util.LazyList
Get the real List from a LazyList.
getListener() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getListener() - Method in interface org.eclipse.jetty.http2.IStream
 
getListener() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getListener() - Method in class org.eclipse.jetty.http2.parser.ServerParser
 
getListener() - Method in class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
getListener() - Method in class org.eclipse.jetty.servlet.ListenerHolder
 
getListeners() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getListeners() - Method in class org.eclipse.jetty.util.PathWatcher
Get an iterator over the listeners.
getListeners(Class<T>) - Method in interface org.eclipse.jetty.client.api.Response
 
getListeners(Class<T>) - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getListeners(Class<T>) - Method in class org.eclipse.jetty.client.HttpResponse
 
getListHTML(String, boolean, String) - Method in class org.eclipse.jetty.util.resource.Resource
Get the resource list as a HTML directory listing.
getListModules() - Method in class org.eclipse.jetty.start.StartArgs
 
getLo() - Method in class org.eclipse.jetty.util.AtomicBiInteger
 
getLo(long) - Static method in class org.eclipse.jetty.util.AtomicBiInteger
Gets a lo value from the given encoded value.
getLoadStatement(Connection, String, SessionContext) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getLocalAddr() - Method in class org.eclipse.jetty.server.Request
 
getLocalAddr() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getLocalAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getLocalAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getLocalAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getLocalAddress() - Method in interface org.eclipse.jetty.http2.api.Session
Deprecated.
getLocalAddress() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getLocalAddress() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getLocalAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getLocalAddress() - Method in interface org.eclipse.jetty.io.EndPoint
Deprecated.
getLocalAddress() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getLocalAddress() - Method in class org.eclipse.jetty.server.HttpChannel
 
getLocalAddress() - Method in class org.eclipse.jetty.server.HttpConfiguration
Get the SocketAddress override to be reported as the local address of all connections
getLocalAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getLocalAddress() - Method in interface org.eclipse.jetty.websocket.api.Session
The Local Socket Address for the active Session
getLocalAddress() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getLocalAddress() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getLocalAddress() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The Local Socket Address for the connection
getLocalAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
getLocalAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getLocale() - Method in class org.eclipse.jetty.server.Request
 
getLocale() - Method in class org.eclipse.jetty.server.Response
 
getLocale() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getLocale() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getLocale() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getLocale() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getLocale() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getLocaleEncoding(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getLocaleEncoding(Locale) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get the character encoding for a locale.
getLocaleEncodings() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get all of the locale encodings
getLocales() - Method in class org.eclipse.jetty.server.Request
 
getLocales() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getLocales() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getLocales() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getLocales() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getLocalName() - Method in class org.eclipse.jetty.server.HttpChannel
Return the local name of the connected channel.
getLocalName() - Method in class org.eclipse.jetty.server.Request
 
getLocalName() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getLocalPort() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
getLocalPort() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
getLocalPort() - Method in class org.eclipse.jetty.server.HttpChannel
Return the Local Port of the connected channel.
getLocalPort() - Method in interface org.eclipse.jetty.server.NetworkConnector
 
getLocalPort() - Method in class org.eclipse.jetty.server.Request
 
getLocalPort() - Method in class org.eclipse.jetty.server.ServerConnector
 
getLocalPort() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.client.api.Connection
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.http2.api.Session
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.http3.api.Session
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.io.EndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getLocalURL(URL) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
Only useful for equinox: on felix we get the file:// or jar:// url already.
getLocalURL(URL) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
Only useful for equinox: on felix we get the file:// or jar:// url already.
getLocationOfClass(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
Attempt to find the Location of a loaded Class.
getLock() - Method in interface org.eclipse.jetty.client.Synchronizable
 
getLock() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
getLog() - Static method in class org.eclipse.jetty.util.log.Log
Deprecated.
getLogger() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getLogger(Class<?>) - Static method in class org.eclipse.jetty.util.log.Log
Deprecated.
getLogger(String) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
Main interface for ILoggerFactory
getLogger(String) - Static method in class org.eclipse.jetty.util.log.Log
Deprecated.
getLogger(String) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
 
getLoggerCount() - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getLoggerFactory() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
getLoggerLevel(String) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getLoggerName() - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
getLoggerNames() - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getLoginService() - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
getLoginService() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
 
getLoginService() - Method in class org.eclipse.jetty.security.DefaultAuthenticatorFactory
 
getLoginService() - Method in class org.eclipse.jetty.security.openid.OpenIdAuthConfiguration
 
getLoginService() - Method in class org.eclipse.jetty.security.SecurityHandler
Get the loginService.
getLoginService() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getLoginServices() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getLoginServices() - Method in class org.eclipse.jetty.ant.types.LoginServices
 
getLongContentLength() - Method in class org.eclipse.jetty.server.Response
 
getLongField(String) - Method in interface org.eclipse.jetty.http.HttpFields
Get a header as an long value.
getLongField(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
Get a header as an long value.
getLongsPerCacheLine() - Static method in class org.eclipse.jetty.util.MemoryUtils
 
getLongType() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getLongValue() - Method in class org.eclipse.jetty.http.HttpField
 
getLongValue() - Method in class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
getLongValue() - Method in class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
getLowerCaseName() - Method in class org.eclipse.jetty.http.HttpField
 
getLowResourceChecks() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getLowResourcesIdleTimeout() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getLowResourcesReasons() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getLowResourcesStarted() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getLowThreadsThreshold() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getMainArgs(Set<String>) - Method in class org.eclipse.jetty.start.StartArgs
 
getMainClassname() - Method in class org.eclipse.jetty.start.StartArgs
 
getMajor() - Method in class org.eclipse.jetty.start.Version
 
getMajor() - Method in class org.eclipse.jetty.util.JavaVersion
Returns the major number version, such as 1 for JDK 1.8.0_92 and 9 for JDK 9.2.4.
getMajorVersion() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getMajorVersion() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
getManagedObject() - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
getManagedServerName() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
getManifest(Class<?>) - Static method in class org.eclipse.jetty.util.ManifestUtils
 
getManifestHeaderValue(String, String, Dictionary<String, String>) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
Get the value of a manifest header.
getManifestHeaderValue(String, Dictionary<String, String>) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
Get the value of a manifest header.
getMap() - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
getMapColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getMapFactory() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
getMappedBuffer(Resource) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getMappedServlet(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
getMapping(String) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Returns the creator for the given path spec.
getMappingMatch() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getMappingName() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getMappings() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
getMappings() - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
getMappings(ServletContext) - Static method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
getMarkerFactory() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
getMask() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
getMask() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
getMask() - Method in class org.eclipse.jetty.websocket.core.Frame
 
getMatch(String) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
Deprecated, for removal: This API element is subject to removal in a future version.
getMatched(String) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
Find the best single match for a path.
getMatchedList(String) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
Return a list of MatchedResource matches for the specified path.
getMatchedNegotiator(String, Consumer<PathSpec>) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
Get the matching MappedResource for the provided target.
getMatchedPath() - Method in class org.eclipse.jetty.http.pathmap.MatchedResource
 
getMatchedServlet(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
ServletHolder matching target path.
getMatcher(String) - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getMatcher(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getMatcher(String) - Static method in class org.eclipse.jetty.start.PathMatchers
 
getMatches(String) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
Return a list of MappedResource matches for the specified path.
getMatchValue() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getMavenBaseUri() - Method in class org.eclipse.jetty.start.StartArgs
 
getMavenLocalRepoDir() - Method in class org.eclipse.jetty.start.StartArgs
 
getMax() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
 
getMax() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getMax() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getMaxAge() - Method in class org.eclipse.jetty.http.HttpCookie
 
getMaxAge() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
getMaxAvailableThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The maximum number of threads available to run transient jobs.
getMaxBidirectionalRemoteStreams() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getMaxBinaryMessageBufferSize() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getMaxBinaryMessageSize() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
Get the maximum size of a binary message during parsing.
getMaxBinaryMessageSize() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getMaxBinaryMessageSize() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getMaxBinaryMessageSize() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getMaxBinaryMessageSize() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
getMaxBinaryMessageSize() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getMaxBinaryMessageSize() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getMaxBlockedStreams() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getMaxBlockedStreams() - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
getMaxBlockedStreams() - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
getMaxBucketSize() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMaxBucketSize() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getMaxBucketSize() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getMaxBucketSize() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getMaxBusyThreads() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getMaxCachedFiles() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getMaxCachedFileSize() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getMaxCacheSize() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getMaxCapacity() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
getMaxCertPathLength() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getMaxCertPathLength() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
getMaxCertPathLength() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getMaxConcurrentPushedStreams() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxConcurrentStreams() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxConnectionCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getMaxConnections() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getMaxConnectionsPerDestination() - Method in class org.eclipse.jetty.client.HttpClient
 
getMaxCookieAge() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getMaxDecoderTableCapacity() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxDecoderTableCapacity() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxDecoderTableCapacity() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getMaxDirectMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMaxDirectMemory() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getMaxDirectMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getMaxDirectMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getMaxDuration() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
Get the max usage duration in milliseconds of the pool's connections.
getMaxDynamicTableSize() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
Deprecated.
getMaxDynamicTableSize() - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
getMaxDynamicTableSize() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
getMaxEncoderTableCapacity() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxEncoderTableCapacity() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getMaxEncoderTableCapacity() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxEncoderTableCapacity() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getMaxEntries() - Method in class org.eclipse.jetty.util.Pool
 
getMaxErrorDispatches() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMaxEvictCount() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getMaxFilterChainsCacheSize() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getMaxFormContentSize() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getMaxFormKeys() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getMaxFrameLength() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
Deprecated.
getMaxFrameLength() - Method in class org.eclipse.jetty.http2.parser.Parser
Deprecated.
getMaxFrameLength() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
Deprecated.
getMaxFrameSize() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxFrameSize() - Method in class org.eclipse.jetty.http2.generator.FrameGenerator
 
getMaxFrameSize() - Method in class org.eclipse.jetty.http2.generator.HeaderGenerator
 
getMaxFrameSize() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getMaxFrameSize() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxFrameSize() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The maximum payload size of any WebSocket Frame which can be received.
getMaxFrameSize() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getMaxFrameSize() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getMaxFrameSize() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getMaxFrameSize() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
getMaxFrameSize() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getMaxFrameSize() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getMaxHeaderBlockFragment() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxHeaderBlockFragment() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxHeaderListSize() - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
getMaxHeaderListSize() - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
getMaxHeaderListSize() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockParser
 
getMaxHeadersSize() - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
getMaxHeadersSize() - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
getMaxHeapMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMaxHeapMemory() - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getMaxHeapMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getMaxHeapMemory() - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getMaxIdleTime() - Method in class org.eclipse.jetty.ant.types.Connector
 
getMaxIdleTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getMaxInactive() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getMaxInactiveInterval() - Method in class org.eclipse.jetty.server.session.Session
 
getMaxInactiveInterval() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getMaxInactiveMs() - Method in class org.eclipse.jetty.server.session.SessionData
 
getMaxInputBufferSize() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
Returns the maximum input buffer size, after which the input is overflown to disk.
getMaxIntervalColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getMaxKeys() - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
getMaxLeasedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The maximum number of threads that are leased to internal components, as some component may allocate its threads lazily.
getMaxLocalStreams() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getMaxLocalStreams() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getMaxLocalStreams() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getMaxLowResourcesTime() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMaxMemory() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMaxMemory() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
getMaxMessageSize() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
getMaxMultiplex() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getMaxMultiplex() - Method in interface org.eclipse.jetty.client.ConnectionPool.Multiplexable
 
getMaxMultiplex() - Method in class org.eclipse.jetty.client.MultiplexConnectionPool
 
getMaxMultiplex() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
getMaxMultiplex() - Method in class org.eclipse.jetty.util.Pool
Deprecated.
Multiplex functionalities will be removed
getMaxMultiplex(T) - Method in class org.eclipse.jetty.util.Pool
Deprecated.
Multiplex functionalities will be removed
getMaxNonceAge() - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
getMaxNonceCount() - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
getMaxOutgoingFrames() - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Get the maximum number of data frames allowed to be waiting to be sent at any one time.
getMaxOutgoingFrames() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
getMaxOutgoingFrames() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getMaxOutgoingFrames() - Method in interface org.eclipse.jetty.websocket.core.Configuration
Get the maximum number of data frames allowed to be waiting to be sent at any one time.
getMaxOutgoingFrames() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getMaxOutputBufferSize() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
Returns the maximum output buffer size, after which the output is overflown to disk.
getMaxProxyHeader() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory
 
getMaxQueueLatency() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getMaxQueueSize() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getMaxRate() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getMaxRedirects() - Method in class org.eclipse.jetty.client.HttpClient
 
getMaxRemoteStreams() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getMaxRequestHeadersSize() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getMaxRequestsPerConnection() - Method in class org.eclipse.jetty.client.MultiplexHttpDestination
 
getMaxRequestsQueuedPerDestination() - Method in class org.eclipse.jetty.client.HttpClient
 
getMaxReservedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getMaxResponseHeadersSize() - Method in class org.eclipse.jetty.client.HttpClient
 
getMaxResponseHeadersSize() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxResponseHeadersSize() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getMaxResults() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getMaxRetries() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getMaxRetries() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getMaxScanWait(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Work out how long we should wait for the async scanning to occur.
getMaxSelectedKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getMaxSettingsKeys() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getMaxSettingsKeys() - Method in class org.eclipse.jetty.http2.parser.Parser
 
getMaxSettingsKeys() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getMaxSize() - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
getMaxTableCapacity() - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
getMaxTableCapacity() - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
getMaxTableCapacity() - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
getMaxTableCapacity() - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
getMaxTaskLatency() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getMaxTextMessageBufferSize() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getMaxTextMessageSize() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
Get the maximum size of a text message during parsing.
getMaxTextMessageSize() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getMaxTextMessageSize() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getMaxTextMessageSize() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getMaxTextMessageSize() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
getMaxTextMessageSize() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getMaxTextMessageSize() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getMaxThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getMaxThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getMaxThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPool.SizedThreadPool
 
getMaxUnidirectionalRemoteStreams() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getMaxUsageCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getMaxUsageCount() - Method in interface org.eclipse.jetty.client.ConnectionPool.MaxUsable
 
getMaxUsageCount() - Method in class org.eclipse.jetty.client.DuplexConnectionPool
 
getMaxUsageCount() - Method in class org.eclipse.jetty.client.MultiplexConnectionPool
 
getMaxUsageCount() - Method in class org.eclipse.jetty.util.Pool
Deprecated.
MaxUsage functionalities will be removed
getMaxUsageCount(T) - Method in class org.eclipse.jetty.util.Pool
Deprecated.
MaxUsage functionalities will be removed
getMBeanContainer() - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
getMBeanInfo() - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
getMBeanInfo() - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
getMBeanServer() - Method in class org.eclipse.jetty.jmx.MBeanContainer
Retrieve instance of MBeanServer used by container
getMDCAdapter() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
getMean() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getMediaType() - Method in interface org.eclipse.jetty.client.api.ContentResponse
 
getMediaType() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getMediaType() - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
getMemory(boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMemory(boolean) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
getMemory(boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
getMemory(boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
getMessage() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
 
getMessage(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Get the status message for a specific code.
getMessageAlignColumn() - Method in class org.eclipse.jetty.logging.StdErrAppender
 
getMessageHandler() - Method in class org.eclipse.jetty.websocket.jakarta.common.RegisteredMessageHandler
 
getMessageHandlerMap() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getMessageHandlers() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getMessageHandlers() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getMessageLayer() - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
getMessagesIn() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getMessagesIn() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getMessagesIn() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
getMessagesIn() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getMessagesIn() - Method in interface org.eclipse.jetty.io.Connection
 
getMessagesIn() - Method in class org.eclipse.jetty.server.HttpConnection
 
getMessagesIn() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getMessagesOut() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
getMessagesOut() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getMessagesOut() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
getMessagesOut() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getMessagesOut() - Method in interface org.eclipse.jetty.io.Connection
 
getMessagesOut() - Method in class org.eclipse.jetty.server.HttpConnection
 
getMessagesOut() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
getMessagesOut() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getMetadata(Class<?>) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
getMetadata(Class<?>, EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientFrameHandlerFactory
 
getMetadata(Class<?>, EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
getMetadata(Class<?>, EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerFrameHandlerFactory
 
getMetaData() - Method in class org.eclipse.jetty.http2.frames.HeadersFrame
 
getMetaData() - Method in class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
getMetaData() - Method in class org.eclipse.jetty.http3.frames.HeadersFrame
 
getMetaData() - Method in class org.eclipse.jetty.server.Request
 
getMetaData() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getMetaDataComplete() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
getMethod() - Method in interface org.eclipse.jetty.client.api.Request
 
getMethod() - Method in class org.eclipse.jetty.client.HttpRequest
 
getMethod() - Method in interface org.eclipse.jetty.client.Socks5.Authentication.Factory
 
getMethod() - Method in class org.eclipse.jetty.client.Socks5.NoAuthenticationFactory
 
getMethod() - Method in class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
getMethod() - Method in class org.eclipse.jetty.http.HttpTester.Request
 
getMethod() - Method in class org.eclipse.jetty.http.MetaData.Request
 
getMethod() - Method in class org.eclipse.jetty.security.ConstraintMapping
 
getMethod() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getMethod() - Method in class org.eclipse.jetty.server.Request
 
getMethod() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getMethod() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
getMethod() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
The HTTP method for this Upgrade Request.
getMethod() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getMethod() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getMethod() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getMethod() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getMethod() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getMethodHandle() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
getMethodIncludeExclude() - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
getMethodName() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getMethodName() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
getMethodOmissions() - Method in class org.eclipse.jetty.security.ConstraintMapping
 
getMicro() - Method in class org.eclipse.jetty.util.JavaVersion
Returns the micro number version (aka security number), such as 0 for JDK 1.8.0_92 and 4 for JDK 9.2.4.
getMimeByExtension(String) - Method in class org.eclipse.jetty.http.MimeTypes
Get the MIME type by filename extension.
getMimeIncludeExclude() - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
getMimeMap() - Method in class org.eclipse.jetty.http.MimeTypes
 
getMimeType() - Method in interface org.eclipse.jetty.http.HttpContent
 
getMimeType() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getMimeType() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getMimeType() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getMimeType(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getMimeType(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getMimeTypes() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getMimeTypes() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getMinCapacity() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
getMinGzipSize() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the minimum size, in bytes, that a response Content-Length must be before compression will trigger.
getMinor() - Method in class org.eclipse.jetty.util.JavaVersion
Returns the minor number version, such as 8 for JDK 1.8.0_92 and 2 for JDK 9.2.4.
getMinorVersion() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getMinorVersion() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
getMinRequestDataRate() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMinResponseDataRate() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMinThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getMinThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getMinThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPool.SizedThreadPool
 
getModuleGraphFilename() - Method in class org.eclipse.jetty.start.StartArgs
 
getModuleLocation(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
getMonitoredConnectors() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMonitoredDirName() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
getMonitoredDirResource() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
getMonitoredOrServerConnectors() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMonitoredResources() - Method in class org.eclipse.jetty.deploy.providers.jmx.WebAppProviderMBean
 
getMonitoredResources() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
getMonitorThreads() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMultipartConfig() - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
getMultipartFormDataCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMyExpiredSessionsStatement(Connection, SessionContext, long) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getName() - Method in class org.eclipse.jetty.ant.types.Attribute
 
getName() - Method in class org.eclipse.jetty.client.ContinueProtocolHandler
 
getName() - Method in class org.eclipse.jetty.client.HttpClient
 
getName() - Method in interface org.eclipse.jetty.client.ProtocolHandler
 
getName() - Method in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
getName() - Method in class org.eclipse.jetty.client.RedirectProtocolHandler
 
getName() - Method in class org.eclipse.jetty.client.UpgradeProtocolHandler
 
getName() - Method in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
getName() - Method in class org.eclipse.jetty.deploy.graph.Node
 
getName() - Method in interface org.eclipse.jetty.http.ComplianceViolation
 
getName() - Method in interface org.eclipse.jetty.http.ComplianceViolation.Mode
 
getName() - Method in class org.eclipse.jetty.http.CookieCompliance
 
getName() - Method in enum org.eclipse.jetty.http.CookieCompliance.Violation
 
getName() - Method in class org.eclipse.jetty.http.HttpCompliance
 
getName() - Method in enum org.eclipse.jetty.http.HttpCompliance.Violation
 
getName() - Method in class org.eclipse.jetty.http.HttpCookie
 
getName() - Method in class org.eclipse.jetty.http.HttpField
 
getName() - Method in class org.eclipse.jetty.http.UriCompliance
 
getName() - Method in enum org.eclipse.jetty.http.UriCompliance.Violation
 
getName() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getName() - Method in class org.eclipse.jetty.jaas.JAASLoginService
Get the name of the realm.
getName() - Method in class org.eclipse.jetty.jaas.JAASPrincipal
 
getName() - Method in class org.eclipse.jetty.jaas.JAASUserPrincipal
Get the name identifying the user
getName() - Method in class org.eclipse.jetty.jndi.NamingContext
Getter for _name
getName() - Method in class org.eclipse.jetty.logging.JettyLogger
 
getName() - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Returns the header name.
getName() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
Returns the header name.
getName() - Method in class org.eclipse.jetty.security.AbstractLoginService
 
getName() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
getName() - Method in class org.eclipse.jetty.security.EmptyLoginService
 
getName() - Method in interface org.eclipse.jetty.security.LoginService
 
getName() - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
getName() - Method in class org.eclipse.jetty.security.openid.OpenIdUserPrincipal
 
getName() - Method in class org.eclipse.jetty.security.RolePrincipal
 
getName() - Method in class org.eclipse.jetty.security.SecurityHandler.NotChecked
 
getName() - Method in class org.eclipse.jetty.security.SpnegoUserPrincipal
 
getName() - Method in class org.eclipse.jetty.security.UserPrincipal
 
getName() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getName() - Method in interface org.eclipse.jetty.server.Connector
Get the connector name if set.
getName() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getName() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getName() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
getName() - Method in interface org.eclipse.jetty.server.UserIdentity.Scope
 
getName() - Method in class org.eclipse.jetty.servlet.Holder
 
getName() - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
getName() - Method in class org.eclipse.jetty.start.Module
 
getName() - Method in class org.eclipse.jetty.util.Fields.Field
 
getName() - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
 
getName() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
getName() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
getName() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getName() - Method in class org.eclipse.jetty.util.resource.Resource
The name of the resource.
getName() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
getName() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns the name of the resource
getName() - Method in class org.eclipse.jetty.util.security.Constraint
 
getName() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getName() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getName() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
getName() - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
getName() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
getName() - Method in class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
getName() - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
getName() - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
getName() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getName() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getName() - Method in interface org.eclipse.jetty.websocket.core.Extension
The Sec-WebSocket-Extensions name for this extension.
getName() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.FrameCaptureExtension
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
getName() - Method in class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
getName() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
 
getName() - Method in class org.eclipse.jetty.xml.XmlParser.Attribute
 
getNamedDispatcher(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getNamedDispatcher(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getNamedFragmentDescriptors() - Method in class org.eclipse.jetty.webapp.MetaData
 
getNamedTemplateVariables() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getNameForScope(Object) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
getNameInJar() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
getNameInNamespace() - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
getNameInNamespace() - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getNameInNamespace() - Method in class org.eclipse.jetty.jndi.NamingContext
Get the full name of this Context node by visiting it's ancestors back to root.
getNameOfJspClass(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getNameParser(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
getNameParser(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getNameParser(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Return a NameParser for this Context.
getNameParser(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
getNameParser(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getNameParser(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Return a NameParser for this Context.
getNames() - Method in class org.eclipse.jetty.server.session.Session
 
getNames() - Method in class org.eclipse.jetty.util.Fields
 
getNamespace() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getNamespace() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getNeedClientAuth() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
getNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getNegotiatedExtensions() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The negotiated WebSocket Extension Configurations for this session.
getNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
Get the list of negotiated extensions, each entry being a full "name; params" extension configuration
getNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getNegotiatedExtensions(List<Extension>, List<Extension>) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
 
getNegotiatedProtocol() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getNegotiatedProtocols() - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
getNegotiatedSubprotocol() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getNegotiatedSubprotocol(List<String>, List<String>) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
 
getNegotiatedSubProtocol() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getNegotiatedSubProtocol() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The negotiated WebSocket Sub-Protocol for this session.
getNegotiatedSubProtocol() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getNestedValue(DBObject, String) - Static method in class org.eclipse.jetty.nosql.mongodb.MongoUtils
Dig through a given dbObject for the nested value
getNetworkTrafficListener() - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
getNewContextURL() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
getNextIncoming() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getNextIncoming() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getNextInterceptor() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
getNextInterceptor() - Method in class org.eclipse.jetty.server.HttpChannel
 
getNextInterceptor() - Method in interface org.eclipse.jetty.server.HttpOutput.Interceptor
 
getNextOutgoing() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
getNextOutgoing() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getNextProtocol() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
getNode(int) - Method in class org.eclipse.jetty.deploy.graph.Path
 
getNodeByName(String) - Method in class org.eclipse.jetty.deploy.graph.Graph
Get the Node by Name.
getNodes() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getNodes() - Method in class org.eclipse.jetty.deploy.graph.Graph
 
getNodes() - Method in class org.eclipse.jetty.deploy.graph.Path
 
getNodes() - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
getNonComplianceWarnings() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
 
getNonComplianceWarnings() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
getNonComplianceWarnings() - Method in interface org.eclipse.jetty.server.MultiParts
 
getNonComplianceWarnings() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
getNonComplianceWarnings() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
getNonExcludedInitializers(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Get SCIs that are not excluded from consideration
getNonHidden() - Static method in class org.eclipse.jetty.start.PathMatchers
 
getNullPrintWriter() - Static method in class org.eclipse.jetty.util.IO
 
getNullStream() - Static method in class org.eclipse.jetty.util.IO
 
getNullWriter() - Static method in class org.eclipse.jetty.util.IO
 
getNumberType() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
getNumberType(Class<?>) - Static method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
getNumSessions() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
getNumSessions() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
getObject() - Method in class org.eclipse.jetty.jaas.callback.ObjectCallback
 
getObjectContextBasis() - Method in class org.eclipse.jetty.client.jmx.HttpClientMBean
 
getObjectContextBasis() - Method in class org.eclipse.jetty.jmx.ObjectMBean
Allows to customize the ObjectName property context.
getObjectContextBasis() - Method in class org.eclipse.jetty.server.handler.jmx.AbstractHandlerMBean
 
getObjectContextBasis() - Method in class org.eclipse.jetty.server.jmx.AbstractConnectorMBean
 
getObjectFactory() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
The DecoratedObjectFactory for use by IoC containers (weld / spring / etc)
getObjectFactory() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getObjectFactory() - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
getObjectFactory() - Method in class org.eclipse.jetty.websocket.core.WebSocketComponents
 
getObjectFactory() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.eclipse.jetty.jndi.ContextFactory
Find or create a context which pertains to a classloader.
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference
Create a javax.mail.Session instance based on the information passed in the Reference
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.eclipse.jetty.jndi.java.javaURLContextFactory
Either return a new context or the resolution of a url.
getObjectName() - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
getObjectName() - Method in class org.eclipse.jetty.jmx.ObjectMBean
Allows to customize the ObjectName of this MBean.
getObjectNameBasis() - Method in class org.eclipse.jetty.jmx.ObjectMBean
Allows to customize the ObjectName property name.
getObjectNameBasis() - Method in class org.eclipse.jetty.servlet.jmx.FilterMappingMBean
 
getObjectNameBasis() - Method in class org.eclipse.jetty.servlet.jmx.HolderMBean
 
getObjectNameBasis() - Method in class org.eclipse.jetty.servlet.jmx.ServletMappingMBean
 
getOcspResponderURL() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getOcspResponderURL() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
getOcspResponderURL() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getOfferedExtensions() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getOfferedSubprotocols() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getOldest(TimeUnit) - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getOmittedMethods(String) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Given a string of the form <method>.<method>.omission split out the individual method names.
getOpCode() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
getOpCode() - Method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
getOpCode() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
getOpCode() - Method in class org.eclipse.jetty.websocket.core.Frame
 
getOpCode(byte) - Static method in class org.eclipse.jetty.websocket.core.OpCode
 
getOpenHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getOpenHandle() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getOpenSessions() - Method in interface org.eclipse.jetty.websocket.api.WebSocketContainer
Get the collection of open Sessions being tracked by this container
getOpenSessions() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getOpenSessions() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
Used in Session.getOpenSessions()
getOpenSessions() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getOpenSessions() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getOptional() - Method in class org.eclipse.jetty.start.Module
Deprecated.
use Module.getAfter() instead
getOrCreateStreamEndPoint(long, Consumer<QuicStreamEndPoint>) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getOrCreateStreamEndPoint(long, Consumer<QuicStreamEndPoint>) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getOrdering() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
getOrdering() - Method in class org.eclipse.jetty.webapp.MetaData
 
getOrdering() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
getOrigin() - Method in class org.eclipse.jetty.client.HttpDestination
 
getOrigin() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getOrigin() - Method in class org.eclipse.jetty.servlet.Source
 
getOrigin() - Method in class org.eclipse.jetty.start.RawArgs.Entry
 
getOrigin() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
The WebSocket Origin of this Upgrade Request
getOrigin() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getOrigin() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getOrigin() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getOrigin() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getOrigin(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
getOriginalPathAttribute() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
getOriginalPathAttribute() - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
getOriginalURI() - Method in class org.eclipse.jetty.server.Request
 
getOriginAttribute() - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
getOriginDescriptor(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
getOriginId() - Method in class org.eclipse.jetty.deploy.App
The origin of this App as specified by the AppProvider
getOriginId(Bundle, String) - Static method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
getOriginInfo(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
getOrigins() - Method in class org.eclipse.jetty.webapp.MetaData
 
getOriginType() - Method in class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
getOrThrow() - Method in class org.eclipse.jetty.util.FuturePromise
Return the result if completed successfully or in the case of failure, throw the Exception/Error, or an ExecutionException wrapping the cause if it is neither an Exception or Error.
getOtherType() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
getOut() - Method in class org.eclipse.jetty.util.MultiPartOutputStream
 
getOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getOutputAggregationSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getOutputBufferSize() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getOutputBufferSize() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
getOutputBufferSize() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
getOutputBufferSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getOutputBufferSize() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The output (write to network layer) buffer size.
getOutputBufferSize() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getOutputBufferSize() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getOutputBufferSize() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getOutputBufferSize() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
getOutputBufferSize() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getOutputBufferSize() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
getOutputFilePrefix() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
getOutputStream() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
getOutputStream() - Method in class org.eclipse.jetty.client.util.OutputStreamRequestContent
 
getOutputStream() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer.Sink
 
getOutputStream() - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
getOutputStream() - Method in class org.eclipse.jetty.server.Response
 
getOutputStream() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getOutputString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getOutputString(Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getOverflowDirectory() - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
Returns the directory where input and output are overflown to temporary files if they exceed, respectively, the max input size or the max output size.
getOverrideDescriptor() - Method in class org.eclipse.jetty.webapp.WebAppContext
The override descriptor is a web.xml format file that is applied to the context after the standard WEB-INF/web.xml
getOverrideDescriptors() - Method in class org.eclipse.jetty.webapp.MetaData
 
getOverrideDescriptors() - Method in class org.eclipse.jetty.webapp.WebAppContext
An override descriptor is a web.xml format file that is applied to the context after the standard WEB-INF/web.xml
getPackageOfJspClass(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getPackages() - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getPaddingLength() - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
 
getPageEncoding() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getParam() - Method in interface org.eclipse.jetty.http.HttpURI
Get a URI path parameter.
getParam() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getParam() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getParam(String) - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
getParamArg(Method, Class<?>, int) - Method in interface org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.ParamIdentifier
 
getParamArg(Method, Class<?>, int) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.PathParamIdentifier
 
getParamClass() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getParameter(String) - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getParameter(String) - Method in class org.eclipse.jetty.server.Request
 
getParameter(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getParameter(String, int) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
getParameter(String, int) - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getParameter(String, int) - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getParameter(String, String) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
getParameter(String, String) - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getParameter(String, String) - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getParameterizedName() - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
getParameterizedName() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getParameterizedName() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getParameterizedNameWithoutInternalParams() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getParameterKeys() - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
getParameterKeys() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
getParameterKeys() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
getParameterMap() - Method in class org.eclipse.jetty.server.Request
 
getParameterMap() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Returns a map of the query parameters of the request.
getParameterMap() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getParameterMap() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The parameter map (from URI Query) for the active session.
getParameterMap() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getParameterMap() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getParameterName() - Method in class org.eclipse.jetty.jaas.callback.RequestParameterCallback
 
getParameterNames() - Method in class org.eclipse.jetty.server.Request
 
getParameterNames() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getParameters() - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getParameters() - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
Return parameters found in request URI.
getParameters() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
Return parameters found in request URI.
getParameters() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
Return parameters found in request URI.
getParameters() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
 
getParameterValues() - Method in class org.eclipse.jetty.jaas.callback.RequestParameterCallback
 
getParameterValues(String) - Method in class org.eclipse.jetty.server.Request
 
getParameterValues(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getParams() - Method in interface org.eclipse.jetty.client.api.Request
 
getParams() - Method in class org.eclipse.jetty.client.HttpRequest
 
getParent() - Method in class org.eclipse.jetty.jndi.NamingContext
Getter for _parent
getParent() - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
getParent() - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
getParentClassLoaderForWebapps() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
The classloader that should be the parent classloader for each webapp deployed on this server.
getParentStreamId() - Method in class org.eclipse.jetty.http2.frames.PriorityFrame
 
getParsedParts() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Get the already parsed parts.
getParser() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getParser() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
getParser() - Method in class org.eclipse.jetty.server.HttpConnection
 
getParser() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getParser(boolean) - Static method in class org.eclipse.jetty.webapp.WebDescriptor
Get a parser for parsing web descriptor content.
getParserListener() - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
getParserListener() - Method in class org.eclipse.jetty.http2.parser.ServerParser.Listener.Wrapper
 
getPart(String) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Get the named Part.
getPart(String) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Get the named Part.
getPart(String) - Method in interface org.eclipse.jetty.server.MultiParts
 
getPart(String) - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
getPart(String) - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
getPart(String) - Method in class org.eclipse.jetty.server.Request
 
getPart(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getPart(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getPartialString() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
getPartialString() - Method in class org.eclipse.jetty.util.Utf8StringBuffer
 
getPartialString() - Method in class org.eclipse.jetty.util.Utf8StringBuilder
 
getPartialString() - Method in class org.eclipse.jetty.websocket.core.internal.NullAppendable
 
getParts() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Parse, if necessary, the multipart data and return the list of Parts.
getParts() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Parse, if necessary, the multipart data and return the list of Parts.
getParts() - Method in interface org.eclipse.jetty.server.MultiParts
 
getParts() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
getParts() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
getParts() - Method in class org.eclipse.jetty.server.Request
 
getParts() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getParts() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getPassword() - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
getPassword(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Returns the password object for the given realm.
getPassword(String, String, String) - Static method in class org.eclipse.jetty.util.security.Password
Get a password.
getPasswordAuthentication() - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
getPath() - Method in interface org.eclipse.jetty.client.api.Request
 
getPath() - Method in class org.eclipse.jetty.client.HttpRequest
 
getPath() - Method in class org.eclipse.jetty.http.HttpCookie
 
getPath() - Method in interface org.eclipse.jetty.http.HttpURI
 
getPath() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getPath() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getPath() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getPath() - Method in class org.eclipse.jetty.server.handler.InetAccessSet.AccessTuple
 
getPath() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getPath() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
getPath() - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
getPath() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
getPath() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getPath() - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
getPath() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.BasicServerEndpointConfig
 
getPath() - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
getPath(String) - Method in class org.eclipse.jetty.start.BaseHome
Get a specific path reference.
getPath(String, String) - Method in class org.eclipse.jetty.deploy.graph.Graph
Convenience method for Graph.getPath(Node, Node)
getPath(Node, Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
Using BFS (Breadth First Search) return the path from a any arbitrary node to any other.
getPath(Resource) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
getPathDepth() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
Get the number of path elements that this path spec declares.
getPathDepth() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getPathDepth() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getPathDepth() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPathIncludeExclude() - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
getPathInContext() - Method in class org.eclipse.jetty.server.Request
Get the path in the context.
getPathInContext() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getPathInContext() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaClientUpgradeRequest
 
getPathInContext() - Method in interface org.eclipse.jetty.websocket.jakarta.common.UpgradeRequest
For obtaining PathParam values from the Request context path.
getPathInContext() - Method in class org.eclipse.jetty.websocket.jakarta.common.UpgradeRequestAdapter
 
getPathInContext() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaServerUpgradeRequest
 
getPathInfo() - Method in interface org.eclipse.jetty.http.pathmap.MatchedPath
Return the portion of the path that is after the path spec.
getPathInfo() - Method in class org.eclipse.jetty.http.pathmap.MatchedResource
Return the portion of the path that is after the path spec.
getPathInfo() - Method in class org.eclipse.jetty.server.Request
 
getPathInfo() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getPathInfo() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getPathInfo() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getPathInfo(String) - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
Deprecated.
getPathInfo(String) - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getPathInfo(String) - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
getPathInfo(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPathMatch() - Method in interface org.eclipse.jetty.http.pathmap.MatchedPath
Return the portion of the path that matches a path spec.
getPathMatch() - Method in class org.eclipse.jetty.http.pathmap.MatchedResource
Return the portion of the path that matches a path spec.
getPathMatch(String) - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
Deprecated.
getPathMatch(String) - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getPathMatch(String) - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
getPathMatch(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPathParameters() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getPathParams() - Method in class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
getPathParams() - Method in interface org.eclipse.jetty.websocket.jakarta.common.PathParamProvider
 
getPathParams() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getPathParams() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.PathParamServerEndpointConfig
 
getPathParams(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPathQuery() - Method in interface org.eclipse.jetty.http.HttpURI
 
getPathQuery() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getPathQuery() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getPaths(String) - Method in class org.eclipse.jetty.start.BaseHome
Get a List of Paths from a provided pattern.
getPaths(Path, int, String) - Method in class org.eclipse.jetty.start.BaseHome
Search specified Path with pattern and return hits
getPathSpec() - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
getPathSpec() - Method in class org.eclipse.jetty.http.pathmap.MatchedResource
 
getPathSpec() - Method in class org.eclipse.jetty.security.ConstraintMapping
 
getPathSpec() - Method in class org.eclipse.jetty.servlet.ServletHandler.MappedServlet
 
getPathSpecs() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
getPathSpecs() - Method in class org.eclipse.jetty.servlet.ServletMapping
 
getPathsToRequiredBundles(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
getPathsWithUncoveredHttpMethods() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Servlet spec 3.1 pg.
getPathTranslated() - Method in class org.eclipse.jetty.server.Request
 
getPathTranslated() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getPathTranslated() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getPattern() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getPattern() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPattern() - Method in class org.eclipse.jetty.rewrite.handler.PatternRule
 
getPattern() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getPattern() - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
getPatterns() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
getPayload() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
getPayload() - Method in class org.eclipse.jetty.http2.frames.PingFrame
 
getPayload() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
getPayload() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
getPayload() - Method in class org.eclipse.jetty.websocket.core.Frame
Get the payload ByteBuffer.
getPayloadAsLong() - Method in class org.eclipse.jetty.http2.frames.PingFrame
 
getPayloadAsUTF8() - Method in class org.eclipse.jetty.websocket.core.Frame
Get the payload of the frame as a UTF-8 string.
getPayloadLength() - Method in interface org.eclipse.jetty.websocket.api.Frame
The original payload length (Buffer.remaining())
getPayloadLength() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
getPayloadLength() - Method in class org.eclipse.jetty.websocket.core.Frame
 
getPayloadLength() - Method in class org.eclipse.jetty.websocket.core.internal.Parser
 
getPCTasksConsumed() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
getPECTasksExecuted() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
getPemWorkDirectory() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getPending() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
getPendingConnectionCount() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
getPeriod() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getPeriod() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getPeriod() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getPermissions() - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
 
getPermissions() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getPermissions(CodeSource) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getPermissions(CodeSource) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
getPhrase() - Method in class org.eclipse.jetty.websocket.api.CloseStatus
 
getPICTasksExecuted() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
getPingHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getPkixCertPathChecker() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getPlatform() - Method in class org.eclipse.jetty.util.JavaVersion
Returns the Java Platform version, such as 8 for JDK 1.8.0_92 and 9 for JDK 9.2.4.
getPolicy() - Method in interface org.eclipse.jetty.websocket.api.Session
Access the (now read-only) WebSocketPolicy in use for this connection.
getPongHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getPongHandle() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getPool() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
getPooled() - Method in class org.eclipse.jetty.util.Pool.Entry
 
getPort() - Method in class org.eclipse.jetty.ant.types.Connector
 
getPort() - Method in interface org.eclipse.jetty.client.api.Destination
 
getPort() - Method in interface org.eclipse.jetty.client.api.Request
 
getPort() - Method in class org.eclipse.jetty.client.HttpDestination
 
getPort() - Method in class org.eclipse.jetty.client.HttpRequest
 
getPort() - Method in class org.eclipse.jetty.client.Origin.Address
 
getPort() - Method in class org.eclipse.jetty.http.HostPortHttpField
Get the port.
getPort() - Method in interface org.eclipse.jetty.http.HttpURI
 
getPort() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getPort() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getPort() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getPort() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
getPort() - Method in interface org.eclipse.jetty.server.NetworkConnector
 
getPort() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
getPort() - Method in class org.eclipse.jetty.util.HostPort
Get the port.
getPort(int) - Method in class org.eclipse.jetty.http.HostPortHttpField
Get the port.
getPort(int) - Method in class org.eclipse.jetty.util.HostPort
Get the port or the given default port.
getPostConstructCallbackMap() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Generate a read-only view of the post-construct callbacks
getPostConstructCallbacks() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Amalgamate all post-construct callbacks and return a read only set
getPostConstructCallbacks(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
 
getPrecompressedContents() - Method in interface org.eclipse.jetty.http.HttpContent
 
getPrecompressedContents() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getPrecompressedContents() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getPrecompressedContents() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getPrecompressedFormats() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getPrecompressedFormats() - Method in class org.eclipse.jetty.server.ResourceService
 
getPreDestroyCallbackMap() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Generate a read-only view of the pre-destroy callbacks
getPreDestroyCallbacks() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
Amalgamate all pre-destroy callbacks and return a read only set
getPreDestroyCallbacks(Object) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
 
getPreferredSubprotocols() - Method in class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
getPrefix() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
A simple prefix match for the pathspec or null
getPrefix() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getPrefix() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getPrefix() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getPrefix() - Method in interface org.eclipse.jetty.util.security.CredentialProvider
Get the prefix of the credential strings convertible into credentials
getPreMatched() - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
getPreviousAssociation() - Method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
getPrimaryTag() - Method in class org.eclipse.jetty.start.Module
 
getPrincipal() - Method in interface org.eclipse.jetty.http.spi.JettyExchange
 
getPrincipal() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getPrincipal() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getPrincipal() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getPriority() - Method in class org.eclipse.jetty.http2.frames.HeadersFrame
 
getPriorityFrame() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
getPrivateKey(String) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
getPrivateKey(String) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
getPrivateKey(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
getProducerTask() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
getProducerTask() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getProducerTask() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
getProjectId() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
getProjectId() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getPromise() - Method in class org.eclipse.jetty.util.Promise.Wrapper
 
getPromisedStreamId() - Method in class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
getProp(String) - Method in class org.eclipse.jetty.start.config.ConfigSources
 
getProp(String) - Method in class org.eclipse.jetty.start.Props
 
getProp(String, boolean) - Method in class org.eclipse.jetty.start.Props
 
getProperties() - Method in interface org.eclipse.jetty.deploy.ConfigurationManager
 
getProperties() - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
getProperties() - Method in class org.eclipse.jetty.start.StartArgs
 
getProperties() - Method in class org.eclipse.jetty.xml.XmlConfiguration
Get the map of properties used by the Property XML element to parametrize configuration.
getProperty(String) - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getProperty(String) - Method in interface org.eclipse.jetty.start.config.ConfigSource
Return the value of the specified property.
getProperty(String) - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getPropertyName() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
getPropertyUserStore(String) - Method in class org.eclipse.jetty.jaas.PropertyUserStoreManager
 
getProps() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getProps() - Method in interface org.eclipse.jetty.start.config.ConfigSource
The properties for this ConfigSource
getProps() - Method in class org.eclipse.jetty.start.config.ConfigSources
 
getProps() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getProtectedTargets() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getProtocol() - Method in class org.eclipse.jetty.client.Origin
 
getProtocol() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getProtocol() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getProtocol() - Method in class org.eclipse.jetty.http.MetaData.ConnectRequest
 
getProtocol() - Method in class org.eclipse.jetty.http.MetaData.Request
 
getProtocol() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getProtocol() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getProtocol() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getProtocol() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
getProtocol() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getProtocol() - Method in interface org.eclipse.jetty.server.ConnectionFactory
 
getProtocol() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getProtocol() - Method in class org.eclipse.jetty.server.Request
 
getProtocol() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getProtocol() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getProtocolHandlers() - Method in class org.eclipse.jetty.client.HttpClient
 
getProtocols() - Method in class org.eclipse.jetty.alpn.client.ALPNClientConnection
 
getProtocols() - Method in class org.eclipse.jetty.client.Origin.Protocol
 
getProtocols() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getProtocols() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getProtocols() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getProtocols() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getProtocols() - Method in interface org.eclipse.jetty.server.ConnectionFactory
 
getProtocols() - Method in interface org.eclipse.jetty.server.Connector
 
getProtocols() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getProtocols(boolean) - Method in class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2.HTTP2
 
getProtocols(boolean) - Method in class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3.HTTP3
 
getProtocols(boolean) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
getProtocolSession() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getProtocolVersion() - Method in interface org.eclipse.jetty.websocket.api.Session
Returns the version of the websocket protocol currently being used.
getProtocolVersion() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the WebSocket Protocol Version
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getProtocolVersion() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The active Sec-WebSocket-Version (protocol version) in use.
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getProtocolVersion() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getProtoFile() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSerializationContextInitializer
 
getProtoFileName() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSerializationContextInitializer
 
getProvider() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Get the optional Security Provider name.
getProvides() - Method in class org.eclipse.jetty.start.Module
 
getProxiedObject() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getProxiedObject() - Method in interface org.eclipse.jetty.ant.utils.ServerProxy
 
getProxies() - Method in class org.eclipse.jetty.client.ProxyConfiguration
getProxy() - Method in class org.eclipse.jetty.client.HttpDestination
 
getProxyAsAuthority() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getProxyConfiguration() - Method in class org.eclipse.jetty.client.HttpClient
 
getPushListener() - Method in class org.eclipse.jetty.client.HttpRequest
 
getQualityCSV(String) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name, split and sorted as a QuotedQualityCSV
getQualityCSV(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name, split and sorted as a QuotedQualityCSV
getQualityCSV(HttpHeader, ToIntFunction<String>) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name, split and sorted as a QuotedQualityCSV
getQuery() - Method in interface org.eclipse.jetty.client.api.Request
 
getQuery() - Method in class org.eclipse.jetty.client.HttpRequest
 
getQuery() - Method in interface org.eclipse.jetty.http.HttpURI
 
getQuery() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getQuery() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getQueryEncoding() - Method in class org.eclipse.jetty.server.Request
 
getQueryManager() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
getQueryManager() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
getQueryManager(BasicCache<String, InfinispanSessionData>) - Method in class org.eclipse.jetty.session.infinispan.NullQueryManagerFactory
 
getQueryManager(BasicCache<String, InfinispanSessionData>) - Method in interface org.eclipse.jetty.session.infinispan.QueryManagerFactory
 
getQueryParameters() - Method in class org.eclipse.jetty.server.Request
 
getQueryString() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getQueryString() - Method in class org.eclipse.jetty.server.Request
 
getQueryString() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getQueryString() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the Query String of the request URI.
getQueryString() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getQueryString() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getQueryString() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getQueryString() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getQueryString() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getQueryString() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getQueryString() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getQueue() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getQueuedRequestCount() - Method in class org.eclipse.jetty.client.HttpDestination
 
getQueueSize() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getQuicConfiguration() - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
getQuicConfiguration() - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
getQuicConfiguration() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
getQuicConnection() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getQuicConnection() - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
getQuickStartWebXml() - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
getQuickStartWebXml(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
Get the quickstart-web.xml file as a Resource.
getQuicSession() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
getQuicSession() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getQuicSession() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
getQuicSession() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
getQuicSessions() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
getQuicStreamEndPoints() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getRandom() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
getRate() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getRate() - Method in class org.eclipse.jetty.util.statistic.RateCounter
 
getRate() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getRateControl() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
getRateControlFactory() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getRawContentArrived() - Method in interface org.eclipse.jetty.server.ContentProducer
Get the byte count produced by the underlying HttpChannel.
getRawEndpoint() - Method in class org.eclipse.jetty.websocket.jakarta.common.ConfiguredEndpoint
 
getReadableByteChannel() - Method in interface org.eclipse.jetty.http.HttpContent
 
getReadableByteChannel() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getReadableByteChannel() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getReadableByteChannel() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getReadableByteChannel() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
getReadableByteChannel() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getReadableByteChannel() - Method in class org.eclipse.jetty.util.resource.Resource
Readable ByteChannel for the resource.
getReadableByteChannel() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
getReadableByteChannel() - Method in class org.eclipse.jetty.util.resource.URLResource
 
getReader() - Method in class org.eclipse.jetty.server.Request
 
getReader() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getReadyThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The fundamental value that represents the number of threads ready to execute transient jobs.
getRealm() - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getRealm() - Method in class org.eclipse.jetty.client.util.AbstractAuthentication
 
getRealmName() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
 
getRealmName() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getRealmName() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getRealPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getRealPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getRealPath(String) - Method in class org.eclipse.jetty.server.Request
Deprecated.
getRealPath(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getReason() - Method in interface org.eclipse.jetty.client.api.Response
 
getReason() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getReason() - Method in class org.eclipse.jetty.client.HttpResponse
 
getReason() - Method in exception class org.eclipse.jetty.http.BadMessageException
 
getReason() - Method in class org.eclipse.jetty.http.HttpTester.Response
 
getReason() - Method in class org.eclipse.jetty.http.MetaData.Response
 
getReason() - Method in class org.eclipse.jetty.http2.frames.FailureFrame
 
getReason() - Method in class org.eclipse.jetty.server.LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck
 
getReason() - Method in interface org.eclipse.jetty.server.LowResourceMonitor.LowResourceCheck
 
getReason() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MainThreadPoolLowResourceCheck
 
getReason() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MaxConnectionsLowResourceCheck
 
getReason() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
getReason() - Method in class org.eclipse.jetty.server.Response
 
getReason() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
getReasonBuffer(int) - Static method in class org.eclipse.jetty.http.HttpGenerator
 
getReasons() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getReceiveBufferSize() - Method in class org.eclipse.jetty.io.ClientConnector
 
getReceivedBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getRecurseDepth() - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
getRecvWindow() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getRecvWindow() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getRefreshCookieAge() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getRegex() - Method in class org.eclipse.jetty.rewrite.handler.RegexRule
 
getRegisteredDecoders() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
getRegisteredDecoders(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getRegisteredDecoders(Class<? extends Decoder>, Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getRegisteredEncoderFor(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
getRegistration() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
getRegistration() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
getRegistration() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getRegistrationContext(String) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
getRegistrationIDs(AuthConfigProvider) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
getRemote() - Method in interface org.eclipse.jetty.websocket.api.Session
Return a reference to the RemoteEndpoint object representing the other end of this conversation.
getRemote() - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
getRemote() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getRemoteAddr() - Method in class org.eclipse.jetty.server.Request
 
getRemoteAddr() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRemoteAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getRemoteAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getRemoteAddress() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getRemoteAddress() - Method in interface org.eclipse.jetty.http2.api.Session
Deprecated.
getRemoteAddress() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getRemoteAddress() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getRemoteAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getRemoteAddress() - Method in interface org.eclipse.jetty.io.EndPoint
Deprecated.
getRemoteAddress() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getRemoteAddress() - Method in class org.eclipse.jetty.server.HttpChannel
 
getRemoteAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getRemoteAddress() - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Get the SocketAddress for the established connection.
getRemoteAddress() - Method in interface org.eclipse.jetty.websocket.api.Session
The Remote Socket Address for the active Session
getRemoteAddress() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
getRemoteAddress() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getRemoteAddress() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getRemoteAddress() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The Remote Socket Address for the connection
getRemoteAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
getRemoteAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getRemoteCloseInfo() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getRemoteHost() - Method in class org.eclipse.jetty.server.Request
 
getRemoteHost() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRemoteInetSocketAddress() - Method in class org.eclipse.jetty.server.Request
Access the underlying Remote InetSocketAddress for this request.
getRemoteIP(Request) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getRemotePort() - Method in class org.eclipse.jetty.server.Request
 
getRemotePort() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.client.api.Connection
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.http2.api.Session
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.http3.api.Session
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.io.EndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getRemoteUri() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
getRemoteUser() - Method in class org.eclipse.jetty.server.Request
 
getRemoteUser() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getRemoteUser() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRenegotiationLimit() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getRenegotiationLimit() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getReportDirs() - Method in class org.eclipse.jetty.util.Scanner
 
getReportExistingFilesOnStartup() - Method in class org.eclipse.jetty.util.Scanner
 
getRequest() - Method in interface org.eclipse.jetty.client.api.Response
 
getRequest() - Method in class org.eclipse.jetty.client.api.Result
 
getRequest() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getRequest() - Method in class org.eclipse.jetty.client.HttpExchange
 
getRequest() - Method in exception class org.eclipse.jetty.client.HttpRequestException
 
getRequest() - Method in class org.eclipse.jetty.client.HttpResponse
 
getRequest() - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
getRequest() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
getRequest() - Method in class org.eclipse.jetty.fcgi.parser.ContentParser
 
getRequest() - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
 
getRequest() - Method in class org.eclipse.jetty.jaas.callback.ServletRequestCallback
 
getRequest() - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
getRequest() - Method in class org.eclipse.jetty.server.AsyncContextState
 
getRequest() - Method in class org.eclipse.jetty.server.HttpChannel
 
getRequest() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getRequestBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getRequestBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getRequestBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getRequestBufferSize() - Method in class org.eclipse.jetty.client.HttpClient
 
getRequestCharacterEncoding() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getRequestCharacterEncoding() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getRequestContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get the context path in a form suitable to be returned from HttpServletRequest.getContextPath() or ServletContext.getContextPath().
getRequestCookieCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getRequestDispatcher(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getRequestDispatcher(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getRequestDispatcher(String) - Method in class org.eclipse.jetty.server.Request
 
getRequestDispatcher(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRequestedApiVersion() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
getRequestedSessionId() - Method in class org.eclipse.jetty.server.Request
 
getRequestedSessionId() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getRequestedSessionId() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRequestFailure() - Method in class org.eclipse.jetty.client.api.Result
 
getRequestFailure() - Method in class org.eclipse.jetty.client.HttpExchange
 
getRequestHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getRequestHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getRequestHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getRequestHeaderSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getRequestId(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getRequestListeners() - Method in class org.eclipse.jetty.client.HttpClient
Returns a non thread-safe list of Request.Listeners that can be modified before performing requests.
getRequestListeners(Class<T>) - Method in interface org.eclipse.jetty.client.api.Request
 
getRequestListeners(Class<T>) - Method in class org.eclipse.jetty.client.HttpRequest
 
getRequestLog() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getRequestLog() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getRequestLog() - Method in class org.eclipse.jetty.server.handler.RequestLogHandler
 
getRequestLog() - Method in class org.eclipse.jetty.server.HttpChannel
 
getRequestLog() - Method in class org.eclipse.jetty.server.Server
 
getRequestMessage() - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
getRequestMethod() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getRequestMethod() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getRequestMethod() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getRequestNotifier() - Method in class org.eclipse.jetty.client.HttpDestination
 
getRequestParameterMap() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getRequestPath() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getRequestPath() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getRequestPath() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getRequestPathSpec() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getRequests() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequests() - Method in class org.eclipse.jetty.server.HttpChannel
 
getRequests() - Method in class org.eclipse.jetty.server.session.Session
Returns the current number of requests that are active in the Session.
getRequestsActive() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestsActiveMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestTimeMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestTimeMean() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestTimeStdDev() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestTimeTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getRequestURI() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getRequestURI() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getRequestURI() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getRequestURI() - Method in class org.eclipse.jetty.server.Request
 
getRequestURI() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getRequestURI() - Method in exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
getRequestURI() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the Request URI
getRequestURI() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getRequestURI() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The active connection's Request URI.
getRequestURI() - Method in exception class org.eclipse.jetty.websocket.core.exception.UpgradeException
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaClientUpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getRequestURI() - Method in interface org.eclipse.jetty.websocket.jakarta.common.UpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.jakarta.common.UpgradeRequestAdapter
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaServerUpgradeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getRequestURI() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getRequestURL() - Method in class org.eclipse.jetty.server.Request
 
getRequestURL() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getRequestURL() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getReseed() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
getReservedCount() - Method in class org.eclipse.jetty.util.Pool
 
getReservedThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getReservedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getResolvedUserIdentity() - Method in class org.eclipse.jetty.server.Request
 
getResource() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
getResource() - Method in interface org.eclipse.jetty.http.HttpContent
 
getResource() - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
getResource() - Method in class org.eclipse.jetty.http.pathmap.MatchedResource
 
getResource() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
getResource() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
getResource() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
getResource() - Method in class org.eclipse.jetty.servlet.Source
 
getResource() - Method in class org.eclipse.jetty.webapp.Descriptor
 
getResource() - Method in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
getResource(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getResource(String) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
getResource(String) - Method in class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
Get a resource from the classloader Copied from WebAppClassLoader
getResource(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getResource(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Attempt to get a Resource from the Context.
getResource(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getResource(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getResource(String) - Method in class org.eclipse.jetty.servlet.DefaultServlet
get Resource to serve.
getResource(String) - Static method in class org.eclipse.jetty.util.Loader
 
getResource(String) - Method in class org.eclipse.jetty.util.resource.Resource
Get a resource from within this resource.
getResource(String) - Method in interface org.eclipse.jetty.util.resource.ResourceFactory
Get a Resource from a provided String.
getResource(String) - Method in class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
getResource(String) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
Get a resource from the classloader NOTE: this method provides a convenience of hacking off a leading / should one be present.
getResource(String) - Method in class org.eclipse.jetty.webapp.WebAppContext.Context
 
getResource(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getResource(Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
getResourceAlias(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getResourceAliases() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getResourceAsStream(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getResourceAsStream(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getResourceAsStream(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getResourceBase() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getResourceBase() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getResourceBase() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getResourceBaseName(Resource) - Static method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
getResourceBundle(String, boolean, Locale) - Static method in class org.eclipse.jetty.util.Loader
 
getResourceClass() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getResourceDescription() - Method in class org.eclipse.jetty.util.LeakDetector.LeakInfo
 
getResourcePaths(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getResourcePaths(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getResourcePaths(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getResources() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
Retrieves the resource collection's resources.
getResources(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getResources(String) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
getResources(String) - Method in class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
 
getResources(String) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
getResponse() - Method in class org.eclipse.jetty.client.api.Result
 
getResponse() - Method in class org.eclipse.jetty.client.HttpExchange
 
getResponse() - Method in exception class org.eclipse.jetty.client.HttpResponseException
 
getResponse() - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectContext
 
getResponse() - Method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
getResponse() - Method in class org.eclipse.jetty.server.AsyncContextState
 
getResponse() - Method in class org.eclipse.jetty.server.HttpChannel
 
getResponse() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
Wait for a response using a parser to detect the end of message
getResponse() - Method in class org.eclipse.jetty.server.Request
 
getResponse() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getResponse() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getResponse(boolean, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
Wait for a response using a parser to detect the end of message
getResponse(String) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponse(String, boolean, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponse(String, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponse(ByteBuffer) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponse(ByteBuffer, boolean, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponse(ByteBuffer, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector
Get a single response using a parser to search for the end of the message.
getResponseBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getResponseBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getResponseBody() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getResponseBuffer() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
getResponseBufferSize() - Method in class org.eclipse.jetty.client.HttpClient
 
getResponseCharacterEncoding() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getResponseCharacterEncoding() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getResponseCode() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getResponseCode() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getResponseCode() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getResponseCookieCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getResponseData() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
getResponseFailure() - Method in class org.eclipse.jetty.client.api.Result
 
getResponseFailure() - Method in class org.eclipse.jetty.client.HttpExchange
 
getResponseHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
getResponseHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
getResponseHeaders() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getResponseHeaderSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getResponseListener() - Method in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
getResponseListener() - Method in class org.eclipse.jetty.client.ContinueProtocolHandler
 
getResponseListener() - Method in interface org.eclipse.jetty.client.ProtocolHandler
 
getResponseListener() - Method in class org.eclipse.jetty.client.RedirectProtocolHandler
 
getResponseListener() - Method in class org.eclipse.jetty.client.UpgradeProtocolHandler
 
getResponseListeners() - Method in class org.eclipse.jetty.client.HttpConversation
Returns the list of response listeners that needs to be notified of response events.
getResponseListeners() - Method in class org.eclipse.jetty.client.HttpExchange
 
getResponseListeners() - Method in class org.eclipse.jetty.client.HttpRequest
 
getResponseMessage() - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
getResponseNotifier() - Method in class org.eclipse.jetty.client.HttpDestination
 
getResponses(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getResponses(String, long, TimeUnit) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getResponses(ByteBuffer) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getResponses(ByteBuffer, long, TimeUnit) - Method in class org.eclipse.jetty.servlet.ServletTester
 
getResponses1xx() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponses2xx() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponses3xx() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponses4xx() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponses5xx() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponsesBytesTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResponseStatusCode() - Method in exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
getResponseStatusCode() - Method in exception class org.eclipse.jetty.websocket.core.exception.UpgradeException
 
getResponsesThrown() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResult() - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
getRetainDays() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve the number of days before rotated log files are deleted.
getRetainDays() - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
getReuseAddress() - Method in class org.eclipse.jetty.io.ClientConnector
 
getReuseAddress() - Method in class org.eclipse.jetty.server.ServerConnector
 
getReuseAddress() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
getRevision() - Method in class org.eclipse.jetty.start.Version
 
getRFC2965SetCookie() - Method in class org.eclipse.jetty.http.HttpCookie
 
getRFC6265SetCookie() - Method in class org.eclipse.jetty.http.HttpCookie
 
getRoleClassNames() - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
getRoleName() - Method in class org.eclipse.jetty.plus.annotation.RunAs
Deprecated.
 
getRolePrincipals() - Method in class org.eclipse.jetty.security.UserStore.User
 
getRolePrincipals(String) - Method in class org.eclipse.jetty.security.UserStore
 
getRoleRefMap() - Method in interface org.eclipse.jetty.server.UserIdentity.Scope
 
getRoleRefMap() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getRoles() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
getRoles() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
getRoles() - Method in interface org.eclipse.jetty.security.ConstraintAware
 
getRoles() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
getRoles() - Method in class org.eclipse.jetty.security.RoleInfo
 
getRoles() - Method in class org.eclipse.jetty.util.security.Constraint
 
getRoles(String) - Method in class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule
 
getRoleTableKey() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getRoleTableName() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getRoleTableRoleField() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getRoot() - Static method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
getRoot() - Static method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getRoot() - Method in class org.eclipse.jetty.webapp.Descriptor
 
getRootLogger() - Static method in class org.eclipse.jetty.util.log.Log
Deprecated.
getRootURL() - Method in class org.eclipse.jetty.server.Request
Reconstructs the URL the client used to make the request.
getRsv1User() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getRsv2User() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getRsv3User() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
getRuleContainer() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
getRules() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
Returns the list of rules.
getRules() - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
Returns the list of rules.
getRunAs(Object) - Method in class org.eclipse.jetty.plus.annotation.RunAsCollection
Deprecated.
 
getRunAsRole() - Method in class org.eclipse.jetty.security.RoleRunAsToken
 
getRunAsRole() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getRunAsRole() - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
getSameSite() - Method in class org.eclipse.jetty.http.HttpCookie
 
getSameSite() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSameSiteDefault(Attributes) - Static method in class org.eclipse.jetty.http.HttpCookie
Get the default value for SameSite cookie attribute, if one has been set for the given context.
getSameSiteFromComment(String) - Static method in class org.eclipse.jetty.http.HttpCookie
 
getSavePeriodSec() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
getSavePeriodSec() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStoreFactory
 
getSAXParser() - Method in class org.eclipse.jetty.xml.XmlParser
 
getScanDepth() - Method in class org.eclipse.jetty.util.Scanner
Get the scanDepth.
getScanFiles() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getScanInterval() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
getScanInterval() - Method in class org.eclipse.jetty.util.Scanner
Get the scan interval
getScanInterval() - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
getScanIntervalSeconds() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getScanIntervalSecs() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getScannables() - Method in class org.eclipse.jetty.util.Scanner
 
getScanTargetFiles() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
getScheduler() - Method in class org.eclipse.jetty.client.HttpClient
 
getScheduler() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getScheduler() - Method in class org.eclipse.jetty.io.ClientConnector
 
getScheduler() - Method in class org.eclipse.jetty.io.CyclicTimeout
 
getScheduler() - Method in class org.eclipse.jetty.io.IdleTimeout
 
getScheduler() - Method in class org.eclipse.jetty.io.SelectorManager
 
getScheduler() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getScheduler() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
getScheduler() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getScheduler() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getScheduler() - Method in interface org.eclipse.jetty.server.Connector
 
getScheduler() - Method in class org.eclipse.jetty.server.HttpChannel
 
getScheduler() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getScheduler() - Method in class org.eclipse.jetty.util.SocketAddressResolver.Async
 
getSchemaName() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getScheme() - Method in interface org.eclipse.jetty.client.api.Destination
 
getScheme() - Method in interface org.eclipse.jetty.client.api.Request
 
getScheme() - Method in class org.eclipse.jetty.client.HttpDestination
 
getScheme() - Method in class org.eclipse.jetty.client.HttpRequest
 
getScheme() - Method in class org.eclipse.jetty.client.Origin
 
getScheme() - Method in interface org.eclipse.jetty.http.HttpURI
 
getScheme() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getScheme() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getScheme() - Method in class org.eclipse.jetty.rewrite.handler.ForwardedSchemeHeaderRule
 
getScheme() - Method in class org.eclipse.jetty.server.Request
 
getScheme() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getScopedClassLoader() - Method in class org.eclipse.jetty.util.thread.ThreadClassLoaderScope
 
getScopes() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getScriptingInvalid() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getScriptRoot() - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
getSearchRoot(String) - Static method in class org.eclipse.jetty.start.PathMatchers
Provide the non-glob / non-regex prefix on the pattern as a Path reference.
getSeconds() - Method in class org.eclipse.jetty.util.DateCache.Tick
 
getSecureCookies() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSecurePort() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSecurePort(HttpConfiguration) - Static method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getSecureRandomAlgorithm() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSecureRandomInstance() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSecureScheme() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSecurityHandler() - Method in class org.eclipse.jetty.security.SecurityHandler.NotChecked
 
getSecurityHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
getSecurityManager() - Static method in class org.eclipse.jetty.util.security.SecurityUtils
 
getSelectableChannel() - Method in class org.eclipse.jetty.io.ClientConnector.Configurator.ChannelWithAddress
 
getSelectCount() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getSelectedCipherSuites() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSelectedModules() - Method in class org.eclipse.jetty.start.StartArgs
The list of selected Modules to enable based on configuration obtained from start.d/*.ini, start.ini, and command line.
getSelectedProtocols() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSelector() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getSelectorCount() - Method in class org.eclipse.jetty.io.SelectorManager
 
getSelectorManager() - Method in class org.eclipse.jetty.server.ServerConnector
 
getSelectorManager() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
getSelectors() - Method in class org.eclipse.jetty.client.AbstractConnectorHttpClientTransport
 
getSelectors() - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
getSelectors() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getSelectors() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSendBufferSize() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSendDateHeader() - Method in class org.eclipse.jetty.server.HttpConfiguration
Indicates if the Date header will be sent in responses.
getSendServerVersion() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSendStream() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
getSendTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
getSendWindow() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getSendWindow() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getSendWriter() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
getSendXPoweredBy() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSentBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSerialization() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
getSerializedAttributes() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
getServeIcon() - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
getServer() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
getServer() - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
getServer() - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
getServer() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
getServer() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getServer() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getServer() - Method in interface org.eclipse.jetty.server.Connector
 
getServer() - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
getServer() - Method in interface org.eclipse.jetty.server.Handler
 
getServer() - Method in class org.eclipse.jetty.server.HttpChannel
 
getServer() - Method in class org.eclipse.jetty.server.HttpConnection
 
getServer() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
getServer() - Method in class org.eclipse.jetty.servlet.ServletTester
 
getServerAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.AliasedX509ExtendedKeyManager
 
getServerAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
getServerAliases(String, Principal[]) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
getServerAuthConfig(String, String, CallbackHandler) - Method in class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
getServerAuthority() - Method in class org.eclipse.jetty.server.HttpChannel
 
getServerAuthority() - Method in class org.eclipse.jetty.server.HttpConfiguration
Get the Server authority override to be used if no authority is provided by a request.
getServerClasses() - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
getServerClasses() - Method in interface org.eclipse.jetty.webapp.Configuration
Get the system classes associated with this Configuration.
getServerClasses() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getServerClassMatcher() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getServerDefault(Server) - Static method in class org.eclipse.jetty.webapp.Configurations
Get/Create the server default Configuration ClassList.
getServerInfo() - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
getServerInfo() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getServerInstanceWrapper() - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider
 
getServerInstanceWrapper() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
getServerMethodHandleLookup() - Static method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
Gives a MethodHandles.Lookup instance to be used to find methods in server classes.
getServerMethodHandleLookup() - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
Gives a MethodHandles.Lookup instance to be used to find methods in server classes.
getServerName() - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
getServerName() - Method in class org.eclipse.jetty.server.Request
 
getServerName() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getServerPort() - Method in class org.eclipse.jetty.server.Request
 
getServerPort() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getServiceName() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getServiceName() - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
getServiceSubject() - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
getServlet() - Method in class org.eclipse.jetty.servlet.ServletHolder
Get the servlet.
getServlet(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
Deprecated.
getServlet(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getServletAttribute(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getServletAttribute(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getServletAttribute(String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getServletAttributes() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getServletAttributes() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getServletAttributes() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getServletConfig() - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
getServletContainerInitializerHolders() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.ServletContainerInitializerStarter
 
getServletContext() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getServletContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getServletContext() - Method in class org.eclipse.jetty.server.Request
 
getServletContext() - Method in class org.eclipse.jetty.server.session.Session
 
getServletContext() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getServletContext() - Method in class org.eclipse.jetty.servlet.DecoratingListener
 
getServletContext() - Method in class org.eclipse.jetty.servlet.Holder.HolderConfig
 
getServletContext() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getServletContext() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getServletContextHandler() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getServletContextHandler(ServletContext) - Static method in class org.eclipse.jetty.servlet.ServletContextHandler
 
getServletContextHandler(ServletContext, String) - Static method in class org.eclipse.jetty.servlet.ServletContextHandler
 
getServletContextName() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getServletContextName() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getServletHandler() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getServletHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
getServletHolder() - Method in class org.eclipse.jetty.servlet.ServletHandler.MappedServlet
 
getServletInfo() - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
getServletInstance() - Method in class org.eclipse.jetty.servlet.ServletHolder
Get the servlet instance (no initialization done).
getServletMapping(String) - Method in class org.eclipse.jetty.servlet.ServletHandler
Get the ServletMapping matching the path
getServletMappings() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getServletMappings(String) - Method in class org.eclipse.jetty.annotations.ServletSecurityAnnotationHandler
Get the ServletMappings for the servlet's class.
getServletName() - Method in class org.eclipse.jetty.server.Request
 
getServletName() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getServletName() - Method in class org.eclipse.jetty.servlet.ServletHolder.Config
 
getServletName() - Method in class org.eclipse.jetty.servlet.ServletMapping
 
getServletNameMappings() - Method in class org.eclipse.jetty.servlet.FilterHolder.Registration
 
getServletNames() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
Deprecated.
getServletNames() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
getServletParameters() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getServletParameters() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getServletParameters() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
getServletPath() - Method in class org.eclipse.jetty.server.Request
 
getServletPath() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
getServletPath() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getServletPath() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getServletPathMapping() - Method in class org.eclipse.jetty.server.Request
 
getServletPathMapping(String, MatchedPath) - Method in class org.eclipse.jetty.servlet.ServletHandler.MappedServlet
 
getServletRegistration(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getServletRegistration(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getServletRegistrations() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getServletRegistrations() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getServletResponse() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getServletResponse() - Method in class org.eclipse.jetty.server.Request
 
getServletResponse(AsyncContextEvent) - Method in class org.eclipse.jetty.server.HttpChannelState
 
getServlets() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
Deprecated.
getServlets() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getServlets(Class<?>) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
getSession() - Method in interface org.eclipse.jetty.http2.api.Stream
 
getSession() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getSession() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
getSession() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
getSession() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
getSession() - Method in interface org.eclipse.jetty.http2.IStream
 
getSession() - Method in interface org.eclipse.jetty.http3.api.Stream
 
getSession() - Method in class org.eclipse.jetty.server.Request
 
getSession() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getSession() - Method in class org.eclipse.jetty.server.session.Session
 
getSession() - Method in interface org.eclipse.jetty.server.session.SessionHandler.SessionIf
 
getSession() - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
getSession() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
getSession() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getSession() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getSession() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getSession() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getSession() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
Access the Servlet HTTP Session (if present)
getSession(boolean) - Method in class org.eclipse.jetty.server.Request
 
getSession(boolean) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getSession(boolean) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getSession(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Get a known existing session
getSession(SessionHandler) - Method in class org.eclipse.jetty.server.Request
Find a session that this request has already entered for the given SessionHandler
getSessionCache() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionCache(SessionHandler) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
getSessionCache(SessionHandler) - Method in interface org.eclipse.jetty.server.session.SessionCacheFactory
 
getSessionContext() - Method in class org.eclipse.jetty.server.session.Session
Deprecated.
getSessionContext() - Method in exception class org.eclipse.jetty.server.session.UnreadableSessionDataException
 
getSessionContext() - Method in exception class org.eclipse.jetty.server.session.UnwriteableSessionDataException
 
getSessionCookie() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionCookie(HttpSession, String, boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
A session cookie is marked as secure IFF any of the following conditions are true: SessionCookieConfig.setSecure == true SessionCookieConfig.setSecure == false && _secureRequestOnly==true && request is HTTPS According to SessionCookieConfig javadoc, case 1 can be used when: "...
getSessionCookieConfig() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getSessionCookieConfig() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionCookieConfig() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getSessionCookieName(SessionCookieConfig) - Static method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionData() - Method in class org.eclipse.jetty.server.session.Session
 
getSessionDataMap() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
getSessionDataMap() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
getSessionDataMap() - Method in interface org.eclipse.jetty.server.session.SessionDataMapFactory
 
getSessionDataStore() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
getSessionDataStore() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.server.session.NullSessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in interface org.eclipse.jetty.server.session.SessionDataStoreFactory
 
getSessionDataStore(SessionHandler) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
getSessionDomain() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionHandler() - Method in class org.eclipse.jetty.server.Request
 
getSessionHandler() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
getSessionHandler() - Method in class org.eclipse.jetty.server.session.Session
 
getSessionHandler() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
getSessionHandler() - Method in class org.eclipse.jetty.server.session.SessionContext
 
getSessionHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
getSessionHandlers() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Get SessionHandler for every context.
getSessionHandlers() - Method in interface org.eclipse.jetty.server.SessionIdManager
Get the set of all session handlers for this node
getSessionHouseKeeper() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
getSessionHouseKeeper() - Method in interface org.eclipse.jetty.server.SessionIdManager
 
getSessionId() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
getSessionIdManager() - Method in class org.eclipse.jetty.server.Server
 
getSessionIdManager() - Method in class org.eclipse.jetty.server.session.SessionHandler
Gets the cross context session id manager
getSessionIdPathParameterName() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionIdPathParameterNamePrefix() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionMaxInactiveIntervalOnAuthentication() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
Get the interval in seconds, which if non-zero, will be set with HttpSession.setMaxInactiveInterval(int) when a session is newly authenticated
getSessionMaxInactiveIntervalOnAuthentication() - Method in class org.eclipse.jetty.security.SecurityHandler
 
getSessionMaxInactiveIntervalOnAuthentication() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
getSessionPath() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionRecvWindow() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getSessions() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
getSessions() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
getSessions() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
getSessionsCreated() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionsCurrent() - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
getSessionsMax() - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
getSessionStallTime() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
getSessionStore() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
getSessionsTotal() - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
getSessionTimeMax() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionTimeMean() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionTimeout() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getSessionTimeout() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
getSessionTimeStdDev() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSessionTimeTotal() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
getSetCookie(CookieCompliance) - Method in class org.eclipse.jetty.http.HttpCookie
 
getSetter(String) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
getSettings() - Method in class org.eclipse.jetty.http2.frames.SettingsFrame
 
getSettings() - Method in class org.eclipse.jetty.http3.frames.SettingsFrame
 
getShowContexts() - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
getShowMessageInTitle() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
getShowModules() - Method in class org.eclipse.jetty.start.StartArgs
 
getShutdownIdleTimeout() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getShutdownToken() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
getSignature() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getSignature() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getSignature() - Method in class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
getSingle() - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
getSinkClass() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
getSize() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
Get the number of elements of the ordering
getSize() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.Entry
 
getSize() - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
Get the size.
getSize() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
getSize() - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
getSize() - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
getSize() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getSize() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getSize() - Method in class org.eclipse.jetty.util.Fields
 
getSize() - Method in class org.eclipse.jetty.util.thread.Sweeper
 
getSizedThreadPool() - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
 
getSkipFileValidationModules() - Method in class org.eclipse.jetty.start.StartArgs
 
getSnapshot(String, String) - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getSnapshotBuildNumber() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getSnapshots() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getSnapshotTimestamp() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getSNIProvider() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
getSNISelector() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
getSocketAddress() - Method in class org.eclipse.jetty.client.Origin.Address
 
getSocketAddress() - Method in class org.eclipse.jetty.io.ClientConnector.Configurator.ChannelWithAddress
 
getSocketAddressResolver() - Method in class org.eclipse.jetty.client.HttpClient
 
getSortedAll() - Method in class org.eclipse.jetty.start.Modules
 
getSortedNames(List<String>) - Method in class org.eclipse.jetty.start.Modules
 
getSource() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
getSource() - Method in class org.eclipse.jetty.servlet.ServletMapping
 
getSourceAddress() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
getSourceAddress() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getSourcePort() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
getSourcePort() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getSources(String) - Method in class org.eclipse.jetty.start.StartArgs
 
getSpecLength() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
The length of the spec.
getSpecLength() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getSpecLength() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getSpecLength() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getSslConnection() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getSslContext() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSslContextFactory() - Method in class org.eclipse.jetty.client.HttpClient
 
getSslContextFactory() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getSslContextFactory() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSslContextFactory() - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
getSslContextFactory() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
getSslContextFactory() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getSSLContextInstance() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getSSLEngine() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
getSSLEngine() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getSSLEngine() - Method in class org.eclipse.jetty.io.ssl.SslHandshakeListener.Event
 
getSSLEngine() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getSSLSession() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
getSslSessionAttribute() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
getSslSessionCacheSize() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Get SSL session cache size.
getSslSessionTimeout() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Get SSL session timeout.
getStackFrames() - Method in class org.eclipse.jetty.util.LeakDetector.LeakInfo
 
getStartArgs() - Method in class org.eclipse.jetty.start.BaseBuilder
 
getStartInis() - Method in interface org.eclipse.jetty.start.config.ConfigSource
 
getStartInis() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getStartModules() - Method in class org.eclipse.jetty.start.StartArgs
 
getStartupTime() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getState() - Method in class org.eclipse.jetty.http.HttpGenerator
 
getState() - Method in class org.eclipse.jetty.http.HttpParser
 
getState() - Method in class org.eclipse.jetty.server.HttpChannel
 
getState() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getState() - Method in class org.eclipse.jetty.server.MultiPartParser
 
getState() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
getState(LifeCycle) - Static method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
getStateTimestamps() - Method in class org.eclipse.jetty.deploy.DeploymentManager.AppEntry
 
getStatic(HttpHeader) - Static method in class org.eclipse.jetty.http2.hpack.HpackContext
 
getStaticHuffmanValue() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.Entry
 
getStaticHuffmanValue() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.StaticEntry
 
getStaticValue() - Method in class org.eclipse.jetty.http2.hpack.StaticTableHttpField
 
getStatistic() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
getStatsOnMs() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getStatus() - Method in interface org.eclipse.jetty.client.api.Response
 
getStatus() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getStatus() - Method in class org.eclipse.jetty.client.HttpResponse
 
getStatus() - Method in class org.eclipse.jetty.http.HttpTester.Response
 
getStatus() - Method in class org.eclipse.jetty.http.MetaData.Response
 
getStatus() - Method in class org.eclipse.jetty.server.Response
 
getStatus() - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
getStatus() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getStatusCode() - Method in exception class org.eclipse.jetty.websocket.api.exceptions.CloseException
 
getStatusCode() - Method in interface org.eclipse.jetty.websocket.api.UpgradeResponse
Get the HTTP Response Status Code
getStatusCode() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeResponse
 
getStatusCode() - Method in exception class org.eclipse.jetty.websocket.core.exception.CloseException
 
getStatusCode() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
getStatusCode() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
getStatusString() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getStdDev() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getStopAtShutdown() - Method in class org.eclipse.jetty.server.Server
 
getStopKey() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getStopKey() - Method in class org.eclipse.jetty.ant.JettyStopTask
 
getStopKey() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getStopPort() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getStopPort() - Method in class org.eclipse.jetty.ant.JettyStopTask
 
getStopPort() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getStopTimeout() - Method in class org.eclipse.jetty.server.Server
 
getStopTimeout() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getStopTimeout() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
getStopWait() - Method in class org.eclipse.jetty.ant.JettyStopTask
 
getStoreDir() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
getStoreDir() - Method in class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
getStream() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getStream() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
getStream() - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
getStream() - Method in class org.eclipse.jetty.logging.StdErrAppender
 
getStream() - Static method in class org.eclipse.jetty.start.StartLog
 
getStream(int) - Method in interface org.eclipse.jetty.http2.api.Session
Retrieves the stream with the given streamId.
getStream(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStream(int) - Method in interface org.eclipse.jetty.http2.ISession
 
getStreamCount() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStreamEndPoint(long) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
getStreamId() - Method in class org.eclipse.jetty.http2.frames.ContinuationFrame
 
getStreamId() - Method in class org.eclipse.jetty.http2.frames.ResetFrame
 
getStreamId() - Method in class org.eclipse.jetty.http2.frames.StreamFrame
 
getStreamId() - Method in class org.eclipse.jetty.http2.frames.WindowUpdateFrame
 
getStreamId() - Method in class org.eclipse.jetty.http2.IStream.FrameList
 
getStreamId() - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
getStreamId() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
getStreamId() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
getStreamId() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
getStreamIdleTimeout() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
getStreamIdleTimeout() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStreamIdleTimeout() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
getStreamIdleTimeout() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
getStreamListener() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
getStreams() - Method in interface org.eclipse.jetty.http2.api.Session
 
getStreams() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStreams() - Method in interface org.eclipse.jetty.http3.api.Session
 
getStreamsClosed() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStreamsOpened() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getStreamsStallTime() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
getString(String) - Method in class org.eclipse.jetty.start.Props
 
getString(String) - Method in class org.eclipse.jetty.util.MultiMap
Get value as String.
getString(String, boolean, boolean) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get a tag as a string.
getString(String, String) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
 
getString(String, String) - Method in class org.eclipse.jetty.start.Props
 
getStringBuffer() - Method in class org.eclipse.jetty.util.Utf8StringBuffer
 
getStringBufferSize() - Method in class org.eclipse.jetty.util.ajax.JSON
 
getStringBuilder() - Method in class org.eclipse.jetty.util.Utf8StringBuilder
 
getStringType() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
getStsMaxAge() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
getStylesheet() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getSubject() - Method in class org.eclipse.jetty.jaas.JAASUserPrincipal
Provide access to the Subject
getSubject() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
getSubject() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
getSubject() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
getSubject() - Method in class org.eclipse.jetty.security.DefaultUserIdentity
 
getSubject() - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
getSubject() - Method in class org.eclipse.jetty.security.openid.OpenIdUserIdentity
 
getSubject() - Method in class org.eclipse.jetty.security.SpnegoUserIdentity
 
getSubject() - Method in interface org.eclipse.jetty.server.UserIdentity
 
getSubmittedFileName() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
getSubmittedFileName() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
getSubprotocol() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getSubProtocol() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
getSubprotocols() - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
getSubProtocols() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the list of offered WebSocket sub-protocols.
getSubProtocols() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getSubProtocols() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getSubProtocols() - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
getSubProtocols() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getSubProtocols() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getSuffix() - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
A simple suffix match for the pathspec or null
getSuffix() - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
getSuffix() - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
getSuffix() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getSuffix() - Method in class org.eclipse.jetty.start.Version
 
getSuffix(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getSuffix(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
getSuperName() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getSupportedMessageTypes() - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
getSuspendedContext() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getSysPropertyName() - Method in class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
getSystemClasses() - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
getSystemClasses() - Method in interface org.eclipse.jetty.webapp.Configuration
Get the system classes associated with this Configuration.
getSystemClasses() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getSystemClassLoaderLocation(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
 
getSystemClassMatcher() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getSystemClassPath(ClassLoader) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntServletHolder
 
getSystemProperties() - Method in class org.eclipse.jetty.ant.types.SystemProperties
 
getSystemProperties() - Method in class org.eclipse.jetty.start.StartArgs
 
getSystemUserIdentity() - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
getSystemUserIdentity() - Method in interface org.eclipse.jetty.security.IdentityService
 
getTableCapacity() - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
getTableCapacity() - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
getTableName() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getTag() - Method in interface org.eclipse.jetty.client.api.Request
 
getTag() - Method in class org.eclipse.jetty.client.HttpRequest
 
getTag() - Method in class org.eclipse.jetty.client.Origin
 
getTag() - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
getTaglibLocation() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
getTaglibs() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
getTaglibURI() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
getTags() - Method in class org.eclipse.jetty.start.Module
 
getTarget() - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
getTarget() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getTarget() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
getTargetClass() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
getTargetClass() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
getTargetClass() - Method in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
getTargetClassName() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
getTargetClassName() - Method in class org.eclipse.jetty.plus.annotation.RunAs
Deprecated.
 
getTasks() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
getTempDir() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Get the user supplied Work Directory.
getTempDir() - Method in class org.eclipse.jetty.server.handler.FileBufferedResponseHandler
 
getTempDirectory() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
getTempDirectory() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getTempDirectory() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getTextDecoders(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getTextHandle() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getTextMetadata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getTextMetadata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getTextSink() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
getTextStreamDecoders(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
getThreadCallerPrincipalCallback() - Method in class org.eclipse.jetty.security.jaspi.ServletCallbackHandler
 
getThreadGroupPrincipalCallback() - Method in class org.eclipse.jetty.security.jaspi.ServletCallbackHandler
 
getThreadLimit() - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getThreadLimit(String) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getThreadPool() - Method in class org.eclipse.jetty.server.Server
 
getThreadPoolBudget() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getThreadPoolBudget() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getThreadPoolBudget() - Method in interface org.eclipse.jetty.util.thread.ThreadPool.SizedThreadPool
 
getThreads() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
getThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The fundamental value that represents the number of threads currently known by this thread pool.
getThreads() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
getThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPool
 
getThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPoolBudget.Lease
 
getThreads() - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget.Leased
 
getThreadsPriority() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getThreadsPriority() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getThrowable() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
getThrowable(int) - Method in exception class org.eclipse.jetty.util.MultiException
 
getThrowables() - Method in exception class org.eclipse.jetty.util.MultiException
 
getTicketCachePath() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getTimeout() - Method in interface org.eclipse.jetty.client.api.Request
 
getTimeout() - Method in class org.eclipse.jetty.client.HttpConversation
Returns the total timeout for the conversation.
getTimeout() - Method in class org.eclipse.jetty.client.HttpRequest
 
getTimeout() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getTimeout() - Method in class org.eclipse.jetty.server.AsyncContextState
 
getTimeout() - Method in class org.eclipse.jetty.server.HttpChannelState
 
getTimeout() - Method in class org.eclipse.jetty.util.SocketAddressResolver.Async
 
getTimeout() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getTimeStamp() - Method in class org.eclipse.jetty.server.Request
Get Request TimeStamp
getTimeZone() - Method in class org.eclipse.jetty.server.RequestLogWriter
 
getTimeZone() - Method in class org.eclipse.jetty.util.DateCache
 
getTimeZone(String) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
 
getTldBundles() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
getTlds(File) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Find all .tld files in all subdirs of the given dir.
getTlds(URI) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Find all .tld files in the given jar.
getTLV(int) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
Gets a TLV vector, see section 2.2.7 of the PROXY protocol specification.
getTLVs() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
getTo() - Method in class org.eclipse.jetty.deploy.graph.Edge
 
getToken() - Method in class org.eclipse.jetty.security.SpnegoUserPrincipal
 
getToken(byte) - Static method in class org.eclipse.jetty.http.HttpTokens
 
getToken(char) - Static method in class org.eclipse.jetty.http.HttpTokens
 
getTokenEndpoint() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
getTotal() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
 
getTotal() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getTotalKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getTotalKeys() - Method in class org.eclipse.jetty.io.SelectorManager
Get total number of keys from each selector.
getTotalLength() - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
getTrailerFields() - Method in class org.eclipse.jetty.server.Request
 
getTrailerFields() - Method in class org.eclipse.jetty.server.Response
 
getTrailerHttpFields() - Method in class org.eclipse.jetty.server.Request
 
getTrailers() - Method in class org.eclipse.jetty.client.HttpRequest
 
getTrailers() - Method in class org.eclipse.jetty.client.HttpResponse
 
getTrailers() - Method in class org.eclipse.jetty.server.Response
 
getTrailerSupplier() - Method in class org.eclipse.jetty.http.MetaData
 
getTransientListeners() - Method in class org.eclipse.jetty.server.HttpChannel
Deprecated.
getTransport() - Method in class org.eclipse.jetty.client.HttpClient
 
getTransport() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getTransport() - Method in interface org.eclipse.jetty.io.EndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getTransport() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
getTransport() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
getTransport() - Method in interface org.eclipse.jetty.server.Connector
 
getTransport() - Method in class org.eclipse.jetty.server.LocalConnector
 
getTransport() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getTransport() - Method in class org.eclipse.jetty.server.ServerConnector
 
getTransport() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
getTrimDirectiveWhitespaces() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getTrustManagerFactoryAlgorithm() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustManagerFactoryInstance() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustManagers(KeyStore, Collection<? extends CRL>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustStore() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getTrustStore() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
getTrustStore() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustStorePath() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustStoreProvider() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getTrustStoreProvider() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustStoreResource() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTrustStoreType() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
getTrustStoreType() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getTunnellingEndPoint() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
getTunnellingEndPoint() - Method in class org.eclipse.jetty.server.HttpChannel
 
getTunnellingEndPoint() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
getType() - Method in class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
getType() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.TLV
 
getType() - Method in class org.eclipse.jetty.client.util.AbstractAuthentication
 
getType() - Method in class org.eclipse.jetty.client.util.BasicAuthentication
 
getType() - Method in class org.eclipse.jetty.client.util.DigestAuthentication
 
getType() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getType() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
getType() - Method in class org.eclipse.jetty.http2.frames.Frame
 
getType() - Method in enum org.eclipse.jetty.http2.frames.FrameType
 
getType() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
getType() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
getType() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
getType() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
getType() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
getTypeName() - Method in class org.eclipse.jetty.session.infinispan.SessionDataMarshaller
 
getUnavailableException() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
getUnavailableException() - Method in class org.eclipse.jetty.webapp.WebAppContext
Get an exception that caused the webapp to be unavailable
getUndecoratable() - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
Get the set of classes that will not be decorated.
getUnidirectionalStreamRecvWindow() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
getUnits() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getUnits() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
getUnixSocket() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
getUpdate() - Method in class org.eclipse.jetty.start.Version
 
getUpdated() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata.Snapshot
 
getUpdateSessionStatement(Connection, String, SessionContext) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getUpdateStatement(Connection, String, SessionContext) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getUpgradeProtocol() - Method in class org.eclipse.jetty.client.HttpRequest
 
getUpgradeRequest() - Method in interface org.eclipse.jetty.websocket.api.Session
Get the UpgradeRequest used to create this session
getUpgradeRequest() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
getUpgradeRequest() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getUpgradeRequest() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
getUpgradeResponse() - Method in interface org.eclipse.jetty.websocket.api.Session
Get the UpgradeResponse used to create this session
getUpgradeResponse() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
getUpgradeResponse() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
getUptime() - Method in class org.eclipse.jetty.util.Uptime.DefaultImpl
 
getUptime() - Static method in class org.eclipse.jetty.util.Uptime
 
getUptime() - Method in interface org.eclipse.jetty.util.Uptime.Impl
 
getUri() - Method in class org.eclipse.jetty.http.HttpTester.Request
 
getURI() - Method in interface org.eclipse.jetty.client.api.Authentication.Result
 
getURI() - Method in interface org.eclipse.jetty.client.api.Request
 
getURI() - Method in class org.eclipse.jetty.client.HttpProxy
 
getURI() - Method in class org.eclipse.jetty.client.HttpProxy.TunnelRequest
 
getURI() - Method in class org.eclipse.jetty.client.HttpRequest
 
getURI() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
getURI() - Method in class org.eclipse.jetty.client.util.AbstractAuthentication
 
getURI() - Method in class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
getURI() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication.SPNEGOResult
 
getURI() - Method in class org.eclipse.jetty.http.MetaData.Request
 
getURI() - Method in class org.eclipse.jetty.server.Server
 
getURI() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
getURI() - Method in class org.eclipse.jetty.util.resource.PathResource
 
getURI() - Method in class org.eclipse.jetty.util.resource.Resource
URI representing the resource.
getURI() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
getURI() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns a URI representing the given resource
getURI(Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
getUriCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getUriLastPathSegment(URI) - Static method in class org.eclipse.jetty.util.URIUtil
Given a URI, attempt to get the last segment.
getURIs() - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
getURIs() - Method in class org.eclipse.jetty.util.HttpCookieStore
 
getURIString() - Method in class org.eclipse.jetty.http.MetaData.Request
 
getUriTemplatePathSpec() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
getURL() - Method in interface org.eclipse.jetty.http.ComplianceViolation
 
getURL() - Method in enum org.eclipse.jetty.http.CookieCompliance.Violation
 
getURL() - Method in enum org.eclipse.jetty.http.HttpCompliance.Violation
 
getURL() - Method in enum org.eclipse.jetty.http.UriCompliance.Violation
 
getURL() - Method in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
getUrlPatternMappings() - Method in class org.eclipse.jetty.servlet.FilterHolder.Registration
 
getUrlPatterns() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
getURLs() - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
getURLs() - Method in class org.eclipse.jetty.osgi.boot.utils.FakeURLClassLoader
 
getUrlsForBundlesWithTlds(DeploymentManager, BundleFileLocatorHelper) - Method in interface org.eclipse.jetty.osgi.boot.utils.TldBundleDiscoverer
Find bundles that contain tlds and convert into URL references to their location.
getUseCaches() - Method in class org.eclipse.jetty.util.resource.URLResource
 
getUser() - Method in interface org.eclipse.jetty.http.HttpURI
 
getUser() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getUser() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getUser() - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
getUser(String) - Method in class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule
Load info from database
getUser(String) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
getUser(String) - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
get the available information about the user
getUser(String) - Method in class org.eclipse.jetty.jaas.spi.PropertyFileLoginModule
 
getUserAgentField() - Method in class org.eclipse.jetty.client.HttpClient
 
getUserDataConstraint() - Method in class org.eclipse.jetty.security.RoleInfo
 
getUserId() - Method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
getUserIdentity() - Method in class org.eclipse.jetty.security.AbstractUserAuthentication
 
getUserIdentity() - Method in class org.eclipse.jetty.security.authentication.SessionAuthentication
 
getUserIdentity() - Method in interface org.eclipse.jetty.server.Authentication.User
 
getUserIdentity() - Method in class org.eclipse.jetty.server.Request
 
getUserIdentity(HttpServletRequest, String) - Method in interface org.eclipse.jetty.security.authentication.AuthorizationService
 
getUserIdentityScope() - Method in class org.eclipse.jetty.server.Request
 
getUserKey() - Method in class org.eclipse.jetty.security.JDBCLoginService.JDBCUserPrincipal
 
getUserKeyTabPath() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getUsername() - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
getUserName() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getUserName() - Method in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
getUserName() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
getUserName() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
getUserName() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
getUserPassword() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
getUserPrincipal() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
getUserPrincipal() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
getUserPrincipal() - Method in class org.eclipse.jetty.security.DefaultUserIdentity
 
getUserPrincipal() - Method in class org.eclipse.jetty.security.openid.OpenIdUserIdentity
 
getUserPrincipal() - Method in class org.eclipse.jetty.security.SpnegoUserIdentity
 
getUserPrincipal() - Method in class org.eclipse.jetty.security.UserStore.User
 
getUserPrincipal() - Method in class org.eclipse.jetty.server.Request
 
getUserPrincipal() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
getUserPrincipal() - Method in interface org.eclipse.jetty.server.UserIdentity
 
getUserPrincipal() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Get the User Principal for this request.
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaClientUpgradeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getUserPrincipal() - Method in interface org.eclipse.jetty.websocket.jakarta.common.UpgradeRequest
For Session.getUserPrincipal()
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.jakarta.common.UpgradeRequestAdapter
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaServerUpgradeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
getUserPrincipal() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
getUserPrincipal(String) - Method in class org.eclipse.jetty.security.UserStore
 
getUserProperties() - Method in class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
getUserProperties() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
getUserRoleLink(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
get a user role link.
getUserRoleTableName() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserRoleTableRoleKey() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserRoleTableUserKey() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserTableKey() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserTableName() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserTablePasswordField() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUserTableUserField() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
getUtf8Bytes(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
getUtilizationRate() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The rate between the number of utilized threads and the maximum number of utilizable threads.
getUtilizedThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
The number of threads executing transient jobs.
getValidatingConnectionCount() - Method in class org.eclipse.jetty.client.ValidatingConnectionPool
 
getValue() - Method in class org.eclipse.jetty.annotations.AnnotationParser.FieldInfo
 
getValue() - Method in class org.eclipse.jetty.ant.types.Attribute
 
getValue() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.TLV
 
getValue() - Method in class org.eclipse.jetty.http.HttpCookie
 
getValue() - Method in class org.eclipse.jetty.http.HttpField
 
getValue() - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Returns the header value.
getValue() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
Returns the header value.
getValue() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata.Snapshot
 
getValue() - Method in class org.eclipse.jetty.util.Fields.Field
 
getValue() - Method in class org.eclipse.jetty.xml.XmlParser.Attribute
 
getValue(String) - Method in class org.eclipse.jetty.server.session.Session
Deprecated.
getValue(String) - Static method in class org.eclipse.jetty.start.Props
 
getValue(String, int) - Method in class org.eclipse.jetty.util.MultiMap
Get a value from a multiple value.
getValueAsInt() - Method in class org.eclipse.jetty.util.Fields.Field
Attempts to convert the result of Fields.Field.getValue() to an integer, returning it if the conversion is successful; returns null if the result of Fields.Field.getValue() is null.
getValueNames() - Method in class org.eclipse.jetty.server.session.Session
Deprecated.
As of Servlet 2.2, this method is replaced by Session.getAttributeNames()
getValueParameters(String, Map<String, String>) - Static method in class org.eclipse.jetty.http.HttpField
Get field value parameters.
getValues() - Method in class org.eclipse.jetty.http.HttpField
 
getValues() - Method in class org.eclipse.jetty.http.QuotedCSV
 
getValues() - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
getValues() - Method in class org.eclipse.jetty.util.Fields.Field
 
getValues(String) - Method in interface org.eclipse.jetty.http.HttpFields
Get multi headers
getValues(String) - Static method in class org.eclipse.jetty.start.Props
 
getValues(String) - Method in class org.eclipse.jetty.util.MultiMap
Get multiple values.
getValuesList(String) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple header of the same name
getValuesList(HttpHeader) - Method in interface org.eclipse.jetty.http.HttpFields
Get multiple field values of the same name
getVariableCount() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getVariables() - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
getVariance() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
getVary() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
getVaryField() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
getVersion() - Method in class org.eclipse.jetty.annotations.AnnotationParser.ClassInfo
 
getVersion() - Method in interface org.eclipse.jetty.client.api.Request
 
getVersion() - Method in interface org.eclipse.jetty.client.api.Response
 
getVersion() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
getVersion() - Method in class org.eclipse.jetty.client.HttpRequest
 
getVersion() - Method in class org.eclipse.jetty.client.HttpResponse
 
getVersion() - Method in class org.eclipse.jetty.deploy.DeploymentManager.AppEntry
 
getVersion() - Method in class org.eclipse.jetty.http.HttpCookie
 
getVersion() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
getVersion() - Method in enum org.eclipse.jetty.http.HttpVersion
 
getVersion() - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
getVersion() - Static method in class org.eclipse.jetty.server.Server
 
getVersion() - Method in class org.eclipse.jetty.start.fileinits.MavenMetadata
 
getVersion() - Method in class org.eclipse.jetty.start.Module
 
getVersion() - Method in class org.eclipse.jetty.util.JavaVersion
 
getVersion() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
 
getVersion() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
getVersion() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
getVersion(File) - Static method in class org.eclipse.jetty.start.JarVersion
 
getVersion(Class<?>) - Static method in class org.eclipse.jetty.util.ManifestUtils
Attempts to return the version of the jar/module for the given class.
getVhost() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
getVhost() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
getVhost() - Method in class org.eclipse.jetty.server.session.SessionContext
 
getVhost() - Method in class org.eclipse.jetty.server.session.SessionData
 
getVHost() - Method in class org.eclipse.jetty.server.session.Session
 
getViaHost() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getViolations() - Method in interface org.eclipse.jetty.http.HttpURI
 
getViolations() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
getViolations() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
getVirtualHostColumn() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
getVirtualHosts() - Method in class org.eclipse.jetty.rewrite.handler.VirtualHostRuleContainer
Get the virtual hosts that the rules within this container will apply to
getVirtualHosts() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get the virtual hosts for the context.
getVirtualServerName() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
getVirtualServerName() - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
getVirtualThreadsExecutor() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
getVirtualThreadsExecutor() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
getVirtualThreadsExecutor() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
getVirtualThreadsExecutor() - Method in interface org.eclipse.jetty.util.VirtualThreads.Configurable
 
getVirtualThreadsExecutor(Executor) - Static method in class org.eclipse.jetty.util.VirtualThreads
 
getWantClientAuth() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
getWar() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getWeakETag() - Method in class org.eclipse.jetty.util.resource.Resource
Generate a weak ETag reference for this Resource.
getWeakETag(String) - Method in class org.eclipse.jetty.util.resource.Resource
 
getWebApplications() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
getWebDescriptor() - Method in class org.eclipse.jetty.webapp.MetaData
 
getWebInf() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
getWebInfClassesResources() - Method in class org.eclipse.jetty.webapp.MetaData
 
getWebInfResources(boolean) - Method in class org.eclipse.jetty.webapp.MetaData
 
getWebSocketComponents() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
getWebSocketComponents() - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
getWebSocketComponents() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
getWebSocketComponents() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
getWebSocketComponents() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getWebSocketComponents() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
getWebSocketComponents(ServletContext) - Static method in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
 
getWebSocketCoreClient() - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
getWebSocketCreator() - Method in class org.eclipse.jetty.websocket.core.server.internal.CreatorNegotiator
 
getWebSocketCreator(PathSpec) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
getWebsocketMessageType() - Method in class org.eclipse.jetty.websocket.jakarta.common.RegisteredMessageHandler
 
getWebSocketNegotiator(PathSpec) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
getWeight() - Method in class org.eclipse.jetty.http2.frames.PriorityFrame
 
getWeight() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
getWeight() - Method in interface org.eclipse.jetty.start.config.ConfigSource
The weight of this source, used for proper ordering of the config source search order.
getWeight() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
getWelcomeFactory() - Method in class org.eclipse.jetty.server.ResourceService
 
getWelcomeFile(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getWelcomeFile(String) - Method in interface org.eclipse.jetty.server.ResourceService.WelcomeFactory
Finds a matching welcome file for the supplied Resource.
getWelcomeFile(String) - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
getWelcomeFiles() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getWelcomeFiles() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getWhiteListHosts() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
getWhiteListHosts() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
getWildcardIndex() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
 
getWilds() - Method in class org.eclipse.jetty.util.ssl.X509
 
getWindowCapacity() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getWindowCapacity(long) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
getWindowDelta() - Method in class org.eclipse.jetty.http2.frames.WindowUpdateFrame
 
getWorkerName() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Get the workname.
getWorkerName() - Method in class org.eclipse.jetty.server.session.SessionContext
 
getWorkerName() - Method in interface org.eclipse.jetty.server.SessionIdManager
 
getWrapped() - Method in class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.servlet.ListenerHolder.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
getWriteFlusher() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getWriteFlusher() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
getWriter() - Method in class org.eclipse.jetty.server.CustomRequestLog
 
getWriter() - Method in class org.eclipse.jetty.server.Response
 
getWriter() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
getWriteThreshold() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
getWriteTimeout() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
getWriteTimeout() - Method in interface org.eclipse.jetty.websocket.core.Configuration
Get the Write Timeout
getWriteTimeout() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
getWriteTimeout() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
getWritten() - Method in class org.eclipse.jetty.server.HttpOutput
 
getX509(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
getX509CertChain(SSLSession) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Obtain the X509 Certificate Chain from the provided SSLSession using this SslContextFactory's optional Provider specific CertificateFactory.
getXML() - Method in class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 
getXmlFiles() - Method in class org.eclipse.jetty.start.StartArgs
 
getXmlParser() - Method in class org.eclipse.jetty.xml.XmlConfiguration
 
getXmls() - Method in class org.eclipse.jetty.start.Module
 
getXpath() - Method in class org.eclipse.jetty.xml.XmlParser
 
GIT_HASH - Static variable in class org.eclipse.jetty.util.Jetty
 
GLOBAL_ERROR_PAGE - Static variable in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
GlobalWebappConfigBinding - Class in org.eclipse.jetty.deploy.bindings
Provides a way of globally setting various aspects of webapp contexts.
GlobalWebappConfigBinding() - Constructor for class org.eclipse.jetty.deploy.bindings.GlobalWebappConfigBinding
 
GO_AWAY - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
goAway(boolean) - Method in interface org.eclipse.jetty.http3.api.Session
Initiates the shutdown of this session by sending a GOAWAY frame to the other peer.
goAway(GoAwayFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
GOAWAY - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
GoAwayBodyParser - Class in org.eclipse.jetty.http2.parser
 
GoAwayBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.GoAwayBodyParser
 
GoAwayFrame - Class in org.eclipse.jetty.http2.frames
 
GoAwayFrame - Class in org.eclipse.jetty.http3.frames
 
GoAwayFrame(int, int, byte[]) - Constructor for class org.eclipse.jetty.http2.frames.GoAwayFrame
 
GoAwayFrame(long) - Constructor for class org.eclipse.jetty.http3.frames.GoAwayFrame
 
GoAwayGenerator - Class in org.eclipse.jetty.http2.generator
 
GoAwayGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.GoAwayGenerator
 
GONE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
GONE_410 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
Graceful - Interface in org.eclipse.jetty.util.component
Jetty components that wish to be part of a Graceful shutdown implement this interface so that the Graceful.shutdown() method will be called to initiate a shutdown.
GRACEFUL - Static variable in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
Graceful.Shutdown - Class in org.eclipse.jetty.util.component
A utility class to assist implementing the Graceful interface.
Graceful.ThrowingRunnable - Interface in org.eclipse.jetty.util.component
 
Graph - Class in org.eclipse.jetty.deploy.graph
Basic directed graph implementation
Graph() - Constructor for class org.eclipse.jetty.deploy.graph.Graph
 
GraphOutputDot - Class in org.eclipse.jetty.deploy.graph
Output the Graph in GraphViz Dot format.
groupId - Variable in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
GZIP - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
GZIP - Static variable in class org.eclipse.jetty.http.CompressedContentFormat
 
GZIP - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
GZIP_HANDLER_ETAGS - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
GZIPContentDecoder - Class in org.eclipse.jetty.client
ContentDecoder for the "gzip" encoding.
GZIPContentDecoder - Class in org.eclipse.jetty.http
Decoder for the "gzip" content encoding.
GZIPContentDecoder() - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder
 
GZIPContentDecoder() - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder(int) - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder
 
GZIPContentDecoder(int) - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.client.GZIPContentDecoder
 
GZIPContentDecoder(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder(ByteBufferPool, int, boolean) - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder(InflaterPool, ByteBufferPool, int) - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder(InflaterPool, ByteBufferPool, int, boolean) - Constructor for class org.eclipse.jetty.http.GZIPContentDecoder
 
GZIPContentDecoder.Factory - Class in org.eclipse.jetty.client
Specialized ContentDecoder.Factory for the "gzip" encoding.
GZIPContentTransformer(HttpClient, AsyncMiddleManServlet.ContentTransformer) - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.GZIPContentTransformer
 
GZIPContentTransformer(AsyncMiddleManServlet.ContentTransformer) - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.GZIPContentTransformer
 
GzipFactory - Interface in org.eclipse.jetty.server.handler.gzip
 
GzipHandler - Class in org.eclipse.jetty.server.handler.gzip
A Handler that can dynamically GZIP uncompress requests, and compress responses.
GzipHandler() - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHandler
Instantiates a new GzipHandler.
GzipHttpInputInterceptor - Class in org.eclipse.jetty.server.handler.gzip
An HttpInput Interceptor that inflates GZIP encoded request content.
GzipHttpInputInterceptor(InflaterPool, ByteBufferPool, int) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHttpInputInterceptor
 
GzipHttpInputInterceptor(InflaterPool, ByteBufferPool, int, boolean) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHttpInputInterceptor
 
GzipHttpOutputInterceptor - Class in org.eclipse.jetty.server.handler.gzip
 
GzipHttpOutputInterceptor(GzipFactory, HttpField, int, HttpChannel, HttpOutput.Interceptor, boolean) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
GzipHttpOutputInterceptor(GzipFactory, HttpField, HttpChannel, HttpOutput.Interceptor, boolean) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
GzipHttpOutputInterceptor(GzipFactory, HttpChannel, HttpOutput.Interceptor, boolean) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 

H

H3_GENERAL_PROTOCOL_ERROR - Static variable in exception class org.eclipse.jetty.http3.qpack.QpackException
 
HaltLifeCycleListener - Class in org.eclipse.jetty.util.component
A LifeCycle listener that halts the JVM with exit code 0 when notified of the "started" event.
HaltLifeCycleListener() - Constructor for class org.eclipse.jetty.util.component.HaltLifeCycleListener
 
handle() - Method in class org.eclipse.jetty.server.HttpChannel
 
handle(Class<?>) - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
handle(Class<?>) - Method in interface org.eclipse.jetty.annotations.AnnotationIntrospector.IntrospectableAnnotationHandler
 
handle(Runnable) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
handle(Runnable) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Can be overridden to scope into the correct classloader before calling application code.
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.security.SecurityHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.AbstractHandler.ErrorDispatchHandler
Deprecated.
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.AsyncDelayHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in interface org.eclipse.jetty.server.Handler
Handle a request.
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.HandlerList
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Checks the incoming request against the whitelist and blacklist
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.RequestLogHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ScopedHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.SecuredRedirectHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
handle(Callback[]) - Method in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
handle(Callback[]) - Method in class org.eclipse.jetty.jaas.callback.DefaultCallbackHandler
 
handle(Callback[]) - Method in class org.eclipse.jetty.security.jaspi.ServletCallbackHandler
 
handle(AnnotationParser.ClassInfo) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.ClassInfo) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.ClassInfo) - Method in class org.eclipse.jetty.annotations.ClassInheritanceHandler
 
handle(AnnotationParser.ClassInfo, String) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.ClassInfo, String) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.ClassInfo, String) - Method in class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
Handle finding a class that is annotated with the annotation we were constructed with.
handle(AnnotationParser.ClassInfo, String) - Method in class org.eclipse.jetty.annotations.WebFilterAnnotationHandler
 
handle(AnnotationParser.ClassInfo, String) - Method in class org.eclipse.jetty.annotations.WebListenerAnnotationHandler
 
handle(AnnotationParser.ClassInfo, String) - Method in class org.eclipse.jetty.annotations.WebServletAnnotationHandler
Handle discovering a WebServlet annotation.
handle(AnnotationParser.FieldInfo) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.FieldInfo) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.FieldInfo, String) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.FieldInfo, String) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.FieldInfo, String) - Method in class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
Handle finding a field that is annotated with the annotation we were constructed with.
handle(AnnotationParser.FieldInfo, String) - Method in class org.eclipse.jetty.annotations.WebFilterAnnotationHandler
 
handle(AnnotationParser.FieldInfo, String) - Method in class org.eclipse.jetty.annotations.WebListenerAnnotationHandler
 
handle(AnnotationParser.FieldInfo, String) - Method in class org.eclipse.jetty.annotations.WebServletAnnotationHandler
 
handle(AnnotationParser.MethodInfo) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.MethodInfo) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.MethodInfo, String) - Method in class org.eclipse.jetty.annotations.AnnotationParser.AbstractHandler
 
handle(AnnotationParser.MethodInfo, String) - Method in interface org.eclipse.jetty.annotations.AnnotationParser.Handler
 
handle(AnnotationParser.MethodInfo, String) - Method in class org.eclipse.jetty.annotations.ContainerInitializerAnnotationHandler
Handle finding a method that is annotated with the annotation we were constructed with.
handle(AnnotationParser.MethodInfo, String) - Method in class org.eclipse.jetty.annotations.WebFilterAnnotationHandler
 
handle(AnnotationParser.MethodInfo, String) - Method in class org.eclipse.jetty.annotations.WebListenerAnnotationHandler
 
handle(AnnotationParser.MethodInfo, String) - Method in class org.eclipse.jetty.annotations.WebServletAnnotationHandler
 
handle(HttpChannel) - Method in class org.eclipse.jetty.server.Server
 
handle(Request, ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHolder
Service a request with this servlet.
handle(Request, Runnable) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Handle a runnable in the scope of this context and a particular request
handle(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
Called when there is demand for a single frame to be produced.
handle(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension.FragmentingDemandingFlusher
 
handleAcceptFailure(Throwable) - Method in class org.eclipse.jetty.server.AbstractConnector
 
handleAcceptFailure(Throwable) - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
handleAsync(HttpChannel) - Method in class org.eclipse.jetty.server.Server
 
handleAuthentication(HttpServletRequest, HttpServletResponse, String) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Handles the authentication before setting up the tunnel to the remote server.
handleClass(Class<?>) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
 
handleConnect(Request, HttpServletRequest, HttpServletResponse, String) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Handles a CONNECT request.
handleErrorPage(HttpServletRequest, Writer, int, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
handleException(Throwable) - Method in class org.eclipse.jetty.server.HttpChannel
Sends an error 500, performing a special logic to detect whether the request is suspended, to avoid concurrent writes from the application.
handleException(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
handleException(Throwable) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
handleField(Class<?>, Field) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
 
handleField(String, String, int, String, String, Object, String) - Method in class org.eclipse.jetty.annotations.RunAsAnnotationHandler
 
handleMethod(Class<?>, Method) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
Process a Resource annotation on a Method.
handleMethod(String, String, int, String, String, String[], String) - Method in class org.eclipse.jetty.annotations.RunAsAnnotationHandler
 
handleOptions(Request, Response) - Method in class org.eclipse.jetty.server.Server
 
Handler - Interface in org.eclipse.jetty.server
A Jetty Server Handler.
HandlerCollection - Class in org.eclipse.jetty.server.handler
A collection of handlers.
HandlerCollection() - Constructor for class org.eclipse.jetty.server.handler.HandlerCollection
 
HandlerCollection(boolean, Handler...) - Constructor for class org.eclipse.jetty.server.handler.HandlerCollection
 
HandlerCollection(Handler...) - Constructor for class org.eclipse.jetty.server.handler.HandlerCollection
 
HandlerCollection.Handlers - Class in org.eclipse.jetty.server.handler
 
HandlerContainer - Interface in org.eclipse.jetty.server
A Handler that contains other Handlers.
HandlerList - Class in org.eclipse.jetty.server.handler
HandlerList.
HandlerList() - Constructor for class org.eclipse.jetty.server.handler.HandlerList
 
HandlerList(Handler...) - Constructor for class org.eclipse.jetty.server.handler.HandlerList
 
Handlers(Handler[]) - Constructor for class org.eclipse.jetty.server.handler.HandlerCollection.Handlers
 
HandlerWrapper - Class in org.eclipse.jetty.server.handler
A HandlerWrapper acts as a Handler but delegates the handle method and life cycle events to a delegate.
HandlerWrapper() - Constructor for class org.eclipse.jetty.server.handler.HandlerWrapper
 
handleSelectFailure(Selector, Throwable) - Method in class org.eclipse.jetty.io.ManagedSelector
 
handleUnknown(JSON.Source, char) - Method in class org.eclipse.jetty.util.ajax.JSON
 
handleWatchEvent(Path, PathWatcher.PathWatchEvent) - Method in class org.eclipse.jetty.util.PathWatcher
Add an event reported by the WatchService to list of pending events that will be sent after their quiet time has expired.
handling() - Method in class org.eclipse.jetty.server.HttpChannelState
 
HANDLING - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.State
 
handshakeFailed(SslHandshakeListener.Event, Throwable) - Method in interface org.eclipse.jetty.io.ssl.SslHandshakeListener
Callback method invoked when the TLS handshake fails.
Handshaker - Interface in org.eclipse.jetty.websocket.core.server
 
HandshakerSelector - Class in org.eclipse.jetty.websocket.core.server.internal
Selects between the two Handshaker implementations, RFC6455 (HTTP/1.1 WebSocket Upgrades) and RFC68441 (HTTP/2 WebSocket Upgrades)
HandshakerSelector() - Constructor for class org.eclipse.jetty.websocket.core.server.internal.HandshakerSelector
 
handshakeSucceeded(SslHandshakeListener.Event) - Method in interface org.eclipse.jetty.io.ssl.SslHandshakeListener
Callback method invoked when the TLS handshake succeeds.
hasAmbiguousEmptySegment() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAmbiguousEncoding() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAmbiguousParameter() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAmbiguousSegment() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAmbiguousSeparator() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAuthenticationResults() - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
 
hasAuthenticationResults() - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
hasAuthority() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasAuthority() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
hasAuthority() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
hasBinaryMetadata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
hasContent() - Method in interface org.eclipse.jetty.server.ContentProducer
Check if this ContentProducer instance contains some content without querying the underlying HttpChannel.
hasContent() - Method in class org.eclipse.jetty.server.HttpInput.Content
Check if there is at least one byte left in the buffer.
hasContent() - Method in class org.eclipse.jetty.server.HttpInput
Check if this HttpInput instance has content stored internally, without fetching/parsing anything from the underlying channel.
hasContent() - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
hasContent(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
hasContent(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Check for a non null and non empty buffer.
hasDataConstraint() - Method in class org.eclipse.jetty.util.security.Constraint
 
hasDefaultConfig() - Method in class org.eclipse.jetty.start.Module
 
hasDemandOrStall() - Method in class org.eclipse.jetty.client.HttpReceiver
 
hasEntry(Object) - Static method in class org.eclipse.jetty.util.LazyList
Simple utility method to test if List has at least 1 entry.
hasExcludes() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
hasFiles(BaseHome, Props) - Method in class org.eclipse.jetty.start.Module
 
hasFlag(int) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
hasFlag(int) - Method in class org.eclipse.jetty.http2.parser.HeaderParser
Returns whether the given header flag is present.
hasFlag(int) - Method in class org.eclipse.jetty.http2.parser.Parser
 
hashCode() - Method in class org.eclipse.jetty.client.ContentDecoder.Factory
 
hashCode() - Method in class org.eclipse.jetty.client.Origin.Address
 
hashCode() - Method in class org.eclipse.jetty.client.Origin
 
hashCode() - Method in class org.eclipse.jetty.client.Origin.Protocol
 
hashCode() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
 
hashCode() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
 
hashCode() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.TLV
 
hashCode() - Method in class org.eclipse.jetty.deploy.graph.Edge
 
hashCode() - Method in class org.eclipse.jetty.deploy.graph.Node
 
hashCode() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
hashCode() - Method in class org.eclipse.jetty.http.HttpField
 
hashCode() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
hashCode() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
hashCode() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
hashCode() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
hashCode() - Method in class org.eclipse.jetty.http.pathmap.AbstractPathSpec
 
hashCode() - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
hashCode() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
hashCode() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
hashCode() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
hashCode() - Method in class org.eclipse.jetty.jaas.JAASPrincipal
 
hashCode() - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
hashCode() - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
hashCode() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
hashCode() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
hashCode() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
hashCode() - Method in class org.eclipse.jetty.start.FileArg
 
hashCode() - Method in class org.eclipse.jetty.start.Module
 
hashCode() - Method in class org.eclipse.jetty.util.Fields.Field
 
hashCode() - Method in class org.eclipse.jetty.util.Fields
 
hashCode() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
hashCode() - Method in class org.eclipse.jetty.util.resource.PathResource
 
hashCode() - Method in class org.eclipse.jetty.util.resource.URLResource
 
hashCode() - Method in class org.eclipse.jetty.util.security.Password
 
hashCode() - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
hashCode() - Method in class org.eclipse.jetty.websocket.core.Frame
 
hashCode() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
 
hashCode() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
hashKey(String) - Static method in class org.eclipse.jetty.websocket.core.internal.WebSocketCore
Concatenate the provided key with the Magic GUID and return the Base64 encoded form.
HashLoginService - Class in org.eclipse.jetty.security
An implementation of a LoginService that stores users and roles in-memory in HashMaps.
HashLoginService() - Constructor for class org.eclipse.jetty.security.HashLoginService
 
HashLoginService(String) - Constructor for class org.eclipse.jetty.security.HashLoginService
 
HashLoginService(String, String) - Constructor for class org.eclipse.jetty.security.HashLoginService
 
hasHost() - Method in class org.eclipse.jetty.util.HostPort
 
hasIncludes() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
hasIniTemplate() - Method in class org.eclipse.jetty.start.Module
 
hasJvmArgs() - Method in class org.eclipse.jetty.start.StartArgs
 
hasKnownValues(HttpHeader) - Static method in enum org.eclipse.jetty.http.HttpHeaderValue
 
hasLicense() - Method in class org.eclipse.jetty.start.Module
 
hasLicenses() - Method in class org.eclipse.jetty.start.Licensing
 
hasListener(AsyncListener) - Method in class org.eclipse.jetty.server.HttpChannelState
 
hasMetaData() - Method in class org.eclipse.jetty.server.Request
 
hasMore() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
hasMore() - Method in class org.eclipse.jetty.jndi.BindingEnumeration
 
hasMore() - Method in class org.eclipse.jetty.jndi.NameEnumeration
 
hasMoreElements() - Method in class org.eclipse.jetty.jndi.BindingEnumeration
 
hasMoreElements() - Method in class org.eclipse.jetty.jndi.NameEnumeration
 
hasMoreTokens() - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
hasMultipleValues() - Method in class org.eclipse.jetty.util.Fields.Field
 
hasNegotiatedExtensions() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
hasNext() - Method in class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
hasNext() - Method in interface org.eclipse.jetty.util.ajax.JSON.Source
 
hasNext() - Method in class org.eclipse.jetty.util.ajax.JSON.StringSource
 
hasNoBody(int) - Static method in class org.eclipse.jetty.http.HttpStatus
 
hasOriginalRequestAndResponse() - Method in class org.eclipse.jetty.server.AsyncContextState
 
hasPayload() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
hasPayload() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
hasPayload() - Method in class org.eclipse.jetty.websocket.core.Frame
 
hasPort() - Method in class org.eclipse.jetty.util.HostPort
 
hasPropertyKey(String) - Static method in class org.eclipse.jetty.start.Props
 
hasRemaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
hasRole(String) - Method in class org.eclipse.jetty.util.security.Constraint
 
hasRsv() - Method in class org.eclipse.jetty.websocket.core.Frame
 
hasScheme(String) - Static method in class org.eclipse.jetty.util.URIUtil
 
hasSubProtocol(String) - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Test if a specific sub-protocol is offered
hasSubProtocol(String) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
hasSubProtocol(String) - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
hasSubProtocol(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
hasSubProtocol(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
hasSystemProperties() - Method in class org.eclipse.jetty.start.StartArgs
 
hasTextMetdata() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
hasTimeoutTask() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
hasUtf16Encoding() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasViolation(UriCompliance.Violation) - Method in interface org.eclipse.jetty.http.HttpURI
 
hasViolation(UriCompliance.Violation) - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
hasViolation(UriCompliance.Violation) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
hasViolations() - Method in interface org.eclipse.jetty.http.HttpURI
 
hasViolations() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
hasViolations() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
hasWildcard() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
 
HEAD - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
HEAD_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
header(String, String) - Method in interface org.eclipse.jetty.client.api.Request
Deprecated.
header(String, String) - Method in class org.eclipse.jetty.client.HttpRequest
Deprecated.
header(HttpField) - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
header(HttpHeader, String) - Method in interface org.eclipse.jetty.client.api.Request
Deprecated.
header(HttpHeader, String) - Method in class org.eclipse.jetty.client.HttpRequest
Deprecated.
HEADER - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
HEADER_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.Frame
 
HEADER_OVERFLOW - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
HEADER_TABLE_SIZE - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
HeaderBlockFragments - Class in org.eclipse.jetty.http2.parser
 
HeaderBlockFragments(ByteBufferPool) - Constructor for class org.eclipse.jetty.http2.parser.HeaderBlockFragments
Deprecated.
HeaderBlockFragments(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
HeaderBlockParser - Class in org.eclipse.jetty.http2.parser
 
HeaderBlockParser(HeaderParser, ByteBufferPool, HpackDecoder, BodyParser) - Constructor for class org.eclipse.jetty.http2.parser.HeaderBlockParser
 
headerComplete() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
headerComplete() - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
 
headerComplete() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
headerComplete() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
headerComplete() - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
HeaderGenerator - Class in org.eclipse.jetty.http2.generator
 
HeaderGenerator() - Constructor for class org.eclipse.jetty.http2.generator.HeaderGenerator
 
HeaderGenerator(boolean) - Constructor for class org.eclipse.jetty.http2.generator.HeaderGenerator
 
HeaderInfo(HttpHeader, String, Map<String, String>) - Constructor for class org.eclipse.jetty.client.api.Authentication.HeaderInfo
 
headerParser - Variable in class org.eclipse.jetty.fcgi.parser.Parser
 
HeaderParser - Class in org.eclipse.jetty.fcgi.parser
Parser for the FastCGI frame header.
HeaderParser - Class in org.eclipse.jetty.http2.parser
The parser for the frame header of HTTP/2 frames.
HeaderParser() - Constructor for class org.eclipse.jetty.fcgi.parser.HeaderParser
 
HeaderParser(RateControl) - Constructor for class org.eclipse.jetty.http2.parser.HeaderParser
 
HeaderPatternRule - Class in org.eclipse.jetty.rewrite.handler
Sets the header in the response whenever the rule finds a match.
HeaderPatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
 
HeaderPatternRule(String, String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
 
HeaderRegexRule - Class in org.eclipse.jetty.rewrite.handler
Rule to add a header based on a Regex match
HeaderRegexRule() - Constructor for class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
 
HeaderRegexRule(String, String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
 
HeaderRule - Class in org.eclipse.jetty.rewrite.handler
Abstract rule that matches against request headers.
HeaderRule() - Constructor for class org.eclipse.jetty.rewrite.handler.HeaderRule
 
headers(Consumer<HttpFields.Mutable>) - Method in interface org.eclipse.jetty.client.api.Request
Modifies the headers of this request.
headers(Consumer<HttpFields.Mutable>) - Method in class org.eclipse.jetty.client.HttpRequest
 
headers(Consumer<HttpFields.Mutable>) - Method in class org.eclipse.jetty.client.HttpResponse
 
headers(HeadersFrame) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given HEADERS frame representing an HTTP response.
headers(HeadersFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given HEADERS frame.
headers(HeadersFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
HEADERS - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
HEADERS - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
HeadersBodyParser - Class in org.eclipse.jetty.http2.parser
 
HeadersBodyParser(HeaderParser, Parser.Listener, HeaderBlockParser, HeaderBlockFragments) - Constructor for class org.eclipse.jetty.http2.parser.HeadersBodyParser
 
HeadersFrame - Class in org.eclipse.jetty.http2.frames
 
HeadersFrame - Class in org.eclipse.jetty.http3.frames
 
HeadersFrame(int, MetaData, PriorityFrame, boolean) - Constructor for class org.eclipse.jetty.http2.frames.HeadersFrame
Creates a new HEADERS frame with the specified stream id.
HeadersFrame(MetaData, boolean) - Constructor for class org.eclipse.jetty.http3.frames.HeadersFrame
 
HeadersFrame(MetaData, PriorityFrame, boolean) - Constructor for class org.eclipse.jetty.http2.frames.HeadersFrame
Creates a new HEADERS frame with an unspecified stream id.
HeadersGenerator - Class in org.eclipse.jetty.http2.generator
 
HeadersGenerator(HeaderGenerator, HpackEncoder) - Constructor for class org.eclipse.jetty.http2.generator.HeadersGenerator
 
HeadersGenerator(HeaderGenerator, HpackEncoder, int) - Constructor for class org.eclipse.jetty.http2.generator.HeadersGenerator
 
headersToCommit(HttpExchange) - Method in class org.eclipse.jetty.client.HttpSender
 
hide(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Hide classes from the web application by adding them to the AbstractConfiguration.getServerClasses()
hint(String) - Static method in class org.eclipse.jetty.websocket.core.internal.util.TextUtils
Create a hint of what the text is like.
Holder<T> - Class in org.eclipse.jetty.servlet
Holder Specialization of AbstractHolder for servlet-related classes that have init-params etc
Holder(Source) - Constructor for class org.eclipse.jetty.servlet.Holder
 
Holder.HolderConfig - Class in org.eclipse.jetty.servlet
 
Holder.HolderRegistration - Class in org.eclipse.jetty.servlet
 
HolderConfig() - Constructor for class org.eclipse.jetty.servlet.Holder.HolderConfig
 
HolderMBean - Class in org.eclipse.jetty.servlet.jmx
 
HolderMBean(Object) - Constructor for class org.eclipse.jetty.servlet.jmx.HolderMBean
 
HolderRegistration() - Constructor for class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
HomeBaseWarning - Class in org.eclipse.jetty.server
Display an optional Warning Message if the {jetty.home} and {jetty.base} are the same directory.
HomeBaseWarning() - Constructor for class org.eclipse.jetty.server.HomeBaseWarning
 
HOP_HEADERS - Static variable in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
host(String) - Method in interface org.eclipse.jetty.client.api.Request
 
host(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
host(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
HOST - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
HostHeaderCustomizer - Class in org.eclipse.jetty.server
Adds a missing Host header (for example, HTTP 1.0 or 2.0 requests).
HostHeaderCustomizer() - Constructor for class org.eclipse.jetty.server.HostHeaderCustomizer
Construct customizer that uses Request.getServerName() and Request.getServerPort() to create a host header.
HostHeaderCustomizer(String) - Constructor for class org.eclipse.jetty.server.HostHeaderCustomizer
 
HostHeaderCustomizer(String, int) - Constructor for class org.eclipse.jetty.server.HostHeaderCustomizer
 
HostMap<TYPE> - Class in org.eclipse.jetty.util
 
HostMap() - Constructor for class org.eclipse.jetty.util.HostMap
Construct empty HostMap.
HostMap(int) - Constructor for class org.eclipse.jetty.util.HostMap
Construct empty HostMap.
HostPort - Class in org.eclipse.jetty.util
Parse an authority string (in the form host:port) into host and port, handling IPv4 and IPv6 host formats as defined in RFC 2732
HostPort(String) - Constructor for class org.eclipse.jetty.util.HostPort
 
HostPort(String, int) - Constructor for class org.eclipse.jetty.util.HostPort
 
HostPortHttpField - Class in org.eclipse.jetty.http
An HttpField holding a preparsed Host and port number
HostPortHttpField(String) - Constructor for class org.eclipse.jetty.http.HostPortHttpField
 
HostPortHttpField(String, int) - Constructor for class org.eclipse.jetty.http.HostPortHttpField
 
HostPortHttpField(HttpHeader, String, String) - Constructor for class org.eclipse.jetty.http.HostPortHttpField
 
HostPortHttpField(HttpHeader, String, HostPort) - Constructor for class org.eclipse.jetty.http.HostPortHttpField
 
HostPortHttpField(HostPort) - Constructor for class org.eclipse.jetty.http.HostPortHttpField
 
HotSwapHandler - Class in org.eclipse.jetty.server.handler
A HandlerContainer that allows a hot swap of a wrapped handler.
HotSwapHandler() - Constructor for class org.eclipse.jetty.server.handler.HotSwapHandler
 
HouseKeeper - Class in org.eclipse.jetty.server.session
HouseKeeper There is 1 session HouseKeeper per SessionIdManager instance.
HouseKeeper() - Constructor for class org.eclipse.jetty.server.session.HouseKeeper
 
HouseKeeper.Runner - Class in org.eclipse.jetty.server.session
Runner
HpackContext - Class in org.eclipse.jetty.http2.hpack
HPACK - Header Compression for HTTP/2
HpackContext.Entry - Class in org.eclipse.jetty.http2.hpack
 
HpackContext.StaticEntry - Class in org.eclipse.jetty.http2.hpack
 
HpackDecoder - Class in org.eclipse.jetty.http2.hpack
Hpack Decoder
HpackDecoder(int, LongSupplier) - Constructor for class org.eclipse.jetty.http2.hpack.HpackDecoder
 
HpackEncoder - Class in org.eclipse.jetty.http2.hpack
 
HpackEncoder() - Constructor for class org.eclipse.jetty.http2.hpack.HpackEncoder
 
HpackException - Exception Class in org.eclipse.jetty.http2.hpack
 
HpackException.CompressionException - Exception Class in org.eclipse.jetty.http2.hpack
 
HpackException.SessionException - Exception Class in org.eclipse.jetty.http2.hpack
A Session HPACK Exception.
HpackException.StreamException - Exception Class in org.eclipse.jetty.http2.hpack
A Stream HPACK exception.
HpackFieldPreEncoder - Class in org.eclipse.jetty.http2.hpack
 
HpackFieldPreEncoder() - Constructor for class org.eclipse.jetty.http2.hpack.HpackFieldPreEncoder
 
HTAB - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
HTTP - Enum constant in enum org.eclipse.jetty.http.HttpScheme
 
HTTP - Static variable in class org.eclipse.jetty.util.URIUtil
 
HTTP_0_9 - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the expectation that HTTP/0.9 is supported has been removed from the specification.
HTTP_0_9 - Enum constant in enum org.eclipse.jetty.http.HttpVersion
 
HTTP_1_0 - Enum constant in enum org.eclipse.jetty.http.HttpVersion
 
HTTP_1_1 - Enum constant in enum org.eclipse.jetty.http.HttpVersion
 
HTTP_1_1_REQUIRED_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that HTTP/1.1 must be used rather than HTTP/2.
HTTP_2 - Enum constant in enum org.eclipse.jetty.http.HttpVersion
 
HTTP_3 - Enum constant in enum org.eclipse.jetty.http.HttpVersion
 
HTTP_CONNECT_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that the connection established by an HTTP CONNECT was abnormally closed.
HTTP_CONNECTION_PROMISE_CONTEXT_KEY - Static variable in interface org.eclipse.jetty.client.HttpClientTransport
 
HTTP_DESTINATION_CONTEXT_KEY - Static variable in interface org.eclipse.jetty.client.HttpClientTransport
 
HTTP_ONLY_COMMENT - Static variable in class org.eclipse.jetty.http.HttpCookie
String used in the Comment attribute of HttpCookie, parsed with HttpCookie.isHttpOnlyInComment(String), to support the HttpOnly attribute.
HTTP_SERVLET - Static variable in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
HTTP_VERSION_NOT_SUPPORTED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
HTTP_VERSION_NOT_SUPPORTED_505 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
HTTP11 - Static variable in class org.eclipse.jetty.client.http.HttpClientConnectionFactory
Representation of the HTTP/1.1 application protocol used by HttpClientTransportDynamic.
HTTP11 - Static variable in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
Http1FieldPreEncoder - Class in org.eclipse.jetty.http
 
Http1FieldPreEncoder() - Constructor for class org.eclipse.jetty.http.Http1FieldPreEncoder
 
HTTP2(HTTP2Client) - Constructor for class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2.HTTP2
 
HTTP2_SETTINGS - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
HTTP2Channel - Interface in org.eclipse.jetty.http2
A HTTP/2 specific handler of events for normal and tunnelled exchanges.
HTTP2Channel.Client - Interface in org.eclipse.jetty.http2
A client specific handler for events that happen after a HEADERS response frame is received.
HTTP2Channel.Server - Interface in org.eclipse.jetty.http2
A server specific handler for events that happen after a HEADERS request frame is received.
HTTP2Cipher - Class in org.eclipse.jetty.http2
 
HTTP2Cipher() - Constructor for class org.eclipse.jetty.http2.HTTP2Cipher
 
HTTP2Cipher.CipherComparator - Class in org.eclipse.jetty.http2
Comparator that orders non blacklisted ciphers before blacklisted ones.
HTTP2Client - Class in org.eclipse.jetty.http2.client
HTTP2Client provides an asynchronous, non-blocking implementation to send HTTP/2 frames to a server.
HTTP2Client() - Constructor for class org.eclipse.jetty.http2.client.HTTP2Client
 
HTTP2Client(ClientConnector) - Constructor for class org.eclipse.jetty.http2.client.HTTP2Client
 
HTTP2ClientConnectionFactory - Class in org.eclipse.jetty.http2.client
 
HTTP2ClientConnectionFactory() - Constructor for class org.eclipse.jetty.http2.client.HTTP2ClientConnectionFactory
 
HTTP2ClientSession - Class in org.eclipse.jetty.http2.client
 
HTTP2ClientSession(Scheduler, EndPoint, Parser, Generator, Session.Listener, FlowControlStrategy) - Constructor for class org.eclipse.jetty.http2.client.HTTP2ClientSession
 
HTTP2Connection - Class in org.eclipse.jetty.http2
 
HTTP2Connection(RetainableByteBufferPool, Executor, EndPoint, HTTP2Session, int) - Constructor for class org.eclipse.jetty.http2.HTTP2Connection
 
HTTP2Connection.HTTP2Producer - Class in org.eclipse.jetty.http2
 
HTTP2CServerConnectionFactory - Class in org.eclipse.jetty.http2.server
HTTP2 Clear Text Connection factory.
HTTP2CServerConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.http2.server.HTTP2CServerConnectionFactory
 
HTTP2CServerConnectionFactory(HttpConfiguration, String...) - Constructor for class org.eclipse.jetty.http2.server.HTTP2CServerConnectionFactory
 
HTTP2Flusher - Class in org.eclipse.jetty.http2
 
HTTP2Flusher(HTTP2Session) - Constructor for class org.eclipse.jetty.http2.HTTP2Flusher
 
HTTP2Flusher.Entry - Class in org.eclipse.jetty.http2
 
HTTP2Producer() - Constructor for class org.eclipse.jetty.http2.HTTP2Connection.HTTP2Producer
 
HTTP2ServerConnection - Class in org.eclipse.jetty.http2.server
 
HTTP2ServerConnection(RetainableByteBufferPool, Executor, EndPoint, HttpConfiguration, HTTP2ServerSession, int, ServerSessionListener) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
HTTP2ServerConnection.ServerHttpChannelOverHTTP2 - Class in org.eclipse.jetty.http2.server
 
HTTP2ServerConnectionFactory - Class in org.eclipse.jetty.http2.server
 
HTTP2ServerConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory
 
HTTP2ServerConnectionFactory(HttpConfiguration, String...) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory
 
HTTP2ServerConnectionFactory.HTTPServerSessionListener - Class in org.eclipse.jetty.http2.server
 
HTTP2ServerSession - Class in org.eclipse.jetty.http2.server
 
HTTP2ServerSession(Scheduler, EndPoint, ServerParser, Generator, ServerSessionListener, FlowControlStrategy) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
HTTP2Session - Class in org.eclipse.jetty.http2
 
HTTP2Session(Scheduler, EndPoint, Parser, Generator, Session.Listener, FlowControlStrategy, int) - Constructor for class org.eclipse.jetty.http2.HTTP2Session
 
HTTP2SessionContainer() - Constructor for class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
HTTP2Stream - Class in org.eclipse.jetty.http2
 
HTTP2Stream(ISession, int, MetaData.Request, boolean) - Constructor for class org.eclipse.jetty.http2.HTTP2Stream
 
HTTP2Stream(Scheduler, ISession, int, MetaData.Request, boolean) - Constructor for class org.eclipse.jetty.http2.HTTP2Stream
Deprecated.
HTTP2StreamEndPoint - Class in org.eclipse.jetty.http2
 
HTTP2StreamEndPoint(IStream) - Constructor for class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
HTTP3(HTTP3Client) - Constructor for class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3.HTTP3
 
HTTP3Client - Class in org.eclipse.jetty.http3.client
HTTP3Client provides an asynchronous, non-blocking implementation to send HTTP/3 frames to a server.
HTTP3Client() - Constructor for class org.eclipse.jetty.http3.client.HTTP3Client
 
HTTP3ClientConnectionFactory - Class in org.eclipse.jetty.http3.client
A ClientConnectionFactory implementation that creates HTTP/3 specific Connection objects to be linked to a QuicStreamEndPoint.
HTTP3ClientConnectionFactory() - Constructor for class org.eclipse.jetty.http3.client.HTTP3ClientConnectionFactory
 
HTTP3Configuration - Class in org.eclipse.jetty.http3
The HTTP/3 configuration parameters.
HTTP3Configuration() - Constructor for class org.eclipse.jetty.http3.HTTP3Configuration
 
HTTP3ServerConnectionFactory - Class in org.eclipse.jetty.http3.server
 
HTTP3ServerConnectionFactory() - Constructor for class org.eclipse.jetty.http3.server.HTTP3ServerConnectionFactory
 
HTTP3ServerConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.http3.server.HTTP3ServerConnectionFactory
 
HTTP3ServerConnector - Class in org.eclipse.jetty.http3.server
A HTTP/3 specific QuicServerConnector that configures QUIC parameters according to HTTP/3 requirements.
HTTP3ServerConnector(Server, Executor, Scheduler, ByteBufferPool, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.http3.server.HTTP3ServerConnector
 
HTTP3ServerConnector(Server, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.http3.server.HTTP3ServerConnector
 
HttpAuthenticationStore - Class in org.eclipse.jetty.client
 
HttpAuthenticationStore() - Constructor for class org.eclipse.jetty.client.HttpAuthenticationStore
 
HttpChannel - Class in org.eclipse.jetty.client
 
HttpChannel - Class in org.eclipse.jetty.server
HttpChannel represents a single endpoint for HTTP semantic processing.
HttpChannel(HttpDestination) - Constructor for class org.eclipse.jetty.client.HttpChannel
 
HttpChannel(Connector, HttpConfiguration, EndPoint, HttpTransport) - Constructor for class org.eclipse.jetty.server.HttpChannel
 
HttpChannel.Listener - Interface in org.eclipse.jetty.server
Listener for HttpChannel events.
HttpChannel.TransientListeners - Class in org.eclipse.jetty.server
Deprecated.
HttpChannelListeners - Class in org.eclipse.jetty.server
A HttpChannel.Listener that holds a collection of other HttpChannel.Listener instances that are efficiently invoked without iteration.
HttpChannelListeners(Collection<HttpChannel.Listener>) - Constructor for class org.eclipse.jetty.server.HttpChannelListeners
 
HttpChannelOverFCGI - Class in org.eclipse.jetty.fcgi.client.http
 
HttpChannelOverFCGI - Class in org.eclipse.jetty.fcgi.server
 
HttpChannelOverFCGI(HttpConnectionOverFCGI, Flusher, long) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
HttpChannelOverFCGI(ServerFCGIConnection, Connector, HttpConfiguration, EndPoint, HttpTransport) - Constructor for class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
HttpChannelOverHttp - Class in org.eclipse.jetty.server
An HttpChannel customized to be transported over the HTTP/1 protocol
HttpChannelOverHttp(HttpConnection, Connector, HttpConfiguration, EndPoint, HttpTransport) - Constructor for class org.eclipse.jetty.server.HttpChannelOverHttp
 
HttpChannelOverHTTP - Class in org.eclipse.jetty.client.http
 
HttpChannelOverHTTP(HttpConnectionOverHTTP) - Constructor for class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
HttpChannelOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
HttpChannelOverHTTP2 - Class in org.eclipse.jetty.http2.server
 
HttpChannelOverHTTP2(HttpDestination, HttpConnectionOverHTTP2, Session) - Constructor for class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
HttpChannelOverHTTP2(Connector, HttpConfiguration, EndPoint, HttpTransportOverHTTP2) - Constructor for class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
HttpChannelState - Class in org.eclipse.jetty.server
Implementation of AsyncContext interface that holds the state of request-response cycle.
HttpChannelState(HttpChannel) - Constructor for class org.eclipse.jetty.server.HttpChannelState
 
HttpChannelState.Action - Enum in org.eclipse.jetty.server
The actions to take as the channel moves from state to state.
HttpChannelState.State - Enum in org.eclipse.jetty.server
 
HttpClient - Class in org.eclipse.jetty.client
HttpClient provides an efficient, asynchronous, non-blocking implementation to perform HTTP requests to a server through a simple API that offers also blocking semantic.
HttpClient() - Constructor for class org.eclipse.jetty.client.HttpClient
Creates a HttpClient instance that can perform HTTP/1.1 requests to non-TLS and TLS destinations.
HttpClient(HttpClientTransport) - Constructor for class org.eclipse.jetty.client.HttpClient
 
HTTPCLIENT_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
 
HttpClientConnectionFactory - Class in org.eclipse.jetty.client.http
 
HttpClientConnectionFactory() - Constructor for class org.eclipse.jetty.client.http.HttpClientConnectionFactory
 
HttpClientMBean - Class in org.eclipse.jetty.client.jmx
 
HttpClientMBean(Object) - Constructor for class org.eclipse.jetty.client.jmx.HttpClientMBean
 
HttpClientProvider - Interface in org.eclipse.jetty.websocket.core.client.internal
 
HttpClientTransport - Interface in org.eclipse.jetty.client
HttpClientTransport represents what transport implementations should provide in order to plug-in a different transport for HttpClient.
HttpClientTransportDynamic - Class in org.eclipse.jetty.client.dynamic
A HttpClientTransport that can dynamically switch among different application protocols.
HttpClientTransportDynamic() - Constructor for class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
Creates a transport that speaks only HTTP/1.1.
HttpClientTransportDynamic(ClientConnectionFactory.Info...) - Constructor for class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
HttpClientTransportDynamic(ClientConnector, ClientConnectionFactory.Info...) - Constructor for class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
Creates a transport with the given ClientConnector and the given application protocols.
HttpClientTransportOverFCGI - Class in org.eclipse.jetty.fcgi.client.http
 
HttpClientTransportOverFCGI(int, String) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
HttpClientTransportOverFCGI(String) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
HttpClientTransportOverFCGI(ClientConnector, String) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
HttpClientTransportOverHTTP - Class in org.eclipse.jetty.client.http
 
HttpClientTransportOverHTTP() - Constructor for class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
HttpClientTransportOverHTTP(int) - Constructor for class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
HttpClientTransportOverHTTP(ClientConnector) - Constructor for class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
HttpClientTransportOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
HttpClientTransportOverHTTP2(HTTP2Client) - Constructor for class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
HttpClientTransportOverHTTP3 - Class in org.eclipse.jetty.http3.client.http
 
HttpClientTransportOverHTTP3(HTTP3Client) - Constructor for class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
HttpClientTransportOverUnixSockets - Class in org.eclipse.jetty.unixsocket.client
Deprecated, for removal: This API element is subject to removal in a future version.
use any HttpClientTransport with ClientConnector.forUnixDomain(Path) instead (requires Java 16 or later)
HttpClientTransportOverUnixSockets(String) - Constructor for class org.eclipse.jetty.unixsocket.client.HttpClientTransportOverUnixSockets
Deprecated.
 
HttpCompliance - Class in org.eclipse.jetty.http
HTTP compliance modes for Jetty HTTP parsing and handling.
HttpCompliance.Violation - Enum in org.eclipse.jetty.http
 
HttpConfiguration - Class in org.eclipse.jetty.server
HTTP Configuration.
HttpConfiguration() - Constructor for class org.eclipse.jetty.server.HttpConfiguration
 
HttpConfiguration(HttpConfiguration) - Constructor for class org.eclipse.jetty.server.HttpConfiguration
Creates a configuration from another.
HttpConfiguration.ConnectionFactory - Interface in org.eclipse.jetty.server
 
HttpConfiguration.Customizer - Interface in org.eclipse.jetty.server
An interface that allows a request object to be customized for a particular HTTP connector configuration.
HttpConnection - Class in org.eclipse.jetty.client
 
HttpConnection - Class in org.eclipse.jetty.server
A Connection that handles the HTTP protocol.
HttpConnection(HttpDestination) - Constructor for class org.eclipse.jetty.client.HttpConnection
 
HttpConnection(HttpConfiguration, Connector, EndPoint, boolean) - Constructor for class org.eclipse.jetty.server.HttpConnection
 
HttpConnectionFactory - Class in org.eclipse.jetty.server
A Connection Factory for HTTP Connections.
HttpConnectionFactory() - Constructor for class org.eclipse.jetty.server.HttpConnectionFactory
 
HttpConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.server.HttpConnectionFactory
 
HttpConnectionOverFCGI - Class in org.eclipse.jetty.fcgi.client.http
 
HttpConnectionOverFCGI(EndPoint, HttpDestination, Promise<Connection>) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
HttpConnectionOverHTTP - Class in org.eclipse.jetty.client.http
 
HttpConnectionOverHTTP(EndPoint, Map<String, Object>) - Constructor for class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
HttpConnectionOverHTTP(EndPoint, HttpDestination, Promise<Connection>) - Constructor for class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
HttpConnectionOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
HttpConnectionOverHTTP2(HttpDestination, Session) - Constructor for class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
HttpContent - Interface in org.eclipse.jetty.http
HttpContent interface.
HttpContent.ContentFactory - Interface in org.eclipse.jetty.http
 
HttpContentRangeWriter - Class in org.eclipse.jetty.server.resource
Range Writer selection for HttpContent
HttpContentRangeWriter() - Constructor for class org.eclipse.jetty.server.resource.HttpContentRangeWriter
 
HttpContentResponse - Class in org.eclipse.jetty.client
 
HttpContentResponse(Response, byte[], String, String) - Constructor for class org.eclipse.jetty.client.HttpContentResponse
 
HttpConversation - Class in org.eclipse.jetty.client
 
HttpConversation() - Constructor for class org.eclipse.jetty.client.HttpConversation
 
HttpCookie - Class in org.eclipse.jetty.http
 
HttpCookie(String) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, long) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, String, String) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, String, String, long, boolean, boolean) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, String, String, long, boolean, boolean, String, int) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, String, String, long, boolean, boolean, String, int, HttpCookie.SameSite) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie(String, String, String, String, long, boolean, boolean, String, int, HttpCookie.SameSite, boolean) - Constructor for class org.eclipse.jetty.http.HttpCookie
 
HttpCookie.SameSite - Enum in org.eclipse.jetty.http
 
HttpCookie.SetCookieHttpField - Class in org.eclipse.jetty.http
 
HttpCookieStore - Class in org.eclipse.jetty.util
Implementation of CookieStore that delegates to an instance created by CookieManager via CookieManager.getCookieStore().
HttpCookieStore() - Constructor for class org.eclipse.jetty.util.HttpCookieStore
 
HttpCookieStore.Empty - Class in org.eclipse.jetty.util
 
HttpDestination - Class in org.eclipse.jetty.client
 
HttpDestination(HttpClient, Origin, boolean) - Constructor for class org.eclipse.jetty.client.HttpDestination
 
HttpDestination.Multiplexed - Interface in org.eclipse.jetty.client
 
HttpExchange - Class in org.eclipse.jetty.client
 
HttpExchange(HttpDestination, HttpRequest, List<Response.ResponseListener>) - Constructor for class org.eclipse.jetty.client.HttpExchange
 
HttpField - Class in org.eclipse.jetty.http
An HTTP Field
HttpField(String, String) - Constructor for class org.eclipse.jetty.http.HttpField
 
HttpField(HttpHeader, String) - Constructor for class org.eclipse.jetty.http.HttpField
 
HttpField(HttpHeader, String, String) - Constructor for class org.eclipse.jetty.http.HttpField
 
HttpField(HttpHeader, HttpHeaderValue) - Constructor for class org.eclipse.jetty.http.HttpField
 
HttpField.IntValueHttpField - Class in org.eclipse.jetty.http
 
HttpField.LongValueHttpField - Class in org.eclipse.jetty.http
 
HttpFieldPreEncoder - Interface in org.eclipse.jetty.http
Interface to pre-encode HttpFields.
HttpFields - Interface in org.eclipse.jetty.http
Interface that represents on ordered collection of HttpFields.
HttpFields.Immutable - Class in org.eclipse.jetty.http
HTTP Fields.
HttpFields.Mutable - Class in org.eclipse.jetty.http
HTTP Fields.
HttpGenerator - Class in org.eclipse.jetty.http
HttpGenerator.
HttpGenerator() - Constructor for class org.eclipse.jetty.http.HttpGenerator
 
HttpGenerator(boolean, boolean) - Constructor for class org.eclipse.jetty.http.HttpGenerator
 
HttpGenerator.Result - Enum in org.eclipse.jetty.http
 
HttpGenerator.State - Enum in org.eclipse.jetty.http
 
HttpHeader - Enum in org.eclipse.jetty.http
 
HttpHeaderValue - Enum in org.eclipse.jetty.http
 
HttpInput - Class in org.eclipse.jetty.server
While this class is-a Runnable, it should never be dispatched in it's own thread.
HttpInput(HttpChannelState) - Constructor for class org.eclipse.jetty.server.HttpInput
 
HttpInput.Content - Class in org.eclipse.jetty.server
A content represents the production of a HttpChannel returned by HttpChannel.produceContent().
HttpInput.EofContent - Class in org.eclipse.jetty.server
EOF special content.
HttpInput.ErrorContent - Class in org.eclipse.jetty.server
Error special content.
HttpInput.Interceptor - Interface in org.eclipse.jetty.server
HttpInput.SpecialContent - Class in org.eclipse.jetty.server
Abstract class that implements the standard special content behavior.
HttpInput.WrappingContent - Class in org.eclipse.jetty.server
Simple non-special content wrapper allow overriding the EOF flag.
HttpMethod - Enum in org.eclipse.jetty.http
Known HTTP Methods
HttpOutput - Class in org.eclipse.jetty.server
HttpOutput implements ServletOutputStream as required by the Servlet specification.
HttpOutput(HttpChannel) - Constructor for class org.eclipse.jetty.server.HttpOutput
 
HttpOutput.Interceptor - Interface in org.eclipse.jetty.server
The HttpOutput.Interceptor is a single intercept point for all output written to the HttpOutput: via writer; via output stream; asynchronously; or blocking.
HttpParser - Class in org.eclipse.jetty.http
A Parser for 1.0 and 1.1 as defined by RFC7230
HttpParser(HttpParser.RequestHandler) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.RequestHandler, int) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.RequestHandler, int, HttpCompliance) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.RequestHandler, HttpCompliance) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.ResponseHandler) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.ResponseHandler, int) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser(HttpParser.ResponseHandler, int, HttpCompliance) - Constructor for class org.eclipse.jetty.http.HttpParser
 
HttpParser.FieldState - Enum in org.eclipse.jetty.http
 
HttpParser.HttpHandler - Interface in org.eclipse.jetty.http
 
HttpParser.RequestHandler - Interface in org.eclipse.jetty.http
 
HttpParser.ResponseHandler - Interface in org.eclipse.jetty.http
 
HttpParser.State - Enum in org.eclipse.jetty.http
 
HttpProxy - Class in org.eclipse.jetty.client
 
HttpProxy(String, int) - Constructor for class org.eclipse.jetty.client.HttpProxy
 
HttpProxy(Origin.Address, boolean) - Constructor for class org.eclipse.jetty.client.HttpProxy
 
HttpProxy(Origin.Address, boolean, Origin.Protocol) - Constructor for class org.eclipse.jetty.client.HttpProxy
 
HttpProxy(Origin.Address, SslContextFactory.Client) - Constructor for class org.eclipse.jetty.client.HttpProxy
 
HttpProxy(Origin.Address, SslContextFactory.Client, Origin.Protocol) - Constructor for class org.eclipse.jetty.client.HttpProxy
 
HttpProxy.TunnelRequest - Class in org.eclipse.jetty.client
 
HttpReceiver - Class in org.eclipse.jetty.client
HttpReceiver provides the abstract code to implement the various steps of the receive of HTTP responses.
HttpReceiver(HttpChannel) - Constructor for class org.eclipse.jetty.client.HttpReceiver
 
HttpReceiverOverFCGI - Class in org.eclipse.jetty.fcgi.client.http
 
HttpReceiverOverFCGI(HttpChannel) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
HttpReceiverOverHTTP - Class in org.eclipse.jetty.client.http
 
HttpReceiverOverHTTP(HttpChannelOverHTTP) - Constructor for class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
HttpReceiverOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
HttpReceiverOverHTTP2(HttpChannel) - Constructor for class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
HttpRedirector - Class in org.eclipse.jetty.client
Utility class that handles HTTP redirects.
HttpRedirector(HttpClient) - Constructor for class org.eclipse.jetty.client.HttpRedirector
 
HttpRequest - Class in org.eclipse.jetty.client
 
HttpRequest(HttpClient, HttpConversation, URI) - Constructor for class org.eclipse.jetty.client.HttpRequest
 
HttpRequestException - Exception Class in org.eclipse.jetty.client
 
HttpRequestException(String, Request) - Constructor for exception class org.eclipse.jetty.client.HttpRequestException
 
HttpResponse - Class in org.eclipse.jetty.client
 
HttpResponse(Request, List<Response.ResponseListener>) - Constructor for class org.eclipse.jetty.client.HttpResponse
 
HttpResponseException - Exception Class in org.eclipse.jetty.client
 
HttpResponseException(String, Response) - Constructor for exception class org.eclipse.jetty.client.HttpResponseException
 
HttpResponseException(String, Response, Throwable) - Constructor for exception class org.eclipse.jetty.client.HttpResponseException
 
HTTPS - Enum constant in enum org.eclipse.jetty.http.HttpScheme
 
HTTPS - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
HTTPS - Static variable in class org.eclipse.jetty.util.URIUtil
 
HttpScheme - Enum in org.eclipse.jetty.http
HTTP and WebSocket Schemes
HttpSender - Class in org.eclipse.jetty.client
HttpSender abstracts the algorithm to send HTTP requests, so that subclasses only implement the transport-specific code to send requests over the wire, implementing HttpSender.sendHeaders(HttpExchange, ByteBuffer, boolean, Callback) and HttpSender.sendContent(HttpExchange, ByteBuffer, boolean, Callback).
HttpSender(HttpChannel) - Constructor for class org.eclipse.jetty.client.HttpSender
 
HttpSenderOverFCGI - Class in org.eclipse.jetty.fcgi.client.http
 
HttpSenderOverFCGI(HttpChannel) - Constructor for class org.eclipse.jetty.fcgi.client.http.HttpSenderOverFCGI
 
HttpSenderOverHTTP - Class in org.eclipse.jetty.client.http
 
HttpSenderOverHTTP(HttpChannelOverHTTP) - Constructor for class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
HttpSenderOverHTTP2 - Class in org.eclipse.jetty.http2.client.http
 
HttpSenderOverHTTP2(HttpChannelOverHTTP2) - Constructor for class org.eclipse.jetty.http2.client.http.HttpSenderOverHTTP2
 
HTTPServerSessionListener(Connector, EndPoint) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
HttpSpiContextHandler - Class in org.eclipse.jetty.http.spi
Jetty handler that bridges requests to HttpHandler.
HttpSpiContextHandler(HttpContext, HttpHandler) - Constructor for class org.eclipse.jetty.http.spi.HttpSpiContextHandler
 
HttpStatus - Class in org.eclipse.jetty.http
Http Status Codes
HttpStatus() - Constructor for class org.eclipse.jetty.http.HttpStatus
 
HttpStatus.Code - Enum in org.eclipse.jetty.http
 
HttpTester - Class in org.eclipse.jetty.http
A HTTP Testing helper class.
HttpTester.Input - Class in org.eclipse.jetty.http
 
HttpTester.Message - Class in org.eclipse.jetty.http
 
HttpTester.Request - Class in org.eclipse.jetty.http
 
HttpTester.Response - Class in org.eclipse.jetty.http
 
HttpTokens - Class in org.eclipse.jetty.http
HTTP constants
HttpTokens() - Constructor for class org.eclipse.jetty.http.HttpTokens
 
HttpTokens.EndOfContent - Enum in org.eclipse.jetty.http
 
HttpTokens.Token - Class in org.eclipse.jetty.http
 
HttpTokens.Type - Enum in org.eclipse.jetty.http
 
HttpTransport - Interface in org.eclipse.jetty.server
Abstraction of the outbound HTTP transport.
HttpTransportOverFCGI - Class in org.eclipse.jetty.fcgi.server
 
HttpTransportOverFCGI(ByteBufferPool, boolean, boolean, Flusher, int) - Constructor for class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
HttpTransportOverHTTP2 - Class in org.eclipse.jetty.http2.server
 
HttpTransportOverHTTP2(Connector, HTTP2ServerConnection) - Constructor for class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
HttpUpgrader - Interface in org.eclipse.jetty.client
HttpUpgrader prepares a HTTP request to upgrade from one protocol to another, and implements the upgrade mechanism.
HttpUpgrader.Factory - Interface in org.eclipse.jetty.client
A factory for HttpUpgraders.
HttpUpgraderOverHTTP - Class in org.eclipse.jetty.websocket.core.client.internal
 
HttpUpgraderOverHTTP(CoreClientUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP
 
HttpUpgraderOverHTTP2 - Class in org.eclipse.jetty.websocket.core.client.internal
 
HttpUpgraderOverHTTP2(CoreClientUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP2
 
HttpURI - Interface in org.eclipse.jetty.http
Http URI.
HttpURI.Immutable - Class in org.eclipse.jetty.http
 
HttpURI.Mutable - Class in org.eclipse.jetty.http
 
HttpVersion - Enum in org.eclipse.jetty.http
 
HttpWriter - Class in org.eclipse.jetty.server
 
HttpWriter(HttpOutput) - Constructor for class org.eclipse.jetty.server.HttpWriter
 
Huffman - Class in org.eclipse.jetty.http.compression
This class contains the Huffman Codes defined in RFC7541.
HuffmanDecoder - Class in org.eclipse.jetty.http.compression
Used to decoded Huffman encoded strings.
HuffmanDecoder() - Constructor for class org.eclipse.jetty.http.compression.HuffmanDecoder
 
HuffmanEncoder - Class in org.eclipse.jetty.http.compression
Used to encode strings Huffman encoding.

I

IConnection - Interface in org.eclipse.jetty.client
 
id(T) - Method in class org.eclipse.jetty.util.LeakDetector
Generates a unique ID for the given resource.
ID - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
IDENTITY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
IDENTITY - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
IDENTITY - Static variable in interface org.eclipse.jetty.proxy.AsyncMiddleManServlet.ContentTransformer
The identity transformer that does not perform any transformation.
IdentityExtension - Class in org.eclipse.jetty.websocket.core.internal
 
IdentityExtension() - Constructor for class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
IdentityService - Interface in org.eclipse.jetty.security
Associates UserIdentities from with threads and UserIdentity.Contexts.
idle(Connection, boolean) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
IDLE - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.State
 
IDLE - Enum constant in enum org.eclipse.jetty.util.IteratingCallback.Action
Indicates that IteratingCallback.process() has no more work to do, but the iteration is not completed yet, probably waiting for additional events to trigger more work.
idleTimeout() - Element in annotation type org.eclipse.jetty.websocket.api.annotations.WebSocket
The time in ms (milliseconds) that a websocket may be idle before closing.
idleTimeout(long, TimeUnit) - Method in interface org.eclipse.jetty.client.api.Request
 
idleTimeout(long, TimeUnit) - Method in class org.eclipse.jetty.client.HttpRequest
 
IdleTimeout - Class in org.eclipse.jetty.io
An Abstract implementation of an Idle Timeout.
IdleTimeout(Scheduler) - Constructor for class org.eclipse.jetty.io.IdleTimeout
 
IdleTimeoutHandler - Class in org.eclipse.jetty.server.handler
Handler to adjust the idle timeout of requests while dispatched.
IdleTimeoutHandler() - Constructor for class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
IF_MATCH - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
IF_MODIFIED_SINCE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
IF_NONE_MATCH - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
IF_RANGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
IF_UNMODIFIED_SINCE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ifExceptionThrow() - Method in exception class org.eclipse.jetty.util.MultiException
Throw a multiexception.
ifExceptionThrowMulti() - Method in exception class org.eclipse.jetty.util.MultiException
Throw a multiexception.
ifExceptionThrowRuntime() - Method in exception class org.eclipse.jetty.util.MultiException
Throw a Runtime exception.
ifExceptionThrowSuppressed() - Method in exception class org.eclipse.jetty.util.MultiException
Throw an Exception, potentially with suppress.
ignore(Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Ignore an exception.
IGNORE - Enum constant in enum org.eclipse.jetty.util.PathWatcher.DirAction
 
illegalStateIfContextStarted() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
IM_A_TEAPOT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
IM_A_TEAPOT_418 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
Immutable(HttpField[]) - Constructor for class org.eclipse.jetty.http.HttpFields.Immutable
Initialize HttpFields from copy.
impact() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedOperation
The impact of an operation.
implementsInterface(Class<? extends Decoder>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
implementsInterface(Class<? extends Encoder>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
IN_NAME - Enum constant in enum org.eclipse.jetty.http.HttpParser.FieldState
 
IN_NAME - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.FieldState
 
IN_VALUE - Enum constant in enum org.eclipse.jetty.http.HttpParser.FieldState
 
IN_VALUE - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.FieldState
 
INADEQUATE_SECURITY_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that the transport properties do not meet minimum security requirements.
include() - Method in class org.eclipse.jetty.server.Response
 
include(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.server.Dispatcher
 
include(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
include(String) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
include(String) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Includes an InetAccess pattern with an optional connector name, address and URI mapping.
include(String) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
include(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
include(String...) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Includes InetAccess patterns
include(String...) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
include(String, String, PathSpec) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Includes an InetAccess entry.
include(T) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
include(T...) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
INCLUDE - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
includeConnector(String) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Deprecated.
includeConnectors(String...) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Deprecated.
included() - Method in class org.eclipse.jetty.server.Response
 
includeExclude - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
IncludeExclude<ITEM> - Class in org.eclipse.jetty.util
Utility class to maintain a set of inclusions and exclusions.
IncludeExclude() - Constructor for class org.eclipse.jetty.util.IncludeExclude
 
IncludeExclude(Class<SET>) - Constructor for class org.eclipse.jetty.util.IncludeExclude
 
IncludeExclude(Set<ITEM>, Predicate<ITEM>, Set<ITEM>, Predicate<ITEM>) - Constructor for class org.eclipse.jetty.util.IncludeExclude
 
IncludeExcludeConnectionStatistics - Class in org.eclipse.jetty.io
 
IncludeExcludeConnectionStatistics() - Constructor for class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
IncludeExcludeConnectionStatistics.ConnectionSet - Class in org.eclipse.jetty.io
 
IncludeExcludeSet<T,P> - Class in org.eclipse.jetty.util
Utility class to maintain a set of inclusions and exclusions.
IncludeExcludeSet() - Constructor for class org.eclipse.jetty.util.IncludeExcludeSet
Default constructor over HashSet
IncludeExcludeSet(Class<SET>) - Constructor for class org.eclipse.jetty.util.IncludeExcludeSet
Construct an IncludeExclude.
IncludeExcludeSet(Set<T>, Predicate<P>, Set<T>, Predicate<P>) - Constructor for class org.eclipse.jetty.util.IncludeExcludeSet
Construct an IncludeExclude
includeField(String, Object, Method) - Method in class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
includeField(String, Method) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
includes(JettyLevel) - Method in enum org.eclipse.jetty.logging.JettyLevel
Tests that a provided level is included by the level value of this level.
InclusiveByteRange - Class in org.eclipse.jetty.server
Byte range inclusive of end points.
InclusiveByteRange(long, long) - Constructor for class org.eclipse.jetty.server.InclusiveByteRange
 
incoming(Socket, ByteBuffer) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when bytes sent by a remote client arrived on the server.
IncomingFrames - Interface in org.eclipse.jetty.websocket.core
Interface for dealing with Incoming Frames.
inContentState() - Method in class org.eclipse.jetty.http.HttpParser
 
increment() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
Increments the value by one.
incrementCount() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
incrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
Deprecated.
incrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Deprecated.
incrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
Deprecated.
incrementMemory(ByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
Deprecated.
index(HpackContext.Entry) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
Index<V> - Interface in org.eclipse.jetty.util
An immutable String lookup data structure.
Index.Builder<V> - Class in org.eclipse.jetty.util
Builder of Index instances.
Index.Mutable<V> - Interface in org.eclipse.jetty.util
A mutable String lookup data structure.
Index.Mutable.Builder<V> - Class in org.eclipse.jetty.util
Builder of Index.Mutable instances.
indexBundle(Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
Keep track of a jetty URI Resource and its associated OSGi bundle.
indexFrom(String, String) - Static method in class org.eclipse.jetty.util.StringUtil
returns the next index of a character from the chars string
indexOfControlChars(String) - Static method in class org.eclipse.jetty.util.StringUtil
Find the index of a control characters in String
INET4 - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
 
INET6 - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
 
InetAccessHandler - Class in org.eclipse.jetty.server.handler
InetAddress Access Handler
InetAccessHandler() - Constructor for class org.eclipse.jetty.server.handler.InetAccessHandler
 
InetAccessSet - Class in org.eclipse.jetty.server.handler
 
InetAccessSet() - Constructor for class org.eclipse.jetty.server.handler.InetAccessSet
 
InetAccessSet.AccessTuple - Class in org.eclipse.jetty.server.handler
 
InetAccessSet.PatternTuple - Class in org.eclipse.jetty.server.handler
 
InetAddressPattern - Class in org.eclipse.jetty.util
A pattern representing a single or range of InetAddress.
InetAddressPattern(String) - Constructor for class org.eclipse.jetty.util.InetAddressPattern
 
InetAddressSet - Class in org.eclipse.jetty.util
A set of InetAddress patterns.
InetAddressSet() - Constructor for class org.eclipse.jetty.util.InetAddressSet
 
INFERRED - Static variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
InfinispanKeyBuilder - Class in org.eclipse.jetty.session.infinispan
 
InfinispanKeyBuilder() - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanKeyBuilder
 
InfinispanSerializationContextInitializer - Class in org.eclipse.jetty.session.infinispan
Set up the marshaller for InfinispanSessionData serialization
InfinispanSerializationContextInitializer() - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSerializationContextInitializer
 
InfinispanSessionData - Class in org.eclipse.jetty.session.infinispan
InfinispanSessionData Specialization of SessionData to hold the attributes as a serialized byte array.
InfinispanSessionData(String, String, String, long, long, long, long) - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
InfinispanSessionData(String, String, String, long, long, long, long, Map<String, Object>) - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
InfinispanSessionDataStore - Class in org.eclipse.jetty.session.infinispan
InfinispanSessionDataStore
InfinispanSessionDataStore() - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
InfinispanSessionDataStoreFactory - Class in org.eclipse.jetty.session.infinispan
InfinispanSessionDataStoreFactory
InfinispanSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
InfinispanSessionLegacyConverter - Class in org.eclipse.jetty.session.infinispan
InfinispanSessionLegacyConverter Converts sessions saved in the old serialization format into the new protobuf-based serialization.
InfinispanSessionLegacyConverter(String) - Constructor for class org.eclipse.jetty.session.infinispan.InfinispanSessionLegacyConverter
 
InflaterPool - Class in org.eclipse.jetty.util.compression
 
InflaterPool(int, boolean) - Constructor for class org.eclipse.jetty.util.compression.InflaterPool
Create a Pool of Inflater instances.
info(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
info(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
info(String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(String, Object...) - Static method in class org.eclipse.jetty.start.StartLog
 
info(String, Object...) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Formats and logs at info level.
info(String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(String, Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given message at info level, with Throwable information.
info(Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given Throwable information at info level
info(Marker, String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(Marker, String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(Marker, String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(Marker, String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
info(Marker, String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
Info(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
INFO - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
inHeaderState() - Method in class org.eclipse.jetty.http.HttpParser
 
init() - Method in class org.eclipse.jetty.alpn.conscrypt.client.ConscryptClientALPNProcessor
 
init() - Method in class org.eclipse.jetty.alpn.conscrypt.server.ConscryptServerALPNProcessor
 
init() - Method in class org.eclipse.jetty.alpn.java.client.JDK9ClientALPNProcessor
 
init() - Method in class org.eclipse.jetty.alpn.java.server.JDK9ServerALPNProcessor
 
init() - Method in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
init() - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Initializes this ALPNProcessor
init() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
init() - Method in class org.eclipse.jetty.proxy.BalancerServlet
 
init() - Method in class org.eclipse.jetty.servlet.DefaultServlet
 
init() - Method in class org.eclipse.jetty.servlet.Invoker
 
init() - Method in class org.eclipse.jetty.servlet.JspPropertyGroupServlet
 
init() - Method in class org.eclipse.jetty.servlet.StatisticsServlet
 
init() - Method in class org.eclipse.jetty.start.StartIni
 
init() - Method in class org.eclipse.jetty.start.TextFile
 
init() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
init() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServlet
 
init(FilterConfig) - Method in class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
init(FilterConfig) - Method in class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
init(FilterConfig) - Method in class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
 
init(ServletConfig) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet.TransparentDelegate
 
init(ServletConfig) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.Transparent
 
init(ServletConfig) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.Transparent
 
init(ServletConfig) - Method in class org.eclipse.jetty.proxy.ProxyServlet.Transparent
 
init(ServletConfig) - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
init(ClientEndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.ClientEndpointConfigWrapper
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AbstractDecoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.InputStreamDecoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ReaderDecoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AbstractEncoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteArrayEncoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.ByteBufferEncoder
 
init(EndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.EndpointConfigWrapper
 
init(ServerEndpointConfig) - Method in class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
init(String[]) - Method in class org.eclipse.jetty.start.Main
 
init(Parser.Listener) - Method in class org.eclipse.jetty.http2.parser.Parser
 
init(Parser.Listener) - Method in class org.eclipse.jetty.http2.parser.ServerParser
 
init(Resource, XmlParser.Node, XmlConfiguration) - Method in interface org.eclipse.jetty.xml.ConfigurationProcessor
Initialize a ConfigurationProcessor from provided Resource and XML
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
init(ExtensionConfig, WebSocketComponents) - Method in interface org.eclipse.jetty.websocket.core.Extension
 
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.internal.FrameCaptureExtension
 
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
init(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
initClassLoader() - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
Establish a classloader with custom paths (if any)
initContextHandler(ServletContext) - Method in class org.eclipse.jetty.servlet.DefaultServlet
Compute the field _contextHandler.
In the case where the DefaultServlet is deployed on the HttpService it is likely that this method needs to be overwritten to unwrap the ServletContext facade until we reach the original jetty's ContextHandler.
initDb() - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
Lookup the datasource for the jndiName and formulate the necessary sql query strings based on the configured table and column names.
InitException - Exception Class in org.eclipse.jetty.websocket.jakarta.common
Exception during initialization of the Endpoint
InitException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.jakarta.common.InitException
 
INITIAL_URI_LENGTH - Static variable in class org.eclipse.jetty.http.HttpParser
 
INITIAL_WINDOW_SIZE - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
InitialContextFactory - Class in org.eclipse.jetty.jndi
InitialContextFactory.java Factory for the default InitialContext.
InitialContextFactory() - Constructor for class org.eclipse.jetty.jndi.InitialContextFactory
 
InitialContextFactory.DefaultParser - Class in org.eclipse.jetty.jndi
 
initialize() - Method in class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
initialize() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
initialize() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
initialize() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
initialize() - Method in class org.eclipse.jetty.servlet.BaseHolder
Do any setup necessary after starting
initialize() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
initialize() - Method in class org.eclipse.jetty.servlet.ServletHandler
Initialize filters and load-on-startup servlets.
initialize() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
initialize(MessagePolicy, MessagePolicy, CallbackHandler, Map) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
initialize(MessagePolicy, MessagePolicy, CallbackHandler, Map) - Method in class org.eclipse.jetty.security.jaspi.modules.BasicAuthenticationAuthModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.DataSourceLoginModule
Init LoginModule.
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.JDBCLoginModule
Init LoginModule.
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
Init LoginModule.
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class org.eclipse.jetty.jaas.spi.PropertyFileLoginModule
Use a PropertyUserStore to read the authentication and authorizaton information contained in the file named by the option "file".
initialize(SessionContext) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
initialize(SessionContext) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
initialize(SessionContext) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
initialize(SessionContext) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
initialize(SessionContext) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
initialize(SessionContext) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
initialize(SessionContext) - Method in interface org.eclipse.jetty.server.session.SessionCache
 
initialize(SessionContext) - Method in interface org.eclipse.jetty.server.session.SessionDataMap
Initialize this data map for the given context.
initialize(BaseHome, CommandLineConfigSource) - Method in class org.eclipse.jetty.start.StartLog
 
initialize(IncomingFrames, OutgoingFrames, WebSocketCoreSession) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
initializeContextPath(ContextHandler, String, boolean) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
INITIALIZED - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.ContextStatus
 
initializeDefaults(Object) - Method in class org.eclipse.jetty.xml.XmlConfiguration
Initialize a new Object defaults.
initializeHolders(Collection<? extends BaseHolder<?>>) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
Initializer(ServletContextHandler, ServletContainerInitializer) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.Initializer
Deprecated.
 
Initializer(ServletContextHandler, ServletContainerInitializer, Set<Class<?>>) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.Initializer
Deprecated.
 
initializeStore() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Read the names of the existing session files and build a map of fully qualified session ids (ie with context) to filename.
initializeWebAppContextDefaults(WebAppContext) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
initialValue() - Method in class org.eclipse.jetty.util.ClassLoadingObjectInputStream.ClassLoaderThreadLocal
 
initJspServlet() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
initLogFile(Path) - Method in class org.eclipse.jetty.start.StartLog
 
initRandom() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Set up a random number generator for the sessionids.
initScanFiles() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
inject(Object) - Method in class org.eclipse.jetty.plus.annotation.Injection
Inject a value for a Resource from JNDI into an object
inject(Object) - Method in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
injectField(Field, Object) - Method in class org.eclipse.jetty.plus.annotation.Injection
Inject value from jndi into a field of an instance
Injection - Class in org.eclipse.jetty.plus.annotation
Injection
Injection(Class<?>, Field, Class<?>, String, String) - Constructor for class org.eclipse.jetty.plus.annotation.Injection
 
Injection(Class<?>, Method, Class<?>, Class<?>, String, String) - Constructor for class org.eclipse.jetty.plus.annotation.Injection
 
Injection(Class<?>, String, Class<?>, String, String) - Constructor for class org.eclipse.jetty.plus.annotation.Injection
 
INJECTION_COLLECTION - Static variable in class org.eclipse.jetty.plus.annotation.InjectionCollection
 
InjectionCollection - Class in org.eclipse.jetty.plus.annotation
InjectionCollection Map of classname to all injections requested on that class, whether by declaration in web.xml or via equivalent annotations.
InjectionCollection() - Constructor for class org.eclipse.jetty.plus.annotation.InjectionCollection
 
injectMethod(Method, Object) - Method in class org.eclipse.jetty.plus.annotation.Injection
Inject value from jndi into a setter method of an instance
Input() - Constructor for class org.eclipse.jetty.http.HttpTester.Input
 
inputBufferSize() - Element in annotation type org.eclipse.jetty.websocket.api.annotations.WebSocket
The size of the buffer (in bytes) used to read from the network layer.
InputStreamContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
InputStreamContentProvider(InputStream) - Constructor for class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
InputStreamContentProvider(InputStream, int) - Constructor for class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
InputStreamContentProvider(InputStream, int, boolean) - Constructor for class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
InputStreamDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
InputStreamDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.InputStreamDecoder
 
InputStreamMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
InputStreamMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.InputStreamMessageSink
 
InputStreamRangeWriter - Class in org.eclipse.jetty.server.resource
Default Range Writer for InputStream
InputStreamRangeWriter(InputStreamRangeWriter.InputStreamSupplier) - Constructor for class org.eclipse.jetty.server.resource.InputStreamRangeWriter
Create InputStreamRangeWriter
InputStreamRangeWriter.InputStreamSupplier - Interface in org.eclipse.jetty.server.resource
 
InputStreamRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content that produces content from an InputStream.
InputStreamRequestContent(InputStream) - Constructor for class org.eclipse.jetty.client.util.InputStreamRequestContent
 
InputStreamRequestContent(InputStream, int) - Constructor for class org.eclipse.jetty.client.util.InputStreamRequestContent
 
InputStreamRequestContent(String, InputStream) - Constructor for class org.eclipse.jetty.client.util.InputStreamRequestContent
 
InputStreamRequestContent(String, InputStream, int) - Constructor for class org.eclipse.jetty.client.util.InputStreamRequestContent
 
InputStreamResponseListener - Class in org.eclipse.jetty.client.util
Implementation of Response.Listener that produces an InputStream that allows applications to read the response content.
InputStreamResponseListener() - Constructor for class org.eclipse.jetty.client.util.InputStreamResponseListener
 
INSENSITIVE_CACHE - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
insert(int, ByteBuffer, boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
insert(HttpField) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
A speculative insert of a Header into the Encoders Dynamic Table.
insertHandler(HandlerWrapper) - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
Replace the current handler with another HandlerWrapper linked to the current handler.
insertHandler(HandlerWrapper) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Insert a HandlerWrapper before the first Session, Security or ServletHandler but after any other HandlerWrappers.
insertLifeCycleNode(String, String, String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Convenience method to allow for insertion of nodes into the lifecycle.
insertNode(Edge, String) - Method in class org.eclipse.jetty.deploy.graph.Graph
Convenience method for Graph.insertNode(Edge, Node)
insertNode(Edge, Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
Insert an arbitrary node on an existing edge.
instance - Variable in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
INSTANCE - Static variable in class org.eclipse.jetty.jaas.JAASLoginService
 
INSTANCE - Static variable in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
 
INSTANCE - Static variable in class org.eclipse.jetty.util.resource.EmptyResource
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.client.internal.EmptyConfigurator
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.BooleanDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteArrayDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteBufferDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.CharacterDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.DoubleDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.FloatDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.IntegerDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.LongDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.ShortDecoder
 
INSTANCE - Static variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.StringDecoder
 
Instruction - Interface in org.eclipse.jetty.http3.qpack
 
Instruction.Handler - Interface in org.eclipse.jetty.http3.qpack
A handler for instructions issued by an QpackEncoder or QpackDecoder.
INSUFFICIENT_STORAGE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
INSUFFICIENT_STORAGE_507 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
IntegerDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Integer decoder
IntegerDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.IntegerDecoder
 
IntegerEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Integer to Encoder.Text Message encoder
IntegerEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.IntegerEncoder
 
Integral - Enum constant in enum org.eclipse.jetty.security.UserDataConstraint
 
interfaceType - Variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
interfaceType - Variable in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
INTERNAL_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates an internal error.
INTERNAL_SERVER_ERROR - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
INTERNAL_SERVER_ERROR_500 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
interruptAcceptors() - Method in class org.eclipse.jetty.server.AbstractConnector
 
interruptThread(long) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
introspect(Object, Object) - Method in class org.eclipse.jetty.annotations.AnnotationDecorator
Look for annotations that can be discovered with introspection: Resource Resources RunAs PostConstruct PreDestroy DeclareRoles MultiPart ServletSecurity
introspect(Object, Object) - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector
 
IntrospectionUtil - Class in org.eclipse.jetty.util
IntrospectionUtil
IntrospectionUtil() - Constructor for class org.eclipse.jetty.util.IntrospectionUtil
 
IntrospectorCleaner - Class in org.eclipse.jetty.servlet.listener
IntrospectorCleaner Cleans a static cache of Methods held by java.beans.Introspector class when a context is undeployed.
IntrospectorCleaner() - Constructor for class org.eclipse.jetty.servlet.listener.IntrospectorCleaner
 
intToLevel(int) - Static method in enum org.eclipse.jetty.logging.JettyLevel
 
IntValueHttpField(HttpHeader, int) - Constructor for class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
IntValueHttpField(HttpHeader, String, int) - Constructor for class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
IntValueHttpField(HttpHeader, String, String) - Constructor for class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
IntValueHttpField(HttpHeader, String, String, int) - Constructor for class org.eclipse.jetty.http.HttpField.IntValueHttpField
 
INVALID - Enum constant in enum org.eclipse.jetty.server.session.Session.State
 
INVALID_COOKIES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
An invalid cookie was found, without a more specific violation.
INVALID_UPSTREAM_RESPONSE - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1014 indicates that a gateway or proxy received and invalid upstream response.
invalidate() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
invalidate() - Method in class org.eclipse.jetty.server.session.Session
Called by users to invalidate a session, or called by the access method as a request enters the session if the session has expired, or called by manager as a result of scavenger expiring session
invalidate(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Called by SessionIdManager to remove a session that has been invalidated, either by this context or another context.
invalidateAll(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
invalidateAll(String) - Method in interface org.eclipse.jetty.server.SessionIdManager
Invalidate all sessions on all contexts that share the same id.
invalidateChainsCache() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
INVALIDATING - Enum constant in enum org.eclipse.jetty.server.session.Session.State
 
InvalidCookieException() - Constructor for exception class org.eclipse.jetty.http.CookieParser.InvalidCookieException
 
InvalidCookieException(String) - Constructor for exception class org.eclipse.jetty.http.CookieParser.InvalidCookieException
 
InvalidCookieException(String, Throwable) - Constructor for exception class org.eclipse.jetty.http.CookieParser.InvalidCookieException
 
InvalidCookieException(Throwable) - Constructor for exception class org.eclipse.jetty.http.CookieParser.InvalidCookieException
 
InvalidSignatureException - Exception Class in org.eclipse.jetty.websocket.core.exception
 
InvalidSignatureException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.InvalidSignatureException
 
InvalidSignatureException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.InvalidSignatureException
 
InvalidWebSocketException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Indicating that the provided Class is not a valid WebSocket as defined by the API.
InvalidWebSocketException - Exception Class in org.eclipse.jetty.websocket.core.exception
Indicating that the provided Class is not a valid WebSocket per the chosen API.
InvalidWebSocketException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.InvalidWebSocketException
 
InvalidWebSocketException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.InvalidWebSocketException
 
InvalidWebSocketException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.InvalidWebSocketException
 
InvalidWebSocketException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.InvalidWebSocketException
 
Invocable - Interface in org.eclipse.jetty.util.thread
A task (typically either a Runnable or Callable that declares how it will behave when invoked:
Invocable.InvocationType - Enum in org.eclipse.jetty.util.thread
The behavior of an Invocable when it is invoked.
Invocable.ReadyTask - Class in org.eclipse.jetty.util.thread
A Runnable decorated with an Invocable.InvocationType.
Invocable.Task - Interface in org.eclipse.jetty.util.thread
A task with an Invocable.InvocationType.
invoke(Object, Object) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
invoke(String, Object[], String[]) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
invoke(String, Object[], String[]) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
invokeMain(ClassLoader, StartArgs) - Method in class org.eclipse.jetty.start.Main
 
invokeNonBlocking(Runnable) - Static method in interface org.eclipse.jetty.util.thread.Invocable
Invoke a task with the calling thread, tagged to indicate that it will not block.
invokeObject(Object, Object) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
Invoker - Class in org.eclipse.jetty.servlet
Dynamic Servlet Invoker.
Invoker() - Constructor for class org.eclipse.jetty.servlet.Invoker
 
InvokerUtils - Class in org.eclipse.jetty.websocket.core.internal.util
 
InvokerUtils() - Constructor for class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
 
InvokerUtils.Arg - Class in org.eclipse.jetty.websocket.core.internal.util
 
InvokerUtils.ParamIdentifier - Interface in org.eclipse.jetty.websocket.core.internal.util
 
inwardClose(long, String) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
inwardClose(long, String) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
IO - Class in org.eclipse.jetty.util
IO Utilities.
IO() - Constructor for class org.eclipse.jetty.util.IO
 
is(String) - Method in class org.eclipse.jetty.http.HttpField
 
is(String) - Method in enum org.eclipse.jetty.http.HttpHeader
 
is(String) - Method in enum org.eclipse.jetty.http.HttpHeaderValue
 
is(String) - Method in enum org.eclipse.jetty.http.HttpMethod
 
is(String) - Method in enum org.eclipse.jetty.http.HttpScheme
 
is(String) - Method in enum org.eclipse.jetty.http.HttpVersion
 
is(String) - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
isAbnormal() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
isAbsolute() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
isAbsolute() - Method in interface org.eclipse.jetty.http.HttpURI
 
isAbsolute() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
isAbsolute(String) - Static method in class org.eclipse.jetty.start.PathMatchers
Tests if provided pattern is an absolute reference (or not)
isAcceptable(String, String, String) - Method in class org.eclipse.jetty.http2.server.HTTP2CServerConnectionFactory
 
isAcceptable(String, String, String) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory
 
isAcceptable(String, String, String) - Method in interface org.eclipse.jetty.server.NegotiatingServerConnection.CipherDiscriminator
 
isAccepting() - Method in class org.eclipse.jetty.server.AbstractConnector
 
isAcceptingInLowResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
isAcceptRanges() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isAcceptRanges() - Method in class org.eclipse.jetty.server.ResourceService
 
isActive(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
isActive(Connection) - Method in interface org.eclipse.jetty.client.ConnectionPool
 
isAdd() - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Returns the add flag value.
isAdd() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
 
isAlias() - Method in class org.eclipse.jetty.util.resource.PathResource
 
isAlias() - Method in class org.eclipse.jetty.util.resource.Resource
 
isAlive() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
isAllContentWritten(long) - Method in class org.eclipse.jetty.server.Response
 
isAllowDuplicateFragmentNames() - Method in class org.eclipse.jetty.webapp.MetaData
 
isAllowDuplicateFragmentNames() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isAllowDuplicateMappings() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isAllowed(InetAddress, Request, HttpServletRequest) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Checks if specified address and request are allowed by current InetAddress rules.
isAllowed(Path) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
isAllowedBy(ComplianceViolation.Mode) - Method in interface org.eclipse.jetty.http.ComplianceViolation
 
isAllowInsecureHttpDownloads() - Method in class org.eclipse.jetty.start.StartArgs
 
isAlwaysSaveUri() - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
Deprecated.
isAmbiguous() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
isAmbiguous() - Method in interface org.eclipse.jetty.http.HttpURI
 
isAmbiguous() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
isAnyAuth() - Method in class org.eclipse.jetty.security.RoleInfo
 
isAnyAuth() - Method in class org.eclipse.jetty.util.security.Constraint
Servlet Spec 3.1, pg 140
isAnyRole() - Method in class org.eclipse.jetty.security.RoleInfo
 
isAnyRole() - Method in class org.eclipse.jetty.util.security.Constraint
 
isAppend() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve append to log flag.
isApplicable(URI) - Method in class org.eclipse.jetty.start.FileInitializer
 
isApplicable(URI) - Method in class org.eclipse.jetty.start.fileinits.TestFileInitializer
 
isApplyToAsync() - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
isApproveAllLicenses() - Method in class org.eclipse.jetty.start.StartArgs
 
isAsync() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isAsync() - Method in class org.eclipse.jetty.server.HttpInput
 
isAsync() - Method in class org.eclipse.jetty.server.HttpOutput
 
isAsyncStarted() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isAsyncStarted() - Method in class org.eclipse.jetty.server.Request
 
isAsyncStarted() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isAsyncSupported() - Method in class org.eclipse.jetty.server.Request
 
isAsyncSupported() - Method in class org.eclipse.jetty.servlet.Holder
 
isAsyncSupported() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isAtEOF() - Method in class org.eclipse.jetty.http.HttpParser
 
isAuthenticated() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
isAuthenticateNewUsers() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
isAuthenticateNewUsers() - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
isAuthMandatory() - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
isAuthMandatory(Request, Response, Object) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
isAuthMandatory(Request, Response, Object) - Method in class org.eclipse.jetty.security.SecurityHandler
 
isAuto(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
isAutoFragment() - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
If true, frames are automatically fragmented to respect the maximum frame size.
isAutoFragment() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
isAutoFragment() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
isAutoFragment() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
isAutoFragment() - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
isAutoFragment() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isAutoFragment() - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
isAutoStartScanning() - Method in class org.eclipse.jetty.util.Scanner
Test if scanning should start automatically with Scanner.AbstractLifeCycle.start()
isAvailable() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isAvailable() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isAvailable() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
isAvailable() - Method in interface org.eclipse.jetty.webapp.Configuration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.JaasConfiguration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.JaspiConfiguration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.JmxConfiguration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.JndiConfiguration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.JspConfiguration
 
isAvailable() - Method in class org.eclipse.jetty.webapp.ServletsConfiguration
 
isAvailable(String) - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
isBaseDifferent() - Method in class org.eclipse.jetty.start.BaseHome
 
isBefore(long, long) - Static method in class org.eclipse.jetty.util.NanoTime
Returns whether the first nanoTime is strictly before the second nanoTime.
isBeforeOrSame(long, long) - Static method in class org.eclipse.jetty.util.NanoTime
Returns whether the first nanoTime is before or the same as the second nanoTime.
isBlackListCipher(String) - Static method in class org.eclipse.jetty.http2.HTTP2Cipher
 
isBlackListProtocol(String) - Static method in class org.eclipse.jetty.http2.HTTP2Cipher
 
isBlank(String) - Static method in class org.eclipse.jetty.start.Utils
Is String null, empty, or consisting of only whitespace.
isBlank(String) - Static method in class org.eclipse.jetty.util.StringUtil
Test if a string is null or only has whitespace characters in it.
isCacheable(Resource) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
isCached() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
isCancelled() - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
isCancelled() - Method in class org.eclipse.jetty.util.FutureCallback
 
isCancelled() - Method in class org.eclipse.jetty.util.FuturePromise
 
isCancelled() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
isCertSign(X509Certificate) - Static method in class org.eclipse.jetty.util.ssl.X509
 
isCharsetAssumed() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
isChecked() - Method in class org.eclipse.jetty.security.RoleInfo
 
isCheckingRemoteSessionIdEncoding() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
isCheckWelcomeFiles() - Method in class org.eclipse.jetty.security.SecurityHandler
 
isChunking() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isChunking() - Method in class org.eclipse.jetty.http.HttpParser
 
isClientError() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
Simple test against an code to determine if it falls into the Client Error message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isClientError(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Simple test against an code to determine if it falls into the Client Error message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isClientStream(int) - Static method in class org.eclipse.jetty.http2.HTTP2Session
 
isClose() - Method in class org.eclipse.jetty.http.HttpParser
 
isClosed() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
isClosed() - Method in interface org.eclipse.jetty.client.api.Connection
 
isClosed() - Method in interface org.eclipse.jetty.client.ConnectionPool
 
isClosed() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
isClosed() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
isClosed() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
isClosed() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
isClosed() - Method in class org.eclipse.jetty.http.HttpParser
 
isClosed() - Method in interface org.eclipse.jetty.http2.api.Session
 
isClosed() - Method in interface org.eclipse.jetty.http2.api.Stream
 
isClosed() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
isClosed() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isClosed() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isClosed() - Method in class org.eclipse.jetty.server.HttpOutput
 
isClosed() - Method in class org.eclipse.jetty.util.IteratingCallback
 
isClosed() - Method in class org.eclipse.jetty.util.Pool.Entry
 
isClosed() - Method in class org.eclipse.jetty.util.Pool
 
isClosed() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isClosed() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
isCommitted() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isCommitted() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isCommitted() - Method in interface org.eclipse.jetty.http2.IStream
 
isCommitted() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
isCommitted() - Method in class org.eclipse.jetty.server.HttpChannel
 
isCommitted() - Method in class org.eclipse.jetty.server.Response
 
isCommitted() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
isCommitted() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
isCommitted() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
isCommitted() - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Returns a boolean indicating if the response has been committed.
isCompactPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Deprecated.
use CompactPathRule with RewriteHandler instead.
isComplete() - Method in class org.eclipse.jetty.http.HttpParser
 
isComplete() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
isCondensedNames() - Method in class org.eclipse.jetty.logging.StdErrAppender
 
isConditionalDependency(String) - Static method in class org.eclipse.jetty.start.Module
 
isConfigurationDiscovered() - Method in class org.eclipse.jetty.webapp.WebAppContext
Is the context Automatically configured.
isConnectBlocking() - Method in class org.eclipse.jetty.client.HttpClient
 
isConnectBlocking() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
isConnectBlocking() - Method in class org.eclipse.jetty.io.ClientConnector
 
isConnected() - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
isConnectionEstablished() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
isConnectionPending(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
isConnectionPending(SelectableChannel) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
isConnectProtocolEnabled() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isConnectProtocolEnabled() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.JarFileResource
Check if this jar:file: resource is contained in the named resource.
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.PathResource
 
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.Resource
 
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
isContainedIn(Resource) - Method in class org.eclipse.jetty.util.resource.URLResource
 
isContainedIn(Resource, Resource) - Static method in class org.eclipse.jetty.util.resource.Resource
 
isContentComplete(long) - Method in class org.eclipse.jetty.server.Response
 
isContextPathDefault() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isContinuation() - Method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
isControl() - Method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
isControl(long) - Static method in enum org.eclipse.jetty.http3.frames.FrameType
 
isControlFrame() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isControlFrame(byte) - Static method in class org.eclipse.jetty.websocket.core.OpCode
 
isConvertible() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
isCopyWebDir() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isCopyWebInf() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isCreateFiles() - Method in class org.eclipse.jetty.start.StartArgs
 
isCreateStartD() - Method in class org.eclipse.jetty.start.StartArgs
 
isCreateStartIni() - Method in class org.eclipse.jetty.start.StartArgs
 
isDaemon() - Method in class org.eclipse.jetty.ant.JettyRunTask
 
isDaemon() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
isDaemon() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
isDaemon() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
isDaemon() - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
isData() - Method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
isDataFrame() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isDataFrame(byte) - Static method in class org.eclipse.jetty.websocket.core.OpCode
 
isDebugEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isDebugEnabled() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isDebugEnabled() - Static method in class org.eclipse.jetty.start.StartLog
 
isDebugEnabled() - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
 
isDebugEnabled(Marker) - Method in class org.eclipse.jetty.logging.JettyLogger
 
isDecoratable(Class<?>) - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
Test if a class can be decorated.
isDeepBindingSupported() - Method in class org.eclipse.jetty.jndi.NamingContext
 
isDefaultConstructable(Class<?>) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
isDefaultDispatches() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
isDefaultOrder() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
 
isDefaultPort(String, int) - Method in class org.eclipse.jetty.client.HttpClient
 
isDeferInitialScan() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
Test if initial scan should be deferred.
isDeferred(HttpServletResponse) - Static method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
isDelayDispatchUntilContent() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isDeleteOnExit() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Deprecated.
no replacement provided
isDeleteOnExit() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
no replacement offered.
isDeleteUnrestorableFiles() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
isDeleteUnrestorableFiles() - Method in class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
isDemanding() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
isDemanding() - Method in interface org.eclipse.jetty.websocket.core.FrameHandler
Does the FrameHandler manage it's own demand?
isDemanding() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isDemanding() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
isDenyUncoveredHttpMethods() - Method in interface org.eclipse.jetty.security.ConstraintAware
 
isDenyUncoveredHttpMethods() - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
isDetailedDump() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
isDetailedDump() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
isDetailedDump() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
isDetailedDump() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
isDetailedParseException() - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
isDirAllowed() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isDirAllowed() - Method in class org.eclipse.jetty.server.ResourceService
 
isDirect() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
isDirectBuffersForDecryption() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isDirectBuffersForDecryption() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isDirectBuffersForEncryption() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isDirectBuffersForEncryption() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isDirectoriesListed() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
Get the directory option.
isDirectory() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.PathResource
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.Resource
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
isDirectory() - Method in class org.eclipse.jetty.util.resource.URLResource
 
isDirty() - Method in class org.eclipse.jetty.server.session.SessionData
 
isDisableActiveMigration() - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
isDiscardPathInfo() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
isDiscardQuery() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
isDisconnected() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isDistributable() - Method in class org.eclipse.jetty.webapp.MetaData
A webapp is distributable if web.xml is metadata-complete and distributable=true, or if metadata-complete is false, but all web-fragments.xml are distributable=true.
isDistributable() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isDistributable() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
isDone() - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
isDone() - Method in class org.eclipse.jetty.util.FutureCallback
 
isDone() - Method in class org.eclipse.jetty.util.FuturePromise
 
isDone() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.EncodeFailedFuture
 
isDryRun() - Method in class org.eclipse.jetty.server.Server
 
isDryRun() - Method in class org.eclipse.jetty.start.StartArgs
 
isDumpable(Object) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isDumpable(Object) - Method in interface org.eclipse.jetty.util.component.Dumpable.DumpableContainer
 
isDumpAfterStart() - Method in class org.eclipse.jetty.server.Server
 
isDumpBeforeStop() - Method in class org.eclipse.jetty.server.Server
 
isDumpContext() - Method in class org.eclipse.jetty.server.DebugListener
 
isDurableListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isDynamic() - Method in class org.eclipse.jetty.start.Module
Indicates a module that is dynamic in nature
isEarlyEOF() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
isEmpty() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
isEmpty() - Method in interface org.eclipse.jetty.client.ConnectionPool
 
isEmpty() - Method in class org.eclipse.jetty.deploy.graph.Path
 
isEmpty() - Method in class org.eclipse.jetty.http.QuotedCSV
 
isEmpty() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
isEmpty() - Method in class org.eclipse.jetty.server.HttpInput.Content
Check if the buffer is empty.
isEmpty() - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
isEmpty() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Deprecated.
use getParts().isEmpty()
isEmpty() - Method in interface org.eclipse.jetty.server.MultiParts
 
isEmpty() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
isEmpty() - Method in class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
isEmpty() - Method in class org.eclipse.jetty.start.Classpath
 
isEmpty() - Method in class org.eclipse.jetty.util.Fields
 
isEmpty() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
isEmpty() - Method in interface org.eclipse.jetty.util.Index
Check if the index contains any entry.
isEmpty() - Method in class org.eclipse.jetty.util.RegexSet
 
isEmpty() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
isEmpty() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
isEmpty(Object) - Static method in class org.eclipse.jetty.util.LazyList
Simple utility method to test if List is empty
isEmpty(String) - Static method in class org.eclipse.jetty.util.StringUtil
Checks if a String is empty ("") or null.
isEmpty(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Check for an empty or null buffer.
isEmpty(ByteBuffer[]) - Static method in class org.eclipse.jetty.util.BufferUtil
Check for an empty or null buffers.
isEmptyDir(File) - Static method in class org.eclipse.jetty.util.IO
Test if directory is empty.
isEmptyStringNull() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
isEnableCRLDP() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
isEnableCRLDP() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
isEnableCRLDP() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isEnabled() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
isEnabled() - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
isEnabled() - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
isEnabled() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
isEnabled() - Method in class org.eclipse.jetty.start.Module
 
isEnabledByDefault() - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
isEnabledByDefault() - Method in interface org.eclipse.jetty.webapp.Configuration
 
isEnabledByDefault() - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
isEnableOCSP() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
isEnableOCSP() - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
isEnableOCSP() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isEnd() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isEndHeaders() - Method in class org.eclipse.jetty.http2.frames.ContinuationFrame
 
isEndStream() - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
isEndStream() - Method in class org.eclipse.jetty.http2.frames.HeadersFrame
 
isEndStream() - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
isEndStream() - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
isEnsureDefaultServlet() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isEnsureSecureRequestCustomizer() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isEnvEntryType(Class<?>) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
Check if the class is one of the basic java types permitted as env-entries.
isEof() - Method in class org.eclipse.jetty.server.HttpInput.Content
Check if EOF was reached.
isEof() - Method in class org.eclipse.jetty.server.HttpInput.EofContent
 
isEof() - Method in class org.eclipse.jetty.server.HttpInput.WrappingContent
 
isEOF() - Method in class org.eclipse.jetty.http.HttpTester.Input
 
isEqualTo(HttpFields) - Method in interface org.eclipse.jetty.http.HttpFields
 
isError() - Method in interface org.eclipse.jetty.server.ContentProducer
Check if the underlying HttpChannel reached an error content.
isError() - Method in class org.eclipse.jetty.server.HttpInput
 
isErrorEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isErrorEnabled() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isErrorEnabled(Marker) - Method in class org.eclipse.jetty.logging.JettyLogger
 
isErrorPage(String) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
isEscapedMessages() - Method in class org.eclipse.jetty.logging.StdErrAppender
 
ISession - Interface in org.eclipse.jetty.http2
The SPI interface for implementing an HTTP/2 session.
isEstablished() - Method in class org.eclipse.jetty.security.SpnegoUserIdentity
 
isEtags() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isEtags() - Method in class org.eclipse.jetty.server.ResourceService
 
isExclusive() - Method in class org.eclipse.jetty.http2.frames.PriorityFrame
 
isExec() - Method in class org.eclipse.jetty.start.StartArgs
 
isExitJvm() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
isExitVm() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
isExpecting100Continue() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
isExpecting100Continue() - Method in class org.eclipse.jetty.server.HttpChannel
 
isExpecting100Continue() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
isExpecting102Processing() - Method in class org.eclipse.jetty.server.HttpChannel
 
isExpecting102Processing() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
isExpired() - Method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
isExpired() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isExpired(long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
Check to see if the given time is in the past.
isExpired(long) - Method in class org.eclipse.jetty.http.HttpCookie
 
isExpiredAt(long) - Method in class org.eclipse.jetty.server.session.Session
Check to see if session has expired as at the time given.
isExpiredAt(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
isExpiredTimestamp(String) - Static method in class org.eclipse.jetty.start.fileinits.MavenMetadata
Tests the current time against the provided timestamp.
isExtendedListenerTypes() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
isExtract() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
isExtractWAR() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isExtractWars() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Get the extractWars.
isFailed() - Method in class org.eclipse.jetty.client.api.Result
 
isFailed() - Method in class org.eclipse.jetty.client.HttpReceiver
 
isFailed() - Method in class org.eclipse.jetty.client.HttpSender
 
isFailed() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
isFailed() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
isFailed() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isFailed() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isFailed() - Method in class org.eclipse.jetty.util.IteratingCallback
 
isFalse(Object) - Static method in class org.eclipse.jetty.util.TypeUtil
 
isFatalEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isField() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
isFilePresent(Path...) - Method in class org.eclipse.jetty.start.FileInitializer
Test if any of the Paths exist (as files)
isFillInterested() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
isFillInterested() - Method in class org.eclipse.jetty.io.AbstractConnection
 
isFillInterested() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isFillInterested() - Method in interface org.eclipse.jetty.io.EndPoint
 
isFillInterested() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isFilterChainsCached() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isFin() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
isFin() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
isFin() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isFinished() - Method in class org.eclipse.jetty.http.GZIPContentDecoder
 
isFinished() - Method in class org.eclipse.jetty.server.HttpInput
 
isFinished(long) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
isFlushOnResponseCommit() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
isFlushOnResponseCommit() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
isFlushOnResponseCommit() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
isFollowRedirects() - Method in interface org.eclipse.jetty.client.api.Request
 
isFollowRedirects() - Method in class org.eclipse.jetty.client.HttpClient
 
isFollowRedirects() - Method in class org.eclipse.jetty.client.HttpRequest
 
isFor(Locale, String) - Method in class org.eclipse.jetty.server.ResponseWriter
 
isForbidden() - Method in class org.eclipse.jetty.security.RoleInfo
 
isForbidden() - Method in class org.eclipse.jetty.util.security.Constraint
 
isFormEncodedMethod(String) - Method in class org.eclipse.jetty.server.HttpConfiguration
Tests whether the HTTP method supports x-www-form-urlencoded content
isFromContainerClassPath(WebAppContext, ServletContainerInitializer) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Test if the ServletContainerInitializer is from the container classpath
isFromDefaultDescriptor() - Method in class org.eclipse.jetty.servlet.ServletMapping
 
isFromExcludedJar(WebAppContext, ServletContainerInitializer, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Check to see if the ServletContainerIntializer loaded via the ServiceLoader came from a jar that is excluded by the fragment ordering.
isFromWebInfClasses(WebAppContext, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Test if the ServletContainerInitializer is from WEB-INF/classes
isFull(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Check for a non null and full buffer.
isFullValidate() - Method in class org.eclipse.jetty.security.AbstractLoginService
 
isGraceful() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
isGraceful() - Method in class org.eclipse.jetty.http3.frames.GoAwayFrame
 
isGrowOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
isGzippedContent(String) - Method in class org.eclipse.jetty.server.ResourceService
 
isHandled() - Method in class org.eclipse.jetty.server.Request
 
isHandling() - Method in class org.eclipse.jetty.rewrite.handler.Rule
Returns the handling flag value.
isHead() - Method in class org.eclipse.jetty.server.Request
 
isHeaderCacheCaseSensitive() - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
isHeaderCacheCaseSensitive() - Method in class org.eclipse.jetty.http.HttpParser
 
isHeaderCacheCaseSensitive() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isHeartbeats() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
isHeartbeats() - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
isHeldByCurrentThread() - Method in class org.eclipse.jetty.util.thread.AutoLock
 
isHelp() - Method in class org.eclipse.jetty.start.StartArgs
 
isHex(String, int, int) - Static method in class org.eclipse.jetty.util.StringUtil
 
isHexDigit() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
isHidden(Path) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
isHideStacks() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isHotReload() - Method in class org.eclipse.jetty.security.HashLoginService
Is hot reload enabled on this user store
isHotReload() - Method in class org.eclipse.jetty.security.PropertyUserStore
Is hot reload enabled on this user store
isHttpOnly() - Method in class org.eclipse.jetty.http.HttpCookie
 
isHttpOnly() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
isHttpOnlyInComment(String) - Static method in class org.eclipse.jetty.http.HttpCookie
 
isIdChanged() - Method in class org.eclipse.jetty.server.session.Session
 
isIdempotent() - Method in enum org.eclipse.jetty.http.HttpMethod
An idempotent HTTP method is an HTTP method that can be called many times without different outcomes.
isIdInUse(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
isIdInUse(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Check if id is in use by this context
isIdInUse(String) - Method in interface org.eclipse.jetty.server.SessionIdManager
 
isIdle() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isIdle() - Method in class org.eclipse.jetty.http.HttpParser
 
isIdle() - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Server
 
isIdle() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
isIdle() - Method in class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
isIdle() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isIdle() - Method in class org.eclipse.jetty.util.Pool.Entry
 
isIdle() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
isIdle() - Method in class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
isIdleLongerThan(int) - Method in class org.eclipse.jetty.server.session.Session
Check if the Session has been idle longer than a number of seconds.
isIgnored() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
isIllegalFieldVchar(char) - Static method in class org.eclipse.jetty.http.HttpTokens
Checks whether this is an invalid VCHAR based on RFC9110.
isIncluded(String) - Method in class org.eclipse.jetty.ant.types.FileMatchingConfiguration
Checks if passed file is scanned by any of the directory scanners.
isIncludedAndNotExcluded(P) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
Test Included and not Excluded
isIncludeDirsInResults() - Method in class org.eclipse.jetty.start.PathFinder
 
isIncluding() - Method in class org.eclipse.jetty.server.Response
 
isInclusive() - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
isInfoEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isInfoEnabled() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isInfoEnabled(Marker) - Method in class org.eclipse.jetty.logging.JettyLogger
 
isInformational() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
Simple test against an code to determine if it falls into the Informational message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isInformational(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Simple test against an code to determine if it falls into the Informational message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isInheritable(Package, Member) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
isInheritChannel() - Method in class org.eclipse.jetty.server.ServerConnector
 
isInitial() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isInitialized() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isInputOpen() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isInputOpen() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
isInputOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isInputOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
isInputShutdown() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
isInputShutdown() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isInputShutdown() - Method in interface org.eclipse.jetty.io.EndPoint
Test if the input is shutdown.
isInputShutdown() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
isInputShutdown() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isInputUnready() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isInRange(Version, Version) - Method in class org.eclipse.jetty.start.Version
Check whether this version is in range of versions specified
isInstance() - Method in class org.eclipse.jetty.servlet.BaseHolder
 
isInterested() - Method in class org.eclipse.jetty.io.FillInterest
 
isInterim(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Tests whether the status code is informational but not 101 Switching Protocols.
isInternalExtension() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
isIntrinsicallySecure(SocketAddress) - Method in class org.eclipse.jetty.io.ClientConnector
 
isIntrinsicallySecure(ClientConnector, SocketAddress) - Method in class org.eclipse.jetty.io.ClientConnector.Configurator
Returns whether the connection to a given SocketAddress is intrinsically secure.
isIntrinsicallySecure(ClientConnector, SocketAddress) - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
isIntrospectable(Object, Object) - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector
Test if an object should be introspected for some specific types of annotations like PostConstruct/PreDestroy/MultiPart etc etc.
isInUse() - Method in class org.eclipse.jetty.util.Pool.Entry
 
isInvalid() - Method in class org.eclipse.jetty.server.session.Session
 
isInvalidateOnShutdown() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
isInvalidateOnShutdown() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
isInvalidateOnShutdown() - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
isInvalidateOnShutdown() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
isJavaBeanCompliantSetter(Method) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
isJPMS() - Method in class org.eclipse.jetty.start.StartArgs
 
isJSecurityCheck(String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
isJSecurityCheck(String) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
isJspServlet() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
isJspServlet(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
isKnown(byte) - Static method in class org.eclipse.jetty.websocket.core.OpCode
Test for known opcodes (per the RFC spec)
isLast() - Method in class org.eclipse.jetty.http3.api.Stream.Data
 
isLast() - Method in class org.eclipse.jetty.http3.frames.DataFrame
 
isLast() - Method in class org.eclipse.jetty.http3.frames.HeadersFrame
 
isLast(Frame) - Static method in class org.eclipse.jetty.http3.frames.Frame
 
isLicenseCheckRequired() - Method in class org.eclipse.jetty.start.StartArgs
 
isListClasspath() - Method in class org.eclipse.jetty.start.StartArgs
 
isListConfig() - Method in class org.eclipse.jetty.start.StartArgs
 
isLocal() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isLocal() - Method in interface org.eclipse.jetty.http2.IStream
 
isLocallyClosed() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isLocalStreamClosed(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isLocked() - Method in class org.eclipse.jetty.jndi.NamingContext
 
isLoginOrErrorPage(String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
isLogoutWhenIdTokenIsExpired() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
isLogUrlOnStart() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isLowOnResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck
 
isLowOnResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
isLowOnResources() - Method in interface org.eclipse.jetty.server.LowResourceMonitor.LowResourceCheck
 
isLowOnResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MainThreadPoolLowResourceCheck
 
isLowOnResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MaxConnectionsLowResourceCheck
 
isLowOnResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
isLowOnThreads() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
isLowOnThreads() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
isLowOnThreads() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Returns whether this thread pool is low on threads.
isLowOnThreads() - Method in interface org.eclipse.jetty.util.thread.ThreadPool
 
isManaged(Object) - Method in interface org.eclipse.jetty.util.component.Container
Test if this container manages a bean
isManaged(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
isMandatory(MessageInfo) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
isMasked() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
isMasked() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
isMasked() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isMaximizeConnections() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
isMaxMessageSizeSet() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
isMessage(long) - Static method in enum org.eclipse.jetty.http3.frames.FrameType
 
isMetaDataComplete() - Method in class org.eclipse.jetty.webapp.MetaData
 
isMetaDataComplete(WebDescriptor) - Static method in class org.eclipse.jetty.webapp.WebDescriptor
Check if the descriptor is metadata-complete.
isMetaDataDirty() - Method in class org.eclipse.jetty.server.session.SessionData
 
isMethod() - Method in class org.eclipse.jetty.plus.annotation.Injection
 
isMimeTypeBufferable(String) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
isMimeTypeGzipable(String) - Method in interface org.eclipse.jetty.server.handler.gzip.GzipFactory
 
isMimeTypeGzipable(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Test if the provided MIME type is allowed based on the MIME type filters.
isMultiRelease() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
 
isNegotiate() - Method in class org.eclipse.jetty.client.Origin.Protocol
 
isNew() - Method in class org.eclipse.jetty.server.session.Session
 
isNewerThan(Version) - Method in class org.eclipse.jetty.start.Version
 
isNewerThanOrEqualTo(Version) - Method in class org.eclipse.jetty.start.Version
 
isNoContent() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isNonBlockingInvocation() - Static method in interface org.eclipse.jetty.util.thread.Invocable
Test if the current thread has been tagged as non blocking
isNormal() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
isNormalMainClass() - Method in class org.eclipse.jetty.start.StartArgs
 
isNotBlank(String) - Static method in class org.eclipse.jetty.start.Utils
Is String valid and has something other than whitespace
isNotBlank(String) - Static method in class org.eclipse.jetty.util.StringUtil
Test if a string is not null and contains at least 1 non-whitespace characters in it.
isNotConnected() - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
isNotifiable() - Method in class org.eclipse.jetty.util.PathWatcher
Check to see if the watcher is in a state where it should generate watch events to the listeners.
isNotifyExistingOnStart() - Method in class org.eclipse.jetty.util.PathWatcher
 
isNotifyRemoteAsyncErrors() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
Iso88591HttpWriter - Class in org.eclipse.jetty.server
 
Iso88591HttpWriter(HttpOutput) - Constructor for class org.eclipse.jetty.server.Iso88591HttpWriter
 
Iso88591StringBuilder() - Constructor for class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
isOlderThan(Version) - Method in class org.eclipse.jetty.start.Version
 
isOlderThanOrEqualTo(Version) - Method in class org.eclipse.jetty.start.Version
 
isOpen() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isOpen() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
isOpen() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isOpen() - Method in interface org.eclipse.jetty.io.EndPoint
 
isOpen() - Method in class org.eclipse.jetty.io.IdleTimeout
This abstract method should be called to check if idle timeouts should still be checked.
isOpen() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
isOpen() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
isOpen() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
isOpen() - Method in interface org.eclipse.jetty.server.NetworkConnector
A Connector may be opened and not started (to reserve a port) or closed and running (to allow graceful shutdown of existing connections)
isOpen() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isOpen() - Method in class org.eclipse.jetty.server.ServerConnector
 
isOpen() - Method in interface org.eclipse.jetty.websocket.api.Session
Return true if and only if the underlying socket is open.
isOpen() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
isOpen() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
isOrdered() - Method in class org.eclipse.jetty.webapp.MetaData
 
isOrdered() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
isOrdinary(int) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
isOurContextSessionFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Check if the filename matches our session pattern and is a session for our context.
isOutputOpen() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isOutputOpen() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
isOutputOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isOutputOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
isOutputShutdown() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
isOutputShutdown() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isOutputShutdown() - Method in interface org.eclipse.jetty.io.EndPoint
Test if output is shutdown.
isOutputShutdown() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
isOutputShutdown() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isOverrideWebXml() - Method in class org.eclipse.jetty.plus.jndi.EnvEntry
 
isOverUsed() - Method in class org.eclipse.jetty.util.Pool.Entry
Deprecated.
MaxUsage functionalities will be removed
isPadding() - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
isParentLoaderPriority() - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Get the parentLoaderPriority.
isParentLoaderPriority() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
Get the parentLoaderPriority.
isParentLoaderPriority() - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
 
isParentLoaderPriority() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isParsed() - Method in class org.eclipse.jetty.webapp.Descriptor
 
isPartitioned() - Method in class org.eclipse.jetty.http.HttpCookie
 
isPartitionedInComment(String) - Static method in class org.eclipse.jetty.http.HttpCookie
 
isPassivating() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
isPassivating() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
isPassivating() - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
isPassivating() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
isPassivating() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
isPassivating() - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
isPassivating() - Method in interface org.eclipse.jetty.server.session.SessionDataStore
True if this type of datastore will passivate session objects
isPassivating() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
isPathBufferable(String) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
isPathGzipable(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Test if the provided Request URI is allowed based on the Path Specs filters.
isPathInflatable(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Test if the provided Request URI is allowed to be inflated based on the Path Specs filters.
isPathInfoOnly() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isPathInfoOnly() - Method in class org.eclipse.jetty.server.ResourceService
 
isPaused(long) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
isPending() - Method in class org.eclipse.jetty.io.WriteFlusher
 
isPermanent() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
isPersistent() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isPersistent() - Method in class org.eclipse.jetty.server.HttpChannel
 
isPersistentConnectionsEnabled() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isPersistTempDirectory() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isPrefix(ByteBuffer, ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
isProgrammaticListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isPropertyBased() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
isPropertyFile(String) - Static method in class org.eclipse.jetty.start.FS
 
isPropertyNumber() - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
isProtected() - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
isProtectedTarget(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Check the target.
isPseudo() - Method in enum org.eclipse.jetty.http.HttpHeader
 
isPush() - Method in class org.eclipse.jetty.server.Request
 
isPushEnabled() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isPushEnabled() - Method in interface org.eclipse.jetty.http2.ISession
 
isPushSupported() - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
isPushSupported() - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
isPushSupported() - Method in class org.eclipse.jetty.server.HttpConnection
 
isPushSupported() - Method in interface org.eclipse.jetty.server.HttpTransport
 
isPushSupported() - Method in class org.eclipse.jetty.server.Request
 
isQuiet(long, long) - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
isQuoted(String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
isReady() - Method in interface org.eclipse.jetty.server.ContentProducer
Check if this ContentProducer instance has some content that can be read without blocking.
isReady() - Method in class org.eclipse.jetty.server.HttpInput
 
isReady() - Method in class org.eclipse.jetty.server.HttpOutput
 
isRecordHttpComplianceViolations() - Method in class org.eclipse.jetty.server.HttpConnection
 
isRecordHttpComplianceViolations() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
isRecurseDepthUnlimited() - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
isRecycleHttpChannels() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
isRecycleHttpChannels() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
isRedirect(Response) - Method in class org.eclipse.jetty.client.HttpRedirector
 
isRedirection() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
Simple test against an code to determine if it falls into the Redirection message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isRedirection(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Simple test against an code to determine if it falls into the Redirection message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isRedirectWelcome() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isRedirectWelcome() - Method in class org.eclipse.jetty.server.ResourceService
 
isRegistered(LifeCycle) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
isRegistered(LifeCycle) - Static method in class org.eclipse.jetty.util.thread.ShutdownThread
 
isRelativeRedirectAllowed() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isReleaseable() - Method in class org.eclipse.jetty.websocket.core.internal.Parser.ParsedFrame
 
isRemotelyClosed() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isRemotelyClosed() - Method in interface org.eclipse.jetty.http2.IStream
 
isRemoteStreamClosed(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
isRemoveIdleDestinations() - Method in class org.eclipse.jetty.client.HttpClient
isRemoveUnloadableSessions() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
isRemoveUnloadableSessions() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
isRemoveUnloadableSessions() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
isRenameThread() - Method in class org.eclipse.jetty.server.DebugListener
 
isRenegotiationAllowed() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
isRenegotiationAllowed() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isRenewTGT() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
isReply() - Method in class org.eclipse.jetty.http2.frames.PingFrame
 
isReply() - Method in class org.eclipse.jetty.http2.frames.SettingsFrame
 
isReproducible() - Method in interface org.eclipse.jetty.client.api.ContentProvider
Deprecated.
Whether this ContentProvider can produce exactly the same content more than once.
isReproducible() - Method in interface org.eclipse.jetty.client.api.Request.Content
Whether this content producer can produce exactly the same content more than once.
isReproducible() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
isReproducible() - Method in class org.eclipse.jetty.client.util.ByteBufferContentProvider
Deprecated.
 
isReproducible() - Method in class org.eclipse.jetty.client.util.ByteBufferRequestContent
 
isReproducible() - Method in class org.eclipse.jetty.client.util.BytesContentProvider
Deprecated.
 
isReproducible() - Method in class org.eclipse.jetty.client.util.BytesRequestContent
 
isReproducible() - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
isReproducible() - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
isRequest() - Method in class org.eclipse.jetty.http.MetaData
 
isRequest() - Method in class org.eclipse.jetty.http.MetaData.Request
 
isRequestBufferEmpty() - Method in class org.eclipse.jetty.server.HttpConnection
 
isRequestCompleted() - Method in class org.eclipse.jetty.server.HttpChannel
 
isRequestedSessionIdFromCookie() - Method in class org.eclipse.jetty.server.Request
 
isRequestedSessionIdFromCookie() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
isRequestedSessionIdFromCookie() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isRequestedSessionIdFromUrl() - Method in class org.eclipse.jetty.server.Request
Deprecated.
isRequestedSessionIdFromUrl() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
Deprecated.
isRequestedSessionIdFromUrl() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isRequestedSessionIdFromURL() - Method in class org.eclipse.jetty.server.Request
 
isRequestedSessionIdFromURL() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
isRequestedSessionIdFromURL() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isRequestedSessionIdValid() - Method in class org.eclipse.jetty.server.Request
 
isRequestedSessionIdValid() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
isRequestedSessionIdValid() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isRequireCloseMessage() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isRequireCloseMessage() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
isRequired() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
isReserved() - Method in class org.eclipse.jetty.util.Pool.Entry
 
isReserved(long) - Static method in class org.eclipse.jetty.http3.frames.SettingsFrame
 
isReserved(long) - Static method in enum org.eclipse.jetty.quic.common.StreamType
 
isReset() - Method in interface org.eclipse.jetty.http2.api.Stream
 
isReset() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isResetOrFailed() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
isResetOrFailed() - Method in interface org.eclipse.jetty.http2.IStream
 
isResident() - Method in class org.eclipse.jetty.server.session.Session
 
isResponse() - Method in class org.eclipse.jetty.http.MetaData
 
isResponse() - Method in class org.eclipse.jetty.http.MetaData.Response
 
isResponseCommitted() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isResponseCompleted() - Method in class org.eclipse.jetty.server.HttpChannel
 
isResponseCompleted() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isRetained() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
Checks if RetainableByteBuffer.retain() has been called at least one more time than RetainableByteBuffer.release().
isReusePort() - Method in class org.eclipse.jetty.io.ClientConnector
 
isReusePort() - Method in class org.eclipse.jetty.server.ServerConnector
 
isRewritePathInfo() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
isRewritePathInfo() - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
isRewriteRequestURI() - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
isRewriteRequestURI() - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
isRfc2616Token() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
isRfc6265CookieOctet() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
isRFC6265RejectedCharacter(char) - Method in class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
isRowIdReserved() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
rowId is a reserved word for Oracle, so change the name of this column
isRsv1() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
isRsv1() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
isRsv1() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isRsv1Used() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isRsv1Used() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
isRsv1Used() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
isRsv1Used() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isRsv1User() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
Used to indicate that the extension makes use of the RSV1 bit of the base websocket framing.
isRsv1User() - Method in interface org.eclipse.jetty.websocket.core.Extension
Used to indicate that the extension makes use of the RSV1 bit of the base websocket framing.
isRsv1User() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
isRsv2() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
isRsv2() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
isRsv2() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isRsv2Used() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isRsv2Used() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
isRsv2Used() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
isRsv2Used() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isRsv2User() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
Used to indicate that the extension makes use of the RSV2 bit of the base websocket framing.
isRsv2User() - Method in interface org.eclipse.jetty.websocket.core.Extension
Used to indicate that the extension makes use of the RSV2 bit of the base websocket framing.
isRsv3() - Method in interface org.eclipse.jetty.websocket.api.Frame
 
isRsv3() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
isRsv3() - Method in class org.eclipse.jetty.websocket.core.Frame
 
isRsv3Used() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isRsv3Used() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
 
isRsv3Used() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
isRsv3Used() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isRsv3User() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
Used to indicate that the extension makes use of the RSV3 bit of the base websocket framing.
isRsv3User() - Method in interface org.eclipse.jetty.websocket.core.Extension
Used to indicate that the extension makes use of the RSV3 bit of the base websocket framing.
isRun() - Method in class org.eclipse.jetty.start.StartArgs
 
isRunning() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isRunning() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isSafe() - Method in enum org.eclipse.jetty.http.HttpMethod
An HTTP method is safe if it doesn't alter the state of the server.
isSame(Resource) - Method in class org.eclipse.jetty.util.resource.PathResource
 
isSame(Resource) - Method in class org.eclipse.jetty.util.resource.Resource
Return true if the passed Resource represents the same resource as the Resource.
isSameFile(Path, Path) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
isSameName(Path, Path) - Static method in class org.eclipse.jetty.util.resource.PathResource
Test if the paths are the same name.
isSameName(HttpField) - Method in class org.eclipse.jetty.http.HttpField
 
isSameParameters(Class<?>[], Class<?>[]) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
isSameSignature(Method, Method) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
isSaveOnCreate() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
isSaveOnCreate() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
isSaveOnCreate() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
isSaveOnInactiveEvict() - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
isSaveOnInactiveEvict() - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
isSaveOnInactiveEviction() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Whether we should save a session that has been inactive before we boot it from the cache.
isSaveOnInactiveEviction() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
isScanned(File) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
isSchemeSecure(String) - Static method in class org.eclipse.jetty.client.HttpClient
 
isSecure() - Method in class org.eclipse.jetty.client.HttpDestination
 
isSecure() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
isSecure() - Method in class org.eclipse.jetty.http.HttpCookie
 
isSecure() - Method in class org.eclipse.jetty.server.Request
 
isSecure() - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
isSecure() - Method in interface org.eclipse.jetty.websocket.api.Session
Return true if and only if the underlying socket is using a secure transport.
isSecure() - Method in interface org.eclipse.jetty.websocket.api.UpgradeRequest
Test if connection is secure.
isSecure() - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
isSecure() - Method in class org.eclipse.jetty.websocket.client.impl.DelegatedJettyClientUpgradeRequest
 
isSecure() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
isSecure() - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
isSecure() - Method in interface org.eclipse.jetty.websocket.core.CoreSession
The active connection's Secure status indicator.
isSecure() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
isSecure() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
isSecure() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isSecure() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
isSecure() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
isSecure() - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
isSecureRequestOnly() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
isSendError() - Method in class org.eclipse.jetty.server.HttpChannel
 
isSendError() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isSendShutdownAtStart() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
isServerClass(Class<?>) - Method in interface org.eclipse.jetty.util.ClassVisibilityChecker
Is the class a Server Class.
isServerClass(Class<?>) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
isServerClass(Class<?>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isServerError() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
Simple test against an code to determine if it falls into the Server Error message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isServerError(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Simple test against an code to determine if it falls into the Server Error message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isServerResource(String, URL) - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
 
isServerResource(String, URL) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isSessionCachingEnabled() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isSessionFilename(String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Check if the filename is a session filename.
isSessionRenewedOnAuthentication() - Method in interface org.eclipse.jetty.security.Authenticator.AuthConfiguration
Should session ID be renewed on authentication.
isSessionRenewedOnAuthentication() - Method in class org.eclipse.jetty.security.SecurityHandler
 
isSessionRenewedOnAuthentication() - Method in class org.eclipse.jetty.security.WrappedAuthConfiguration
 
isShowHeaders() - Method in class org.eclipse.jetty.server.DebugListener
 
isShowServlet() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
isShowStacks() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
isShutdown() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
isShutdown() - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
isShutdown() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
isShutdown() - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
isShutdown() - Method in class org.eclipse.jetty.server.AbstractConnector
 
isShutdown() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isShutdown() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
isShutdown() - Method in interface org.eclipse.jetty.util.component.Graceful
 
isShutdown() - Method in class org.eclipse.jetty.util.component.Graceful.Shutdown
 
isShutdown() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
isShutdown() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
isShutdownDone() - Method in class org.eclipse.jetty.util.component.Graceful.Shutdown
 
isSkipFilesValidation() - Method in class org.eclipse.jetty.start.Module
 
isSniHostCheck() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSniRequired() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSniRequired() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
Returns whether an SNI match is required when choosing the alias that identifies the certificate to send to the client.
isSpecial() - Method in class org.eclipse.jetty.server.HttpInput.Content
Check if the content is special.
isSpecial() - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
isSslIsSecure() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
isStale() - Method in class org.eclipse.jetty.client.HttpDestination
 
isStart() - Method in class org.eclipse.jetty.http.HttpParser
 
isStarted() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isStarted() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isStarting() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isStarting() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isStartWithUnavailable() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
isState(HttpGenerator.State) - Method in class org.eclipse.jetty.http.HttpGenerator
 
isState(HttpParser.State) - Method in class org.eclipse.jetty.http.HttpParser
 
isState(MultiPartParser.State) - Method in class org.eclipse.jetty.server.MultiPartParser
 
isStatic() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.Entry
 
isStatic() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.StaticEntry
 
isStopAtShutdown() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
isStopCommand() - Method in class org.eclipse.jetty.start.StartArgs
 
isStopped() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isStopped() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isStopping() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
isStopping() - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
isStreamFinished() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
isStreaming() - Method in class org.eclipse.jetty.server.Response
 
isStrictEventOrdering() - Method in class org.eclipse.jetty.client.HttpClient
 
isStsIncludeSubDomains() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSucceeded() - Method in class org.eclipse.jetty.client.api.Result
 
isSucceeded() - Method in class org.eclipse.jetty.util.IteratingCallback
 
isSuccess() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
Simple test against an code to determine if it falls into the Success message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
isSuccess() - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
isSuccess() - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
isSuccess(int) - Static method in class org.eclipse.jetty.http.HttpStatus
Simple test against an code to determine if it falls into the Success message category as defined in the RFC 1945 - HTTP/1.0, and RFC 7231 - HTTP/1.1.
ISSUER - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
isSupportedProtocol(String) - Static method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
isSuspended() - Method in class org.eclipse.jetty.server.HttpChannelState
 
isSyncFlush() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Is the Deflater running Deflater.SYNC_FLUSH or not.
isSystemClass(Class<?>) - Method in interface org.eclipse.jetty.util.ClassVisibilityChecker
Is the class a System Class.
isSystemClass(Class<?>) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
isSystemClass(Class<?>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isSystemResource(String, URL) - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
 
isSystemResource(String, URL) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isTCPNoDelay() - Method in class org.eclipse.jetty.client.HttpClient
Deprecated.
isTCPNoDelay() - Method in class org.eclipse.jetty.io.ClientConnector
 
isTerminated() - Method in class org.eclipse.jetty.http.HttpParser
 
isTerminating() - Method in class org.eclipse.jetty.rewrite.handler.Rule
Returns the terminating flag value.
isTestingModeEnabled() - Method in class org.eclipse.jetty.start.StartArgs
 
isTheEmptyBuffer(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
isThrowUnavailableOnStartupException() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
isTraceEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isTraceEnabled() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isTraceEnabled(Marker) - Method in class org.eclipse.jetty.logging.JettyLogger
 
isTransitive() - Method in class org.eclipse.jetty.start.Module
 
isTransmittable(int) - Static method in class org.eclipse.jetty.websocket.api.StatusCode
Test if provided status code can be sent/received on a WebSocket close.
isTransmittableStatusCode(int) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
Test if provided status code can be sent/received on a WebSocket close.
IStream - Interface in org.eclipse.jetty.http2
The SPI interface for implementing an HTTP/2 stream.
IStream.FrameList - Class in org.eclipse.jetty.http2
An ordered list of frames belonging to the same stream.
isTrue(Object) - Static method in class org.eclipse.jetty.util.TypeUtil
 
isTrustAll() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isTunnel(String, int) - Static method in class org.eclipse.jetty.http.MetaData
Returns whether the given HTTP request method and HTTP response status code identify a successful HTTP CONNECT tunnel.
isTunnellingSupported() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
isTunnellingSupported() - Method in class org.eclipse.jetty.server.HttpChannel
 
isTunnellingSupported() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
isType(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
isType(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
isTypeCompatible(Class<?>, Class<?>, boolean) - Static method in class org.eclipse.jetty.util.IntrospectionUtil
 
isUnmanaged(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
isUnwrapServletException() - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
isUpdateIni() - Method in class org.eclipse.jetty.start.StartArgs
 
isUseALPN() - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
isUseALPN() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
isUseCacheForOtherClassLoaders() - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
isUseCipherSuitesOrder() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isUseDirectByteBuffers() - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
isUseDirectByteBuffers() - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
isUseDirectByteBuffers() - Method in class org.eclipse.jetty.http2.generator.FrameGenerator
 
isUseDirectByteBuffers() - Method in class org.eclipse.jetty.http2.generator.HeaderGenerator
 
isUseDirectByteBuffers() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
isUseFileMappedBuffer() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.client.HttpClient
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpChannel
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnection
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
isUseMultiThreading(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Check if we should use multiple threads to scan for annotations or not
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.client.HttpClient
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.http3.HTTP3Configuration
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpChannel
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnection
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
isUseRealPaths() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
isUserInRole(String) - Method in class org.eclipse.jetty.server.Request
 
isUserInRole(String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
isUserInRole(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
isUserInRole(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
isUserInRole(String) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
isUserInRole(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
isUserInRole(String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
isUserInRole(String, UserIdentity.Scope) - Method in class org.eclipse.jetty.security.DefaultUserIdentity
 
isUserInRole(String, UserIdentity.Scope) - Method in class org.eclipse.jetty.security.openid.OpenIdUserIdentity
 
isUserInRole(String, UserIdentity.Scope) - Method in class org.eclipse.jetty.security.SpnegoUserIdentity
 
isUserInRole(String, UserIdentity.Scope) - Method in interface org.eclipse.jetty.server.UserIdentity
Check if the user is in a role.
isUserInRole(UserIdentity.Scope, String) - Method in class org.eclipse.jetty.security.AbstractUserAuthentication
 
isUserInRole(UserIdentity.Scope, String) - Method in interface org.eclipse.jetty.server.Authentication.User
 
isUseStandardBindings() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
isUseTicketCache() - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
isUseVirtualThreads() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
isUseVirtualThreads() - Method in interface org.eclipse.jetty.util.VirtualThreads.Configurable
Deprecated, for removal: This API element is subject to removal in a future version.
isUseVirtualThreads(Executor) - Static method in class org.eclipse.jetty.util.VirtualThreads
Tests whether the given executor implements VirtualThreads.Configurable and it has been configured to use virtual threads.
isUsingCookies() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
isUsingSecurityManager() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isUsingURLs() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
isUTF8(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
isUtf8SequenceComplete() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
isValid() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedPrecompressedHttpContent
 
isValid() - Method in class org.eclipse.jetty.server.session.Session
 
isValid(HttpSession) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
isValidateCerts() - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
isValidateCerts() - Method in class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
isValidateCerts() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isValidateEncoding() - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
isValidatePeerCerts() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
isValidateXml() - Method in class org.eclipse.jetty.webapp.MetaData
 
isValidating() - Method in class org.eclipse.jetty.xml.XmlParser
 
isValidChar(int) - Method in class org.eclipse.jetty.rewrite.handler.ValidUrlRule
 
isValidClassFileName(String) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Check that the given path represents a valid class file name.
isValidClassFilePath(String) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Check that the given path does not contain hidden directories
isValidDirectory(Path) - Static method in class org.eclipse.jetty.start.FS
 
isValidHostName(String) - Method in class org.eclipse.jetty.util.HostPort
 
isValidHostRegisteredName(String) - Static method in class org.eclipse.jetty.util.URIUtil
True if token is a RFC3986 reg-name (Registered Name)
isValidIpAddress(String) - Method in class org.eclipse.jetty.util.HostPort
 
isVersion() - Method in class org.eclipse.jetty.start.StartArgs
 
isVersioned() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
isVersionExplicit() - Method in class org.eclipse.jetty.client.HttpRequest
 
isVirtualThread() - Static method in class org.eclipse.jetty.util.VirtualThreads
 
isWarnEnabled() - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
isWarnEnabled() - Method in class org.eclipse.jetty.logging.JettyLogger
 
isWarnEnabled(Marker) - Method in class org.eclipse.jetty.logging.JettyLogger
 
isWebArchive(File) - Static method in class org.eclipse.jetty.deploy.util.FileID
Is the path a Web Archive?
isWebArchiveFile(File) - Static method in class org.eclipse.jetty.deploy.util.FileID
Is the path a Web Archive File (not directory)
isWriteFilesWithFilenames() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
 
isWriteFilesWithFilenames() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
isWriting() - Method in class org.eclipse.jetty.server.Response
 
isWritingOrStreaming() - Method in class org.eclipse.jetty.server.Response
 
isWritten() - Method in class org.eclipse.jetty.http.HttpGenerator
 
isWritten() - Method in class org.eclipse.jetty.server.HttpOutput
 
isXml(String) - Static method in class org.eclipse.jetty.start.FS
 
isXmlFile(File) - Static method in class org.eclipse.jetty.deploy.util.FileID
 
iterate() - Method in class org.eclipse.jetty.util.IteratingCallback
This method must be invoked by applications to start the processing of asynchronous sub-tasks.
IteratingCallback - Class in org.eclipse.jetty.util
This specialized callback implements a pattern that allows a large asynchronous task to be broken into smaller asynchronous sub-tasks using iteration rather than recursion.
IteratingCallback() - Constructor for class org.eclipse.jetty.util.IteratingCallback
 
IteratingCallback(boolean) - Constructor for class org.eclipse.jetty.util.IteratingCallback
 
IteratingCallback.Action - Enum in org.eclipse.jetty.util
The indication of the overall progress of the iteration that implementations of IteratingCallback.process() must return.
IteratingNestedCallback - Class in org.eclipse.jetty.util
Iterating Nested Callback.
IteratingNestedCallback(Callback) - Constructor for class org.eclipse.jetty.util.IteratingNestedCallback
 
IterativeDescriptorProcessor - Class in org.eclipse.jetty.webapp
IterativeDescriptorProcessor
IterativeDescriptorProcessor() - Constructor for class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
iterator() - Method in class org.eclipse.jetty.client.util.ByteBufferContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.BytesContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
iterator() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
iterator() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
iterator() - Method in class org.eclipse.jetty.http.MetaData
 
iterator() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
iterator() - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
iterator() - Method in class org.eclipse.jetty.http.QuotedCSV
 
iterator() - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
iterator() - Method in class org.eclipse.jetty.io.CyclicTimeouts
 
iterator() - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
iterator() - Method in class org.eclipse.jetty.server.handler.InetAccessSet
 
iterator() - Method in class org.eclipse.jetty.start.Classpath
 
iterator() - Method in class org.eclipse.jetty.start.config.ConfigSources
 
iterator() - Method in class org.eclipse.jetty.start.Modules
 
iterator() - Method in class org.eclipse.jetty.start.Props
 
iterator() - Method in class org.eclipse.jetty.start.RawArgs
 
iterator() - Method in class org.eclipse.jetty.start.TextFile
 
iterator() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
iterator() - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
iterator() - Method in class org.eclipse.jetty.util.Fields
 
iterator() - Method in class org.eclipse.jetty.util.InetAddressSet
 
iterator() - Method in class org.eclipse.jetty.util.RegexSet
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
iterator() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
iterator() - Method in class org.eclipse.jetty.webapp.Configurations
 
iterator() - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
iterator() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
iterator(Object) - Static method in class org.eclipse.jetty.util.LazyList
 
iterator(String) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Iterator over named child nodes.

J

J_METHOD - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
J_POST - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
J_SECURITY_CHECK - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
J_URI - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
JaasConfiguration - Class in org.eclipse.jetty.webapp
JAAS Configuration
JaasConfiguration() - Constructor for class org.eclipse.jetty.webapp.JaasConfiguration
 
JAASLoginService - Class in org.eclipse.jetty.jaas
JAASLoginService Implementation of jetty's LoginService that works with JAAS for authorization and authentication.
JAASLoginService() - Constructor for class org.eclipse.jetty.jaas.JAASLoginService
 
JAASLoginService(String) - Constructor for class org.eclipse.jetty.jaas.JAASLoginService
 
JAASPrincipal - Class in org.eclipse.jetty.jaas
JAASPrincipal
JAASPrincipal(String) - Constructor for class org.eclipse.jetty.jaas.JAASPrincipal
 
JAASRole - Class in org.eclipse.jetty.jaas
 
JAASRole(String) - Constructor for class org.eclipse.jetty.jaas.JAASRole
 
JAASUser(UserPrincipal) - Constructor for class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
JAASUserPrincipal - Class in org.eclipse.jetty.jaas
JAASUserPrincipal
JAASUserPrincipal(String, Subject, LoginContext) - Constructor for class org.eclipse.jetty.jaas.JAASUserPrincipal
 
JAKARTA_API - Enum constant in enum org.eclipse.jetty.servlet.Source.Origin
 
JAKARTA_SERVLET_REQUEST_CIPHER_SUITE - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
JAKARTA_SERVLET_REQUEST_KEY_SIZE - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
JAKARTA_SERVLET_REQUEST_SSL_SESSION_ID - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
JAKARTA_SERVLET_REQUEST_X_509_CERTIFICATE - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
JAKARTA_WEBSOCKET_CONTAINER_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
JakartaClientUpgradeRequest - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
JakartaClientUpgradeRequest(JakartaWebSocketClientContainer, WebSocketCoreClient, URI, Object) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaClientUpgradeRequest
 
JakartaServerUpgradeRequest - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JakartaServerUpgradeRequest(ServerUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaServerUpgradeRequest
 
JakartaWebSocketAsyncRemote - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketAsyncRemote(JakartaWebSocketSession, CoreSession) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
JakartaWebSocketBasicRemote - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketBasicRemote(JakartaWebSocketSession, CoreSession) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
JakartaWebSocketClientContainer - Class in org.eclipse.jetty.websocket.jakarta.client.internal
Container for Client use of the jakarta.websocket API.
JakartaWebSocketClientContainer() - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
JakartaWebSocketClientContainer(HttpClient) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
Create a WebSocketContainer using the supplied HttpClient for environments where you want to configure SSL/TLS or Proxy behaviors.
JakartaWebSocketClientContainer(WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
JakartaWebSocketClientContainer(WebSocketComponents, Function<WebSocketComponents, WebSocketCoreClient>) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
JakartaWebSocketClientContainerProvider - Class in org.eclipse.jetty.websocket.jakarta.client
Client ContainerProvider implementation.
JakartaWebSocketClientContainerProvider() - Constructor for class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketClientContainerProvider
 
JakartaWebSocketClientFrameHandlerFactory - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
JakartaWebSocketClientFrameHandlerFactory(JakartaWebSocketContainer) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientFrameHandlerFactory
 
JakartaWebSocketClientFrameHandlerFactory(JakartaWebSocketContainer, InvokerUtils.ParamIdentifier) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientFrameHandlerFactory
 
JakartaWebSocketConfiguration - Class in org.eclipse.jetty.websocket.jakarta.server.config
Websocket Configuration
JakartaWebSocketConfiguration() - Constructor for class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketConfiguration
 
JakartaWebSocketContainer - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketContainer(WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
JakartaWebSocketCreator - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JakartaWebSocketCreator(JakartaWebSocketContainer, ServerEndpointConfig, WebSocketExtensionRegistry) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
JakartaWebSocketExtension - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketExtension(String) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
A potential (unconfigured) extension
JakartaWebSocketExtension(ExtensionConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
A configured extension
JakartaWebSocketExtensionConfig - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketExtensionConfig(Extension) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtensionConfig
 
JakartaWebSocketFrameHandler - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketFrameHandler(JakartaWebSocketContainer, UpgradeRequest, Object, MethodHandle, MethodHandle, MethodHandle, JakartaWebSocketMessageMetadata, JakartaWebSocketMessageMetadata, MethodHandle, EndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
JakartaWebSocketFrameHandlerFactory - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketFrameHandlerFactory(JakartaWebSocketContainer, InvokerUtils.ParamIdentifier) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
JakartaWebSocketFrameHandlerMetadata - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketFrameHandlerMetadata(EndpointConfig, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
JakartaWebSocketMessageMetadata - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketMessageMetadata() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
JakartaWebSocketPongMessage - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketPongMessage(ByteBuffer) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketPongMessage
 
JakartaWebSocketRemoteEndpoint - Class in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketRemoteEndpoint(JakartaWebSocketSession, CoreSession) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
JakartaWebSocketServerContainer - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JakartaWebSocketServerContainer(WebSocketMappings, WebSocketComponents, Function<WebSocketComponents, WebSocketCoreClient>) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
JakartaWebSocketServerFrameHandlerFactory - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JakartaWebSocketServerFrameHandlerFactory(JakartaWebSocketContainer) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerFrameHandlerFactory
 
JakartaWebSocketServletContainerInitializer - Class in org.eclipse.jetty.websocket.jakarta.server.config
 
JakartaWebSocketServletContainerInitializer() - Constructor for class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
 
JakartaWebSocketServletContainerInitializer(JakartaWebSocketServletContainerInitializer.Configurator) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
 
JakartaWebSocketServletContainerInitializer.Configurator - Interface in org.eclipse.jetty.websocket.jakarta.server.config
 
JakartaWebSocketSession - Class in org.eclipse.jetty.websocket.jakarta.common
Client Session for the JSR.
JakartaWebSocketSession(JakartaWebSocketContainer, CoreSession, JakartaWebSocketFrameHandler, EndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
JakartaWebSocketSessionListener - Interface in org.eclipse.jetty.websocket.jakarta.common
 
JakartaWebSocketShutdownContainer - Class in org.eclipse.jetty.websocket.jakarta.client
This manages the LifeCycle of WebSocketContainer instances that are created with ContainerProvider, if this code is being run from another ServletContainer, or if run inside a Jetty Server with the WebSocket client classes provided by the webapp.
JakartaWebSocketShutdownContainer() - Constructor for class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketShutdownContainer
 
JAR_WITH_SUCH_CLASS_MUST_BE_EXCLUDED - Static variable in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
when a logging framework is setup in the osgi classloaders, it can access this and register the classes that must not be found in the jar.
JarFileResource - Class in org.eclipse.jetty.util.resource
 
JarFileResource(URL, boolean) - Constructor for class org.eclipse.jetty.util.resource.JarFileResource
 
JarResource - Class in org.eclipse.jetty.util.resource
 
JarResource(URL) - Constructor for class org.eclipse.jetty.util.resource.JarResource
 
JarResource(URL, boolean) - Constructor for class org.eclipse.jetty.util.resource.JarResource
 
JarVersion - Class in org.eclipse.jetty.start
Attempt to determine the version of the Jar File based on common version locations.
JarVersion() - Constructor for class org.eclipse.jetty.start.JarVersion
 
JaspiAuthConfigProvider - Class in org.eclipse.jetty.security.jaspi.provider
A Jetty implementation of the AuthConfigProvider to allow registration of a ServerAuthModule directly without having to write a custom AuthConfigProvider.
JaspiAuthConfigProvider(ServerAuthModule) - Constructor for class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
JaspiAuthConfigProvider(ServerAuthModule, Map) - Constructor for class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
JaspiAuthConfigProvider(String) - Constructor for class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
JaspiAuthConfigProvider(String, Map) - Constructor for class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
JaspiAuthConfigProvider(Map, AuthConfigFactory) - Constructor for class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
Constructor with signature and implementation that's required by API.
JaspiAuthenticator - Class in org.eclipse.jetty.security.jaspi
Implementation of Jetty LoginAuthenticator that is a bridge from Jakarta Authentication to Jetty Security.
JaspiAuthenticator(ServerAuthConfig, Map, ServletCallbackHandler, Subject, boolean, IdentityService) - Constructor for class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
Deprecated.
JaspiAuthenticator(Subject, String, boolean) - Constructor for class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
JaspiAuthenticatorFactory - Class in org.eclipse.jetty.security.jaspi
Jakarta Authentication (JASPI) Authenticator Factory.
JaspiAuthenticatorFactory() - Constructor for class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
JaspiConfiguration - Class in org.eclipse.jetty.webapp
JASPI Configuration
JaspiConfiguration() - Constructor for class org.eclipse.jetty.webapp.JaspiConfiguration
 
JaspiMessageInfo - Class in org.eclipse.jetty.security.jaspi
Almost an implementation of jaspi MessageInfo.
JaspiMessageInfo(ServletRequest, ServletResponse, boolean) - Constructor for class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
JAVA_TARGET_PLATFORM - Static variable in class org.eclipse.jetty.util.JavaVersion
Context attribute that can be set to target a different version of the jvm than the current runtime.
javaNameParser - Class in org.eclipse.jetty.jndi.java
javaNameParser
javaNameParser() - Constructor for class org.eclipse.jetty.jndi.java.javaNameParser
 
javaRootURLContext - Class in org.eclipse.jetty.jndi.java
javaRootURLContext
javaRootURLContext(Hashtable) - Constructor for class org.eclipse.jetty.jndi.java.javaRootURLContext
Creates a new javaRootURLContext instance.
javaURLContextFactory - Class in org.eclipse.jetty.jndi.java
javaURLContextFactory
javaURLContextFactory() - Constructor for class org.eclipse.jetty.jndi.java.javaURLContextFactory
 
JavaVersion - Class in org.eclipse.jetty.util
Java Version Utility class.
JAVAX_API - Static variable in class org.eclipse.jetty.servlet.Source
 
JDBCLoginModule - Class in org.eclipse.jetty.jaas.spi
JAAS LoginModule to retrieve user information from a database and authenticate the user.
JDBCLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.JDBCLoginModule
 
JDBCLoginService - Class in org.eclipse.jetty.security
JDBC as a source of user authentication and authorization information.
JDBCLoginService() - Constructor for class org.eclipse.jetty.security.JDBCLoginService
 
JDBCLoginService(String) - Constructor for class org.eclipse.jetty.security.JDBCLoginService
 
JDBCLoginService(String, String) - Constructor for class org.eclipse.jetty.security.JDBCLoginService
 
JDBCLoginService(String, IdentityService, String) - Constructor for class org.eclipse.jetty.security.JDBCLoginService
 
JDBCLoginService.JDBCUserPrincipal - Class in org.eclipse.jetty.security
JDBCUserPrincipal A UserPrincipal with extra jdbc key info.
JDBCSessionDataStore - Class in org.eclipse.jetty.server.session
JDBCSessionDataStore Session data stored in database
JDBCSessionDataStore() - Constructor for class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
JDBCSessionDataStore.SessionTableSchema - Class in org.eclipse.jetty.server.session
SessionTableSchema
JDBCSessionDataStoreFactory - Class in org.eclipse.jetty.server.session
JDBCSessionDataStoreFactory
JDBCSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.server.session.JDBCSessionDataStoreFactory
 
JDBCUser(UserPrincipal) - Constructor for class org.eclipse.jetty.jaas.spi.AbstractDatabaseLoginModule.JDBCUser
 
JDBCUserPrincipal(String, Credential, int) - Constructor for class org.eclipse.jetty.security.JDBCLoginService.JDBCUserPrincipal
 
JDK9ClientALPNProcessor - Class in org.eclipse.jetty.alpn.java.client
 
JDK9ClientALPNProcessor() - Constructor for class org.eclipse.jetty.alpn.java.client.JDK9ClientALPNProcessor
 
JDK9ServerALPNProcessor - Class in org.eclipse.jetty.alpn.java.server
 
JDK9ServerALPNProcessor() - Constructor for class org.eclipse.jetty.alpn.java.server.JDK9ServerALPNProcessor
 
Jetty - Class in org.eclipse.jetty.util
 
JETTY_BASE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
 
JETTY_BASE - Static variable in class org.eclipse.jetty.start.BaseHome
 
JETTY_BUNDLE_INSTALL_LOCATION_OVERRIDE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
path to the base folder that overrides the computed bundle installation location if not null useful to install webapps or jetty context files that are in fact not embedded in a bundle
JETTY_BUNDLE_ROOT - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
installation path of webapp bundle
JETTY_CONTEXT_FILE_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
List of relative pathes within the bundle to the jetty context files.
JETTY_DEFAULT_WEB_XML_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
defaultweb.xml file path
JETTY_ETC_FILES - Static variable in class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
contains a comma separated list of paths to the etc/jetty-*.xml files
JETTY_EXTRA_CLASSPATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Extra classpath
JETTY_HOME - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
Usual system property used as the hostname for a typical jetty configuration.
JETTY_HOME - Static variable in class org.eclipse.jetty.start.BaseHome
 
JETTY_HOME_BUNDLE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
System property to point to a bundle that embeds a jetty configuration and that jetty configuration should be the default jetty server.
JETTY_HOST - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
Usual system property used as the hostname for a typical jetty configuration.
JETTY_OSGI_BUNDLE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Name of the servlet context attribute that points to the bundle object.
JETTY_PORT - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
Usual system property used as the port for http for a typical jetty configuration.
JETTY_PORT_SSL - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
Usual system property used as the port for https for a typical jetty configuration.
JETTY_WAR_FRAGMENT_RESOURCE_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
path within a fragment hosted by a web-bundle to a folder that contains basic resources.
JETTY_WAR_PREPEND_FRAGMENT_RESOURCE_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
path within a fragment hosted by a web-bundle to a folder that contains basic resources.
JETTY_WAR_RESOURCE_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
path within the bundle to the folder that contains the basic resources.
JETTY_WEB_XML - Static variable in class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
 
JETTY_WEB_XML_PATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
web.xml file path
JETTY_WEBSOCKET_CONTAINER_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
JettyAppender - Interface in org.eclipse.jetty.logging
 
JettyBaseConfigSource - Class in org.eclipse.jetty.start.config
${jetty.base} specific ConfigSource
JettyBaseConfigSource(Path) - Constructor for class org.eclipse.jetty.start.config.JettyBaseConfigSource
 
JettyBootstrapActivator - Class in org.eclipse.jetty.osgi.boot
JettyBootstrapActivator
JettyBootstrapActivator() - Constructor for class org.eclipse.jetty.osgi.boot.JettyBootstrapActivator
 
JettyClientUpgradeRequest - Class in org.eclipse.jetty.websocket.client.impl
 
JettyClientUpgradeRequest(WebSocketCoreClient, ClientUpgradeRequest, URI, JettyWebSocketFrameHandlerFactory, Object) - Constructor for class org.eclipse.jetty.websocket.client.impl.JettyClientUpgradeRequest
 
JettyExchange - Interface in org.eclipse.jetty.http.spi
 
JettyExtensionConfig - Class in org.eclipse.jetty.websocket.common
Represents an Extension Configuration, as seen during the connection Handshake process.
JettyExtensionConfig(String) - Constructor for class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
JettyExtensionConfig(String, Map<String, String>) - Constructor for class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
JettyExtensionConfig(JettyExtensionConfig) - Constructor for class org.eclipse.jetty.websocket.common.JettyExtensionConfig
Copy constructor
JettyExtensionConfig(ExtensionConfig) - Constructor for class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
JettyHomeConfigSource - Class in org.eclipse.jetty.start.config
${jetty.home} specific ConfigSource
JettyHomeConfigSource(Path) - Constructor for class org.eclipse.jetty.start.config.JettyHomeConfigSource
 
JettyHttpContext - Class in org.eclipse.jetty.http.spi
Jetty implementation of HttpContext
JettyHttpContext(HttpServer, String, HttpHandler) - Constructor for class org.eclipse.jetty.http.spi.JettyHttpContext
 
JettyHttpExchange - Class in org.eclipse.jetty.http.spi
 
JettyHttpExchange(HttpContext, HttpServletRequest, HttpServletResponse) - Constructor for class org.eclipse.jetty.http.spi.JettyHttpExchange
 
JettyHttpExchangeDelegate - Class in org.eclipse.jetty.http.spi
Jetty implementation of HttpExchange
JettyHttpServer - Class in org.eclipse.jetty.http.spi
Jetty implementation of HttpServer.
JettyHttpServer(Server, boolean) - Constructor for class org.eclipse.jetty.http.spi.JettyHttpServer
 
JettyHttpServer(Server, boolean, HttpConfiguration) - Constructor for class org.eclipse.jetty.http.spi.JettyHttpServer
 
JettyHttpServerProvider - Class in org.eclipse.jetty.http.spi
Jetty implementation of Java HTTP Server SPI
JettyHttpServerProvider() - Constructor for class org.eclipse.jetty.http.spi.JettyHttpServerProvider
 
JettyHttpsExchange - Class in org.eclipse.jetty.http.spi
 
JettyHttpsExchange(HttpContext, HttpServletRequest, HttpServletResponse) - Constructor for class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
JettyJasperInitializer - Class in org.eclipse.jetty.apache.jsp
JettyJasperInitializer
JettyJasperInitializer() - Constructor for class org.eclipse.jetty.apache.jsp.JettyJasperInitializer
 
JettyJspServlet - Class in org.eclipse.jetty.jsp
JettyJspServlet Wrapper for the jsp servlet that handles receiving requests mapped from jsp-property-groups.
JettyJspServlet() - Constructor for class org.eclipse.jetty.jsp.JettyJspServlet
 
JettyLevel - Enum in org.eclipse.jetty.logging
 
JettyLogger - Class in org.eclipse.jetty.logging
 
JettyLogger(JettyLoggerFactory, String, JettyAppender) - Constructor for class org.eclipse.jetty.logging.JettyLogger
 
JettyLogger(JettyLoggerFactory, String, JettyAppender, JettyLevel, boolean) - Constructor for class org.eclipse.jetty.logging.JettyLogger
 
JettyLoggerConfiguration - Class in org.eclipse.jetty.logging
JettyLogger specific configuration: <name>.LEVEL=(String:LevelName) <name>.STACKS=(boolean)
JettyLoggerConfiguration() - Constructor for class org.eclipse.jetty.logging.JettyLoggerConfiguration
Default JettyLogger configuration (empty)
JettyLoggerConfiguration(Properties) - Constructor for class org.eclipse.jetty.logging.JettyLoggerConfiguration
JettyLogger configuration from provided Properties
JettyLoggerFactory - Class in org.eclipse.jetty.logging
 
JettyLoggerFactory(JettyLoggerConfiguration) - Constructor for class org.eclipse.jetty.logging.JettyLoggerFactory
 
JettyLoggingServiceProvider - Class in org.eclipse.jetty.logging
 
JettyLoggingServiceProvider() - Constructor for class org.eclipse.jetty.logging.JettyLoggingServiceProvider
 
JettyRunTask - Class in org.eclipse.jetty.ant
Ant task for running a Jetty server.
JettyRunTask() - Constructor for class org.eclipse.jetty.ant.JettyRunTask
 
JettyServerFrameHandlerFactory - Class in org.eclipse.jetty.websocket.server.internal
 
JettyServerFrameHandlerFactory(JettyWebSocketServerContainer, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.server.internal.JettyServerFrameHandlerFactory
 
JettyServerServiceTracker - Class in org.eclipse.jetty.osgi.boot.internal.serverfactory
JettyServerServiceTracker Tracks instances of Jetty Servers, and configures them so that they can deploy webapps or ContextHandlers discovered from the OSGi environment.
JettyServerServiceTracker() - Constructor for class org.eclipse.jetty.osgi.boot.internal.serverfactory.JettyServerServiceTracker
 
JettyServerUpgradeRequest - Interface in org.eclipse.jetty.websocket.server
 
JettyServerUpgradeResponse - Interface in org.eclipse.jetty.websocket.server
 
JettyStopTask - Class in org.eclipse.jetty.ant
JettyStopTask
JettyStopTask() - Constructor for class org.eclipse.jetty.ant.JettyStopTask
 
JettyTldPreScanned - Class in org.eclipse.jetty.apache.jsp
JettyTldPreScanned Change to TldPreScanned to not require that the tlds have been pre-scanned from a jar file, but rather may be files in the file system.
JettyTldPreScanned(ServletContext, boolean, boolean, boolean, Collection<URL>) - Constructor for class org.eclipse.jetty.apache.jsp.JettyTldPreScanned
 
JettyUpgradeListener - Interface in org.eclipse.jetty.websocket.client
 
JettyWebSocketClientConfiguration - Class in org.eclipse.jetty.websocket.client.config
Websocket Configuration
JettyWebSocketClientConfiguration() - Constructor for class org.eclipse.jetty.websocket.client.config.JettyWebSocketClientConfiguration
 
JettyWebSocketConfiguration - Class in org.eclipse.jetty.websocket.server.config
Websocket Configuration
JettyWebSocketConfiguration() - Constructor for class org.eclipse.jetty.websocket.server.config.JettyWebSocketConfiguration
 
JettyWebSocketCreator - Interface in org.eclipse.jetty.websocket.server
Abstract WebSocket creator interface.
JettyWebSocketFrame - Class in org.eclipse.jetty.websocket.common
 
JettyWebSocketFrame(Frame) - Constructor for class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
JettyWebSocketFrameHandler - Class in org.eclipse.jetty.websocket.common
 
JettyWebSocketFrameHandler(WebSocketContainer, Object, MethodHandle, MethodHandle, MethodHandle, MethodHandle, MethodHandle, Class<? extends MessageSink>, Class<? extends MessageSink>, MethodHandle, MethodHandle, MethodHandle, BatchMode, Configuration.Customizer) - Constructor for class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
JettyWebSocketFrameHandlerFactory - Class in org.eclipse.jetty.websocket.common
Factory to create JettyWebSocketFrameHandler instances suitable for use with jetty-native websocket API.
JettyWebSocketFrameHandlerFactory(WebSocketContainer, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
JettyWebSocketFrameHandlerMetadata - Class in org.eclipse.jetty.websocket.common
 
JettyWebSocketFrameHandlerMetadata() - Constructor for class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
JettyWebSocketRemoteEndpoint - Class in org.eclipse.jetty.websocket.common
 
JettyWebSocketRemoteEndpoint(CoreSession, BatchMode) - Constructor for class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
JettyWebSocketServerContainer - Class in org.eclipse.jetty.websocket.server
 
JettyWebSocketServlet - Class in org.eclipse.jetty.websocket.server
Abstract Servlet used to bridge the Servlet API to the WebSocket API.
JettyWebSocketServlet() - Constructor for class org.eclipse.jetty.websocket.server.JettyWebSocketServlet
 
JettyWebSocketServletContainerInitializer - Class in org.eclipse.jetty.websocket.server.config
ServletContext configuration for Jetty Native WebSockets API.
JettyWebSocketServletContainerInitializer() - Constructor for class org.eclipse.jetty.websocket.server.config.JettyWebSocketServletContainerInitializer
 
JettyWebSocketServletContainerInitializer(JettyWebSocketServletContainerInitializer.Configurator) - Constructor for class org.eclipse.jetty.websocket.server.config.JettyWebSocketServletContainerInitializer
 
JettyWebSocketServletContainerInitializer.Configurator - Interface in org.eclipse.jetty.websocket.server.config
 
JettyWebSocketServletFactory - Interface in org.eclipse.jetty.websocket.server
 
JettyWebXmlConfiguration - Class in org.eclipse.jetty.webapp
JettyWebConfiguration.
JettyWebXmlConfiguration() - Constructor for class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
 
JmxConfiguration - Class in org.eclipse.jetty.webapp
JMX Configuration
JmxConfiguration() - Constructor for class org.eclipse.jetty.webapp.JmxConfiguration
 
jmxContext() - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
JndiConfiguration - Class in org.eclipse.jetty.webapp
JNDI Configuration
JndiConfiguration() - Constructor for class org.eclipse.jetty.webapp.JndiConfiguration
 
join() - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
join() - Method in class org.eclipse.jetty.server.AbstractConnector
 
join() - Method in class org.eclipse.jetty.server.Server
 
join() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
join() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Blocks until the thread pool is LifeCycle stopped.
join() - Method in interface org.eclipse.jetty.util.thread.ThreadPool
Blocks until the thread pool is stopped.
join(long) - Method in class org.eclipse.jetty.server.AbstractConnector
 
join(Object[], int, int, String) - Static method in class org.eclipse.jetty.start.Utils
 
join(Object[], String) - Static method in class org.eclipse.jetty.start.Utils
 
join(String...) - Static method in class org.eclipse.jetty.http.QuotedCSV
Join a list into Quoted CSV string
join(StringBuilder, List<String>) - Static method in class org.eclipse.jetty.http.QuotedCSV
Join a list into Quoted CSV StringBuilder
join(Collection<?>, String) - Static method in class org.eclipse.jetty.start.Utils
 
join(List<String>) - Static method in class org.eclipse.jetty.http.QuotedCSV
Join a list into Quoted CSV string
join(Generator.Result) - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
joinValues(List<String>) - Static method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
JSON - Class in org.eclipse.jetty.util.ajax
JSON parser and generator.
JSON() - Constructor for class org.eclipse.jetty.util.ajax.JSON
 
JSON.Convertible - Interface in org.eclipse.jetty.util.ajax
JSON Convertible object.
JSON.Convertor - Interface in org.eclipse.jetty.util.ajax
JSON Convertor.
JSON.Generator - Interface in org.eclipse.jetty.util.ajax
JSON Generator.
JSON.Literal - Class in org.eclipse.jetty.util.ajax
A Literal JSON generator.
JSON.Output - Interface in org.eclipse.jetty.util.ajax
JSON Output class for use by JSON.Convertible.
JSON.ReaderSource - Class in org.eclipse.jetty.util.ajax
A Reader source for a JSON string.
JSON.Source - Interface in org.eclipse.jetty.util.ajax
A generic source for a JSON representation.
JSON.StringSource - Class in org.eclipse.jetty.util.ajax
An in-memory source for a JSON string.
JSONCollectionConvertor - Class in org.eclipse.jetty.util.ajax
 
JSONCollectionConvertor() - Constructor for class org.eclipse.jetty.util.ajax.JSONCollectionConvertor
 
JSONDateConvertor - Class in org.eclipse.jetty.util.ajax
Convert a Date to JSON.
JSONDateConvertor() - Constructor for class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
JSONDateConvertor(boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
JSONDateConvertor(String, TimeZone, boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
JSONDateConvertor(String, TimeZone, boolean, Locale) - Constructor for class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
JSONEnumConvertor - Class in org.eclipse.jetty.util.ajax
Convert an Enum to JSON.
JSONEnumConvertor() - Constructor for class org.eclipse.jetty.util.ajax.JSONEnumConvertor
 
JSONEnumConvertor(boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONEnumConvertor
 
JSONObjectConvertor - Class in org.eclipse.jetty.util.ajax
Converts an Object to JSON using reflection on getters methods.
JSONObjectConvertor() - Constructor for class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
JSONObjectConvertor(boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
JSONObjectConvertor(boolean, String[]) - Constructor for class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
JSONPojoConvertor - Class in org.eclipse.jetty.util.ajax
Converts POJOs to JSON and vice versa.
JSONPojoConvertor(Class<?>) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
JSONPojoConvertor(Class<?>, boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
JSONPojoConvertor(Class<?>, String[]) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
JSONPojoConvertor(Class<?>, Set<String>) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
JSONPojoConvertor(Class<?>, Set<String>, boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
JSONPojoConvertor.NumberType - Interface in org.eclipse.jetty.util.ajax
 
JSONPojoConvertor.Setter - Class in org.eclipse.jetty.util.ajax
 
JSONPojoConvertorFactory - Class in org.eclipse.jetty.util.ajax
 
JSONPojoConvertorFactory(JSON) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertorFactory
 
JSONPojoConvertorFactory(JSON, boolean) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertorFactory
 
JSP_GENERATED_PACKAGE_NAME - Static variable in class org.eclipse.jetty.servlet.ServletHolder
 
JspConfig() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
JspConfiguration - Class in org.eclipse.jetty.webapp
JSP Configuration
JspConfiguration() - Constructor for class org.eclipse.jetty.webapp.JspConfiguration
 
JspPropertyGroup() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
JspPropertyGroupServlet - Class in org.eclipse.jetty.servlet
Servlet handling JSP Property Group mappings
JspPropertyGroupServlet(ContextHandler, ServletHandler) - Constructor for class org.eclipse.jetty.servlet.JspPropertyGroupServlet
 
JsrHandshakeRequest - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JsrHandshakeRequest(ServerUpgradeRequest) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeRequest
 
JsrHandshakeResponse - Class in org.eclipse.jetty.websocket.jakarta.server.internal
 
JsrHandshakeResponse(ServerUpgradeResponse) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeResponse
 
JsrUpgradeListener - Class in org.eclipse.jetty.websocket.jakarta.client.internal
 
JsrUpgradeListener(ClientEndpointConfig.Configurator) - Constructor for class org.eclipse.jetty.websocket.jakarta.client.internal.JsrUpgradeListener
 
JuliLog - Class in org.eclipse.jetty.apache.jsp
 
JuliLog() - Constructor for class org.eclipse.jetty.apache.jsp.JuliLog
 
JuliLog(String) - Constructor for class org.eclipse.jetty.apache.jsp.JuliLog
 
JwtDecoder - Class in org.eclipse.jetty.security.openid
Used to decode the ID Token from the base64 encrypted JSON Web Token (JWT).
JwtDecoder() - Constructor for class org.eclipse.jetty.security.openid.JwtDecoder
 

K

KEEP_ALIVE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
KEEP_ALIVE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
key - Variable in class org.eclipse.jetty.start.Props.Prop
 
KEY - Static variable in interface org.eclipse.jetty.util.component.Dumpable
 
KEYPASSWORD_PROPERTY - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory
String name of key password property.
keySet() - Method in interface org.eclipse.jetty.util.Index
Get a Set of the keys contained in this index.
keySet() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
KeyStoreScanner - Class in org.eclipse.jetty.util.ssl
The KeyStoreScanner is used to monitor the KeyStore file used by the SslContextFactory.
KeyStoreScanner(SslContextFactory) - Constructor for class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
KIND - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 

L

LABEL - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
LAST_MODIFIED - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
LASTACCESSED - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
lastEdge() - Method in class org.eclipse.jetty.deploy.graph.Path
 
lastModified() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
lastModified() - Method in class org.eclipse.jetty.util.resource.JarFileResource
Returns the last modified time
lastModified() - Method in class org.eclipse.jetty.util.resource.PathResource
 
lastModified() - Method in class org.eclipse.jetty.util.resource.Resource
Time resource was last modified.
lastModified() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
lastModified() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns the last modified time
lastNode() - Method in class org.eclipse.jetty.deploy.graph.Path
 
LASTNODE - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
LASTSAVED - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
LAX - Enum constant in enum org.eclipse.jetty.http.HttpCookie.SameSite
 
LazyList - Class in org.eclipse.jetty.util
Lazy List creation.
LDAPBindingUser(UserPrincipal, DirContext, String) - Constructor for class org.eclipse.jetty.jaas.spi.LdapLoginModule.LDAPBindingUser
 
LdapLoginModule - Class in org.eclipse.jetty.jaas.spi
A LdapLoginModule for use with JAAS setups
LdapLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.LdapLoginModule
 
LdapLoginModule.LDAPBindingUser - Class in org.eclipse.jetty.jaas.spi
 
LdapLoginModule.LDAPUser - Class in org.eclipse.jetty.jaas.spi
 
LDAPUser(UserPrincipal, Attributes) - Constructor for class org.eclipse.jetty.jaas.spi.LdapLoginModule.LDAPUser
 
LeakDetector<T> - Class in org.eclipse.jetty.util
A facility to detect improper usage of resource pools.
LeakDetector() - Constructor for class org.eclipse.jetty.util.LeakDetector
 
LeakDetector.LeakInfo - Class in org.eclipse.jetty.util
Information about the leak of a resource.
leaked(LeakDetector.LeakInfo) - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
leaked(LeakDetector.LeakInfo) - Method in class org.eclipse.jetty.client.LeakTrackingConnectionPool
 
leaked(LeakDetector.LeakInfo) - Method in class org.eclipse.jetty.util.LeakDetector
Callback method invoked by LeakDetector when it detects that a resource has been leaked.
LeakTrackingByteBufferPool - Class in org.eclipse.jetty.io
 
LeakTrackingByteBufferPool(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
LeakTrackingConnectionPool - Class in org.eclipse.jetty.client
 
LeakTrackingConnectionPool(HttpDestination, int, Callback) - Constructor for class org.eclipse.jetty.client.LeakTrackingConnectionPool
 
Lease(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.ByteBufferPool.Lease
 
leaseFrom(Executor, Object, int) - Static method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
 
leaseTo(Object, int) - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
 
LEGACY - Enum constant in enum org.eclipse.jetty.server.MultiPartFormDataCompliance
Legacy multiPart/form-data parsing which is slow but forgiving.
LEGACY - Static variable in class org.eclipse.jetty.http.HttpCompliance
A legacy HttpCompliance mode that allows all violations except case-insensitive methods.
LEGACY - Static variable in class org.eclipse.jetty.http.UriCompliance
length() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
length() - Method in class org.eclipse.jetty.util.resource.JarFileResource
Return the length of the resource
length() - Method in class org.eclipse.jetty.util.resource.PathResource
 
length() - Method in class org.eclipse.jetty.util.resource.Resource
Length of the resource.
length() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
length() - Method in class org.eclipse.jetty.util.resource.URLResource
Return the length of the resource
length() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
length() - Method in class org.eclipse.jetty.util.Utf8StringBuffer
 
length() - Method in class org.eclipse.jetty.util.Utf8StringBuilder
 
length() - Method in class org.eclipse.jetty.websocket.core.internal.NullAppendable
 
length(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Get remaining from null checked buffer
LENGTH_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
LENGTH_REQUIRED_411 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
LF - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
LF - Enum constant in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
 
LF - Static variable in class org.eclipse.jetty.util.TypeUtil
 
LF_LINE_TERMINATION - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
LibExtClassLoaderHelper - Class in org.eclipse.jetty.osgi.boot.internal.webapp
LibExtClassLoaderHelper
LibExtClassLoaderHelper() - Constructor for class org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper
 
LibExtClassLoaderHelper.IFilesInJettyHomeResourcesProcessor - Interface in org.eclipse.jetty.osgi.boot.internal.webapp
IFilesInJettyHomeResourcesProcessor Interface for callback impls
licenseMap - Variable in class org.eclipse.jetty.start.Licensing
 
Licensing - Class in org.eclipse.jetty.start
Handles basic license presentation and acknowledgement.
Licensing() - Constructor for class org.eclipse.jetty.start.Licensing
 
LifeCycle - Interface in org.eclipse.jetty.util.component
The lifecycle interface for generic components.
LIFECYCLE_CALLBACK_COLLECTION - Static variable in class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
 
LifeCycle.Listener - Interface in org.eclipse.jetty.util.component
Listener.
LifeCycleCallback - Class in org.eclipse.jetty.plus.annotation
LifeCycleCallback Holds information about a class and method that has either been configured in web.xml to have postconstruct or predestroy callbacks, or has the equivalent annotations.
LifeCycleCallback(Class<?>, String) - Constructor for class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
LifeCycleCallback(String, String) - Constructor for class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
LifeCycleCallbackCollection - Class in org.eclipse.jetty.plus.annotation
LifeCycleCallbackCollection This class collects the classes and methods that have been configured in web.xml with postconstruct/predestroy callbacks, or that contain the equivalent annotations.
LifeCycleCallbackCollection() - Constructor for class org.eclipse.jetty.plus.annotation.LifeCycleCallbackCollection
 
lifeCycleFailure(LifeCycle, Throwable) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleFailure(LifeCycle, Throwable) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
lifeCycleFailure(LifeCycle, Throwable) - Method in class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
lifeCycleFailure(LifeCycle, Throwable) - Method in interface org.eclipse.jetty.util.component.LifeCycle.Listener
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.util.component.HaltLifeCycleListener
 
lifeCycleStarted(LifeCycle) - Method in interface org.eclipse.jetty.util.component.LifeCycle.Listener
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.util.component.StopLifeCycle
 
lifeCycleStarting(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStarting(LifeCycle) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
lifeCycleStarting(LifeCycle) - Method in class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
lifeCycleStarting(LifeCycle) - Method in interface org.eclipse.jetty.util.component.LifeCycle.Listener
 
lifeCycleStopped(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStopped(LifeCycle) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
lifeCycleStopped(LifeCycle) - Method in class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
lifeCycleStopped(LifeCycle) - Method in interface org.eclipse.jetty.util.component.LifeCycle.Listener
 
lifeCycleStopping(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStopping(LifeCycle) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle.AbstractLifeCycleListener
Deprecated.
 
lifeCycleStopping(LifeCycle) - Method in class org.eclipse.jetty.util.component.FileNoticeLifeCycleListener
Deprecated.
 
lifeCycleStopping(LifeCycle) - Method in interface org.eclipse.jetty.util.component.LifeCycle.Listener
 
lifeCycleStopping(LifeCycle) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
limit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
limit() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
Link - Class in org.eclipse.jetty.plus.jndi
 
Link(Object, String, String) - Constructor for class org.eclipse.jetty.plus.jndi.Link
 
Link(String, String) - Constructor for class org.eclipse.jetty.plus.jndi.Link
 
LINK - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
LINK - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
list() - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
list() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
list() - Method in class org.eclipse.jetty.util.resource.PathResource
 
list() - Method in class org.eclipse.jetty.util.resource.Resource
list of resource names contained in the given resource.
list() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
list() - Method in class org.eclipse.jetty.util.resource.URLResource
Returns a list of resource names contained in the given resource
list(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
list(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
list(String) - Method in class org.eclipse.jetty.jndi.NamingContext
List all names bound at Context named by Name
list(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
list(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
list(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
List all names bound at Context named by Name
listBindings(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
listBindings(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
listBindings(String) - Method in class org.eclipse.jetty.jndi.NamingContext
List all Bindings at Name
listBindings(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
listBindings(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
listBindings(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
List all Bindings present at Context named by Name
listConfig(PrintStream, StartArgs) - Method in class org.eclipse.jetty.start.Main
 
listEnabled(PrintStream) - Method in class org.eclipse.jetty.start.Modules
 
listener(Request.Listener) - Method in interface org.eclipse.jetty.client.api.Request
 
listener(Request.Listener) - Method in class org.eclipse.jetty.client.HttpRequest
 
ListenerHolder - Class in org.eclipse.jetty.servlet
ListenerHolder Specialization of BaseHolder for servlet listeners.
ListenerHolder() - Constructor for class org.eclipse.jetty.servlet.ListenerHolder
 
ListenerHolder(Class<? extends EventListener>) - Constructor for class org.eclipse.jetty.servlet.ListenerHolder
 
ListenerHolder(Source) - Constructor for class org.eclipse.jetty.servlet.ListenerHolder
 
ListenerHolder.WrapFunction - Interface in org.eclipse.jetty.servlet
Experimental Wrapper mechanism for Servlet EventListeners.
ListenerHolder.Wrapper - Class in org.eclipse.jetty.servlet
 
listIterator() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
listIterator() - Method in class org.eclipse.jetty.start.TextFile
 
listIterator(int) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
listIterator(Object) - Static method in class org.eclipse.jetty.util.LazyList
 
listModules(PrintStream, List<String>) - Method in class org.eclipse.jetty.start.Modules
 
listModules(PrintStream, StartArgs) - Method in class org.eclipse.jetty.start.Main
 
literal(String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
Literal(String) - Constructor for class org.eclipse.jetty.util.ajax.JSON.Literal
Constructs a literal JSON instance.
load(InputStream, String) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Load the session data from a file.
load(ClassLoader) - Method in class org.eclipse.jetty.logging.JettyLoggerConfiguration
Load the Configuration from the ClassLoader
load(ClassLoader, String) - Static method in class org.eclipse.jetty.start.Props
 
load(String) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
load(String) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
load(String) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
load(String) - Method in interface org.eclipse.jetty.server.session.SessionDataMap
Read in session data.
load(URL) - Static method in class org.eclipse.jetty.start.Props
 
loadAsResource(String, boolean) - Method in class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
Try to load the class from the bundle classloader.
loadAsResource(String, boolean) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
Look for the classname as a resource to avoid loading a class that is potentially a system resource.
loadClass(Class, String) - Static method in class org.eclipse.jetty.util.Loader
Load a class.
loadClass(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
loadClass(String) - Method in class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
 
loadClass(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
loadClass(String) - Static method in class org.eclipse.jetty.util.Loader
Load a class.
loadClass(String) - Method in class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
loadClass(String, boolean) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
loadClass(String, boolean) - Method in class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
 
loadClass(String, boolean) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
loadConfigurations() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
loadCRL(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Loads certificate revocation list (CRL) from a file.
loadCRL(String) - Static method in class org.eclipse.jetty.util.security.CertificateUtils
 
loadCRL(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Loads certificate revocation list (CRL) from a file.
Loader - Class in org.eclipse.jetty.util
ClassLoader Helper.
Loader() - Constructor for class org.eclipse.jetty.util.Loader
 
loadKeyStore(Resource) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Override this method to provide alternate way to load a keystore.
loadRoleInfo(UserPrincipal) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
loadRoleInfo(UserPrincipal) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
loadRoleInfo(UserPrincipal) - Method in class org.eclipse.jetty.security.HashLoginService
 
loadRoleInfo(UserPrincipal) - Method in class org.eclipse.jetty.security.JDBCLoginService
 
loadTrustStore(Resource) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Override this method to provide alternate way to load a truststore.
loadUserInfo(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
loadUserInfo(String) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
loadUserInfo(String) - Method in class org.eclipse.jetty.security.HashLoginService
 
loadUserInfo(String) - Method in class org.eclipse.jetty.security.JDBCLoginService
 
loadUsers() - Method in class org.eclipse.jetty.security.PropertyUserStore
 
LOCAL - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Command
 
LOCAL - Static variable in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
The PROXY V2 Tag typically used to "ping" the server.
LOCAL_ADDRESS_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The local address attribute name.
LOCAL_PORT_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The local port attribute name.
LocalConnector - Class in org.eclipse.jetty.server
A local connector, mostly for testing purposes.
LocalConnector(Server) - Constructor for class org.eclipse.jetty.server.LocalConnector
 
LocalConnector(Server, Executor, Scheduler, ByteBufferPool, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.LocalConnector
 
LocalConnector(Server, ConnectionFactory) - Constructor for class org.eclipse.jetty.server.LocalConnector
 
LocalConnector(Server, ConnectionFactory, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.LocalConnector
 
LocalConnector(Server, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.LocalConnector
 
LocalConnector.LocalEndPoint - Class in org.eclipse.jetty.server
Local EndPoint
localContextRoot - Class in org.eclipse.jetty.jndi.local
localContext Implementation of the delegate for InitialContext for the local namespace.
localContextRoot(Hashtable) - Constructor for class org.eclipse.jetty.jndi.local.localContextRoot
 
LocalEndPoint() - Constructor for class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
LocalFileInitializer - Class in org.eclipse.jetty.start.fileinits
 
LocalFileInitializer(BaseHome) - Constructor for class org.eclipse.jetty.start.fileinits.LocalFileInitializer
 
LOCALLY_CLOSED - Enum constant in enum org.eclipse.jetty.http2.CloseState
A half-close frame has been generated and sent.
LOCALLY_CLOSING - Enum constant in enum org.eclipse.jetty.http2.CloseState
A half-close frame has been generated.
locateJarsInsideBundle(Bundle) - Method in interface org.eclipse.jetty.osgi.boot.utils.BundleFileLocatorHelper
If the bundle is a jar, returns the jar.
locateJarsInsideBundle(Bundle) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
If the bundle is a jar, returns the jar.
location - Variable in class org.eclipse.jetty.start.FileArg
 
LOCATION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
lock() - Method in interface org.eclipse.jetty.server.ContentProducer
Lock this instance.
lock() - Method in class org.eclipse.jetty.server.session.Session
Grab the lock on the session
lock() - Method in class org.eclipse.jetty.util.thread.AutoLock
Acquires the lock.
lock() - Method in class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
LOCK - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
LOCK_PROPERTY - Static variable in class org.eclipse.jetty.jndi.NamingContext
 
lockCompEnv(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
LOCKED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
LOCKED_423 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
log(Exception, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
log(Exception, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
Deprecated.
log(String) - Static method in class org.eclipse.jetty.ant.utils.TaskLog
 
log(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
log(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
log(String, Object...) - Method in class org.eclipse.jetty.server.DebugListener
 
log(String, Throwable) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
log(String, Throwable) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
log(Request, Response) - Method in class org.eclipse.jetty.server.CustomRequestLog
Writes the request and response information to the output stream.
log(Request, Response) - Method in class org.eclipse.jetty.server.RequestLog.Collection
 
log(Request, Response) - Method in interface org.eclipse.jetty.server.RequestLog
 
log(LoggingEvent) - Method in class org.eclipse.jetty.logging.JettyLogger
Dynamic (via Reflection) entry point for SubstituteLogger usage.
log(Marker, String, int, String, Object[], Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
Entry point for LocationAwareLogger
Log - Class in org.eclipse.jetty.util.log
Deprecated. 
Log() - Constructor for class org.eclipse.jetty.util.log.Log
Deprecated.
 
LOG - Static variable in class org.eclipse.jetty.client.AuthenticationProtocolHandler
 
LOG - Static variable in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
LOG - Static variable in class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
LOG - Static variable in class org.eclipse.jetty.http.HttpCompliance
 
LOG - Static variable in class org.eclipse.jetty.http.HttpParser
 
LOG - Static variable in class org.eclipse.jetty.http.RFC6265CookieParser
 
LOG - Static variable in class org.eclipse.jetty.http.spi.HttpSpiContextHandler
 
LOG - Static variable in class org.eclipse.jetty.http.UriCompliance
 
LOG - Static variable in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
LOG - Static variable in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
LOG - Static variable in class org.eclipse.jetty.http2.HTTP2Connection
 
LOG - Static variable in class org.eclipse.jetty.io.SelectorManager
 
LOG - Static variable in class org.eclipse.jetty.proxy.ConnectHandler
 
LOG - Static variable in class org.eclipse.jetty.proxy.ProxyConnection
 
LOG - Static variable in class org.eclipse.jetty.server.AbstractConnector
 
LOG - Static variable in class org.eclipse.jetty.server.Cookies
 
LOG - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
LOG - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
LOG - Static variable in class org.eclipse.jetty.server.MultiPartParser
 
LOG - Static variable in class org.eclipse.jetty.util.preventers.AbstractLeakPreventer
 
LOG - Static variable in class org.eclipse.jetty.util.Utf8Appendable
 
LOG - Static variable in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
LogarithmicArrayByteBufferPool - Class in org.eclipse.jetty.io
Extension of the ArrayByteBufferPool whose bucket sizes increase exponentially instead of linearly.
LogarithmicArrayByteBufferPool() - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Creates a new ByteBufferPool with a default configuration.
LogarithmicArrayByteBufferPool(int, int) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Creates a new ByteBufferPool with the given configuration.
LogarithmicArrayByteBufferPool(int, int, int) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Creates a new ByteBufferPool with the given configuration.
LogarithmicArrayByteBufferPool(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Creates a new ByteBufferPool with the given configuration.
LogarithmicArrayByteBufferPool(int, int, int, long, long, long, long) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
Creates a new ByteBufferPool with the given configuration.
LogarithmicArrayByteBufferPool.LogarithmicRetainablePool - Class in org.eclipse.jetty.io
A variant of the ArrayRetainableByteBufferPool that uses buckets of buffers that increase in size by a power of 2 (eg 1k, 2k, 4k, 8k, etc.).
LogarithmicRetainablePool() - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool.LogarithmicRetainablePool
 
LogarithmicRetainablePool(int, int, int) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool.LogarithmicRetainablePool
 
LogarithmicRetainablePool(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool.LogarithmicRetainablePool
 
LoggedOutAuthentication - Class in org.eclipse.jetty.security
LoggedOutAuthentication An Authentication indicating that a user has been previously, but is not currently logged in, but may be capable of logging in after a call to Request.login(String,String)
LoggedOutAuthentication(LoginAuthenticator) - Constructor for class org.eclipse.jetty.security.LoggedOutAuthentication
 
Logger - Interface in org.eclipse.jetty.util.log
Deprecated. 
login() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
login() - Method in class org.eclipse.jetty.jaas.spi.LdapLoginModule
since ldap uses a context bind for valid authentication checking, we override login()
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
Only renew the session id if the user has been fully authenticated, don't renew the session for any of the intermediate request/response handshakes.
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
If the UserIdentity is not null after this method calls LoginService.login(String, Object, ServletRequest), it is assumed that the user is fully authenticated and we need to change the session id to prevent session fixation vulnerability.
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.EmptyLoginService
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.LoggedOutAuthentication
 
login(String, Object, ServletRequest) - Method in interface org.eclipse.jetty.security.LoginService
Login a user.
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
login(String, Object, ServletRequest) - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
login(String, Object, ServletRequest) - Method in interface org.eclipse.jetty.server.Authentication.LoginAuthentication
Login with the LOGIN authenticator
login(String, String) - Method in class org.eclipse.jetty.server.Request
 
login(String, String) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
login(String, String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
login(Subject, String, String, MessageInfo) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
login(Subject, String, Credential, String, MessageInfo) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
LOGIN_SERVICE_KEY - Static variable in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
LoginAuthenticator - Class in org.eclipse.jetty.security.authentication
 
LoginAuthenticator() - Constructor for class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
LoginCallback - Interface in org.eclipse.jetty.security.authentication
This is similar to the jaspi PasswordValidationCallback but includes user principal and group info as well.
LoginCallbackImpl - Class in org.eclipse.jetty.security.authentication
This is similar to the jaspi PasswordValidationCallback but includes user principal and group info as well.
LoginCallbackImpl(Subject, String, Object) - Constructor for class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
LoginService - Interface in org.eclipse.jetty.security
Login Service Interface.
LoginServices - Class in org.eclipse.jetty.ant.types
Specifies a jetty configuration <loginServices/> element for Ant build file.
LoginServices() - Constructor for class org.eclipse.jetty.ant.types.LoginServices
 
logout() - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
logout() - Method in class org.eclipse.jetty.server.Request
 
logout() - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
logout() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
logout(ServletRequest) - Method in class org.eclipse.jetty.security.AbstractUserAuthentication
 
logout(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
logout(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
logout(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
logout(ServletRequest) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
logout(ServletRequest) - Method in interface org.eclipse.jetty.server.Authentication.LogoutAuthentication
Remove any user information that may be present in the request such that a call to getUserPrincipal/getRemoteUser will return null.
logout(Authentication.User) - Method in class org.eclipse.jetty.security.SecurityHandler
 
logout(UserIdentity) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
logout(UserIdentity) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
logout(UserIdentity) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
logout(UserIdentity) - Method in class org.eclipse.jetty.security.EmptyLoginService
 
logout(UserIdentity) - Method in interface org.eclipse.jetty.security.LoginService
 
logout(UserIdentity) - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
LOGOUT_REDIRECT_PATH - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
logWithTimestamp(String) - Static method in class org.eclipse.jetty.ant.utils.TaskLog
 
LongDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Text Message to Long decoder
LongDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.LongDecoder
 
LongEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Long to Encoder.Text Message encoder
LongEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.LongEncoder
 
LongValueHttpField(HttpHeader, long) - Constructor for class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
LongValueHttpField(HttpHeader, String, long) - Constructor for class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
LongValueHttpField(HttpHeader, String, String) - Constructor for class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
LongValueHttpField(HttpHeader, String, String, long) - Constructor for class org.eclipse.jetty.http.HttpField.LongValueHttpField
 
LOOK_AHEAD - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
lookAheadGet(byte[], int, int) - Static method in enum org.eclipse.jetty.http.HttpMethod
Deprecated.
Not used
lookAheadGet(byte[], int, int) - Static method in enum org.eclipse.jetty.http.HttpVersion
Optimised lookup to find an Http Version and whitespace in a byte array.
lookAheadGet(ByteBuffer) - Static method in enum org.eclipse.jetty.http.HttpMethod
Optimized lookup to find a method name and trailing space in a byte array.
lookAheadGet(ByteBuffer) - Static method in enum org.eclipse.jetty.http.HttpVersion
Optimised lookup to find an HTTP Version and trailing white space in a byte array.
lookup(Object, String) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
lookup(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
lookup(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
lookup(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Lookup binding of an object by name
lookup(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
lookup(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
lookup(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Lookup a binding by name
lookupInjectedValue() - Method in class org.eclipse.jetty.plus.annotation.Injection
The Resource must already exist in the ENC of this webapp.
lookupLink(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
lookupLink(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
lookupLink(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Lookup link bound to name
lookupLink(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
lookupLink(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
lookupLink(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Lookup link bound to name
lookupNamingEntries(Object, Class<T>) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
Get all NameEntries of a certain type in the given naming environment scope (server-wide names or context-specific names)
lookupNamingEntry(Object, String) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
Find a NamingEntry in the given scope.
LOOP_DETECTED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
LOOP_DETECTED_508 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
low(String, String) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
lowerCaseName() - Method in enum org.eclipse.jetty.http.HttpHeader
 
LowResourceMonitor - Class in org.eclipse.jetty.server
A monitor for low resources, low resources can be detected by: ThreadPool.isLowOnThreads() if Connector.getExecutor() is an instance of ThreadPool and LowResourceMonitor.setMonitorThreads(boolean) is true. If LowResourceMonitor.setMaxMemory(long) is non zero then low resources is detected if the JVMs Runtime instance has Runtime.totalMemory() minus Runtime.freeMemory() greater than LowResourceMonitor.getMaxMemory()
LowResourceMonitor(Server) - Constructor for class org.eclipse.jetty.server.LowResourceMonitor
 
LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck - Class in org.eclipse.jetty.server
 
LowResourceMonitor.LowResourceCheck - Interface in org.eclipse.jetty.server
 
LowResourceMonitor.MainThreadPoolLowResourceCheck - Class in org.eclipse.jetty.server
 
LowResourceMonitor.MaxConnectionsLowResourceCheck - Class in org.eclipse.jetty.server
 
LowResourceMonitor.MemoryLowResourceCheck - Class in org.eclipse.jetty.server
 

M

MAGIC - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
Globally Unique Identifier for use in WebSocket handshake within Sec-WebSocket-Accept and Sec-WebSocket-Key HTTP headers.
MailSessionReference - Class in org.eclipse.jetty.jndi.factories
MailSessionReference This is a subclass of javax.mail.Reference and an ObjectFactory for javax.mail.Session objects.
MailSessionReference() - Constructor for class org.eclipse.jetty.jndi.factories.MailSessionReference
 
MailSessionReference.PasswordAuthenticator - Class in org.eclipse.jetty.jndi.factories
 
main(String...) - Static method in class org.eclipse.jetty.quickstart.PreconfigureQuickStartWar
 
main(String[]) - Static method in class org.eclipse.jetty.runner.Runner
Deprecated.
 
main(String...) - Static method in class org.eclipse.jetty.server.Server
 
main(String...) - Static method in class org.eclipse.jetty.session.infinispan.InfinispanSessionLegacyConverter
 
main(String[]) - Static method in class org.eclipse.jetty.start.Main
 
main(String[]) - Static method in class org.eclipse.jetty.util.security.Password
 
main(String[]) - Static method in class org.eclipse.jetty.util.security.UnixCrypt
 
main(String...) - Static method in class org.eclipse.jetty.xml.XmlConfiguration
Runs the XML configurations as a main application.
Main - Class in org.eclipse.jetty.start
Main start class.
Main() - Constructor for class org.eclipse.jetty.start.Main
 
MainThreadPoolLowResourceCheck() - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MainThreadPoolLowResourceCheck
 
makeConstraint(Class, String[], ServletSecurity.EmptyRoleSemantic, ServletSecurity.TransportGuarantee) - Method in class org.eclipse.jetty.annotations.ServletSecurityAnnotationHandler
Make a jetty Constraint object, which represents the <auth-constraint> and <user-data-constraint> elements, based on the security annotation.
makeEnvEntryInjectionsAndBindings(WebAppContext, Descriptor, XmlParser.Node, String, String, String) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Make injections and any java:comp/env bindings necessary given an env-entry declaration.
makeKey(String, String, String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
makeKey(String, SessionContext) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
Make a unique key for this session.
makeName(String) - Method in class org.eclipse.jetty.jmx.MBeanContainer
 
makeNamingEntryName(NameParser, String) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
makeNamingEntryName(NameParser, NamingEntry) - Static method in class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
makeTempDirectory(File, WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
manage(Object) - Method in interface org.eclipse.jetty.util.component.Container
Manages a bean already contained by this aggregate, so that it is started/stopped/destroyed with this aggregate.
manage(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Manages a bean already contained by this aggregate, so that it is started/stopped/destroyed with this aggregate.
MANAGED_ATTRIBUTES - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
MANAGED_JETTY_SERVER_DEFAULT_NAME - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
Name of the 'default' jetty server instance.
MANAGED_JETTY_SERVER_FACTORY_PID - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
PID of the jetty servers's ManagedFactory
MANAGED_JETTY_SERVER_NAME - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
The associated value of that configuration parameter is the name under which this instance of the jetty server is tracked.
MANAGED_JETTY_SHARED_LIB_FOLDER_URLS - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
List of URLs to the folders where the legacy J2EE shared libraries are stored aka lib/ext, lib/jsp etc.
MANAGED_JETTY_XML_CONFIG_URLS - Static variable in class org.eclipse.jetty.osgi.boot.OSGiServerConstants
List of URLs to the jetty.xml files that configure th server.
ManagedAttribute - Annotation Type in org.eclipse.jetty.util.annotation
The @ManagedAttribute annotation is used to indicate that a given method exposes a JMX attribute.
ManagedAttributeListener - Class in org.eclipse.jetty.server.handler
Enable Jetty style JMX MBeans from within a Context
ManagedAttributeListener(ContextHandler, String...) - Constructor for class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
ManagedObject - Annotation Type in org.eclipse.jetty.util.annotation
The @ManagedObject annotation is used on a class at the top level to indicate that it should be exposed as an mbean.
ManagedOperation - Annotation Type in org.eclipse.jetty.util.annotation
The @ManagedOperation annotation is used to indicate that a given method should be considered a JMX operation.
ManagedSelector - Class in org.eclipse.jetty.io
ManagedSelector wraps a Selector simplifying non-blocking operations on channels.
ManagedSelector(SelectorManager, int) - Constructor for class org.eclipse.jetty.io.ManagedSelector
 
ManagedSelector.Selectable - Interface in org.eclipse.jetty.io
A ManagedSelector.Selectable is an EndPoint that wish to be notified of non-blocking events by the ManagedSelector.
ManagedSelector.SelectorUpdate - Interface in org.eclipse.jetty.io
A selector update to be done when the selector has been woken.
MANDATORY_KEY - Static variable in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
ManifestUtils - Class in org.eclipse.jetty.util
 
mapContexts() - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Remap the contexts.
MappedByteBufferPool - Class in org.eclipse.jetty.io
A ByteBuffer pool where ByteBuffers are held in queues that are held in a Map.
MappedByteBufferPool() - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool
Creates a new MappedByteBufferPool with a default configuration.
MappedByteBufferPool(int) - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool
Creates a new MappedByteBufferPool with the given capacity factor.
MappedByteBufferPool(int, int) - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool
Creates a new MappedByteBufferPool with the given configuration.
MappedByteBufferPool(int, int, long, long) - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool
Creates a new MappedByteBufferPool with the given configuration.
MappedByteBufferPool(int, int, long, long, long, long) - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool
Creates a new MappedByteBufferPool with the given configuration.
MappedByteBufferPool.Retained - Class in org.eclipse.jetty.io
 
MappedByteBufferPool.Tagged - Class in org.eclipse.jetty.io
 
MappedResource<E> - Class in org.eclipse.jetty.http.pathmap
 
MappedResource(PathSpec, E) - Constructor for class org.eclipse.jetty.http.pathmap.MappedResource
 
mask - Variable in class org.eclipse.jetty.websocket.core.Frame
 
match(byte[], int, int) - Method in class org.eclipse.jetty.util.SearchPattern
Search for a complete match of the pattern within the data
match(Class<?>) - Method in class org.eclipse.jetty.webapp.ClassMatcher
Match the class name against the pattern
match(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher
Match the class name against the pattern
match(String, String) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
match(String, String...) - Static method in class org.eclipse.jetty.osgi.boot.utils.internal.DefaultFileLocatorHelper
 
match(String, String, boolean) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
match(String, URI[], boolean) - Method in class org.eclipse.jetty.util.PatternMatcher
 
match(String, URL) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
match(List<URI>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration.ContainerPathNameMatcher
 
match(List<URI>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration.WebAppPathNameMatcher
 
match(Pattern, URI[], boolean) - Method in class org.eclipse.jetty.util.PatternMatcher
Find jar names from the provided list matching a pattern.
match(Origin) - Method in class org.eclipse.jetty.client.ProxyConfiguration
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.CompactPathRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.MsieRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.MsieSslRule
Deprecated.
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.PatternRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RegexRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.Rule
This method calls tests the rule against the request/response pair and if the Rule applies, then the rule's action is triggered.
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
Process the contained rules
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.ValidUrlRule
 
matchAndApply(String, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.rewrite.handler.VirtualHostRuleContainer
Process the contained rules if the request is applicable to the virtual hosts of this rule
matched(String) - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
Get the complete matched details of the provided path.
matched(String) - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
matched(String) - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
matched(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
matched(URI) - Method in class org.eclipse.jetty.util.PatternMatcher
 
matched(URI) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration.ContainerPathNameMatcher
 
matched(URI) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration.WebAppPathNameMatcher
 
MatchedPath - Interface in org.eclipse.jetty.http.pathmap
 
MatchedResource<E> - Class in org.eclipse.jetty.http.pathmap
The match details when using PathMappings.getMatched(String), used to minimize return to the PathSpec or PathMappings for subsequent details that are now provided by the MatchedPath instance.
MatchedResource(E, PathSpec, MatchedPath) - Constructor for class org.eclipse.jetty.http.pathmap.MatchedResource
 
matches(String) - Method in interface org.eclipse.jetty.http.pathmap.PathSpec
Deprecated.
matches(String) - Method in class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
matches(String) - Method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
matches(String) - Method in class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
matches(String) - Method in class org.eclipse.jetty.util.RegexSet
 
matches(String) - Method in class org.eclipse.jetty.util.ssl.X509
 
matches(String, URI, String) - Method in interface org.eclipse.jetty.client.api.Authentication
Matches Authentications based on the given parameters
matches(String, URI, String) - Method in class org.eclipse.jetty.client.util.AbstractAuthentication
 
matches(String, URI, String) - Method in class org.eclipse.jetty.client.util.DigestAuthentication
 
matches(List<String>, boolean) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
Tests whether one of the protocols of this class is also present in the given candidates list.
matches(Origin) - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
Matches the given origin with the included and excluded addresses, returning true if the given origin is to be proxied.
matches(InvokerUtils.Arg) - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
matchesExclusionPattern(ServletContainerInitializer) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Test if the ServletContainerIntializer is excluded by the o.e.j.containerInitializerExclusionPattern
matchesURI(URI, URI) - Static method in class org.eclipse.jetty.client.util.AbstractAuthentication
 
matchPath(URI, List<HttpCookie>) - Static method in class org.eclipse.jetty.util.HttpCookieStore
 
matchPatterns(Pattern, URI[], boolean) - Method in class org.eclipse.jetty.util.PatternMatcher
 
MathUtils - Class in org.eclipse.jetty.util
 
MavenLocalRepoFileInitializer - Class in org.eclipse.jetty.start.fileinits
Attempt to download a maven:// URI, by first attempting to find the resource in the maven repository system (starting with local, then central)
MavenLocalRepoFileInitializer(BaseHome) - Constructor for class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
MavenLocalRepoFileInitializer(BaseHome, Path, boolean) - Constructor for class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
MavenLocalRepoFileInitializer(BaseHome, Path, boolean, String) - Constructor for class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer
 
MavenLocalRepoFileInitializer.Coordinates - Class in org.eclipse.jetty.start.fileinits
 
MavenMetadata - Class in org.eclipse.jetty.start.fileinits
Simple parser for maven-metadata.xml files
MavenMetadata(Path) - Constructor for class org.eclipse.jetty.start.fileinits.MavenMetadata
 
MavenMetadata.Snapshot - Class in org.eclipse.jetty.start.fileinits
 
max(BatchMode, BatchMode) - Static method in enum org.eclipse.jetty.websocket.api.BatchMode
 
MAX_BLOCKED_STREAMS - Static variable in class org.eclipse.jetty.http3.frames.SettingsFrame
 
MAX_CODE - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MAX_CONCURRENT_STREAMS - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
MAX_CONTENT_LENGTH - Static variable in class org.eclipse.jetty.fcgi.generator.Generator
 
MAX_CONTROL_PAYLOAD - Static variable in class org.eclipse.jetty.websocket.core.Frame
Maximum size of Control frame, per RFC 6455
MAX_FIELD_SECTION_SIZE - Static variable in class org.eclipse.jetty.http3.frames.SettingsFrame
 
MAX_FORM_CONTENT_SIZE_KEY - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
MAX_FORM_KEYS_KEY - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
MAX_FORWARDS - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
MAX_FRAME_SIZE - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
MAX_HEADER_LENGTH - Static variable in class org.eclipse.jetty.websocket.core.internal.Generator
The overhead (maximum) for a framing header.
MAX_HEADER_LIST_SIZE - Static variable in class org.eclipse.jetty.http2.frames.SettingsFrame
 
MAX_INTERVAL_NOT_SET - Static variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
MAX_MAX_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.Frame
 
MAX_OUTPUT_CHARS - Static variable in class org.eclipse.jetty.server.HttpWriter
 
MAX_PARAM_LENGTH - Static variable in class org.eclipse.jetty.fcgi.generator.ClientGenerator
 
MAX_PUSH_ID - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
MAX_REASON_PHRASE - Static variable in class org.eclipse.jetty.websocket.api.CloseStatus
 
MAX_SCAN_DEPTH - Static variable in class org.eclipse.jetty.util.Scanner
 
MAX_SCAN_WAIT - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
MAX_TABLE_CAPACITY - Static variable in class org.eclipse.jetty.http3.frames.SettingsFrame
 
MAX_UNIX_SOCKET_PATH_LENGTH - Static variable in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
maxBinaryMessageSize() - Element in annotation type org.eclipse.jetty.websocket.api.annotations.WebSocket
The maximum size of a binary message (in bytes) during parsing/generating.
maxCapacity(int) - Method in class org.eclipse.jetty.util.Index.Mutable.Builder
Configure a maximum capacity for the mutable index.
MaxConnectionsLowResourceCheck(int) - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MaxConnectionsLowResourceCheck
 
MAXINACTIVE - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
maxStringLength(int, String) - Static method in class org.eclipse.jetty.websocket.core.internal.util.TextUtils
Smash a long string to fit within the max string length, by taking the middle section of the string and replacing them with an ellipsis "..."
maxTextMessageSize() - Element in annotation type org.eclipse.jetty.websocket.api.annotations.WebSocket
The maximum size of a text message during parsing/generating.
maxType() - Static method in enum org.eclipse.jetty.http3.frames.FrameType
 
MBeanContainer - Class in org.eclipse.jetty.jmx
Container class for the MBean instances
MBeanContainer(MBeanServer) - Constructor for class org.eclipse.jetty.jmx.MBeanContainer
Constructs MBeanContainer
MBeanContainer(MBeanServer, boolean) - Constructor for class org.eclipse.jetty.jmx.MBeanContainer
Constructs MBeanContainer
mbeanFor(Object) - Method in class org.eclipse.jetty.jmx.MBeanContainer
Creates an ObjectMBean for the given object.
meetDemand() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
MemcachedSessionDataMap - Class in org.eclipse.jetty.memcached.session
MemcachedSessionDataMap Uses memcached as a cache for SessionData.
MemcachedSessionDataMap(String, String) - Constructor for class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
MemcachedSessionDataMap(List<InetSocketAddress>) - Constructor for class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
MemcachedSessionDataMap(List<InetSocketAddress>, int[]) - Constructor for class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
MemcachedSessionDataMap.SessionDataTranscoder - Class in org.eclipse.jetty.memcached.session
SessionDataTranscoder We override memcached deserialization to use our classloader-aware ObjectInputStream.
MemcachedSessionDataMapFactory - Class in org.eclipse.jetty.memcached.session
MemcachedSessionDataMapFactory
MemcachedSessionDataMapFactory() - Constructor for class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
MemoryLowResourceCheck(long) - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
MemoryUtils - Class in org.eclipse.jetty.util
MemoryUtils provides an abstraction over memory properties and operations.
MERGE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
mergeQueryParameters(String, String) - Method in class org.eclipse.jetty.server.Request
 
Message() - Constructor for class org.eclipse.jetty.http.HttpTester.Message
 
MESSAGE_HTTP - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
MESSAGE_LAYER - Static variable in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
MESSAGE_TOO_LARGE - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1009 indicates that an endpoint is terminating the connection because it has received a message that is too big for it to process.
MESSAGE_TOO_LARGE - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
messageComplete() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
messageComplete() - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
 
messageComplete() - Method in class org.eclipse.jetty.http.HttpTester.Message
 
messageComplete() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
messageComplete() - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
MessageHandler - Class in org.eclipse.jetty.websocket.core.internal
A utility implementation of FrameHandler that defragments text frames into a String message before calling MessageHandler.onText(String, Callback).
MessageHandler() - Constructor for class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
MessageInputStream - Class in org.eclipse.jetty.websocket.core.internal.messages
Support class for reading a WebSocket BINARY message via a InputStream.
MessageInputStream() - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
MessageOutputStream - Class in org.eclipse.jetty.websocket.core.internal.messages
Support for writing a single WebSocket BINARY message via a OutputStream
MessageOutputStream(CoreSession, ByteBufferPool) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
MessageReader - Class in org.eclipse.jetty.websocket.core.internal.messages
Support class for reading a (single) WebSocket TEXT message via a Reader.
MessageReader() - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
MessageReader(int) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
MessageSink - Interface in org.eclipse.jetty.websocket.core.internal.messages
Sink consumer for messages (used for multiple frames with continuations, and also to allow for streaming APIs)
MessageTooLargeException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Exception when a message is too large for the internal buffers occurs and should trigger a connection close.
MessageTooLargeException - Exception Class in org.eclipse.jetty.websocket.core.exception
Exception when a message is too large for the internal buffers occurs and should trigger a connection close.
MessageTooLargeException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.MessageTooLargeException
 
MessageTooLargeException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.MessageTooLargeException
 
MessageTooLargeException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.MessageTooLargeException
 
MessageTooLargeException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.MessageTooLargeException
 
MessageTooLargeException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.MessageTooLargeException
 
MessageTooLargeException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.MessageTooLargeException
 
messageType - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
MessageWriter - Class in org.eclipse.jetty.websocket.core.internal.messages
Support for writing a single WebSocket TEXT message via a Writer
MessageWriter(CoreSession, ByteBufferPool) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.MessageWriter
 
MetaData - Class in org.eclipse.jetty.http
 
MetaData - Class in org.eclipse.jetty.webapp
MetaData All data associated with the configuration and deployment of a web application.
MetaData() - Constructor for class org.eclipse.jetty.webapp.MetaData
 
MetaData(HttpVersion, HttpFields) - Constructor for class org.eclipse.jetty.http.MetaData
 
MetaData(HttpVersion, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData
 
MetaData(HttpVersion, HttpFields, long, Supplier<HttpFields>) - Constructor for class org.eclipse.jetty.http.MetaData
 
MetaData.Complete - Enum in org.eclipse.jetty.webapp
 
MetaData.ConnectRequest - Class in org.eclipse.jetty.http
 
MetaData.OriginInfo - Class in org.eclipse.jetty.webapp
Metadata regarding where a deployable element was declared: by annotation or by descriptor.
MetaData.Request - Class in org.eclipse.jetty.http
 
MetaData.Response - Class in org.eclipse.jetty.http
 
MetaDataBuilder - Class in org.eclipse.jetty.http2.hpack
 
MetaDataBuilder(int) - Constructor for class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
METAINF_FRAGMENTS - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
METAINF_RESOURCES - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
METAINF_TLDS - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
MetaInfConfiguration - Class in org.eclipse.jetty.webapp
MetaInfConfiguration
MetaInfConfiguration() - Constructor for class org.eclipse.jetty.webapp.MetaInfConfiguration
 
MetaInfConfiguration.ContainerPathNameMatcher - Class in org.eclipse.jetty.webapp
ContainerPathNameMatcher Matches names of jars on the container classpath against a pattern.
MetaInfConfiguration.WebAppPathNameMatcher - Class in org.eclipse.jetty.webapp
WebAppPathNameMatcher Matches names of jars or dirs on the webapp classpath against a pattern.
method(String) - Method in interface org.eclipse.jetty.client.api.Request
 
method(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
method(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
method(HttpMethod) - Method in interface org.eclipse.jetty.client.api.Request
 
method(HttpMethod) - Method in class org.eclipse.jetty.client.HttpRequest
 
METHOD - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
METHOD - Static variable in class org.eclipse.jetty.client.Socks5.NoAuthenticationFactory
 
METHOD - Static variable in class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
METHOD_NOT_ALLOWED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
METHOD_NOT_ALLOWED_405 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
methodHandle - Variable in class org.eclipse.jetty.websocket.core.internal.messages.AbstractMessageSink
 
MethodInfo(AnnotationParser.ClassInfo, String, int, String, String, String[]) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.MethodInfo
 
MIDDLE_GLOB - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
For path specs that have a hardcoded prefix and suffix with wildcard glob in the middle.
mightCompress() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
millisElapsed(long, long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the milliseconds elapsed between two nanoTimes.
millisSince(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the milliseconds elapsed between a begin nanoTime and the current nanoTime.
millisUntil(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the milliseconds remaining between the current nanoTime and an end nanoTime.
MIME_VERSION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
MimeTypes - Class in org.eclipse.jetty.http
MIME Type enum and utilities
MimeTypes() - Constructor for class org.eclipse.jetty.http.MimeTypes
Constructor.
MimeTypes.Type - Enum in org.eclipse.jetty.http
 
MISDIRECTED_REQUEST - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
MISDIRECTED_REQUEST_421 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MISMATCHED_AUTHORITY - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230: Section 5.4, the HTTP protocol must reject a request if the target URI has an authority that is different than a provided Host header.
MKACTIVITY - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MKCALENDAR - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MKCOL - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MKREDIRECTREF - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MKWORKSPACE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MODE - Static variable in class org.eclipse.jetty.cdi.CdiDecoratingListener
 
MODE - Static variable in class org.eclipse.jetty.cdi.CdiSpiDecorator
 
MODE - Static variable in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
modified() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
MODIFIED - Enum constant in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
 
modifiedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.JettyServerServiceTracker
 
modifiedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ContextTracker
 
modifiedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.WebAppTracker
 
modifyHandshake(ServerEndpointConfig, HandshakeRequest, HandshakeResponse) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.ContainerDefaultConfigurator
 
Module - Class in org.eclipse.jetty.start
Represents a Module metadata, as defined in Jetty.
Module(BaseHome, Path) - Constructor for class org.eclipse.jetty.start.Module
 
ModuleGraphWriter - Class in org.eclipse.jetty.start
Generate a graphviz dot graph of the modules found
ModuleGraphWriter() - Constructor for class org.eclipse.jetty.start.ModuleGraphWriter
 
moduleName - Variable in class org.eclipse.jetty.start.FileArg
 
Modules - Class in org.eclipse.jetty.start
Access for all modules declared, as well as what is enabled.
Modules(BaseHome, StartArgs) - Constructor for class org.eclipse.jetty.start.Modules
 
MongoSessionDataStore - Class in org.eclipse.jetty.nosql.mongodb
MongoSessionDataStore The document model is an outer object that contains the elements: "id" : session_id "created" : create_time "accessed": last_access_time "maxIdle" : max_idle_time setting as session was created "expiry" : time at which session should expire "valid" : session_valid "context" : a nested object containing 1 nested object per context for which the session id is in use Each of the nested objects inside the "context" element contains: unique_context_name : nested object containing name:value pairs of the session attributes for that context unique_context_name: vhost:contextpath, where no vhosts="0_0_0_0", root context = "", contextpath "/" replaced by "_"
MongoSessionDataStore() - Constructor for class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
MongoSessionDataStoreFactory - Class in org.eclipse.jetty.nosql.mongodb
MongoSessionDataStoreFactory
MongoSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
MongoUtils - Class in org.eclipse.jetty.nosql.mongodb
MongoUtils Some utility methods for manipulating mongo data.
MongoUtils() - Constructor for class org.eclipse.jetty.nosql.mongodb.MongoUtils
 
monitor() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
MonitoredQueuedThreadPool - Class in org.eclipse.jetty.util.thread
A QueuedThreadPool subclass that monitors its own activity by recording queue and task statistics.
MonitoredQueuedThreadPool() - Constructor for class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
MonitoredQueuedThreadPool(int) - Constructor for class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
MonitoredQueuedThreadPool(int, int, int, BlockingQueue<Runnable>) - Constructor for class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
 
moreDemand() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
MOST_SPECIFIC_MIME_ORDERING - Static variable in class org.eclipse.jetty.http.QuotedQualityCSV
Lambda to apply a most specific MIME encoding secondary ordering.
MOVE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
MOVED_PERMANENTLY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
MOVED_PERMANENTLY_301 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MOVED_TEMPORARILY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
MOVED_TEMPORARILY_302 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MovedContextHandler - Class in org.eclipse.jetty.server.handler
Moved ContextHandler.
MovedContextHandler() - Constructor for class org.eclipse.jetty.server.handler.MovedContextHandler
 
MovedContextHandler(HandlerContainer, String, String) - Constructor for class org.eclipse.jetty.server.handler.MovedContextHandler
 
MsieRule - Class in org.eclipse.jetty.rewrite.handler
Special handling for MSIE (Microsoft Internet Explorer).
MsieRule() - Constructor for class org.eclipse.jetty.rewrite.handler.MsieRule
 
MsieSslRule - Class in org.eclipse.jetty.rewrite.handler
Deprecated.
use MsieRule
MsieSslRule() - Constructor for class org.eclipse.jetty.rewrite.handler.MsieSslRule
Deprecated.
 
MULTI_STATUS - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
MULTI_STATUS_207 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MULTI_THREADED - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
MultiException - Exception Class in org.eclipse.jetty.util
Wraps multiple exceptions.
MultiException() - Constructor for exception class org.eclipse.jetty.util.MultiException
 
MULTILINE_FIELD_VALUE - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the HTTP protocol no longer supports line folding, which allows a field value to be provided over several lines.
MultiMap<V> - Class in org.eclipse.jetty.util
A multi valued Map.
MultiMap() - Constructor for class org.eclipse.jetty.util.MultiMap
 
MultiMap(Map<String, List<V>>) - Constructor for class org.eclipse.jetty.util.MultiMap
 
MultiMap(MultiMap<V>) - Constructor for class org.eclipse.jetty.util.MultiMap
 
MultiPart(String, String) - Constructor for class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
MultiPart(String, String) - Constructor for class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
MULTIPART_BYTERANGES - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
MULTIPART_FORM_DATA - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
MULTIPART_MIXED - Static variable in class org.eclipse.jetty.util.MultiPartOutputStream
 
MULTIPART_MIXED - Static variable in class org.eclipse.jetty.util.MultiPartWriter
 
MULTIPART_X_MIXED_REPLACE - Static variable in class org.eclipse.jetty.util.MultiPartOutputStream
 
MULTIPART_X_MIXED_REPLACE - Static variable in class org.eclipse.jetty.util.MultiPartWriter
 
MultiPartConfigAnnotationHandler - Class in org.eclipse.jetty.annotations
MultiPartConfigAnnotationHandler
MultiPartConfigAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.MultiPartConfigAnnotationHandler
 
MultiPartContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
MultiPartContentProvider() - Constructor for class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
MultiPartContentProvider(String) - Constructor for class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
MultiPartFormDataCompliance - Enum in org.eclipse.jetty.server
The compliance level for parsing multiPart/form-data
MultiPartFormInputStream - Class in org.eclipse.jetty.server
MultiPartInputStream
MultiPartFormInputStream(InputStream, String, MultipartConfigElement, File) - Constructor for class org.eclipse.jetty.server.MultiPartFormInputStream
 
MultiPartFormInputStream(InputStream, String, MultipartConfigElement, File, int) - Constructor for class org.eclipse.jetty.server.MultiPartFormInputStream
 
MultiPartFormInputStream.MultiPart - Class in org.eclipse.jetty.server
 
MultiPartInputStreamParser - Class in org.eclipse.jetty.server
Deprecated.
Replaced by org.eclipse.jetty.http.MultiPartFormInputStream The code for MultiPartInputStream is slower than its replacement MultiPartFormInputStream. However this class accepts formats non compliant the RFC that the new MultiPartFormInputStream does not accept.
MultiPartInputStreamParser(InputStream, String, MultipartConfigElement, File) - Constructor for class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
MultiPartInputStreamParser(InputStream, String, MultipartConfigElement, File, int) - Constructor for class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
MultiPartInputStreamParser.MultiPart - Class in org.eclipse.jetty.server
Deprecated.
 
MultiPartOutputStream - Class in org.eclipse.jetty.util
Handle a multipart MIME response.
MultiPartOutputStream(OutputStream) - Constructor for class org.eclipse.jetty.util.MultiPartOutputStream
 
MultiPartOutputStream(OutputStream, String) - Constructor for class org.eclipse.jetty.util.MultiPartOutputStream
 
MultiPartParser - Class in org.eclipse.jetty.server
A parser for MultiPart content type.
MultiPartParser(MultiPartParser.Handler, String) - Constructor for class org.eclipse.jetty.server.MultiPartParser
 
MultiPartParser.FieldState - Enum in org.eclipse.jetty.server
 
MultiPartParser.Handler - Interface in org.eclipse.jetty.server
 
MultiPartParser.State - Enum in org.eclipse.jetty.server
 
MultiPartRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content for form uploads with the "multipart/form-data" content type.
MultiPartRequestContent() - Constructor for class org.eclipse.jetty.client.util.MultiPartRequestContent
 
MultiPartRequestContent(String) - Constructor for class org.eclipse.jetty.client.util.MultiPartRequestContent
 
MultiParts - Interface in org.eclipse.jetty.server
 
MultiParts.MultiPartsHttpParser - Class in org.eclipse.jetty.server
 
MultiParts.MultiPartsUtilParser - Class in org.eclipse.jetty.server
 
MultiParts.NonCompliance - Enum in org.eclipse.jetty.server
 
MultiPartsHttpParser(InputStream, String, MultipartConfigElement, File, Request) - Constructor for class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
MultiPartsHttpParser(InputStream, String, MultipartConfigElement, File, Request, int) - Constructor for class org.eclipse.jetty.server.MultiParts.MultiPartsHttpParser
 
MultiPartsUtilParser(InputStream, String, MultipartConfigElement, File, Request) - Constructor for class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
MultiPartsUtilParser(InputStream, String, MultipartConfigElement, File, Request, int) - Constructor for class org.eclipse.jetty.server.MultiParts.MultiPartsUtilParser
 
MultiPartWriter - Class in org.eclipse.jetty.util
Handle a multipart MIME response.
MultiPartWriter(Writer) - Constructor for class org.eclipse.jetty.util.MultiPartWriter
 
MULTIPLE_CHOICES - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
MULTIPLE_CHOICES_300 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
MULTIPLE_CONTENT_LENGTHS - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the HTTP protocol has required that a request is invalid if it contains multiple Content-Length fields or values.
MultiplexConnectionPool - Class in org.eclipse.jetty.client
 
MultiplexConnectionPool(HttpDestination, int, boolean, Callback, int) - Constructor for class org.eclipse.jetty.client.MultiplexConnectionPool
 
MultiplexConnectionPool(HttpDestination, int, Callback, int) - Constructor for class org.eclipse.jetty.client.MultiplexConnectionPool
 
MultiplexConnectionPool(HttpDestination, Pool.StrategyType, int, boolean, Callback, int) - Constructor for class org.eclipse.jetty.client.MultiplexConnectionPool
 
MultiplexConnectionPool(HttpDestination, Pool<Connection>, Callback, int) - Constructor for class org.eclipse.jetty.client.MultiplexConnectionPool
Deprecated.
MultiplexHttpDestination - Class in org.eclipse.jetty.client
A destination for those transports that are multiplex (e.g.
MultiplexHttpDestination(HttpClient, Origin) - Constructor for class org.eclipse.jetty.client.MultiplexHttpDestination
 
MultiplexHttpDestination(HttpClient, Origin, boolean) - Constructor for class org.eclipse.jetty.client.MultiplexHttpDestination
 
MultiReleaseJarFile - Class in org.eclipse.jetty.util
Utility class to handle a Multi Release Jar file
MultiReleaseJarFile(File) - Constructor for class org.eclipse.jetty.util.MultiReleaseJarFile
Construct a multi release jar file for the current JVM version, ignoring directories.
MultiReleaseJarFile(File, int, boolean) - Constructor for class org.eclipse.jetty.util.MultiReleaseJarFile
Construct a multi release jar file
MultiReleaseJarFile.VersionedJarEntry - Class in org.eclipse.jetty.util
A versioned Jar entry
mutable() - Method in class org.eclipse.jetty.util.Index.Builder
Configure the index to be mutable.
mutable() - Method in class org.eclipse.jetty.util.Index.Mutable.Builder
Configure the index to be mutable.
Mutable() - Constructor for class org.eclipse.jetty.http.HttpFields.Mutable
Initialize an empty HttpFields.
mutatedInvoker(MethodHandles.Lookup, Class<?>, Method, InvokerUtils.Arg...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
Build a MethodHandle that can call the method with the calling args provided.
mutatedInvoker(MethodHandles.Lookup, Class<?>, Method, InvokerUtils.ParamIdentifier, String[], InvokerUtils.Arg...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
Create a MethodHandle that performs the following layers MethodHandles.permuteArguments(MethodHandle, MethodType, int...) - moving calling Args around to fit actual actual method parameter arguments (in proper order), with remaining (unused) calling args afterwords MethodHandles.dropArguments(MethodHandle, int, Class[]) - to drop the unused calling args MethodHandle.invoke(Object...) - to call the specific method
mxBean - Variable in class org.eclipse.jetty.util.Uptime.DefaultImpl
 
MyClassVisitor(Set<? extends AnnotationParser.Handler>, Resource, int) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.MyClassVisitor
 
MyFieldVisitor(Set<? extends AnnotationParser.Handler>, AnnotationParser.ClassInfo, int, String, String, String, Object, int) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.MyFieldVisitor
 
MyMethodVisitor(Set<? extends AnnotationParser.Handler>, AnnotationParser.ClassInfo, int, String, String, String, String[], int) - Constructor for class org.eclipse.jetty.annotations.AnnotationParser.MyMethodVisitor
 

N

name() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedAttribute
name to use for the attribute
name(byte) - Static method in class org.eclipse.jetty.websocket.core.OpCode
 
Name - Annotation Type in org.eclipse.jetty.util.annotation
This annotation is used to describe variables in method signatures so that when rendered into tools like JConsole it is clear what the parameters are.
NAME - Static variable in class org.eclipse.jetty.client.ContinueProtocolHandler
 
NAME - Static variable in class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
NAME - Static variable in class org.eclipse.jetty.client.RedirectProtocolHandler
 
NAME - Static variable in class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
NAME - Static variable in class org.eclipse.jetty.servlet.JspPropertyGroupServlet
 
named(String, Object) - Static method in interface org.eclipse.jetty.util.component.Dumpable
 
NameEnumeration - Class in org.eclipse.jetty.jndi
NameEnumeration
NameEnumeration(Iterator<Binding>) - Constructor for class org.eclipse.jetty.jndi.NameEnumeration
 
NAMELESS - Static variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
NamingContext - Class in org.eclipse.jetty.jndi
NamingContext
NamingContext(Hashtable<String, Object>, String, NamingContext, NameParser) - Constructor for class org.eclipse.jetty.jndi.NamingContext
Constructor
NamingContext(Hashtable<String, Object>, String, NamingContext, NameParser, ConcurrentMap<String, Binding>) - Constructor for class org.eclipse.jetty.jndi.NamingContext
 
NamingContext.Listener - Interface in org.eclipse.jetty.jndi
Naming Context Listener.
NamingDump - Class in org.eclipse.jetty.plus.jndi
A utility Dumpable to dump a JNDI naming context tree.
NamingDump() - Constructor for class org.eclipse.jetty.plus.jndi.NamingDump
 
NamingDump(ClassLoader, String) - Constructor for class org.eclipse.jetty.plus.jndi.NamingDump
 
NamingEntry - Class in org.eclipse.jetty.plus.jndi
NamingEntry
NamingEntry(Object, String) - Constructor for class org.eclipse.jetty.plus.jndi.NamingEntry
Create a naming entry.
NamingEntry(String) - Constructor for class org.eclipse.jetty.plus.jndi.NamingEntry
Create a NamingEntry.
NamingEntryUtil - Class in org.eclipse.jetty.plus.jndi
 
NamingEntryUtil() - Constructor for class org.eclipse.jetty.plus.jndi.NamingEntryUtil
 
NamingUtil - Class in org.eclipse.jetty.jndi
Naming Utility Methods
NamingUtil() - Constructor for class org.eclipse.jetty.jndi.NamingUtil
 
NanoTime - Class in org.eclipse.jetty.util
Utility class with methods that deal with System.nanoTime().
NaturalSort - Class in org.eclipse.jetty.start
Natural Language Sorting
NaturalSort() - Constructor for class org.eclipse.jetty.start.NaturalSort
 
NaturalSort.Files - Class in org.eclipse.jetty.start
 
NaturalSort.Paths - Class in org.eclipse.jetty.start
 
NaturalSort.Strings - Class in org.eclipse.jetty.start
 
NBitIntegerDecoder - Class in org.eclipse.jetty.http.compression
Used to decode integers as described in RFC7541.
NBitIntegerDecoder() - Constructor for class org.eclipse.jetty.http.compression.NBitIntegerDecoder
 
NBitIntegerEncoder - Class in org.eclipse.jetty.http.compression
Used to encode integers as described in RFC7541.
NBitStringDecoder - Class in org.eclipse.jetty.http.compression
Used to decode string literals as described in RFC7541.
NBitStringDecoder() - Constructor for class org.eclipse.jetty.http.compression.NBitStringDecoder
 
NBitStringEncoder - Class in org.eclipse.jetty.http.compression
 
NCSA_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
NEED_CHUNK - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
NEED_CHUNK_TRAILER - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
NEED_HEADER - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
NEED_INFO - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
NEED_MORE_BYTES - Enum constant in enum org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting requires more bytes to make a decision.
needContent() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
needContent() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
needContent() - Method in class org.eclipse.jetty.server.HttpChannel
Notify the channel that content is needed.
needContent() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
needsFillInterest() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.FillInterest
Register the read interest Abstract method to be implemented by the Specific ReadInterest to schedule a future call to FillInterest.fillable() or FillInterest.onFail(Throwable)
needsFillInterest() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
negotiate() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
negotiate(List<ExtensionConfig>, List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
Perform the extension negotiation.
negotiate(WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.CreatorNegotiator
 
negotiate(WebSocketNegotiation) - Method in interface org.eclipse.jetty.websocket.core.server.WebSocketNegotiator
 
NEGOTIATE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
Negotiated - Class in org.eclipse.jetty.websocket.core.internal
 
Negotiated(URI, String, boolean, ExtensionStack, String) - Constructor for class org.eclipse.jetty.websocket.core.internal.Negotiated
 
negotiateHeaders(Request) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Negotiation
 
negotiateHeaders(Request) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
NegotiatingClientConnection - Class in org.eclipse.jetty.io
 
NegotiatingClientConnection(EndPoint, Executor, SSLEngine, ClientConnectionFactory, Map<String, Object>) - Constructor for class org.eclipse.jetty.io.NegotiatingClientConnection
 
NegotiatingClientConnectionFactory - Class in org.eclipse.jetty.io
 
NegotiatingClientConnectionFactory(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.NegotiatingClientConnectionFactory
 
NegotiatingServerConnection - Class in org.eclipse.jetty.server
 
NegotiatingServerConnection(Connector, EndPoint, SSLEngine, List<String>, String) - Constructor for class org.eclipse.jetty.server.NegotiatingServerConnection
 
NegotiatingServerConnection.CipherDiscriminator - Interface in org.eclipse.jetty.server
 
NegotiatingServerConnectionFactory - Class in org.eclipse.jetty.server
 
NegotiatingServerConnectionFactory(String, String...) - Constructor for class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
Nested(Callback) - Constructor for class org.eclipse.jetty.util.Callback.Nested
 
Nested(Callback.Nested) - Constructor for class org.eclipse.jetty.util.Callback.Nested
 
NETWORK_AUTHENTICATION_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NETWORK_AUTHENTICATION_REQUIRED_511 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NetworkConnector - Interface in org.eclipse.jetty.server
A Connector for TCP/IP network connectors
networkFill(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
networkFlush(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
NetworkTrafficListener - Interface in org.eclipse.jetty.io
A listener for raw network traffic within Jetty.
NetworkTrafficServerConnector - Class in org.eclipse.jetty.server
A specialized version of ServerConnector that supports NetworkTrafficListeners.
NetworkTrafficServerConnector(Server) - Constructor for class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
NetworkTrafficServerConnector(Server, Executor, Scheduler, ByteBufferPool, int, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
NetworkTrafficServerConnector(Server, ConnectionFactory) - Constructor for class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
NetworkTrafficServerConnector(Server, ConnectionFactory, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
NetworkTrafficServerConnector(Server, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
NetworkTrafficSocketChannelEndPoint - Class in org.eclipse.jetty.io
A specialized version of SocketChannelEndPoint that supports NetworkTrafficListeners.
NetworkTrafficSocketChannelEndPoint(SocketChannel, ManagedSelector, SelectionKey, Scheduler, long, NetworkTrafficListener) - Constructor for class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
NEVER_EVICT - Static variable in interface org.eclipse.jetty.server.session.SessionCache
 
NEVER_INDEX - Static variable in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
newArray(int) - Method in class org.eclipse.jetty.util.ajax.JSON
Deprecated.
newArray(AsyncJSON.Context) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
When a JSON [ is encountered during parsing, this method is called to create a new List instance.
newAsyncJSON() - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
newAuthentication() - Method in interface org.eclipse.jetty.client.Socks5.Authentication.Factory
 
newAuthentication() - Method in class org.eclipse.jetty.client.Socks5.NoAuthenticationFactory
 
newAuthentication() - Method in class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
newBufferedInterceptor(HttpChannel, HttpOutput.Interceptor) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
newBufferedInterceptor(HttpChannel, HttpOutput.Interceptor) - Method in class org.eclipse.jetty.server.handler.FileBufferedResponseHandler
 
newByteBuffer(int, boolean) - Method in interface org.eclipse.jetty.io.ByteBufferPool
Creates a new ByteBuffer of the given capacity and the given directness.
newByteBuffer(int, boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
newChannelWithAddress(ClientConnector, SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector.Configurator
Creates a new SocketChannel to connect to a SocketAddress derived from the input socket address.
newChannelWithAddress(ClientConnector, SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
newClassPathResource(String) - Static method in class org.eclipse.jetty.util.resource.Resource
Find a classpath resource.
newClassPathResource(String, boolean, boolean) - Static method in class org.eclipse.jetty.util.resource.Resource
Find a classpath resource.
newClientConnectionFactory(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.HttpProxy
 
newClientConnectionFactory(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
newClientConnectionFactory(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.Socks4Proxy
 
newClientConnectionFactory(ClientConnectionFactory) - Method in class org.eclipse.jetty.client.Socks5Proxy
 
newClientConnector() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
newClientRequestContentTransformer(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newCondition() - Method in class org.eclipse.jetty.util.thread.AutoLock
 
newConfiguration(String) - Static method in class org.eclipse.jetty.webapp.Configurations
 
newConfigurations() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
newConnectAddress(String, int) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Creates the server address to connect to.
newConnection() - Method in class org.eclipse.jetty.util.resource.JarFileResource
 
newConnection() - Method in class org.eclipse.jetty.util.resource.JarResource
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method to create Connection.
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectManager
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
newConnection(HttpDestination, Promise<Connection>) - Method in class org.eclipse.jetty.client.HttpClient
 
newConnection(ClientConnector, SocketAddress, EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector.Configurator
 
newConnection(ClientConnector, SocketAddress, EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.alpn.client.ALPNClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.http.HttpClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.Socks4Proxy.Socks4ProxyClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.HTTP2ClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.HTTP3ClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.unixsocket.client.HttpClientTransportOverUnixSockets
Deprecated.
 
newConnection(QuicStreamEndPoint) - Method in class org.eclipse.jetty.quic.client.ClientQuicSession
 
newConnection(QuicStreamEndPoint) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
newConnection(QuicStreamEndPoint) - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.http3.server.AbstractHTTP3ServerConnectionFactory
 
newConnection(Connector, EndPoint) - Method in interface org.eclipse.jetty.server.ConnectionFactory
Creates a new Connection with the given parameters
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.server.DetectorConnectionFactory
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
newConnection(Connector, EndPoint) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
newConnection(Promise<Connection>) - Method in interface org.eclipse.jetty.client.api.Destination
Creates asynchronously a new, unpooled, Connection that will be returned at a later time through the given Promise.
newConnection(Promise<Connection>) - Method in class org.eclipse.jetty.client.HttpDestination
 
newConnectionPool(HttpClient) - Method in class org.eclipse.jetty.client.HttpDestination
 
newConnectionPool(HttpDestination) - Method in interface org.eclipse.jetty.client.ConnectionPool.Factory
Creates a new ConnectionPool for the given destination.
newContentDecoder() - Method in class org.eclipse.jetty.client.ContentDecoder.Factory
Factory method for ContentDecoders
newContentDecoder() - Method in class org.eclipse.jetty.client.GZIPContentDecoder.Factory
 
newDecryptedEndPoint() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
newDefaultEndpointConfig(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientFrameHandlerFactory
 
newDefaultEndpointConfig(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
newDownstreamConnection(EndPoint, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.ClientConnector
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method to create EndPoint.
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.proxy.ConnectHandler.ConnectManager
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
newEndPoint(SocketChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
newEndPoint(SocketChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.ServerConnector
 
newEndPoint(ClientConnector, SocketAddress, SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.ClientConnector.Configurator
 
newEndPoint(ClientConnector, SocketAddress, SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
newEntry(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
newEntry(String, boolean) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
newExchangeQueue(HttpClient) - Method in class org.eclipse.jetty.client.HttpDestination
 
newFilterChain(FilterHolder, FilterChain) - Method in class org.eclipse.jetty.servlet.ServletHandler
Create a FilterChain that calls the passed filter with the passed chain
newFilterHolder(Source) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
newFlowControlStrategy() - Method in interface org.eclipse.jetty.http2.FlowControlStrategy.Factory
 
newFrame(byte, byte[], ByteBuffer, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.Parser
 
newFrameHandler(Object, ServerUpgradeRequest, ServerUpgradeResponse) - Method in interface org.eclipse.jetty.websocket.core.server.FrameHandlerFactory
Create a FrameHandler from the provided websocketPojo.
newFrameHandler(Object, ServerUpgradeRequest, ServerUpgradeResponse) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerFrameHandlerFactory
 
newFrameHandler(Object, ServerUpgradeRequest, ServerUpgradeResponse) - Method in class org.eclipse.jetty.websocket.server.internal.JettyServerFrameHandlerFactory
 
newFrameHandler(Object, UpgradeRequest) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
newHandlers(Handler[]) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
newHandlers(Handler[]) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
newHttpChannel() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
newHttpChannel() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
newHttpChannel() - Method in class org.eclipse.jetty.server.HttpConnection
 
newHttpChannel(Request) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
newHttpClient() - Method in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
newHttpClient() - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
The servlet init parameter 'selectors' can be set for the number of selector threads to be used by the HttpClient.
newHttpClient() - Method in interface org.eclipse.jetty.websocket.core.client.internal.HttpClientProvider
 
newHttpClient() - Method in class org.eclipse.jetty.websocket.core.client.internal.XmlHttpClientProvider
 
newHttpClient(ClientConnector) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
newHttpConnection(HttpDestination, Session) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
newHttpConnection(HttpDestination, HTTP3SessionClient) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
newHttpConnection(EndPoint, HttpDestination, Promise<Connection>) - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
newHttpDestination(Origin) - Method in class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
newHttpDestination(Origin) - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
newHttpDestination(Origin) - Method in interface org.eclipse.jetty.client.HttpClientTransport
Creates a new, transport-specific, HttpDestination object.
newHttpDestination(Origin) - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
newHttpDestination(Origin) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
newHttpDestination(Origin) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
newHttpDestination(Origin) - Method in class org.eclipse.jetty.unixsocket.client.HttpClientTransportOverUnixSockets
Deprecated.
 
newHttpGenerator() - Method in class org.eclipse.jetty.server.HttpConnection
 
newHttpOutput() - Method in class org.eclipse.jetty.server.HttpChannel
 
newHttpParser(HttpCompliance) - Method in class org.eclipse.jetty.server.HttpConnection
 
newHttpReceiver() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
newHttpRequest(HttpConversation, URI) - Method in class org.eclipse.jetty.client.HttpClient
 
newHttpSender() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
newHttpSession(HttpServletRequest) - Method in class org.eclipse.jetty.server.session.SessionHandler
Creates a new HttpSession.
newHttpUpgrader(HttpVersion) - Method in interface org.eclipse.jetty.client.HttpUpgrader.Factory
 
newHttpUpgrader(HttpVersion) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
newInputStream() - Method in interface org.eclipse.jetty.server.resource.InputStreamRangeWriter.InputStreamSupplier
 
newInstance() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
newInstance() - Static method in interface org.eclipse.jetty.websocket.core.server.Handshaker
 
newInstance(ExtensionConfig, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
newInvalidJSON(ByteBuffer, String) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
 
newJakartaWebSocketFrameHandler(Object, UpgradeRequest) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
newJarResource(Resource) - Static method in class org.eclipse.jetty.util.resource.JarResource
 
newJettyFrameHandler(Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerFactory
 
newListenerHolder(Source) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
newMap() - Method in class org.eclipse.jetty.util.ajax.JSON
Factory method that creates a Map when a JSON representation of {...} is parsed.
newMessageOutputStream() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
newMessageWriter() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
newNamingContext(Object, ClassLoader, Hashtable, Name, Context) - Method in class org.eclipse.jetty.jndi.ContextFactory
Create a new NamingContext.
newNegotiatedConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
newNegotiation(HttpServletRequest, HttpServletResponse, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
newNegotiation(HttpServletRequest, HttpServletResponse, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
newNegotiation(HttpServletRequest, HttpServletResponse, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
newNonce(Request) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
newObject(AsyncJSON.Context) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
When a JSON { is encountered during parsing, this method is called to create a new Map instance.
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
newOrigin(HttpRequest) - Method in interface org.eclipse.jetty.client.HttpClientTransport
Creates a new Origin with the given request.
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.fcgi.client.http.HttpClientTransportOverFCGI
 
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
newOrigin(HttpRequest) - Method in class org.eclipse.jetty.unixsocket.client.HttpClientTransportOverUnixSockets
Deprecated.
 
newParser(boolean) - Static method in class org.eclipse.jetty.webapp.WebDescriptor
Create a new parser for parsing web descriptors.
newParser(CookieParser.Handler, CookieCompliance, ComplianceViolation.Listener) - Static method in interface org.eclipse.jetty.http.CookieParser
A factory method to create a new parser suitable for the compliance mode.
newPassword(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Creates a new Password object.
newPKIXBuilderParameters(KeyStore, Collection<? extends CRL>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
newPooled() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
newPooled() - Method in class org.eclipse.jetty.util.compression.DeflaterPool
 
newPooled() - Method in class org.eclipse.jetty.util.compression.InflaterPool
 
newProtocolSession(QuicSession, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3.HTTP3
 
newProtocolSession(QuicSession, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.http.HttpClientTransportOverHTTP3
 
newProtocolSession(QuicSession, Map<String, Object>) - Method in class org.eclipse.jetty.http3.client.HTTP3ClientConnectionFactory
 
newProtocolSession(QuicSession, Map<String, Object>) - Method in class org.eclipse.jetty.http3.server.AbstractHTTP3ServerConnectionFactory
 
newProtocolSession(QuicSession, Map<String, Object>) - Method in interface org.eclipse.jetty.quic.common.ProtocolSession.Factory
 
newProxyProtocolConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory
 
newProxyProtocolConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1
 
newProxyProtocolConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2
 
newProxyReadListener(HttpServletRequest, HttpServletResponse, Request, AsyncRequestContent) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newProxyRequest(HttpServletRequest, String) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
newProxyRequestContent(HttpServletRequest, HttpServletResponse, Request) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newProxyResponseListener(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
newProxyResponseListener(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newProxyResponseListener(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.ProxyServlet
 
newProxyWriteListener(HttpServletRequest, Response) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newPushBuilder() - Method in class org.eclipse.jetty.server.Request
 
newRangeWriter(HttpContent) - Static method in class org.eclipse.jetty.server.resource.HttpContentRangeWriter
Obtain a new RangeWriter for the supplied HttpContent.
newRateControl(EndPoint) - Method in interface org.eclipse.jetty.http2.parser.RateControl.Factory
 
newRateControl(EndPoint) - Method in class org.eclipse.jetty.http2.parser.WindowRateControl.Factory
 
newReadListener(HttpServletRequest, HttpServletResponse, Request, AsyncRequestContent) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet
 
newRequest() - Static method in class org.eclipse.jetty.http.HttpTester
 
newRequest(String) - Method in class org.eclipse.jetty.client.HttpClient
Creates a new request with the specified absolute URI in string format.
newRequest(String, int) - Method in class org.eclipse.jetty.client.HttpClient
Creates a new request with the "http" scheme and the specified host and port
newRequest(URI) - Method in class org.eclipse.jetty.client.HttpClient
Creates a new request with the specified absolute URI.
newRequest(HeadersFrame, Stream.Client.Listener) - Method in interface org.eclipse.jetty.http3.api.Session.Client
Makes a request by creating a HTTP/3 stream and sending the given HEADERS frame.
newRequestHandler() - Method in class org.eclipse.jetty.server.HttpConnection
 
newResource(File) - Static method in class org.eclipse.jetty.util.resource.Resource
 
newResource(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Convert a URL or path to a Resource.
newResource(String) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a resource from a string.
newResource(String) - Method in interface org.eclipse.jetty.webapp.WebAppClassLoader.Context
Convert a URL or path to a Resource.
newResource(String, boolean) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a resource from a string.
newResource(URI) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Convert URL to Resource wrapper for Resource.newResource(URL) enables extensions to provide alternate resource implementations.
newResource(URI) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a resource from a uri.
newResource(URL) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Convert URL to Resource wrapper for Resource.newResource(URL) enables extensions to provide alternate resource implementations.
newResource(URL) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a resource from a url.
newResource(Path) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a Resource from provided path
newResponseMetaData() - Method in class org.eclipse.jetty.server.Response
 
newRetainableByteBufferPool(int, int, int, long, long) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
newRetainableByteBufferPool(int, int, int, long, long) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
newRetainableByteBufferPool(int, int, int, long, long) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
newRunAsToken(String) - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
newRunAsToken(String) - Method in interface org.eclipse.jetty.security.IdentityService
Create a new RunAsToken from a runAsName (normally a role).
newSAXParserFactory() - Method in class org.eclipse.jetty.xml.XmlParser
 
newSecurityHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
newSeekableByteChannel() - Method in interface org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter.ChannelSupplier
 
newSeekableByteChannel() - Method in class org.eclipse.jetty.util.resource.PathResource
 
newSelector() - Method in class org.eclipse.jetty.io.SelectorManager
 
newSelector() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
newSelector(int) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method for ManagedSelector.
newSelectorManager() - Method in class org.eclipse.jetty.io.ClientConnector
 
newSelectorManager() - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
newSelectorManager(Executor, Scheduler, int) - Method in class org.eclipse.jetty.server.ServerConnector
 
newSelectorManager(Executor, Scheduler, int) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
newServerConnection(Connector, EndPoint, SSLEngine, List<String>, String) - Method in class org.eclipse.jetty.alpn.server.ALPNServerConnectionFactory
 
newServerConnection(Connector, EndPoint, SSLEngine, List<String>, String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
newServerConnector(InetSocketAddress, int) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
newServerHttpChannelOverHTTP2(Connector, HttpConfiguration, HttpTransportOverHTTP2) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
newServerParser(Connector, RateControl) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
newServerResponseContentTransformer(HttpServletRequest, HttpServletResponse, Response) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
newServletHandler() - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
newServletHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
newServletHolder(Source) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntServletHandler
 
newServletHolder(Source) - Method in class org.eclipse.jetty.servlet.ServletHandler
Add a new servlet holder
newSession(HttpServletRequest, String, long, long) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
newSession(HttpServletRequest, String, long, long) - Method in interface org.eclipse.jetty.server.session.SessionCache
Create an entirely new Session.
newSession(HttpServletRequest, SessionData) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Create a new Session for a request.
newSession(HttpServletRequest, SessionData) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
newSession(HttpServletRequest, SessionData) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
newSession(SessionData) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Create a new Session object from pre-existing session data
newSession(SessionData) - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
newSession(SessionData) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
newSession(SessionData) - Method in interface org.eclipse.jetty.server.session.SessionCache
Re-materialize a Session that has previously existed.
newSessionCache(SessionHandler) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
newSessionCache(SessionHandler) - Method in class org.eclipse.jetty.server.session.DefaultSessionCacheFactory
 
newSessionCache(SessionHandler) - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
newSessionData(String, long, long, long, long) - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore
 
newSessionData(String, long, long, long, long) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
newSessionData(String, long, long, long, long) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
newSessionData(String, long, long, long, long) - Method in class org.eclipse.jetty.server.session.NullSessionDataStore
 
newSessionData(String, long, long, long, long) - Method in interface org.eclipse.jetty.server.session.SessionDataStore
Create a new SessionData
newSessionData(String, long, long, long, long) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
newSessionHandler() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
newSessionId(long) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
newSessionId(HttpServletRequest, long) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Create a new session id if necessary.
newSessionId(HttpServletRequest, long) - Method in interface org.eclipse.jetty.server.SessionIdManager
Create a new Session ID.
newSessionListener(Connector, EndPoint) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
newSessionListener(Connector, EndPoint) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory
 
newSessionListener(Connector, EndPoint) - Method in class org.eclipse.jetty.http2.server.RawHTTP2ServerConnectionFactory
 
newSettings() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
newSink(Frame) - Method in class org.eclipse.jetty.websocket.core.internal.messages.DispatchedMessageSink
 
newSink(Frame) - Method in class org.eclipse.jetty.websocket.core.internal.messages.InputStreamMessageSink
 
newSink(Frame) - Method in class org.eclipse.jetty.websocket.core.internal.messages.ReaderMessageSink
 
newSniX509ExtendedKeyManager(X509ExtendedKeyManager) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
newSslClientConnectionFactory(SslContextFactory.Client, ClientConnectionFactory) - Method in class org.eclipse.jetty.client.HttpClient
 
newSslClientConnectionFactory(SslContextFactory.Client, ClientConnectionFactory) - Method in class org.eclipse.jetty.client.HttpDestination
 
newSslConnection(ByteBufferPool, Executor, EndPoint, SSLEngine) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
newSslConnection(Connector, EndPoint, SSLEngine) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
newSslContextFactory() - Method in class org.eclipse.jetty.io.ClientConnector
 
newSslEngine(String, int, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ssl.SslClientConnectionFactory.SslEngineFactory
Creates a new SSLEngine instance for the given peer host and port, and with the given context to help the creation of the SSLEngine.
newSSLEngine() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Factory method for "scratch" SSLEngines, usually only used for retrieving configuration information such as the application buffer size or the list of protocols/ciphers.
newSSLEngine(String, int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
General purpose factory method for creating SSLEngines, although creation of SSLEngines on the server-side should prefer SslContextFactory.newSSLEngine(InetSocketAddress).
newSSLEngine(InetSocketAddress) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Server-side only factory method for creating SSLEngines.
newSslServerSocket(String, int, int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
newSslSocket() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
newStream(int, MetaData.Request, boolean) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
newStream(HeadersFrame, Stream.Listener) - Method in interface org.eclipse.jetty.http2.api.Session
Sends the given HEADERS frame to create a new Stream.
newStream(HeadersFrame, Promise<Stream>, Stream.Listener) - Method in interface org.eclipse.jetty.http2.api.Session
Sends the given HEADERS frame to create a new Stream.
newStream(HeadersFrame, Promise<Stream>, Stream.Listener) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
newStream(IStream.FrameList, Promise<Stream>, Stream.Listener) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
newStream(IStream.FrameList, Promise<Stream>, Stream.Listener) - Method in interface org.eclipse.jetty.http2.ISession
Sends the given list of frames to create a new Stream.
newStreamId(StreamType) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.AbstractRequestContent
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.ByteBufferRequestContent
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.BytesRequestContent
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.InputStreamRequestContent
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.MultiPartRequestContent
 
newSubscription(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
newSystemResource(String) - Static method in class org.eclipse.jetty.util.resource.Resource
Construct a system resource from a string.
newThread(Runnable) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
newThread(Runnable) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
newTldScanner(ServletContext, boolean, boolean, boolean) - Method in class org.eclipse.jetty.apache.jsp.JettyJasperInitializer
Make a TldScanner, and prefeed it the tlds that have already been discovered in jar files by the MetaInfConfiguration.
newUpgradeStream(HeadersFrame, Stream.Listener, Consumer<Throwable>) - Method in class org.eclipse.jetty.http2.HTTP2Session
Creates a new stream allocating a stream id if the given HEADERS frame does not have one.
newUpstreamConnection(EndPoint, ConnectHandler.ConnectContext) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
newURI(String, String, int, String, String) - Static method in class org.eclipse.jetty.util.URIUtil
Create a new URI from the arguments, handling IPv6 host encoding and default ports
newURIBuilder(String, String, int) - Static method in class org.eclipse.jetty.util.URIUtil
Create a new URI StringBuilder from the arguments, handling IPv6 host encoding and default ports
newUserIdentity(Subject, Principal, String[]) - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
newUserIdentity(Subject, Principal, String[]) - Method in interface org.eclipse.jetty.security.IdentityService
Create a new UserIdentity for use with this identity service.
newWebApp() - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
newWebSocketConnection(EndPoint, Executor, Scheduler, ByteBufferPool, RetainableByteBufferPool, WebSocketCoreSession) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
newWebSocketCoreSession(HttpServletRequest, FrameHandler, Negotiated, WebSocketComponents) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
newWriteListener(HttpServletRequest, Response) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet
 
next() - Method in class org.eclipse.jetty.jndi.BindingEnumeration
 
next() - Method in class org.eclipse.jetty.jndi.NameEnumeration
 
next() - Method in class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
next() - Method in interface org.eclipse.jetty.util.ajax.JSON.Source
 
next() - Method in class org.eclipse.jetty.util.ajax.JSON.StringSource
 
nextContent() - Method in interface org.eclipse.jetty.server.ContentProducer
Get the next content that can be read from or that describes the special condition that was reached (error, eof).
nextElement() - Method in class org.eclipse.jetty.jndi.BindingEnumeration
 
nextElement() - Method in class org.eclipse.jetty.jndi.NameEnumeration
 
nextHandle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ScopedHandler
 
nextIncomingFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
nextIncomingFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
nextOutgoingFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
nextOutgoingFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
nextProtocol(Connector, EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.server.DetectorConnectionFactory
Callback method called when detection was unsuccessful.
nextProtocol(Connector, EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.server.OptionalSslConnectionFactory
Deprecated.
Callback method invoked when the detected bytes are not TLS.
nextScope(String, Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.handler.ScopedHandler
Scope the handler
nextToken() - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
nextToken(String) - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
nioSelect(Selector, boolean) - Method in class org.eclipse.jetty.io.ManagedSelector
 
NO_ARGS - Static variable in class org.eclipse.jetty.util.TypeUtil
 
NO_CACHE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
NO_CLOSE - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1006 is a reserved value and MUST NOT be set as a status code in a Close control frame by an endpoint.
NO_CLOSE - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
NO_CLOSE_STATUS - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
NO_CODE - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1005 is a reserved value and MUST NOT be set as a status code in a Close control frame by an endpoint.
NO_CODE - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
NO_CODE_STATUS - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
NO_COLON_AFTER_FIELD_NAME - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Prior to RFC 7230, the HTTP protocol allowed a header line of a single token with neither a colon nor value following, to be interpreted as a field name with no value.
NO_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NO_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
 
NO_CONTENT_204 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NO_CONTENT_LENGTH - Static variable in class org.eclipse.jetty.server.Response
 
NO_CRLF_AFTER_PREAMBLE - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
NO_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates no errors.
NO_FOLLOW_LINKS - Static variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
NO_PROGRESS_LIMIT - Static variable in class org.eclipse.jetty.server.resource.InputStreamRangeWriter
 
NO_PROGRESS_LIMIT - Static variable in class org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter
 
NO_RATE_CONTROL - Static variable in interface org.eclipse.jetty.http2.parser.RateControl
 
NO_ROLES - Static variable in interface org.eclipse.jetty.security.IdentityService
 
NO_SECURITY - Static variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
NO_SESSIONS - Static variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
NO_TRY - Static variable in interface org.eclipse.jetty.util.thread.TryExecutor
 
NoAuthenticationFactory() - Constructor for class org.eclipse.jetty.client.Socks5.NoAuthenticationFactory
 
noCompression() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
noContent() - Method in class org.eclipse.jetty.fcgi.parser.ContentParser
Invoked by the Parser when the frame content length is zero.
noContent() - Method in class org.eclipse.jetty.fcgi.parser.ParamsContentParser
 
noContent() - Method in class org.eclipse.jetty.fcgi.parser.ResponseContentParser
 
noContent() - Method in class org.eclipse.jetty.fcgi.parser.StreamContentParser
 
Node - Class in org.eclipse.jetty.deploy.graph
Basic Graph Node
Node(String) - Constructor for class org.eclipse.jetty.deploy.graph.Node
 
nodes() - Method in class org.eclipse.jetty.deploy.graph.Path
 
NOIMPL - Static variable in class org.eclipse.jetty.util.Uptime
 
NoJspServlet - Class in org.eclipse.jetty.servlet
 
NoJspServlet() - Constructor for class org.eclipse.jetty.servlet.NoJspServlet
 
NON_AUTHORITATIVE_INFORMATION - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NON_AUTHORITATIVE_INFORMATION_203 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NON_BLOCKING - Enum constant in enum org.eclipse.jetty.util.thread.Invocable.InvocationType
Invoking the Invocable does not block the invoker thread, and the invocation may be performed immediately in the invoker thread.
NON_DOMAIN_SNI_PROVIDER - Static variable in interface org.eclipse.jetty.util.ssl.SslContextFactory.Client.SniProvider
An SNI provider that, if the given serverNames list is empty, retrieves the host via SSLEngine.getPeerHost(), converts it to ASCII bytes, and sends it as SNI.
NON_FRAG_RESOURCE - Static variable in class org.eclipse.jetty.webapp.MetaData
 
None - Enum constant in enum org.eclipse.jetty.security.UserDataConstraint
 
None - Enum constant in enum org.eclipse.jetty.webapp.FragmentDescriptor.OtherType
 
NONE - Enum constant in enum org.eclipse.jetty.http.HttpCookie.SameSite
 
NONE - Enum constant in enum org.eclipse.jetty.server.Response.OutputType
 
NONE - Static variable in class org.eclipse.jetty.http.CompressedContentFormat
 
NONE - Static variable in interface org.eclipse.jetty.http2.Flags
 
NONE - Static variable in class org.eclipse.jetty.util.security.Constraint
 
nonNull(String) - Static method in class org.eclipse.jetty.util.StringUtil
Return a non null string.
NOOP - Static variable in class org.eclipse.jetty.server.HttpChannelListeners
 
NOOP - Static variable in interface org.eclipse.jetty.util.Callback
Instance of Adapter that can be used when the callback methods need an empty implementation without incurring in the cost of allocating a new Adapter object.
NOOP - Static variable in interface org.eclipse.jetty.websocket.api.WriteCallback
 
NOOP_LISTENER - Static variable in class org.eclipse.jetty.server.HttpChannel
 
NoOpGenerator - Class in org.eclipse.jetty.http2.generator
 
NoOpGenerator() - Constructor for class org.eclipse.jetty.http2.generator.NoOpGenerator
 
NORMAL - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1000 indicates a normal closure, meaning that the purpose for which the connection was established has been fulfilled.
NORMAL - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
NORMAL_STATUS - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
normalize() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
normalize(Object) - Method in class org.eclipse.jetty.quickstart.AttributeNormalizer
Normalize a URI, URL, or File reference by replacing known attributes with ${key} attributes.
normalize(String) - Static method in class org.eclipse.jetty.annotations.AnnotationParser
Convert internal name to simple name
normalize(String) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
If a servlet or filter path mapping isn't a suffix mapping, ensure it starts with '/'
normalize(String[]) - Static method in class org.eclipse.jetty.annotations.AnnotationParser
Convert internal names to simple names.
normalizeCharset(String) - Static method in class org.eclipse.jetty.util.StringUtil
Convert alternate charset names (eg utf8) to normalized name (eg UTF-8).
normalizeCharset(String, int, int) - Static method in class org.eclipse.jetty.util.StringUtil
Convert alternate charset names (eg utf8) to normalized name (eg UTF-8).
normalizeHost(String) - Method in class org.eclipse.jetty.client.HttpClient
Deprecated.
no replacement, do not use it
normalizeHost(String) - Static method in class org.eclipse.jetty.util.HostPort
Normalizes IPv6 address as per RFC 2732 and RFC 6874, surrounding with square brackets if they are absent.
normalizeModuleName(String) - Static method in class org.eclipse.jetty.start.Module
 
normalizePath(Path) - Method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
normalizePort(int) - Method in enum org.eclipse.jetty.http.HttpScheme
 
normalizePort(String, int) - Static method in class org.eclipse.jetty.client.HttpClient
 
normalizePort(String, int) - Static method in enum org.eclipse.jetty.http.HttpScheme
 
normalizeRequest(HttpRequest) - Method in class org.eclipse.jetty.client.HttpConnection
 
normalizeRequest(HttpRequest) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
normalizeUri(URI) - Method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
normalizeURI(String) - Static method in class org.eclipse.jetty.xml.XmlConfiguration
 
NoSqlSessionData(String, String, String, long, long, long, long) - Constructor for class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
NoSqlSessionDataStore - Class in org.eclipse.jetty.nosql
NoSqlSessionDataStore
NoSqlSessionDataStore() - Constructor for class org.eclipse.jetty.nosql.NoSqlSessionDataStore
 
NoSqlSessionDataStore.NoSqlSessionData - Class in org.eclipse.jetty.nosql
 
NOT_ACCEPTABLE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NOT_ACCEPTABLE_406 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NOT_CHECKED - Static variable in interface org.eclipse.jetty.server.Authentication
Authentication not checked
NOT_CLOSED - Enum constant in enum org.eclipse.jetty.http2.CloseState
Fully open.
NOT_EXTENDED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NOT_EXTENDED_510 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NOT_FOUND - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NOT_FOUND_404 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NOT_IMPLEMENTED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NOT_IMPLEMENTED_501 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NOT_MODIFIED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
NOT_MODIFIED_304 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
NOT_RECOGNIZED - Enum constant in enum org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting cannot work with the given bytes.
NotChecked() - Constructor for class org.eclipse.jetty.security.SecurityHandler.NotChecked
 
notComplete(SharedBlockingCallback.Blocker) - Method in class org.eclipse.jetty.util.SharedBlockingCallback
 
notFound(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.ResourceService
 
notFound(Request, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
notIdle() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
notIdle() - Method in interface org.eclipse.jetty.http2.IStream
Marks this stream as not idle so that the idle timeout is postponed.
notIdle() - Method in class org.eclipse.jetty.io.IdleTimeout
This method should be called when non-idle activity has taken place.
notifyBeforeContent(Response, ObjLongConsumer<Object>, List<Response.DemandedContentListener>) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyBegin(List<Response.ResponseListener>, Response) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyBegin(Request) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyCallbackFailure(Callback, Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
notifyCallbackSuccess(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
notifyClose(Session, GoAwayFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyCommit(Request) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyComplete(List<Response.ResponseListener>, Result) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.parser.Parser
 
notifyConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.parser.PrefaceParser
 
notifyContent(ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
 
notifyContent(Request, ByteBuffer) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyContent(Response, ObjLongConsumer<Object>, ByteBuffer, Callback, List<Response.DemandedContentListener>) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyData(DataFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyFailure(List<Response.ResponseListener>, Response, Throwable) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyFailure(Request, Throwable) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyFailure(Session, Throwable, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyGoAway(Session, GoAwayFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyGoAway(GoAwayFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyHeader(List<Response.ResponseListener>, Response, HttpField) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyHeaders(List<Response.ResponseListener>, Response) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifyHeaders(Request) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyHeaders(IStream, HeadersFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyIdleTimeout(Session) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyIncoming(ByteBuffer, int) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
notifyNewStream(Stream, HeadersFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyOutgoing(ByteBuffer) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
notifyPing(Session, PingFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyPing(PingFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyPriority(PriorityFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifyQueued(Request) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyReset(Session, ResetFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifyReset(ResetFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifySessionListeners(Consumer<WebSocketSessionListener>) - Method in interface org.eclipse.jetty.websocket.api.WebSocketContainer
Notify the Session Listeners of an event.
notifySessionListeners(Consumer<WebSocketSessionListener>) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
notifySessionListeners(Consumer<WebSocketSessionListener>) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
notifySessionListeners(Consumer<JakartaWebSocketSessionListener>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
Notify Session Listeners of events
notifySettings(Session, SettingsFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
notifySettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
notifySuccess(List<Response.ResponseListener>, Response) - Method in class org.eclipse.jetty.client.ResponseNotifier
 
notifySuccess(Request) - Method in class org.eclipse.jetty.client.RequestNotifier
 
notifyWindowUpdate(WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
NotRetainedByteBufferPool(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.RetainableByteBufferPool.NotRetainedByteBufferPool
 
NoTryExecutor(Executor) - Constructor for class org.eclipse.jetty.util.thread.TryExecutor.NoTryExecutor
 
NotSet - Enum constant in enum org.eclipse.jetty.webapp.MetaData.Complete
 
NotSet - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
NOTSET - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.ContextStatus
 
NotUtf8Exception(String) - Constructor for exception class org.eclipse.jetty.util.Utf8Appendable.NotUtf8Exception
 
now() - Method in class org.eclipse.jetty.util.DateCache
Deprecated.
now() - Static method in class org.eclipse.jetty.util.NanoTime
 
nudge() - Method in class org.eclipse.jetty.util.Scanner
Hint to the scanner to perform a scan cycle as soon as possible.
NULL_CONTEXT_PATH - Static variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore
Used for Oracle and other databases where "" is treated as NULL
NULL_VHOST - Static variable in class org.eclipse.jetty.server.session.SessionContext
 
NullAppendable - Class in org.eclipse.jetty.websocket.core.internal
 
NullAppendable() - Constructor for class org.eclipse.jetty.websocket.core.internal.NullAppendable
 
NullByteBufferPool - Class in org.eclipse.jetty.io
 
NullByteBufferPool() - Constructor for class org.eclipse.jetty.io.NullByteBufferPool
 
NullQueryManagerFactory - Class in org.eclipse.jetty.session.infinispan
NullQueryManagerFactory Trivial impl of the QueryManagerFactory that does not support doing queries.
NullQueryManagerFactory() - Constructor for class org.eclipse.jetty.session.infinispan.NullQueryManagerFactory
 
NullSessionCache - Class in org.eclipse.jetty.server.session
NullSessionCache Does not actually cache any Session objects.
NullSessionCache(SessionHandler) - Constructor for class org.eclipse.jetty.server.session.NullSessionCache
 
NullSessionCacheFactory - Class in org.eclipse.jetty.server.session
NullSessionCacheFactory Factory for NullSessionCaches.
NullSessionCacheFactory() - Constructor for class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
NullSessionDataStore - Class in org.eclipse.jetty.server.session
NullSessionDataStore Does not actually store anything, useful for testing.
NullSessionDataStore() - Constructor for class org.eclipse.jetty.server.session.NullSessionDataStore
 
NullSessionDataStoreFactory - Class in org.eclipse.jetty.server.session
NullSessionDataStoreFactory
NullSessionDataStoreFactory() - Constructor for class org.eclipse.jetty.server.session.NullSessionDataStoreFactory
 

O

obfuscate(String) - Static method in class org.eclipse.jetty.util.security.Password
 
ObjectCallback - Class in org.eclipse.jetty.jaas.callback
ObjectCallback
ObjectCallback() - Constructor for class org.eclipse.jetty.jaas.callback.ObjectCallback
 
objectInput - Variable in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
ObjectMBean - Class in org.eclipse.jetty.jmx
A dynamic MBean that can wrap an arbitrary Object instance.
ObjectMBean(Object) - Constructor for class org.eclipse.jetty.jmx.ObjectMBean
Creates a new ObjectMBean wrapping the given managedObject.
objectType - Variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
objectType - Variable in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
OCTETS - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
octetsNeeded(byte[]) - Static method in class org.eclipse.jetty.http.compression.HuffmanEncoder
 
octetsNeeded(int, long) - Static method in class org.eclipse.jetty.http.compression.NBitIntegerEncoder
 
octetsNeeded(int, String, boolean) - Static method in class org.eclipse.jetty.http.compression.NBitStringEncoder
 
octetsNeeded(String) - Static method in class org.eclipse.jetty.http.compression.HuffmanEncoder
 
octetsNeededLowerCase(String) - Static method in class org.eclipse.jetty.http.compression.HuffmanEncoder
 
of(Object) - Static method in enum org.eclipse.jetty.webapp.Origin
 
of(Map.Entry<PathSpec, E>, MatchedPath) - Static method in class org.eclipse.jetty.http.pathmap.MatchedResource
 
OFF - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
OFF - Enum constant in enum org.eclipse.jetty.websocket.api.BatchMode
Implementers must send frames to the network layer.
offer(E) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
offer(E, long, TimeUnit) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
offer(Runnable, boolean) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
offer(ByteBuffer) - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
offer(ByteBuffer) - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
Adds the given content buffer to this content provider and notifies the listener that content is available.
offer(ByteBuffer, Callback) - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
offer(ByteBuffer, Callback) - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
offer(ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyWriter
 
offer(Sweeper.Sweepable) - Method in class org.eclipse.jetty.util.thread.Sweeper
 
offerData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
offerFailure(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
offerTask(Runnable, boolean) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
OK - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
OK_200 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
omissionsExist(String, Map<String, RoleInfo>) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Check if any http method omissions exist in the list of method to auth info mappings.
ON - Enum constant in enum org.eclipse.jetty.websocket.api.BatchMode
Implementers must batch frames.
onAccept(Session) - Method in class org.eclipse.jetty.http2.api.server.ServerSessionListener.Adapter
 
onAccept(Session) - Method in interface org.eclipse.jetty.http2.api.server.ServerSessionListener
Callback method invoked when a connection has been accepted by the server.
onAccept(Session) - Method in interface org.eclipse.jetty.http3.api.Session.Server.Listener
Callback method invoked when a connection has been accepted by the server.
onAccepted(SelectableChannel) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called after the accepted channel has been allocated an EndPoint and associated Connection, and after the onOpen notifications have been called on both endPoint and connection.
onAccepted(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
onAccepted(SelectableChannel) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAcceptFailed(SelectableChannel, Throwable) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called if the processing of the accepted channel fails prior to calling SelectorManager.AcceptListener.onAccepted(SelectableChannel).
onAcceptFailed(SelectableChannel, Throwable) - Method in class org.eclipse.jetty.io.SelectorManager
 
onAcceptFailed(SelectableChannel, Throwable) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAccepting(SelectableChannel) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called immediately after a new SelectableChannel is accepted, but before it has been submitted to the SelectorManager.
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAfterDispatch(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked just after the application returns from the first invocation.
onAfterDispatch(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onAfterDispatch(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onAllDataRead() - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
onAllDataRead() - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
onBadMessage(BadMessageException) - Method in class org.eclipse.jetty.server.HttpChannel
 
onBeforeContent(Response, LongConsumer) - Method in interface org.eclipse.jetty.client.api.Response.DemandedContentListener
Callback method invoked before response content events.
onBeforeData(Stream) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked before notifying the first DATA frame.
onBeforeData(Stream) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onBeforeDispatch(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked just before calling the application.
onBeforeDispatch(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onBeforeDispatch(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onBegin(int, int, String) - Method in class org.eclipse.jetty.fcgi.parser.ClientParser.Listener.Adapter
 
onBegin(int, int, String) - Method in interface org.eclipse.jetty.fcgi.parser.ClientParser.Listener
 
onBegin(Request) - Method in interface org.eclipse.jetty.client.api.Request.BeginListener
Callback method invoked when the request begins being processed in order to be sent.
onBegin(Request) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onBegin(Response) - Method in interface org.eclipse.jetty.client.api.Response.BeginListener
Callback method invoked when the response line containing HTTP version, HTTP status code and reason has been received and parsed.
onBegin(Response) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onBegin(Response) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
onBegin(Response) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyResponseListener
 
onBinary(ByteBuffer, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Method called when a complete binary message is received.
onBinary(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onBinaryFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onClientRequestFailure(HttpServletRequest, Request, HttpServletResponse, Throwable) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
onClose() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
onClose() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onClose() - Method in class org.eclipse.jetty.io.FillInterest
 
onClose() - Method in class org.eclipse.jetty.io.IdleTimeout
 
onClose() - Method in class org.eclipse.jetty.io.WriteFlusher
 
onClose(long, String) - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
onClose(long, String) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
onClose(long, String) - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
onClose(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onClose(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onClose(Throwable) - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked when this connection is closed.
onClose(Throwable) - Method in interface org.eclipse.jetty.io.EndPoint
Callback method invoked when this EndPoint is closed.
onClose(Throwable) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onClose(Throwable) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
onClose(Throwable) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.server.HttpConnection
 
onClose(Throwable) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
onClose(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Physical connection disconnect.
onClose(Session, GoAwayFrame) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onClose(Session, GoAwayFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
 
onClose(Session, GoAwayFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a GOAWAY frame caused the session to be closed.
onClose(Session, GoAwayFrame, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onClose(HttpConnectionOverHTTP2, GoAwayFrame) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
onClose(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onClosed(Stream) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked after the stream has been closed.
onClosed(Connection) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
onClosed(Connection) - Method in class org.eclipse.jetty.io.Connection.Listener.Adapter
 
onClosed(Connection) - Method in interface org.eclipse.jetty.io.Connection.Listener
 
onClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onClosed(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
onClosed(Connection) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onClosed(Connection) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
onClosed(Connection) - Method in class org.eclipse.jetty.server.SocketCustomizationListener
 
onClosed(QuicSession) - Method in interface org.eclipse.jetty.quic.common.QuicSession.Listener
Callback method invoked when a QuicSession is closed.
onClosed(QuicSession) - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
onClosed(CloseStatus) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onClosed(CloseStatus, Callback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
onClosed(CloseStatus, Callback) - Method in interface org.eclipse.jetty.websocket.core.FrameHandler
This is the Close Handshake Complete event.
onClosed(CloseStatus, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onClosed(CloseStatus, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onCloseFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onCommit(Request) - Method in interface org.eclipse.jetty.client.api.Request.CommitListener
Callback method invoked when the request headers (and perhaps small content) have been sent.
onCommit(Request) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onComplete(AsyncEvent) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
onComplete(AsyncEvent) - Method in class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
onComplete(Response.CompleteListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onComplete(Response.CompleteListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onComplete(Result) - Method in interface org.eclipse.jetty.client.api.Response.CompleteListener
Callback method invoked when the request and the response have been processed, either successfully or not.
onComplete(Result) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onComplete(Result) - Method in class org.eclipse.jetty.client.ContinueProtocolHandler.ContinueListener
 
onComplete(Result) - Method in class org.eclipse.jetty.client.RedirectProtocolHandler
 
onComplete(Result) - Method in class org.eclipse.jetty.client.TimeoutCompleteListener
Deprecated.
 
onComplete(Result) - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
onComplete(Result) - Method in class org.eclipse.jetty.client.util.FutureResponseListener
 
onComplete(Result) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
 
onComplete(Result) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
onComplete(Result) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyResponseListener
 
onComplete(Result) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
onComplete(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the request and response processing are complete.
onComplete(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onComplete(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onCompleted() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
onCompleted() - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
onCompleted() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection.ServerHttpChannelOverHTTP2
 
onCompleted() - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
onCompleted() - Method in class org.eclipse.jetty.server.HttpChannel
 
onCompleted() - Method in class org.eclipse.jetty.server.HttpConnection
 
onCompleted() - Method in interface org.eclipse.jetty.server.HttpTransport
Called to indicated the end of the current request/response cycle (which may be some time after the last content is sent).
onCompleted() - Method in class org.eclipse.jetty.server.Request
Called when the request is fully finished being handled.
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.util.IteratingCallback
Invoked when the overall task has completed with a failure.
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.util.IteratingNestedCallback
 
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
 
onCompleteFailure(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
onCompleteSuccess() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
onCompleteSuccess() - Method in class org.eclipse.jetty.util.IteratingCallback
Invoked when the overall task has completed successfully.
onCompleteSuccess() - Method in class org.eclipse.jetty.util.IteratingNestedCallback
 
onComplianceViolation(ComplianceViolation.Mode, ComplianceViolation, String) - Method in interface org.eclipse.jetty.http.ComplianceViolation.Listener
 
onComplianceViolation(ComplianceViolation.Mode, ComplianceViolation, String) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
onConnected() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onConnectFailure(HttpServletRequest, HttpServletResponse, AsyncContext, Throwable) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
onConnectionClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onConnectionFailure(int, String) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onConnectionFailure(int, String) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onConnectionOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onConnectSuccess(ConnectHandler.ConnectContext, ConnectHandler.UpstreamConnection) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
onContent() - Method in interface org.eclipse.jetty.client.AsyncContentProvider.Listener
Deprecated.
Callback method invoked when content is available
onContent() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
onContent(int, FCGI.StreamType, ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
onContent(int, FCGI.StreamType, ByteBuffer) - Method in interface org.eclipse.jetty.fcgi.parser.Parser.Listener
 
onContent(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.ResponseContentParser
 
onContent(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.StreamContentParser
 
onContent(ByteBuffer, boolean, Callback) - Method in interface org.eclipse.jetty.client.api.Request.Content.Consumer
Callback method invoked by the producer when there is content available and there is demand for content.
onContent(Request, ByteBuffer) - Method in interface org.eclipse.jetty.client.api.Request.ContentListener
Callback method invoked when a chunk of request content has been sent successfully.
onContent(Request, ByteBuffer) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onContent(Response, ByteBuffer) - Method in interface org.eclipse.jetty.client.api.Response.ContentListener
Callback method invoked when the response content has been received, parsed and there is demand.
onContent(Response, ByteBuffer) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onContent(Response, ByteBuffer) - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
onContent(Response, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.client.api.Response.AsyncContentListener
Callback method invoked when the response content has been received, parsed and there is demand.
onContent(Response, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.client.api.Response.ContentListener
 
onContent(Response, ByteBuffer, Callback) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
 
onContent(Response, ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
onContent(Response, ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyResponseListener
 
onContent(Response, LongConsumer, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.client.api.Response.AsyncContentListener
 
onContent(Response, LongConsumer, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.client.api.Response.DemandedContentListener
Callback method invoked when the response content has been received.
onContent(HttpInput.Content) - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
onContent(HttpInput.Content) - Method in class org.eclipse.jetty.server.HttpChannel
 
onContentAdded() - Method in class org.eclipse.jetty.server.HttpChannelState
Called to indicate that some content was produced and is ready for consumption.
onContentComplete() - Method in class org.eclipse.jetty.server.HttpChannel
 
onContentProducible() - Method in interface org.eclipse.jetty.server.ContentProducer
Wake up the thread that is waiting for the next content.
onContentProducible() - Method in class org.eclipse.jetty.server.HttpInput
 
onContinuation(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onContinuationFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onContinue(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
onContinue(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
onContinue(HttpServletRequest, Request) - Method in class org.eclipse.jetty.proxy.ProxyServlet
 
onContinue(Request) - Method in class org.eclipse.jetty.client.ContinueProtocolHandler
 
onCreated(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
onData(Stream, DataFrame, Callback) - Method in class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
onData(Stream, DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a DATA frame has been received.
onData(DataFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onData(DataFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onData(DataFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onData(DataFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onData(DataFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.client.http.ClientHTTP2StreamEndPoint
 
onData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
onData(DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Client
 
onData(DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Server
 
onData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onData(DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.ISession
Callback method invoked when a DATA frame is received.
onData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onData(DataFrame, Callback) - Method in class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
onData(IStream, DataFrame, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onDataAvailable() - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
onDataAvailable() - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
onDataAvailable(Stream.Client) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked if the application has expressed demand for content, and if there may be content available.
onDataAvailable(Stream.Server) - Method in interface org.eclipse.jetty.http3.api.Stream.Server.Listener
Callback method invoked if the application has expressed demand for content, and if there may be content available.
onDataConsumed(ISession, IStream, int) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
onDataConsumed(ISession, IStream, int) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onDataConsumed(ISession, IStream, int) - Method in class org.eclipse.jetty.http2.SimpleFlowControlStrategy
 
onDataDemanded(Stream, DataFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a DATA frame has been demanded.
onDataDemanded(Stream, DataFrame, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onDataReceived(ISession, IStream, int) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onDataReceived(ISession, IStream, int) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onDataSending(IStream, int) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onDataSending(IStream, int) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onDataSent(IStream, int) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onDataSent(IStream, int) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onDisconnect(Session, long, String) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked when the underlying transport has been disconnected.
onDispatchFailure(Request, Throwable) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the application threw an exception.
onDispatchFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onDispatchFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onEnd(int) - Method in class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
onEnd(int) - Method in interface org.eclipse.jetty.fcgi.parser.Parser.Listener
 
onEndPointClosed(EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnector
 
onEndPointOpened(EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnector
 
onEof() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
onEof() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onError(AsyncEvent) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
onError(AsyncEvent) - Method in class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
onError(Runnable, Throwable) - Method in class org.eclipse.jetty.util.thread.SerializedExecutor
 
onError(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
onError(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyWriter
 
onError(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
onError(Throwable) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamWriter
 
onError(Throwable) - Method in class org.eclipse.jetty.server.HttpChannelState
 
onError(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
If no error is set in the CloseStatus this will either, replace the current close status with a CloseStatus.SERVER_ERROR status if we had a NORMAL close code, or, it will set the cause of the CloseStatus if the previous cause was null, this allows onError to be notified after the connection is closed.
onError(Throwable, Callback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
onError(Throwable, Callback) - Method in interface org.eclipse.jetty.websocket.core.FrameHandler
An error has occurred or been detected in websocket-core and being reported to FrameHandler.
onError(Throwable, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onError(Throwable, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onError(HttpField, Throwable) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
onEvent(Object) - Method in interface org.eclipse.jetty.http2.parser.RateControl
Applications should call this method when they want to signal an event that is subject to rate control.
onEvent(Object) - Method in class org.eclipse.jetty.http2.parser.WindowRateControl
 
onExpired(T) - Method in class org.eclipse.jetty.io.CyclicTimeouts
Invoked during the iteration when the given entity is expired.
onFail(Throwable) - Method in class org.eclipse.jetty.io.FillInterest
Call to signal a failure to a registered interest
onFail(Throwable) - Method in class org.eclipse.jetty.io.WriteFlusher
Notify the flusher of a failure
onFailure(int, Throwable) - Method in class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
onFailure(int, Throwable) - Method in interface org.eclipse.jetty.fcgi.parser.Parser.Listener
 
onFailure(long, String, Throwable) - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
onFailure(long, String, Throwable) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
onFailure(long, String, Throwable) - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
onFailure(Throwable) - Method in interface org.eclipse.jetty.client.api.Request.Content.Consumer
Callback method invoked by the producer when it failed to produce content.
onFailure(Throwable) - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
onFailure(Throwable) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
onFailure(Throwable) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
onFailure(Throwable, Callback) - Method in class org.eclipse.jetty.http2.client.http.ClientHTTP2StreamEndPoint
 
onFailure(Throwable, Callback) - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
onFailure(Throwable, Callback) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Client
 
onFailure(Throwable, Callback) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Server
 
onFailure(Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onFailure(Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
onFailure(Request, Throwable) - Method in interface org.eclipse.jetty.client.api.Request.FailureListener
Callback method invoked when the request has failed to be sent
onFailure(Request, Throwable) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onFailure(Response, Throwable) - Method in interface org.eclipse.jetty.client.api.Response.FailureListener
Callback method invoked when the response has failed in the process of being received
onFailure(Response, Throwable) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onFailure(Response, Throwable) - Method in class org.eclipse.jetty.client.ContinueProtocolHandler.ContinueListener
 
onFailure(Response, Throwable) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
 
onFailure(Session, Throwable) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onFailure(Session, Throwable) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
 
onFailure(Session, Throwable, Callback) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a failure has been detected for this session.
onFailure(Session, Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onFailure(Stream, int, String, Throwable, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when the stream failed.
onFailure(Stream, int, String, Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onFailure(Session, long, String, Throwable) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked when a failure has been detected for this session.
onFailure(Stream.Client, long, Throwable) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked when a stream failure occurred.
onFailure(Stream.Server, long, Throwable) - Method in interface org.eclipse.jetty.http3.api.Stream.Server.Listener
Callback method invoked when a stream failure occurred.
onFillable() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
onFillable() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
onFillable() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
onFillable() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
onFillable() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onFillable() - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint is ready to be read.
onFillable() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
onFillable() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
onFillable() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onFillable() - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
onFillable() - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
onFillable() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
onFillable() - Method in class org.eclipse.jetty.server.HttpConnection
 
onFillable() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
onFillable() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
onFillableFail(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
onFillInterestedFailed(Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint failed to be ready to be read.
onFillInterestedFailed(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onFillInterestedFailed(Throwable) - Method in class org.eclipse.jetty.server.HttpConnection
 
onFlushed(long) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onFlushed(long) - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
onFlushed(long) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onFlushed(long) - Method in interface org.eclipse.jetty.http2.ISession
Callback method invoked when bytes are flushed to the network.
onFlushed(long) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onFlushed(long) - Method in interface org.eclipse.jetty.io.WriteFlusher.Listener
Invoked when a WriteFlusher flushed bytes in a non-blocking way, as part of a - possibly larger - write.
onFlushed(long) - Method in class org.eclipse.jetty.server.HttpConnection
 
onFlushed(long) - Method in class org.eclipse.jetty.server.HttpOutput
Invoked when bytes have been flushed to the network.
onFrame(Frame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onFrame(Frame) - Method in interface org.eclipse.jetty.http2.ISession
Callback method invoked during an HTTP/1.1 to HTTP/2 upgrade requests to process the given synthetic frame.
onFrame(Frame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
onFrame(Frame, Callback) - Method in interface org.eclipse.jetty.websocket.core.FrameHandler
Receiver of all Frames.
onFrame(Frame, Callback) - Method in interface org.eclipse.jetty.websocket.core.IncomingFrames
Process the incoming frame.
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
Used to supply the flusher with a new frame.
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.FrameCaptureExtension
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
onFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentingFlusher
 
onFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
Called when a frame is ready to be transformed.
onFrame(Parser.ParsedFrame) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
onGoAway(Session, GoAwayFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a GOAWAY frame has been received.
onGoAway(GoAwayFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onGoAway(GoAwayFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
This method is called when receiving a GO_AWAY from the other peer.
onGoAway(GoAwayFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onGoAway(GoAwayFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onGoAway(GoAwayFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onGoAway(Session, GoAwayFrame) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked when a GOAWAY frame has been received.
onHandshakeRequest(HttpRequest) - Method in interface org.eclipse.jetty.websocket.client.JettyUpgradeListener
Event that triggers before the Handshake request is sent.
onHandshakeRequest(HttpRequest) - Method in interface org.eclipse.jetty.websocket.core.client.UpgradeListener
Event that triggers before the Handshake request is sent.
onHandshakeRequest(HttpRequest) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JsrUpgradeListener
 
onHandshakeResponse(HttpRequest, HttpResponse) - Method in interface org.eclipse.jetty.websocket.client.JettyUpgradeListener
Event that triggers after the Handshake response has been received.
onHandshakeResponse(HttpRequest, HttpResponse) - Method in interface org.eclipse.jetty.websocket.core.client.UpgradeListener
Event that triggers after the Handshake response has been received.
onHandshakeResponse(HttpRequest, HttpResponse) - Method in class org.eclipse.jetty.websocket.jakarta.client.internal.JsrUpgradeListener
 
onHeader(int, HttpField) - Method in class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
onHeader(int, HttpField) - Method in interface org.eclipse.jetty.fcgi.parser.Parser.Listener
 
onHeader(Response, HttpField) - Method in interface org.eclipse.jetty.client.api.Response.HeaderListener
Callback method invoked when a response header has been received and parsed, returning whether the header should be processed or not.
onHeader(Response, HttpField) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onHeader(Response, HttpField) - Method in class org.eclipse.jetty.client.RedirectProtocolHandler
 
onHeaders(int) - Method in class org.eclipse.jetty.fcgi.parser.Parser.Listener.Adapter
 
onHeaders(int) - Method in interface org.eclipse.jetty.fcgi.parser.Parser.Listener
 
onHeaders(Request) - Method in interface org.eclipse.jetty.client.api.Request.HeadersListener
Callback method invoked when the request headers (and perhaps small content) are ready to be sent.
onHeaders(Request) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onHeaders(Response) - Method in interface org.eclipse.jetty.client.api.Response.HeadersListener
Callback method invoked when all the response headers have been received and parsed.
onHeaders(Response) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onHeaders(Response) - Method in class org.eclipse.jetty.client.util.BufferingResponseListener
 
onHeaders(Response) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
 
onHeaders(Response) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
onHeaders(Response) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyResponseListener
 
onHeaders(Stream, HeadersFrame) - Method in class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
onHeaders(Stream, HeadersFrame) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a HEADERS frame representing the HTTP response has been received.
onHeaders(Stream, HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.client.HTTP2ClientSession
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onHeaders(HeadersFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onHeaders(HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
onIdleExpired() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
onIdleExpired() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
onIdleExpired() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onIdleExpired() - Method in class org.eclipse.jetty.io.AbstractConnection
 
onIdleExpired() - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked upon an idle timeout event.
onIdleExpired() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onIdleExpired() - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
onIdleExpired() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
onIdleExpired() - Method in class org.eclipse.jetty.quic.server.ServerQuicConnection
 
onIdleExpired() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.IdleTimeout
This abstract method is called when the idle timeout has expired.
onIdleTimeout() - Method in class org.eclipse.jetty.http2.HTTP2Session
This method is invoked when the idle timeout expires.
onIdleTimeout() - Method in interface org.eclipse.jetty.http2.ISession
Callback invoked when the idle timeout expires.
onIdleTimeout() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
onIdleTimeout() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
onIdleTimeout(long) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
onIdleTimeout(long, Throwable) - Method in class org.eclipse.jetty.client.HttpConnection
 
onIdleTimeout(long, Throwable) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
onIdleTimeout(Throwable) - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
onIdleTimeout(Session) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onIdleTimeout(Session) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when the idle timeout expired.
onIdleTimeout(Session) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onIdleTimeout(Stream, Throwable) - Method in class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
onIdleTimeout(Stream, Throwable) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when the stream exceeds its idle timeout.
onIdleTimeout(Stream, Throwable) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onIdleTimeout(Session) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked when the idle timeout has expired.
onIdleTimeout(Stream.Client, Throwable) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked when the stream idle timeout elapses.
onIdleTimeout(Stream.Server, Throwable) - Method in interface org.eclipse.jetty.http3.api.Stream.Server.Listener
Callback method invoked when the stream idle timeout elapses.
onIncomingFrame(Frame) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.WriteFlusher
Abstract call to be implemented by specific WriteFlushers.
onIncompleteFlush() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
onInstructions(List<Instruction>) - Method in interface org.eclipse.jetty.http3.qpack.Instruction.Handler
 
onJakartaWebSocketSessionClosed(JakartaWebSocketSession) - Method in interface org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSessionListener
 
onJakartaWebSocketSessionClosed(JakartaWebSocketSession) - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
onJakartaWebSocketSessionCreated(JakartaWebSocketSession) - Method in interface org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSessionListener
 
onJakartaWebSocketSessionOpened(JakartaWebSocketSession) - Method in interface org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSessionListener
 
onJakartaWebSocketSessionOpened(JakartaWebSocketSession) - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
onMessage(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedTextMessageSink
 
onMetaData(long, MetaData, boolean) - Method in interface org.eclipse.jetty.http3.qpack.QpackDecoder.Handler
 
onNewStream(Stream) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a stream is created locally by Session.newStream(HeadersFrame, Promise, Listener).
onNewStream(Stream, HeadersFrame) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onNewStream(Stream, HeadersFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a new stream is being created upon receiving a HEADERS frame representing an HTTP request.
onNewStream(Stream, HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onNewStream(Stream.Client) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked when a stream is created locally by Session.Client.newRequest(HeadersFrame, Listener).
onNewStream(Connector, IStream, HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onOpen() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
onOpen() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
onOpen() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
onOpen() - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
onOpen() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onOpen() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
onOpen() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onOpen() - Method in class org.eclipse.jetty.io.AbstractConnection
 
onOpen() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onOpen() - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked when this connection is opened.
onOpen() - Method in interface org.eclipse.jetty.io.EndPoint
Callback method invoked when this EndPoint is opened.
onOpen() - Method in class org.eclipse.jetty.io.IdleTimeout
 
onOpen() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
onOpen() - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
onOpen() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onOpen() - Method in class org.eclipse.jetty.proxy.ConnectHandler.DownstreamConnection
 
onOpen() - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
onOpen() - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
onOpen() - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
onOpen() - Method in class org.eclipse.jetty.quic.server.ServerQuicConnection
 
onOpen() - Method in class org.eclipse.jetty.server.HttpConnection
 
onOpen() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
onOpen() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
onOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Physical connection Open.
onOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Open/Activate the session.
onOpen() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onOpen(CoreSession, Callback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
onOpen(CoreSession, Callback) - Method in interface org.eclipse.jetty.websocket.core.FrameHandler
Async notification that Connection is being opened.
onOpen(CoreSession, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onOpen(CoreSession, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onOpened(Connection) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
onOpened(Connection) - Method in class org.eclipse.jetty.io.Connection.Listener.Adapter
 
onOpened(Connection) - Method in interface org.eclipse.jetty.io.Connection.Listener
 
onOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onOpened(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
onOpened(Connection) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onOpened(Connection) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
onOpened(Connection) - Method in class org.eclipse.jetty.server.SocketCustomizationListener
 
onOpened(QuicSession) - Method in interface org.eclipse.jetty.quic.common.QuicSession.Listener
Callback method invoked when a QuicSession is opened.
onOpened(QuicSession) - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
onOutgoingFrame(Frame) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
onParam(String, String) - Method in class org.eclipse.jetty.fcgi.parser.ParamsContentParser
 
onParams() - Method in class org.eclipse.jetty.fcgi.parser.ParamsContentParser
 
onPathWatchEvent(PathWatcher.PathWatchEvent) - Method in class org.eclipse.jetty.security.PropertyUserStore
 
onPathWatchEvent(PathWatcher.PathWatchEvent) - Method in interface org.eclipse.jetty.util.PathWatcher.Listener
 
onPathWatchEvents(List<PathWatcher.PathWatchEvent>) - Method in interface org.eclipse.jetty.util.PathWatcher.EventListListener
 
onPing(Session, PingFrame) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onPing(Session, PingFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a PING frame has been received.
onPing(PingFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onPing(PingFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onPing(PingFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onPing(PingFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onPing(PingFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onPing(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onPingFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onPong(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onPongFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onPreface() - Method in class org.eclipse.jetty.http2.parser.ServerParser.Listener.Adapter
 
onPreface() - Method in interface org.eclipse.jetty.http2.parser.ServerParser.Listener
 
onPreface() - Method in class org.eclipse.jetty.http2.parser.ServerParser.Listener.Wrapper
 
onPreface() - Method in class org.eclipse.jetty.http2.parser.ServerParser
 
onPreface() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onPreface() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
onPreface(Session) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onPreface(Session) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked:
onPreface(Session) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onPreface(Session) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked just before the initial SETTINGS frame is sent to the remote peer, to gather the configuration settings that the local peer wants to send to the remote peer.
onPriority(PriorityFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onPriority(PriorityFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onPriority(PriorityFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onPriority(PriorityFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onPriority(PriorityFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onProxyResponseFailure(HttpServletRequest, HttpServletResponse, Response, Throwable) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
onProxyResponseSuccess(HttpServletRequest, HttpServletResponse, Response) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
onProxyRewriteFailed(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
Callback method invoked when the URI rewrite performed in AbstractProxyServlet.rewriteTarget(HttpServletRequest) returns null indicating that no rewrite can be performed.
onPush(Stream, PushPromiseFrame) - Method in class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
onPush(Stream, PushPromiseFrame) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a PUSH_PROMISE frame has been received.
onPush(Stream, PushPromiseFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.client.HTTP2ClientSession
 
onPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onPushPromise(PushPromiseFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onPushPromise(PushPromiseFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
onPushRequest(MetaData.Request) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onQueued(Request) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onQueued(Request) - Method in interface org.eclipse.jetty.client.api.Request.QueuedListener
Callback method invoked when the request is queued, waiting to be sent
onRead(byte[], int, int) - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
Callback method invoked just after having read from the stream, but before returning the iteration element (a ByteBuffer to the caller.
onRead(byte[], int, int) - Method in class org.eclipse.jetty.client.util.InputStreamRequestContent
 
onRead(byte[], int, int) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyInputStreamRequestContent
 
onReadable() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
onReadable(long) - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
onReadable(long) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
onReadable(long) - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
onReadEof() - Method in class org.eclipse.jetty.server.HttpChannelState
 
onReadFailure(Throwable) - Method in class org.eclipse.jetty.client.util.InputStreamContentProvider
Deprecated.
Callback method invoked when an exception is thrown while reading from the stream.
onReadFailure(Throwable) - Method in class org.eclipse.jetty.client.util.InputStreamRequestContent
 
onReadFailure(Throwable) - Method in class org.eclipse.jetty.proxy.ProxyServlet.ProxyInputStreamRequestContent
 
onReadIdle() - Method in class org.eclipse.jetty.server.HttpChannelState
Called to indicate that the content is being consumed.
onReadReady() - Method in class org.eclipse.jetty.server.HttpChannelState
Called to signal that the channel is ready for a callback.
onReadTimeout(Throwable) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
onReadTimeout(Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint failed to be ready to be read after a timeout
onReadTimeout(Throwable) - Method in class org.eclipse.jetty.server.HttpConnection
 
onReadTimeout(Throwable) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Event for no activity on connection (read or write)
onReadUnready() - Method in class org.eclipse.jetty.server.HttpChannelState
Called to indicate that no content is currently available, more content has been demanded and may be available, but that a handling thread may need to produce (fill/parse) it.
onRequest() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
onRequest(MetaData.Request) - Method in class org.eclipse.jetty.server.HttpChannel
 
onRequest(HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onRequest(Stream.Server, HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Session.Server.Listener
Callback method invoked when a request is received.
onRequestBegin(Request.BeginListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestBegin(Request.BeginListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestBegin(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked just after the HTTP request line and headers have been parsed.
onRequestBegin(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestBegin(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onRequestCommit(Request.CommitListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestCommit(Request.CommitListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestComplete() - Method in class org.eclipse.jetty.server.HttpChannel
 
onRequestContent(HttpServletRequest, Request, AsyncRequestContent, byte[], int, int, Callback) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
onRequestContent(Request.ContentListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestContent(Request.ContentListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestContent(Request, ByteBuffer) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked every time a request content chunk has been parsed, just before making it available to the application.
onRequestContent(Request, ByteBuffer) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestContent(Request, ByteBuffer) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onRequestContentEnd(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the end of the request content is detected.
onRequestContentEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestContentEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onRequestEnd(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the request has been fully parsed.
onRequestEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onRequestFailure(Request.FailureListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestFailure(Request.FailureListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestFailure(Request, Throwable) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the request processing failed.
onRequestFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onRequestHeaders(Request.HeadersListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestHeaders(Request.HeadersListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestQueued(Request.QueuedListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestQueued(Request.QueuedListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestSuccess(Request.SuccessListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onRequestSuccess(Request.SuccessListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onRequestTrailers(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the request trailers have been parsed.
onRequestTrailers(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onRequestTrailers(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onReset(Session, ResetFrame) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onReset(Session, ResetFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a RST_STREAM frame has been received for an unknown stream.
onReset(Stream, ResetFrame) - Method in class org.eclipse.jetty.http2.api.Stream.Listener.Adapter
 
onReset(Stream, ResetFrame) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a RST_STREAM frame has been received for this stream.
onReset(Stream, ResetFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream.Listener
Callback method invoked when a RST_STREAM frame has been received for this stream.
onReset(Stream, ResetFrame, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnectionFactory.HTTPServerSessionListener
 
onReset(ResetFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onReset(ResetFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onReset(ResetFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onReset(ResetFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onReset(ResetFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onResetForUnknownStream(ResetFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onResponse(Stream.Client, HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked when a response is received.
onResponseBegin(Response.BeginListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseBegin(Response.BeginListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseBegin(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked just before the response line is written to the network.
onResponseBegin(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onResponseBegin(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onResponseCommit() - Method in class org.eclipse.jetty.server.Request
Called when a response is about to be committed, ie sent back to the client
onResponseCommit(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked just after the response is committed (that is, the response line, headers and possibly some content have been written to the network).
onResponseCommit(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onResponseCommit(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onResponseContent(HttpServletRequest, HttpServletResponse, Response, byte[], int, int, Callback) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet
 
onResponseContent(HttpServletRequest, HttpServletResponse, Response, byte[], int, int, Callback) - Method in class org.eclipse.jetty.proxy.ProxyServlet
 
onResponseContent(Response.ContentListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseContent(Response.ContentListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseContent(Request, ByteBuffer) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked after a response content chunk has been written to the network.
onResponseContent(Request, ByteBuffer) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onResponseContent(Request, ByteBuffer) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onResponseContentAsync(Response.AsyncContentListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseContentAsync(Response.AsyncContentListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseContentDemanded(Response.DemandedContentListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseContentDemanded(Response.DemandedContentListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseEnd(Request) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the response has been fully written.
onResponseEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onResponseEnd(Request) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onResponseFailure(Response.FailureListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseFailure(Response.FailureListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseFailure(Request, Throwable) - Method in interface org.eclipse.jetty.server.HttpChannel.Listener
Invoked when the response processing failed.
onResponseFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
onResponseFailure(Request, Throwable) - Method in class org.eclipse.jetty.server.HttpChannelListeners
 
onResponseHeader(Response.HeaderListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseHeader(Response.HeaderListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseHeaders(Response.HeadersListener) - Method in interface org.eclipse.jetty.client.api.Request
Registers a listener for the headers event.
onResponseHeaders(Response.HeadersListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onResponseSuccess(Response.SuccessListener) - Method in interface org.eclipse.jetty.client.api.Request
 
onResponseSuccess(Response.SuccessListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
onSelected() - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when a read or write events has been detected by the ManagedSelector for this endpoint.
onSelected() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onSelectFailed(Throwable) - Method in class org.eclipse.jetty.io.ManagedSelector
 
onServerResponseHeaders(HttpServletRequest, HttpServletResponse, Response) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
onSessionFailure(Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onSessionStalled(ISession) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onSessionTimeout(Throwable) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onSessionUnstalled(ISession) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onSetting(ByteBuffer, Map<Integer, Integer>, int, int) - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
onSettings(ByteBuffer, Map<Integer, Integer>) - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
onSettings(Session, SettingsFrame) - Method in class org.eclipse.jetty.http2.api.Session.Listener.Adapter
 
onSettings(Session, SettingsFrame) - Method in interface org.eclipse.jetty.http2.api.Session.Listener
Callback method invoked when a SETTINGS frame has been received.
onSettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.client.HTTP2ClientSession
 
onSettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onSettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onSettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onSettings(SettingsFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onSettings(SettingsFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onSettings(SettingsFrame, boolean) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onSettings(Session, SettingsFrame) - Method in interface org.eclipse.jetty.http3.api.Session.Listener
Callback method invoked when a SETTINGS frame has been received.
onShutdown() - Method in class org.eclipse.jetty.http2.HTTP2Session
This method is called when the TCP FIN is received from the remote peer.
onShutdown() - Method in interface org.eclipse.jetty.http2.ISession
Callback invoked when the connection reads -1.
onStart() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
onStart() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
onStart(int, FCGI.Role, int) - Method in class org.eclipse.jetty.fcgi.parser.ServerParser.Listener.Adapter
 
onStart(int, FCGI.Role, int) - Method in interface org.eclipse.jetty.fcgi.parser.ServerParser.Listener
 
onStartAsync(AsyncEvent) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
onStartAsync(AsyncEvent) - Method in class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
onStartup(Set<Class<?>>, ServletContext) - Method in class org.eclipse.jetty.cdi.CdiServletContainerInitializer
 
onStartup(Set<Class<?>>, ServletContext) - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder.Wrapper
 
onStartup(Set<Class<?>>, ServletContext) - Method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketShutdownContainer
 
onStartup(Set<Class<?>>, ServletContext) - Method in class org.eclipse.jetty.websocket.jakarta.server.config.JakartaWebSocketServletContainerInitializer
 
onStartup(Set<Class<?>>, ServletContext) - Method in class org.eclipse.jetty.websocket.server.config.JettyWebSocketServletContainerInitializer
 
onStop() - Method in class org.eclipse.jetty.quic.client.ClientProtocolSession
 
onStop() - Method in class org.eclipse.jetty.quic.server.ServerProtocolSession
 
onStreamCreated(IStream) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onStreamCreated(IStream) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
onStreamCreated(IStream) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onStreamDestroyed(IStream) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onStreamDestroyed(IStream) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
onStreamDestroyed(IStream) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onStreamFailure(int, int, String) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onStreamFailure(int, int, String) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onStreamFailure(int, int, String) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onStreamFailure(int, int, String) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onStreamFailure(int, int, String) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onStreamFailure(Throwable) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
onStreamFailure(IStream, Throwable, Callback) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onStreamOpened(IStream) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onStreamStalled(IStream) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onStreamStart(InputStream) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedBinaryStreamMessageSink
 
onStreamStart(Reader) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedTextStreamMessageSink
 
onStreamTimeout(Throwable) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
onStreamTimeout(IStream, Throwable) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onStreamUnstalled(IStream) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onSuccess(Request) - Method in interface org.eclipse.jetty.client.api.Request.Listener
 
onSuccess(Request) - Method in interface org.eclipse.jetty.client.api.Request.SuccessListener
Callback method invoked when the request has been successfully sent.
onSuccess(Response) - Method in interface org.eclipse.jetty.client.api.Response.Listener
 
onSuccess(Response) - Method in interface org.eclipse.jetty.client.api.Response.SuccessListener
Callback method invoked when the whole response has been successfully received.
onSuccess(Response) - Method in class org.eclipse.jetty.client.ContinueProtocolHandler.ContinueListener
 
onSuccess(Response) - Method in class org.eclipse.jetty.client.util.InputStreamResponseListener
 
onSuccess(Response) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
onText(String, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Method called when a complete text message is received.
onText(Frame, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
onTextFrame(Frame, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
 
onTimeout() - Method in class org.eclipse.jetty.server.HttpChannelState
 
onTimeout(AsyncEvent) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
onTimeout(AsyncEvent) - Method in class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
onTimeout(Throwable) - Method in class org.eclipse.jetty.http2.client.http.ClientHTTP2StreamEndPoint
 
onTimeout(Throwable) - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
onTimeout(Throwable) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Client
 
onTimeout(Throwable, Consumer<Runnable>) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Server
 
onTimeout(Throwable, Consumer<Runnable>) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onTimeout(Throwable, Consumer<Runnable>) - Method in class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
onTimeoutExpired() - Method in class org.eclipse.jetty.client.TimeoutCompleteListener
Deprecated.
 
onTimeoutExpired() - Method in class org.eclipse.jetty.io.CyclicTimeout
Invoked when the timeout expires.
onTotalClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onTotalOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onTrailer(HeadersFrame) - Method in interface org.eclipse.jetty.http2.HTTP2Channel.Server
 
onTrailer(HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
onTrailer(HeadersFrame) - Method in class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
onTrailer(Stream.Client, HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Stream.Client.Listener
Callback method invoked when a trailer is received.
onTrailer(Stream.Server, HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Stream.Server.Listener
Callback method invoked when a trailer is received.
onTrailers(HttpFields) - Method in class org.eclipse.jetty.server.HttpChannel
 
onTrailers(IStream, HeadersFrame) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
onUpgradeFrom() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
onUpgradeFrom() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
onUpgradeFrom() - Method in interface org.eclipse.jetty.io.Connection.UpgradeFrom
Invoked during an upgrade to produce a buffer containing bytes that have not been consumed by this connection, and that must be consumed by the upgrade-to connection.
onUpgradeFrom() - Method in class org.eclipse.jetty.server.HttpConnection
 
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onUpgradeTo(ByteBuffer) - Method in interface org.eclipse.jetty.io.Connection.UpgradeTo
Invoked during an upgrade to receive a buffer containing bytes that have not been consumed by the upgrade-from connection, and that must be consumed by this connection.
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.proxy.ConnectHandler.DownstreamConnection
 
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.server.HttpConnection
 
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Extra bytes from the initial HTTP upgrade that need to be processed by the websocket parser before starting to read bytes from the connection
onWebSocketBinary(byte[], int, int) - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
onWebSocketBinary(byte[], int, int) - Method in interface org.eclipse.jetty.websocket.api.WebSocketListener
A WebSocket binary frame has been received.
onWebSocketClose(int, String) - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
onWebSocketClose(int, String) - Method in interface org.eclipse.jetty.websocket.api.WebSocketConnectionListener
A Close Event was received.
OnWebSocketClose - Annotation Type in org.eclipse.jetty.websocket.api.annotations
Annotation for tagging methods to receive connection close events.
onWebSocketConnect(Session) - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
onWebSocketConnect(Session) - Method in interface org.eclipse.jetty.websocket.api.WebSocketConnectionListener
A WebSocket Session has connected successfully and is ready to be used.
OnWebSocketConnect - Annotation Type in org.eclipse.jetty.websocket.api.annotations
Annotation for tagging methods to receive connection open events.
onWebSocketError(Throwable) - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
onWebSocketError(Throwable) - Method in interface org.eclipse.jetty.websocket.api.WebSocketConnectionListener
A WebSocket exception has occurred.
OnWebSocketError - Annotation Type in org.eclipse.jetty.websocket.api.annotations
Annotation for receiving websocket errors (exceptions) that have occurred internally in the websocket implementation.
onWebSocketFrame(Frame) - Method in interface org.eclipse.jetty.websocket.api.WebSocketFrameListener
A WebSocket frame has been received.
OnWebSocketFrame - Annotation Type in org.eclipse.jetty.websocket.api.annotations
(ADVANCED) Annotation for tagging methods to receive frame events.
OnWebSocketMessage - Annotation Type in org.eclipse.jetty.websocket.api.annotations
Annotation for tagging methods to receive Binary or Text Message events.
onWebSocketPartialBinary(ByteBuffer, boolean) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPartialListener
A WebSocket BINARY (or associated CONTINUATION) frame has been received.
onWebSocketPartialText(String, boolean) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPartialListener
A WebSocket TEXT (or associated CONTINUATION) frame has been received.
onWebSocketPing(ByteBuffer) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPingPongListener
A WebSocket PING has been received.
onWebSocketPong(ByteBuffer) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPingPongListener
A WebSocket PONG has been received.
onWebSocketSessionClosed(Session) - Method in interface org.eclipse.jetty.websocket.api.WebSocketSessionListener
 
onWebSocketSessionClosed(Session) - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
onWebSocketSessionCreated(Session) - Method in interface org.eclipse.jetty.websocket.api.WebSocketSessionListener
 
onWebSocketSessionOpened(Session) - Method in interface org.eclipse.jetty.websocket.api.WebSocketSessionListener
 
onWebSocketSessionOpened(Session) - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
onWebSocketText(String) - Method in class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
onWebSocketText(String) - Method in interface org.eclipse.jetty.websocket.api.WebSocketListener
A WebSocket Text frame was received.
onWholeMessage(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.messages.DecodedBinaryMessageSink
 
onWindowUpdate(WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
onWindowUpdate(WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onWindowUpdate(WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Adapter
 
onWindowUpdate(WindowUpdateFrame) - Method in interface org.eclipse.jetty.http2.parser.Parser.Listener
 
onWindowUpdate(WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
onWindowUpdate(ISession, IStream, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
onWindowUpdate(ISession, IStream, WindowUpdateFrame) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
onWindowUpdate(IStream, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
onWindowUpdate(IStream, WindowUpdateFrame) - Method in interface org.eclipse.jetty.http2.ISession
Callback method invoked when a WINDOW_UPDATE frame has been received.
onWritable() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
onWritable(long) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
onWritePossible() - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyWriter
 
onWritePossible() - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamWriter
 
onWritePossible() - Method in class org.eclipse.jetty.server.HttpChannelState
 
OpCode - Class in org.eclipse.jetty.websocket.core
 
OpCode() - Constructor for class org.eclipse.jetty.websocket.core.OpCode
 
open() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
open() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
open() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
open() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
open() - Method in interface org.eclipse.jetty.server.NetworkConnector
Performs the activities needed to open the network communication (for example, to start accepting incoming network connections).
open() - Method in class org.eclipse.jetty.server.ServerConnector
 
open() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
open(ServerSocketChannel) - Method in class org.eclipse.jetty.server.ServerConnector
Open the connector using the passed ServerSocketChannel.
openAcceptChannel() - Method in class org.eclipse.jetty.server.ServerConnector
Called by ServerConnector.open() to obtain the accepting channel.
openDatagramChannel() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
opened() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
opened(Socket) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when a connection from a remote client has been accepted.
OpenIdAuthConfiguration - Class in org.eclipse.jetty.security.openid
This class is used to wrap the Authenticator.AuthConfiguration given to the OpenIdAuthenticator.
OpenIdAuthConfiguration(OpenIdConfiguration, Authenticator.AuthConfiguration) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthConfiguration
 
OpenIdAuthentication(String, UserIdentity) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator.OpenIdAuthentication
 
OpenIdAuthenticator - Class in org.eclipse.jetty.security.openid
Implements authentication using OpenId Connect on top of OAuth 2.0.
OpenIdAuthenticator() - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
OpenIdAuthenticator(OpenIdConfiguration) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
OpenIdAuthenticator(OpenIdConfiguration, String) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
OpenIdAuthenticator(OpenIdConfiguration, String, String) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
OpenIdAuthenticator(OpenIdConfiguration, String, String, String) - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
OpenIdAuthenticator.OpenIdAuthentication - Class in org.eclipse.jetty.security.openid
This Authentication represents a just completed OpenId Connect authentication.
OpenIdAuthenticatorFactory - Class in org.eclipse.jetty.security.openid
 
OpenIdAuthenticatorFactory() - Constructor for class org.eclipse.jetty.security.openid.OpenIdAuthenticatorFactory
 
OpenIdConfiguration - Class in org.eclipse.jetty.security.openid
Holds the configuration for an OpenID Connect service.
OpenIdConfiguration(String, String, String) - Constructor for class org.eclipse.jetty.security.openid.OpenIdConfiguration
Create an OpenID configuration for a specific OIDC provider.
OpenIdConfiguration(String, String, String, String, String, String, String, HttpClient) - Constructor for class org.eclipse.jetty.security.openid.OpenIdConfiguration
Create an OpenID configuration for a specific OIDC provider.
OpenIdConfiguration(String, String, String, String, String, String, HttpClient) - Constructor for class org.eclipse.jetty.security.openid.OpenIdConfiguration
Create an OpenID configuration for a specific OIDC provider.
OpenIdConfiguration(String, String, String, String, String, HttpClient) - Constructor for class org.eclipse.jetty.security.openid.OpenIdConfiguration
Create an OpenID configuration for a specific OIDC provider.
OpenIdCredentials - Class in org.eclipse.jetty.security.openid
The credentials of an user to be authenticated with OpenID Connect.
OpenIdCredentials(String, String) - Constructor for class org.eclipse.jetty.security.openid.OpenIdCredentials
 
OpenIdCredentials(Map<String, Object>) - Constructor for class org.eclipse.jetty.security.openid.OpenIdCredentials
 
OpenIdCredentials.AuthenticationException - Exception Class in org.eclipse.jetty.security.openid
 
OpenIdLoginService - Class in org.eclipse.jetty.security.openid
The implementation of LoginService required to use OpenID Connect.
OpenIdLoginService(OpenIdConfiguration) - Constructor for class org.eclipse.jetty.security.openid.OpenIdLoginService
 
OpenIdLoginService(OpenIdConfiguration, LoginService) - Constructor for class org.eclipse.jetty.security.openid.OpenIdLoginService
Use a wrapped LoginService to store information about user roles.
OpenIdUserIdentity - Class in org.eclipse.jetty.security.openid
 
OpenIdUserIdentity(Subject, Principal, UserIdentity) - Constructor for class org.eclipse.jetty.security.openid.OpenIdUserIdentity
 
OpenIdUserPrincipal - Class in org.eclipse.jetty.security.openid
 
OpenIdUserPrincipal(OpenIdCredentials) - Constructor for class org.eclipse.jetty.security.openid.OpenIdUserPrincipal
 
openProtocolEndPoint(QuicStreamEndPoint) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
openTag(String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
openTag(String, Map<String, String>) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
OPTIONAL_WHITE_SPACE - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Whitespace was found around the cookie name and/or around the cookie value.
optionalMutatedInvoker(MethodHandles.Lookup, Class<?>, Method, InvokerUtils.Arg...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
 
optionalMutatedInvoker(MethodHandles.Lookup, Class<?>, Method, InvokerUtils.ParamIdentifier, String[], InvokerUtils.Arg...) - Static method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
Create an optional MethodHandle that performs the following layers.
OptionalSslConnectionFactory - Class in org.eclipse.jetty.server
Deprecated.
OptionalSslConnectionFactory(SslConnectionFactory, String) - Constructor for class org.eclipse.jetty.server.OptionalSslConnectionFactory
Deprecated.
Creates a new ConnectionFactory whose connections can upgrade to TLS or another protocol.
OPTIONS - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
order(List<Resource>) - Method in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
order(List<Resource>) - Method in interface org.eclipse.jetty.webapp.Ordering
 
order(List<Resource>) - Method in class org.eclipse.jetty.webapp.RelativeOrdering
 
ORDERED_LIBS - Static variable in class org.eclipse.jetty.webapp.MetaData
 
OrderedGroupBinding - Class in org.eclipse.jetty.deploy.bindings
Provides a way of forcing the ordered execution of bindings within a declared binding target.
OrderedGroupBinding(String[]) - Constructor for class org.eclipse.jetty.deploy.bindings.OrderedGroupBinding
 
orderFragments() - Method in class org.eclipse.jetty.webapp.MetaData
 
Ordering - Interface in org.eclipse.jetty.webapp
Ordering options for jars in WEB-INF lib.
ORDERPATCH - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
org.eclipse.jetty.alpn.client - package org.eclipse.jetty.alpn.client
 
org.eclipse.jetty.alpn.conscrypt.client - package org.eclipse.jetty.alpn.conscrypt.client
 
org.eclipse.jetty.alpn.conscrypt.server - package org.eclipse.jetty.alpn.conscrypt.server
 
org.eclipse.jetty.alpn.java.client - package org.eclipse.jetty.alpn.java.client
 
org.eclipse.jetty.alpn.java.server - package org.eclipse.jetty.alpn.java.server
 
org.eclipse.jetty.alpn.server - package org.eclipse.jetty.alpn.server
 
org.eclipse.jetty.annotations - package org.eclipse.jetty.annotations
Jetty Annotations : Support for Servlet Annotations
org.eclipse.jetty.ant - package org.eclipse.jetty.ant
Jetty Ant : Ant Tasks and Configuration
org.eclipse.jetty.ant.types - package org.eclipse.jetty.ant.types
Jetty Ant : Ant Wrappers of Jetty Internals
org.eclipse.jetty.ant.utils - package org.eclipse.jetty.ant.utils
Jetty Ant : Utility Classes
org.eclipse.jetty.apache.jsp - package org.eclipse.jetty.apache.jsp
 
org.eclipse.jetty.cdi - package org.eclipse.jetty.cdi
 
org.eclipse.jetty.client - package org.eclipse.jetty.client
Jetty Client : Implementation and Core Classes This package provides APIs, utility classes and an implementation of an asynchronous HTTP client.
org.eclipse.jetty.client.api - package org.eclipse.jetty.client.api
Jetty Client : API Classes
org.eclipse.jetty.client.dynamic - package org.eclipse.jetty.client.dynamic
 
org.eclipse.jetty.client.http - package org.eclipse.jetty.client.http
 
org.eclipse.jetty.client.internal - package org.eclipse.jetty.client.internal
 
org.eclipse.jetty.client.jmx - package org.eclipse.jetty.client.jmx
 
org.eclipse.jetty.client.util - package org.eclipse.jetty.client.util
Jetty Client : Utility Classes
org.eclipse.jetty.deploy - package org.eclipse.jetty.deploy
Jetty Deploy : Webapp Deploy Management
org.eclipse.jetty.deploy.bindings - package org.eclipse.jetty.deploy.bindings
Jetty Deploy : Standard Deployment Bindings
org.eclipse.jetty.deploy.graph - package org.eclipse.jetty.deploy.graph
Jetty Deploy : Deployment Graph
org.eclipse.jetty.deploy.jmx - package org.eclipse.jetty.deploy.jmx
Jetty Deploy : JMX Integration
org.eclipse.jetty.deploy.providers - package org.eclipse.jetty.deploy.providers
Jetty Deploy : Webapp Deployment Providers
org.eclipse.jetty.deploy.providers.jmx - package org.eclipse.jetty.deploy.providers.jmx
 
org.eclipse.jetty.deploy.util - package org.eclipse.jetty.deploy.util
Jetty Deploy : Utilities
org.eclipse.jetty.fcgi - package org.eclipse.jetty.fcgi
 
org.eclipse.jetty.fcgi.client.http - package org.eclipse.jetty.fcgi.client.http
 
org.eclipse.jetty.fcgi.generator - package org.eclipse.jetty.fcgi.generator
 
org.eclipse.jetty.fcgi.parser - package org.eclipse.jetty.fcgi.parser
 
org.eclipse.jetty.fcgi.server - package org.eclipse.jetty.fcgi.server
 
org.eclipse.jetty.fcgi.server.proxy - package org.eclipse.jetty.fcgi.server.proxy
 
org.eclipse.jetty.gcloud.session - package org.eclipse.jetty.gcloud.session
 
org.eclipse.jetty.http - package org.eclipse.jetty.http
Jetty Http : Tools for Http processing
org.eclipse.jetty.http.compression - package org.eclipse.jetty.http.compression
 
org.eclipse.jetty.http.pathmap - package org.eclipse.jetty.http.pathmap
 
org.eclipse.jetty.http.spi - package org.eclipse.jetty.http.spi
 
org.eclipse.jetty.http2 - package org.eclipse.jetty.http2
 
org.eclipse.jetty.http2.api - package org.eclipse.jetty.http2.api
 
org.eclipse.jetty.http2.api.server - package org.eclipse.jetty.http2.api.server
 
org.eclipse.jetty.http2.client - package org.eclipse.jetty.http2.client
 
org.eclipse.jetty.http2.client.http - package org.eclipse.jetty.http2.client.http
 
org.eclipse.jetty.http2.frames - package org.eclipse.jetty.http2.frames
 
org.eclipse.jetty.http2.generator - package org.eclipse.jetty.http2.generator
 
org.eclipse.jetty.http2.hpack - package org.eclipse.jetty.http2.hpack
 
org.eclipse.jetty.http2.parser - package org.eclipse.jetty.http2.parser
 
org.eclipse.jetty.http2.server - package org.eclipse.jetty.http2.server
 
org.eclipse.jetty.http3 - package org.eclipse.jetty.http3
 
org.eclipse.jetty.http3.api - package org.eclipse.jetty.http3.api
 
org.eclipse.jetty.http3.client - package org.eclipse.jetty.http3.client
 
org.eclipse.jetty.http3.client.http - package org.eclipse.jetty.http3.client.http
 
org.eclipse.jetty.http3.frames - package org.eclipse.jetty.http3.frames
 
org.eclipse.jetty.http3.qpack - package org.eclipse.jetty.http3.qpack
 
org.eclipse.jetty.http3.server - package org.eclipse.jetty.http3.server
 
org.eclipse.jetty.io - package org.eclipse.jetty.io
Jetty IO : Core classes for Jetty IO subsystem
org.eclipse.jetty.io.jmx - package org.eclipse.jetty.io.jmx
 
org.eclipse.jetty.io.ssl - package org.eclipse.jetty.io.ssl
Jetty IO : Core SSL Support
org.eclipse.jetty.jaas - package org.eclipse.jetty.jaas
Jetty Jaas : Support for Jaas
org.eclipse.jetty.jaas.callback - package org.eclipse.jetty.jaas.callback
Jetty Jaas : Jaas Callbacks
org.eclipse.jetty.jaas.spi - package org.eclipse.jetty.jaas.spi
Jetty Jaas : Various Jaas Implementations for Jetty
org.eclipse.jetty.jmx - package org.eclipse.jetty.jmx
Jetty JMX : Integration for JMX in Jetty
org.eclipse.jetty.jndi - package org.eclipse.jetty.jndi
Jetty Jndi : Java Naming Directory Interface
org.eclipse.jetty.jndi.factories - package org.eclipse.jetty.jndi.factories
Jetty Jndi : Factories
org.eclipse.jetty.jndi.java - package org.eclipse.jetty.jndi.java
Jetty Jndi : Mappings for java
org.eclipse.jetty.jndi.local - package org.eclipse.jetty.jndi.local
Jetty Jndi : Mappings for local
org.eclipse.jetty.jsp - package org.eclipse.jetty.jsp
 
org.eclipse.jetty.logging - package org.eclipse.jetty.logging
 
org.eclipse.jetty.memcached.session - package org.eclipse.jetty.memcached.session
 
org.eclipse.jetty.nosql - package org.eclipse.jetty.nosql
Jetty NoSql : Generic Nosql Session Management
org.eclipse.jetty.nosql.mongodb - package org.eclipse.jetty.nosql.mongodb
Jetty NoSql : MongoDB Integration
org.eclipse.jetty.osgi.annotations - package org.eclipse.jetty.osgi.annotations
 
org.eclipse.jetty.osgi.boot - package org.eclipse.jetty.osgi.boot
 
org.eclipse.jetty.osgi.boot.internal.serverfactory - package org.eclipse.jetty.osgi.boot.internal.serverfactory
 
org.eclipse.jetty.osgi.boot.internal.webapp - package org.eclipse.jetty.osgi.boot.internal.webapp
 
org.eclipse.jetty.osgi.boot.utils - package org.eclipse.jetty.osgi.boot.utils
 
org.eclipse.jetty.osgi.boot.utils.internal - package org.eclipse.jetty.osgi.boot.utils.internal
 
org.eclipse.jetty.plus.annotation - package org.eclipse.jetty.plus.annotation
Jetty Plus : Limited JEE Annotation Support
org.eclipse.jetty.plus.jndi - package org.eclipse.jetty.plus.jndi
Jetty Plus : Limited JEE Jndi Support
org.eclipse.jetty.plus.security - package org.eclipse.jetty.plus.security
Jetty Plus : Limited JEE Security Support
org.eclipse.jetty.plus.webapp - package org.eclipse.jetty.plus.webapp
Jetty Plus : Limited Additional JEE Webapp Support
org.eclipse.jetty.proxy - package org.eclipse.jetty.proxy
Jetty Proxy : Async Proxy Support
org.eclipse.jetty.quic.client - package org.eclipse.jetty.quic.client
 
org.eclipse.jetty.quic.common - package org.eclipse.jetty.quic.common
This module contains the main abstractions for the QUIC protocol.
org.eclipse.jetty.quic.server - package org.eclipse.jetty.quic.server
 
org.eclipse.jetty.quickstart - package org.eclipse.jetty.quickstart
 
org.eclipse.jetty.rewrite - package org.eclipse.jetty.rewrite
 
org.eclipse.jetty.rewrite.handler - package org.eclipse.jetty.rewrite.handler
Jetty Rewrite : Rewrite Handler and Rules for Jetty
org.eclipse.jetty.runner - package org.eclipse.jetty.runner
Jetty Runner : Embedded Jetty Tool for running webapps directly
org.eclipse.jetty.security - package org.eclipse.jetty.security
Jetty Security : Modular Support for Security in Jetty
org.eclipse.jetty.security.authentication - package org.eclipse.jetty.security.authentication
Jetty Security : Authenticators and Callbacks
org.eclipse.jetty.security.jaspi - package org.eclipse.jetty.security.jaspi
Jetty Jaspi : Java Authentication SPI
org.eclipse.jetty.security.jaspi.callback - package org.eclipse.jetty.security.jaspi.callback
Jetty Jaspi : Callbacks
org.eclipse.jetty.security.jaspi.modules - package org.eclipse.jetty.security.jaspi.modules
Jetty Jaspi : Authentication Modules
org.eclipse.jetty.security.jaspi.provider - package org.eclipse.jetty.security.jaspi.provider
 
org.eclipse.jetty.security.openid - package org.eclipse.jetty.security.openid
 
org.eclipse.jetty.server - package org.eclipse.jetty.server
Jetty Server : Core Server API
org.eclipse.jetty.server.handler - package org.eclipse.jetty.server.handler
Jetty Server : Core Handler API
org.eclipse.jetty.server.handler.gzip - package org.eclipse.jetty.server.handler.gzip
Jetty GZIP Handler
org.eclipse.jetty.server.handler.jmx - package org.eclipse.jetty.server.handler.jmx
Jetty Server : Handler JMX Integration
org.eclipse.jetty.server.jmx - package org.eclipse.jetty.server.jmx
Jetty Server : Server JMX Integration
org.eclipse.jetty.server.resource - package org.eclipse.jetty.server.resource
 
org.eclipse.jetty.server.session - package org.eclipse.jetty.server.session
Jetty Server : Session Management Implementations
org.eclipse.jetty.servlet - package org.eclipse.jetty.servlet
Jetty Server : Modular Servlet Integration
org.eclipse.jetty.servlet.jmx - package org.eclipse.jetty.servlet.jmx
Jetty Servlet : Servlet JMX Integration
org.eclipse.jetty.servlet.listener - package org.eclipse.jetty.servlet.listener
Jetty Servlet : Useful Servlet Listeners
org.eclipse.jetty.session.infinispan - package org.eclipse.jetty.session.infinispan
 
org.eclipse.jetty.start - package org.eclipse.jetty.start
Jetty Start : Generic Java Start Mechanism
org.eclipse.jetty.start.builders - package org.eclipse.jetty.start.builders
 
org.eclipse.jetty.start.config - package org.eclipse.jetty.start.config
 
org.eclipse.jetty.start.fileinits - package org.eclipse.jetty.start.fileinits
 
org.eclipse.jetty.unixsocket.client - package org.eclipse.jetty.unixsocket.client
 
org.eclipse.jetty.unixsocket.common - package org.eclipse.jetty.unixsocket.common
 
org.eclipse.jetty.unixsocket.server - package org.eclipse.jetty.unixsocket.server
 
org.eclipse.jetty.util - package org.eclipse.jetty.util
Jetty Util : Common Utility Classes
org.eclipse.jetty.util.ajax - package org.eclipse.jetty.util.ajax
Jetty Util : Simple JSON Utility classes
org.eclipse.jetty.util.annotation - package org.eclipse.jetty.util.annotation
Jetty Util : Common Utility Annotations
org.eclipse.jetty.util.component - package org.eclipse.jetty.util.component
Jetty Util : Jetty Lifecycle Management
org.eclipse.jetty.util.compression - package org.eclipse.jetty.util.compression
 
org.eclipse.jetty.util.log - package org.eclipse.jetty.util.log
 
org.eclipse.jetty.util.preventers - package org.eclipse.jetty.util.preventers
Jetty Util : Common Memory Leak Prevention Tooling
org.eclipse.jetty.util.resource - package org.eclipse.jetty.util.resource
Jetty Util : Common Resource Utilities
org.eclipse.jetty.util.security - package org.eclipse.jetty.util.security
Jetty Util : Common Security Utilities
org.eclipse.jetty.util.ssl - package org.eclipse.jetty.util.ssl
Jetty Util : Common SSL Utility Classes
org.eclipse.jetty.util.statistic - package org.eclipse.jetty.util.statistic
Jetty Util : Common Statistics Utility classes
org.eclipse.jetty.util.thread - package org.eclipse.jetty.util.thread
Jetty Util : Common ThreadPool Utilities
org.eclipse.jetty.util.thread.strategy - package org.eclipse.jetty.util.thread.strategy
 
org.eclipse.jetty.webapp - package org.eclipse.jetty.webapp
Jetty Util : Modular Web Application Support
org.eclipse.jetty.websocket.api - package org.eclipse.jetty.websocket.api
Jetty WebSocket API
org.eclipse.jetty.websocket.api.annotations - package org.eclipse.jetty.websocket.api.annotations
Jetty WebSocket API : WebSocket POJO Annotations
org.eclipse.jetty.websocket.api.exceptions - package org.eclipse.jetty.websocket.api.exceptions
Jetty WebSocket API : Exception Types
org.eclipse.jetty.websocket.api.util - package org.eclipse.jetty.websocket.api.util
Jetty WebSocket API : Utility Classes
org.eclipse.jetty.websocket.client - package org.eclipse.jetty.websocket.client
Jetty WebSocket API :: Client
org.eclipse.jetty.websocket.client.config - package org.eclipse.jetty.websocket.client.config
 
org.eclipse.jetty.websocket.client.impl - package org.eclipse.jetty.websocket.client.impl
 
org.eclipse.jetty.websocket.common - package org.eclipse.jetty.websocket.common
Jetty WebSocket Common : Implementation [Internal Use Only]
org.eclipse.jetty.websocket.core - package org.eclipse.jetty.websocket.core
 
org.eclipse.jetty.websocket.core.client - package org.eclipse.jetty.websocket.core.client
 
org.eclipse.jetty.websocket.core.client.internal - package org.eclipse.jetty.websocket.core.client.internal
 
org.eclipse.jetty.websocket.core.exception - package org.eclipse.jetty.websocket.core.exception
 
org.eclipse.jetty.websocket.core.internal - package org.eclipse.jetty.websocket.core.internal
 
org.eclipse.jetty.websocket.core.internal.messages - package org.eclipse.jetty.websocket.core.internal.messages
 
org.eclipse.jetty.websocket.core.internal.util - package org.eclipse.jetty.websocket.core.internal.util
 
org.eclipse.jetty.websocket.core.server - package org.eclipse.jetty.websocket.core.server
 
org.eclipse.jetty.websocket.core.server.internal - package org.eclipse.jetty.websocket.core.server.internal
 
org.eclipse.jetty.websocket.jakarta.client - package org.eclipse.jetty.websocket.jakarta.client
 
org.eclipse.jetty.websocket.jakarta.client.internal - package org.eclipse.jetty.websocket.jakarta.client.internal
 
org.eclipse.jetty.websocket.jakarta.common - package org.eclipse.jetty.websocket.jakarta.common
 
org.eclipse.jetty.websocket.jakarta.common.decoders - package org.eclipse.jetty.websocket.jakarta.common.decoders
 
org.eclipse.jetty.websocket.jakarta.common.encoders - package org.eclipse.jetty.websocket.jakarta.common.encoders
 
org.eclipse.jetty.websocket.jakarta.common.messages - package org.eclipse.jetty.websocket.jakarta.common.messages
 
org.eclipse.jetty.websocket.jakarta.server.config - package org.eclipse.jetty.websocket.jakarta.server.config
 
org.eclipse.jetty.websocket.jakarta.server.internal - package org.eclipse.jetty.websocket.jakarta.server.internal
 
org.eclipse.jetty.websocket.server - package org.eclipse.jetty.websocket.server
 
org.eclipse.jetty.websocket.server.config - package org.eclipse.jetty.websocket.server.config
 
org.eclipse.jetty.websocket.server.internal - package org.eclipse.jetty.websocket.server.internal
 
org.eclipse.jetty.websocket.servlet - package org.eclipse.jetty.websocket.servlet
 
org.eclipse.jetty.xml - package org.eclipse.jetty.xml
Jetty Xml : IoC Mechanism for Jetty Configuration
origin(MetaData, String) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
Find the origin (web.xml, fragment, annotation etc) of a web artifact from MetaData.
Origin - Class in org.eclipse.jetty.client
Class that groups the elements that uniquely identify a destination.
Origin - Enum in org.eclipse.jetty.webapp
 
Origin(String, String, int) - Constructor for class org.eclipse.jetty.client.Origin
 
Origin(String, String, int, Object) - Constructor for class org.eclipse.jetty.client.Origin
 
Origin(String, String, int, Object, Origin.Protocol) - Constructor for class org.eclipse.jetty.client.Origin
 
Origin(String, Origin.Address) - Constructor for class org.eclipse.jetty.client.Origin
 
Origin(String, Origin.Address, Object) - Constructor for class org.eclipse.jetty.client.Origin
 
Origin(String, Origin.Address, Object, Origin.Protocol) - Constructor for class org.eclipse.jetty.client.Origin
 
ORIGIN - Enum constant in enum org.eclipse.jetty.http.HttpHeader
WebSocket Fields.
ORIGIN - Static variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
ORIGIN_ATTRIBUTE - Static variable in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
ORIGIN_CMD_LINE - Static variable in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
ORIGIN_INTERNAL_FALLBACK - Static variable in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
ORIGIN_SYSPROP - Static variable in class org.eclipse.jetty.start.Props
 
ORIGIN_SYSTEM_PROPERTY - Static variable in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
Origin.Address - Class in org.eclipse.jetty.client
 
Origin.Protocol - Class in org.eclipse.jetty.client
The representation of a network protocol.
ORIGINAL_QUERY_ATTRIBUTE_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
ORIGINAL_QUERYSTRING_ATTRIBUTE_SUFFIX - Static variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
ORIGINAL_URI_ATTRIBUTE_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
OriginInfo(String) - Constructor for class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
OriginInfo(String, Annotation, Class<?>) - Constructor for class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
OriginInfo(String, Descriptor) - Constructor for class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
OSGI_BUNDLECONTEXT - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
See OSGi r4 p.427
OSGI_WEB_CONTEXTPATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
service property osgi.web.contextpath.
OSGI_WEB_SYMBOLICNAME - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
service property osgi.web.symbolicname.
OSGI_WEB_VERSION - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
service property osgi.web.symbolicname.
OSGiApp(DeploymentManager, AppProvider, String, Bundle, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
OSGiApp(DeploymentManager, AppProvider, Bundle, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
OSGiApp(DeploymentManager, AppProvider, Bundle, Dictionary, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
OSGiApp(DeploymentManager, AppProvider, Bundle, Dictionary, String, String) - Constructor for class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
OSGiClassLoader - Class in org.eclipse.jetty.osgi.boot.utils
OSGiClassLoader Class loader that is aware of a bundle.
OSGiClassLoader(ClassLoader, Bundle) - Constructor for class org.eclipse.jetty.osgi.boot.utils.OSGiClassLoader
 
OSGiDeployer - Class in org.eclipse.jetty.osgi.boot
OSGiDeployer Extension of standard Jetty deployer that emits OSGi EventAdmin events whenever a webapp is deployed into OSGi via Jetty.
OSGiDeployer(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.OSGiDeployer
 
OSGiMetaInfConfiguration - Class in org.eclipse.jetty.osgi.boot
OSGiWebInfConfiguration Handle adding resources found in bundle fragments, and add them into the
OSGiMetaInfConfiguration() - Constructor for class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
OSGiServerConstants - Class in org.eclipse.jetty.osgi.boot
OSGiServerConstants Name of the properties that configure a jetty Server OSGi service.
OSGiServerConstants() - Constructor for class org.eclipse.jetty.osgi.boot.OSGiServerConstants
 
OSGiUndeployer - Class in org.eclipse.jetty.osgi.boot
OSGiUndeployer Extension of the Jetty Undeployer which emits OSGi EventAdmin events whenever a webapp is undeployed from Jetty.
OSGiUndeployer(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.OSGiUndeployer
 
OSGiWebappClassLoader - Class in org.eclipse.jetty.osgi.boot.internal.webapp
OSGiWebappClassLoader Extends the webapp classloader to also use the classloader of the Bundle defining the webapp.
OSGiWebappClassLoader(ClassLoader, WebAppContext, Bundle) - Constructor for class org.eclipse.jetty.osgi.boot.internal.webapp.OSGiWebappClassLoader
 
OSGiWebappConstants - Class in org.eclipse.jetty.osgi.boot
OSGiWebappConstants Constants (MANIFEST headers, service properties etc) associated with deploying webapps into OSGi via Jetty.
OSGiWebappConstants() - Constructor for class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
 
OSGiWebInfConfiguration - Class in org.eclipse.jetty.osgi.boot
OSGiWebInfConfiguration Handle adding resources found in bundle fragments, and add them into the
OSGiWebInfConfiguration() - Constructor for class org.eclipse.jetty.osgi.boot.OSGiWebInfConfiguration
 
OTEXT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
OTHER - Enum constant in enum org.eclipse.jetty.servlet.ServletHolder.JspContainer
 
OTHER - Static variable in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
otherProtocol(ByteBuffer, EndPoint) - Method in class org.eclipse.jetty.server.OptionalSslConnectionFactory
outgoing(Socket, ByteBuffer) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when bytes are sent to a remote client from the server.
OutgoingFrames - Interface in org.eclipse.jetty.websocket.core
Interface for dealing with frames outgoing to (eventually) the network layer.
OutputStreamContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
OutputStreamContentProvider() - Constructor for class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
OutputStreamRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content that provides content asynchronously through an OutputStream similar to AsyncRequestContent.
OutputStreamRequestContent() - Constructor for class org.eclipse.jetty.client.util.OutputStreamRequestContent
 
OutputStreamRequestContent(String) - Constructor for class org.eclipse.jetty.client.util.OutputStreamRequestContent
 
outwardClose(long, String) - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
outwardClose(long, String) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
outwardClose(QuicSession, Throwable) - Method in class org.eclipse.jetty.quic.client.ClientQuicConnection
 
outwardClose(QuicSession, Throwable) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
outwardClose(QuicSession, Throwable) - Method in class org.eclipse.jetty.quic.server.ServerQuicConnection
 
overlay(Classpath) - Method in class org.eclipse.jetty.start.Classpath
Overlay another classpath, copying its elements into place on this Classpath, while eliminating duplicate entries on the classpath.
OverrideDescriptor - Class in org.eclipse.jetty.webapp
OverrideDescriptor
OverrideDescriptor(Resource) - Constructor for class org.eclipse.jetty.webapp.OverrideDescriptor
 

P

PackageAdminServiceTracker - Class in org.eclipse.jetty.osgi.boot.utils.internal
PackageAdminServiceTracker
PackageAdminServiceTracker(BundleContext) - Constructor for class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
 
padding() - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
PADDING - Static variable in interface org.eclipse.jetty.http2.Flags
 
param(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
param(String, String) - Method in interface org.eclipse.jetty.client.api.Request
Adds a URI query parameter with the given name and value.
param(String, String) - Method in class org.eclipse.jetty.client.HttpRequest
 
PARAM_IDENTITY - Static variable in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils
 
paramIdentifier - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
PARAMS - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
ParamsContentParser - Class in org.eclipse.jetty.fcgi.parser
Parser for the PARAMS frame content.
ParamsContentParser(HeaderParser, ServerParser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.ParamsContentParser
 
parent - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
parentPath(String) - Static method in class org.eclipse.jetty.util.URIUtil
Return the parent Path.
parse() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Parse, if necessary, the multipart stream.
parse() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Parse, if necessary, the multipart stream.
parse(byte[]) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
Feeds the parser with the given bytes chunk.
parse(byte[], int, int) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
Feeds the parser with the given bytes chunk.
parse(File) - Method in class org.eclipse.jetty.xml.XmlParser
Parse File.
parse(InputStream) - Method in class org.eclipse.jetty.xml.XmlParser
Parse InputStream.
parse(String) - Method in class org.eclipse.jetty.jndi.InitialContextFactory.DefaultParser
 
parse(String) - Method in class org.eclipse.jetty.jndi.java.javaNameParser
Parse a name into its components.
parse(String) - Static method in class org.eclipse.jetty.util.JavaVersion
 
parse(String) - Static method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
parse(String) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig.Parser
 
parse(String) - Method in class org.eclipse.jetty.websocket.common.ExtensionConfigParser
Parse a single parameterized name.
parse(String) - Static method in class org.eclipse.jetty.websocket.core.ExtensionConfig
Parse a single parameterized name.
parse(String) - Method in class org.eclipse.jetty.xml.XmlParser
Parse String URL.
parse(String, String) - Method in class org.eclipse.jetty.start.StartArgs
Parse a single line of argument.
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.BeginRequestContentParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.ContentParser
Parses the bytes in the given buffer as FastCGI frame content bytes.
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.EndRequestContentParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
Parses the bytes in the given buffer as FastCGI frame header bytes
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.ParamsContentParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.Parser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.fcgi.parser.StreamContentParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.BodyParser
Parses the body bytes in the given buffer; only the body bytes are consumed, therefore when this method returns, the buffer may contain unconsumed bytes.
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.ContinuationBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.DataBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.GoAwayBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.HeaderParser
Parses the header bytes in the given buffer; only the header bytes are consumed, therefore when this method returns, the buffer may contain unconsumed bytes.
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.HeadersBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.Parser
Parses the given buffer bytes and emit events to a Parser.Listener.
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.PingBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.PrefaceParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.PriorityBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.PushPromiseBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.ResetBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.ServerParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.UnknownBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.WindowUpdateBodyParser
 
parse(ByteBuffer) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON
Feeds the parser with the given buffer chunk.
parse(ByteBuffer) - Method in class org.eclipse.jetty.util.Utf8LineParser
Parse a ByteBuffer (could be a partial buffer), and return once a complete line of UTF8 parsed text has been reached.
parse(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.Parser
Parse the buffer.
parse(ByteBuffer, boolean) - Method in class org.eclipse.jetty.server.MultiPartParser
Parse until next Event.
parse(ByteBuffer, int) - Method in class org.eclipse.jetty.http2.parser.HeaderBlockParser
Parses @{code blockLength} HPACK bytes from the given buffer.
parse(Set<? extends AnnotationParser.Handler>, Class<?>, boolean) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse the given class, optionally walking its inheritance hierarchy
parse(Set<? extends AnnotationParser.Handler>, String) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse a given class
parse(Set<? extends AnnotationParser.Handler>, String[]) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse the given classes
parse(Set<? extends AnnotationParser.Handler>, URI) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse a particular uri
parse(Set<? extends AnnotationParser.Handler>, URI[]) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse classes in the supplied uris.
parse(Set<? extends AnnotationParser.Handler>, URI[]) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
parse(Set<? extends AnnotationParser.Handler>, List<String>) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse the given classes
parse(Set<? extends AnnotationParser.Handler>, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse a resource
parse(Set<? extends AnnotationParser.Handler>, Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationParser
 
parse(ConfigSources) - Method in class org.eclipse.jetty.start.StartArgs
 
parse(JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
Parses the given JSON source into an object.
parse(JSON.Source, boolean) - Method in class org.eclipse.jetty.util.ajax.JSON
Parses the given JSON source into an object.
parse(XmlParser) - Method in class org.eclipse.jetty.webapp.Descriptor
 
parse(XmlParser) - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
parse(XmlParser) - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
parse(InputSource) - Method in class org.eclipse.jetty.xml.XmlParser
 
parseArray(JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
parseBody(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.Parser
 
parseBody(ByteBuffer) - Static method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
Parses the given buffer containing the whole body of a SETTINGS frame (without header bytes), typically from the HTTP2-Settings header.
parseBundle(WebAppContext, AnnotationParser, Bundle, Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
 
parseBytes(String, int) - Static method in class org.eclipse.jetty.util.TypeUtil
Deprecated.
parseContainerPath(WebAppContext, AnnotationParser) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Scan jars on container path.
parseContent(ByteBuffer) - Method in class org.eclipse.jetty.http.HttpParser
 
parseCsvIndex(String, Function<HttpHeaderValue, Boolean>) - Static method in enum org.eclipse.jetty.http.HttpHeaderValue
Parse an unquoted comma separated list of index keys.
parseCsvIndex(String, Function<HttpHeaderValue, Boolean>, Function<String, Boolean>) - Static method in enum org.eclipse.jetty.http.HttpHeaderValue
Parse an unquoted comma separated list of index keys.
parseDate(String) - Static method in class org.eclipse.jetty.http.DateParser
 
parsedField(String, String) - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
ParsedFrame(byte, byte[], ByteBuffer, boolean) - Constructor for class org.eclipse.jetty.websocket.core.internal.Parser.ParsedFrame
 
parsedHeader(HttpField) - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
parsedHeader(HttpField) - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
This is the method called by parser when an HTTP Header name and value is found
parsedHeader(HttpField) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
parsedHeader(HttpField) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
parseDir(Set<? extends AnnotationParser.Handler>, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse all classes in a directory
parsedParam(StringBuffer, int, int, int) - Method in class org.eclipse.jetty.http.QuotedCSVParser
Called when a parameter has been parsed
parsedParam(StringBuffer, int, int, int) - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
parsedTrailer(HttpField) - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
parsedTrailer(HttpField) - Method in interface org.eclipse.jetty.http.HttpParser.HttpHandler
This is the method called by parser when an HTTP Trailer name and value is found
parsedTrailer(HttpField) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
parsedValue(StringBuffer) - Method in class org.eclipse.jetty.http.QuotedCSVParser
Called when a value has been parsed (prior to any parameters)
parsedValue(StringBuffer) - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
parsedValueAndParams(StringBuffer) - Method in class org.eclipse.jetty.http.QuotedCSV
 
parsedValueAndParams(StringBuffer) - Method in class org.eclipse.jetty.http.QuotedCSVParser
Called when a value and it's parameters has been parsed
parsedValueAndParams(StringBuffer) - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
parseEnum(Enumeration<String>) - Static method in class org.eclipse.jetty.websocket.core.ExtensionConfig
Parse enumeration of Sec-WebSocket-Extensions header values into a ExtensionConfig list
parseField(String) - Method in class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
parseField(String) - Method in interface org.eclipse.jetty.http.CookieParser
 
parseField(String) - Method in class org.eclipse.jetty.http.RFC6265CookieParser
 
parseFields(ByteBuffer) - Method in class org.eclipse.jetty.http.HttpParser
 
parseFields(List<String>) - Method in class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
parseFields(List<String>) - Method in interface org.eclipse.jetty.http.CookieParser
 
parseFragmentBundle(WebAppContext, AnnotationParser, Bundle, Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
Scan a fragment bundle for servlet annotations
parseHeader(ByteBuffer) - Method in class org.eclipse.jetty.http2.parser.Parser
 
parseInstructions(ByteBuffer) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
Parse instructions from the Encoder stream.
parseInstructions(ByteBuffer) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
Parse instructions from the Decoder stream.
parseInt(byte[], int, int, int) - Static method in class org.eclipse.jetty.util.TypeUtil
Parse an int from a byte array of ascii characters.
parseInt(String, int, int, int) - Static method in class org.eclipse.jetty.util.TypeUtil
Parse an int from a substring.
parseJar(Set<? extends AnnotationParser.Handler>, Resource) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse a resource that is a jar file.
parseJarEntry(Set<? extends AnnotationParser.Handler>, Resource, MultiReleaseJarFile.VersionedJarEntry) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Parse a single entry in a jar file
parseList(String...) - Static method in class org.eclipse.jetty.websocket.core.ExtensionConfig
Parse 1 or more raw Sec-WebSocket-Extensions header values into a ExtensionConfig list
parseMimePartHeaders(ByteBuffer) - Method in class org.eclipse.jetty.server.MultiPartParser
 
parseNext(ByteBuffer) - Method in class org.eclipse.jetty.http.HttpParser
Parse until next Event.
parseNumber(JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
parseObject(JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
parseOctetContent(ByteBuffer) - Method in class org.eclipse.jetty.server.MultiPartParser
 
parsePathSpec(String) - Static method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
Parse a PathSpec string into a PathSpec instance.
parsePort(String) - Static method in class org.eclipse.jetty.util.HostPort
Parse a string representing a port validating it is a valid port value.
Parser - Class in org.eclipse.jetty.fcgi.parser
The FastCGI protocol exchanges frames.
Parser - Class in org.eclipse.jetty.http2.parser
The HTTP/2 protocol parser.
Parser - Class in org.eclipse.jetty.websocket.core.internal
Parsing of a frames in WebSocket land.
Parser() - Constructor for class org.eclipse.jetty.fcgi.parser.Parser
 
Parser(ByteBufferPool) - Constructor for class org.eclipse.jetty.websocket.core.internal.Parser
 
Parser(ByteBufferPool, int) - Constructor for class org.eclipse.jetty.http2.parser.Parser
 
Parser(ByteBufferPool, int, int) - Constructor for class org.eclipse.jetty.http2.parser.Parser
Deprecated.
Parser(ByteBufferPool, int, int, RateControl) - Constructor for class org.eclipse.jetty.http2.parser.Parser
Deprecated.
Parser(ByteBufferPool, int, RateControl) - Constructor for class org.eclipse.jetty.http2.parser.Parser
 
Parser(ByteBufferPool, Configuration) - Constructor for class org.eclipse.jetty.websocket.core.internal.Parser
 
Parser.Listener - Interface in org.eclipse.jetty.fcgi.parser
 
Parser.Listener - Interface in org.eclipse.jetty.http2.parser
 
Parser.Listener.Adapter - Class in org.eclipse.jetty.fcgi.parser
 
Parser.Listener.Adapter - Class in org.eclipse.jetty.http2.parser
 
Parser.Listener.Wrapper - Class in org.eclipse.jetty.http2.parser
 
Parser.ParsedFrame - Class in org.eclipse.jetty.websocket.core.internal
 
parseRequest(InputStream) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseRequest(String) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseRequest(ByteBuffer) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseRequest(ReadableByteChannel) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseRequest(HttpTester.Input) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseRequiredBundle(WebAppContext, AnnotationParser, Bundle, Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
Scan a bundle required by the webbundle for servlet annotations
parseResponse(InputStream) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseResponse(String) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseResponse(ByteBuffer) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseResponse(HttpTester.Input) - Static method in class org.eclipse.jetty.http.HttpTester
 
parseResponse(HttpTester.Input, HttpTester.Response) - Static method in class org.eclipse.jetty.http.HttpTester
 
ParserTask(AnnotationParser, Set<? extends AnnotationParser.Handler>, Resource) - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
parseString(JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
parseWebBundle(WebAppContext, AnnotationParser, Bundle) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
Scan a bundle required by the webbundle for servlet annotations
parseWebInfClasses(WebAppContext, AnnotationParser) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Scan classes in WEB-INF/classes.
parseWebInfClasses(WebAppContext, AnnotationParser) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
 
parseWebInfLib(WebAppContext, AnnotationParser) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Scan jars in WEB-INF/lib.
parseWebInfLib(WebAppContext, AnnotationParser) - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
Here is the order in which jars and osgi artifacts are scanned for discoverable annotations.
PARTIAL_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PARTIAL_CONTENT_206 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
PartialByteArrayMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
PartialByteArrayMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.PartialByteArrayMessageSink
 
PartialByteBufferMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
PartialByteBufferMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.PartialByteBufferMessageSink
 
partialResponse() - Method in class org.eclipse.jetty.server.HttpChannelState
 
PartialStringMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
PartialStringMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.PartialStringMessageSink
 
PARTITIONED_COMMENT - Static variable in class org.eclipse.jetty.http.HttpCookie
String used in the Comment attribute of HttpCookie, parsed with HttpCookie.isPartitionedInComment(String), to support the Partitioned attribute.
passConditionalHeaders(HttpServletRequest, HttpServletResponse, HttpContent) - Method in class org.eclipse.jetty.server.ResourceService
 
Password - Class in org.eclipse.jetty.util.security
Password utility class.
Password(String) - Constructor for class org.eclipse.jetty.util.security.Password
Constructor.
PASSWORD_PROPERTY - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory
String name of keystore password property.
PasswordAuthenticator() - Constructor for class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
PasswordAuthenticator(String, String) - Constructor for class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
PATCH - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
path - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
path(String) - Method in interface org.eclipse.jetty.client.api.Request
Specifies the URI path - and possibly the query - of this request.
path(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
path(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
path(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
Path - Class in org.eclipse.jetty.deploy.graph
 
Path() - Constructor for class org.eclipse.jetty.deploy.graph.Path
 
PATH_INFO - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
PATH_PARAM_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
pathAdded(Path) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is added.
pathChanged(Path) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is changed.
PathContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
use PathRequestContent instead.
PathContentProvider(String, Path) - Constructor for class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
PathContentProvider(String, Path, int) - Constructor for class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
PathContentProvider(Path) - Constructor for class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
PathContentProvider(Path, int) - Constructor for class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
PathFinder - Class in org.eclipse.jetty.start
 
PathFinder() - Constructor for class org.eclipse.jetty.start.PathFinder
 
pathInfo(String, String) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
Return the portion of a path that is after a path spec.
PathMappings<E> - Class in org.eclipse.jetty.http.pathmap
Path Mappings of PathSpec to Resource.
PathMappings() - Constructor for class org.eclipse.jetty.http.pathmap.PathMappings
 
pathMatch(String, String) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
Return the portion of a path that matches a path spec.
PathMatchers - Class in org.eclipse.jetty.start
Common PathMatcher implementations.
PathMatchers() - Constructor for class org.eclipse.jetty.start.PathMatchers
 
PathMatcherSet() - Constructor for class org.eclipse.jetty.util.PathWatcher.PathMatcherSet
 
PathParamIdentifier - Class in org.eclipse.jetty.websocket.jakarta.server.internal
Method argument identifier for PathParam annotations.
PathParamIdentifier() - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.PathParamIdentifier
 
PathParamProvider - Interface in org.eclipse.jetty.websocket.jakarta.common
Optional interface for custom EndpointConfig implementations in Jetty to expose Path Param values used during the JakartaWebSocketFrameHandler resolution of methods.
PathParamServerEndpointConfig - Class in org.eclipse.jetty.websocket.jakarta.server.internal
Make PathParam information from the incoming request available on ServerEndpointConfig
PathParamServerEndpointConfig(ServerEndpointConfig, Map<String, String>) - Constructor for class org.eclipse.jetty.websocket.jakarta.server.internal.PathParamServerEndpointConfig
 
pathQuery(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
pathRemoved(Path) - Method in interface org.eclipse.jetty.util.Scanner.DiscreteListener
Called when a file is removed.
PathRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content for files using JDK 7's java.nio.file APIs.
PathRequestContent(String, Path) - Constructor for class org.eclipse.jetty.client.util.PathRequestContent
 
PathRequestContent(String, Path, int) - Constructor for class org.eclipse.jetty.client.util.PathRequestContent
 
PathRequestContent(Path) - Constructor for class org.eclipse.jetty.client.util.PathRequestContent
 
PathRequestContent(Path, int) - Constructor for class org.eclipse.jetty.client.util.PathRequestContent
 
PathResource - Class in org.eclipse.jetty.util.resource
Java NIO Path Resource.
PathResource(File) - Constructor for class org.eclipse.jetty.util.resource.PathResource
Construct a new PathResource from a File object.
PathResource(URI) - Constructor for class org.eclipse.jetty.util.resource.PathResource
Construct a new PathResource from a URI object.
PathResource(URL) - Constructor for class org.eclipse.jetty.util.resource.PathResource
Create a new PathResource from a provided URL object.
PathResource(Path) - Constructor for class org.eclipse.jetty.util.resource.PathResource
Construct a new PathResource from a Path object.
Paths() - Constructor for class org.eclipse.jetty.start.NaturalSort.Paths
 
pathsChanged(Set<Path>) - Method in interface org.eclipse.jetty.util.Scanner.BulkListener
 
PathSpec - Interface in org.eclipse.jetty.http.pathmap
A path specification is a URI path template that can be matched against.
PathSpecGroup - Enum in org.eclipse.jetty.http.pathmap
Types of path spec groups.
PathSpecSet - Class in org.eclipse.jetty.http.pathmap
A Set of PathSpec strings.
PathSpecSet() - Constructor for class org.eclipse.jetty.http.pathmap.PathSpecSet
 
PathWatcher - Class in org.eclipse.jetty.util
Watch a Path (and sub directories) for Path changes.
PathWatcher() - Constructor for class org.eclipse.jetty.util.PathWatcher
Construct new PathWatcher
PathWatcher.Config - Class in org.eclipse.jetty.util
 
PathWatcher.DirAction - Enum in org.eclipse.jetty.util
 
PathWatcher.EventListListener - Interface in org.eclipse.jetty.util
Listener that reports accumulated events in one shot
PathWatcher.Listener - Interface in org.eclipse.jetty.util
Listener for path change events
PathWatcher.PathMatcherSet - Class in org.eclipse.jetty.util
 
PathWatcher.PathWatchEvent - Class in org.eclipse.jetty.util
Represents a file event.
PathWatcher.PathWatchEventType - Enum in org.eclipse.jetty.util
Type of an event
PathWatchEvent(Path, WatchEvent<Path>, PathWatcher.Config) - Constructor for class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
PathWatchEvent(Path, PathWatcher.PathWatchEventType, PathWatcher.Config) - Constructor for class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
PatternMatcher - Class in org.eclipse.jetty.util
 
PatternMatcher() - Constructor for class org.eclipse.jetty.util.PatternMatcher
 
PatternRule - Class in org.eclipse.jetty.rewrite.handler
Abstract rule that use a ServletPathSpec for pattern matching.
PatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.PatternRule
 
PatternRule(String) - Constructor for class org.eclipse.jetty.rewrite.handler.PatternRule
 
PatternTuple(String, InetAddressPattern, PathSpec) - Constructor for class org.eclipse.jetty.server.handler.InetAccessSet.PatternTuple
 
pauseUntil - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
payload - Variable in class org.eclipse.jetty.websocket.core.Frame
The payload data.
PAYLOAD_TOO_LARGE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PAYLOAD_TOO_LARGE_413 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
PAYMENT_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PAYMENT_REQUIRED_402 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
peek() - Method in class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
peek() - Method in interface org.eclipse.jetty.util.ajax.JSON.Source
 
peek() - Method in class org.eclipse.jetty.util.ajax.JSON.StringSource
 
peek() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
PENDING - Enum constant in enum org.eclipse.jetty.fcgi.parser.ContentParser.Result
Not enough bytes have been provided to the parser with a call to ContentParser.parse(ByteBuffer).
PERMANENT_REDIRECT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PERMANENT_REDIRECT_308 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
PERMANET_REDIRECT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PerMessageDeflateExtension - Class in org.eclipse.jetty.websocket.core.internal
Per Message Deflate Compression extension for WebSocket.
PerMessageDeflateExtension() - Constructor for class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
PidFile - Class in org.eclipse.jetty.util
Create a PID file for the running process.
ping(PingFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Session
Sends the given PING frame.
ping(PingFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
PING - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
PING - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
PING - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Ping Frame
PING_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.PingFrame
 
PingBodyParser - Class in org.eclipse.jetty.http2.parser
 
PingBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.PingBodyParser
 
PingFrame - Class in org.eclipse.jetty.http2.frames
 
PingFrame(boolean) - Constructor for class org.eclipse.jetty.http2.frames.PingFrame
Creates a PING frame with an empty payload.
PingFrame(byte[], boolean) - Constructor for class org.eclipse.jetty.http2.frames.PingFrame
Creates a PING frame with the given payload.
PingFrame(long, boolean) - Constructor for class org.eclipse.jetty.http2.frames.PingFrame
Creates a PING frame with the given long value as payload.
PingGenerator - Class in org.eclipse.jetty.http2.generator
 
PingGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.PingGenerator
 
PLUS_CONFIGURATION_CLASSES - Static variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
PlusConfiguration - Class in org.eclipse.jetty.plus.webapp
Configuration
PlusConfiguration() - Constructor for class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
PlusDecorator - Class in org.eclipse.jetty.plus.webapp
PlusDecorator
PlusDecorator(WebAppContext) - Constructor for class org.eclipse.jetty.plus.webapp.PlusDecorator
 
PlusDescriptorProcessor - Class in org.eclipse.jetty.plus.webapp
PlusDescriptorProcessor
PlusDescriptorProcessor() - Constructor for class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
POLICY_VIOLATION - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1008 indicates that an endpoint is terminating the connection because it has received a message that violates its policy.
POLICY_VIOLATION - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
PolicyViolationException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Exception when a violation of policy occurs and should trigger a connection close.
PolicyViolationException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.PolicyViolationException
 
PolicyViolationException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.PolicyViolationException
 
PolicyViolationException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.PolicyViolationException
 
poll() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
poll(long, TimeUnit) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
pollTask() - Method in class org.eclipse.jetty.quic.client.ClientQuicSession
 
pollTask() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
PONG - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
PONG - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Pong Frame
Pool<T> - Class in org.eclipse.jetty.util
A pool of objects, with optional support for multiplexing, max usage count and several optimized strategies plus an optional ThreadLocal cache of the last release entry.
Pool(Pool.StrategyType, int) - Constructor for class org.eclipse.jetty.util.Pool
Construct a Pool with a specified lookup strategy and no ThreadLocal cache.
Pool(Pool.StrategyType, int, boolean) - Constructor for class org.eclipse.jetty.util.Pool
Construct a Pool with the specified thread-local cache size and an optional ThreadLocal cache.
Pool.Entry - Class in org.eclipse.jetty.util
A Pool entry that holds metadata and a pooled object.
Pool.StrategyType - Enum in org.eclipse.jetty.util
The type of the strategy to use for the pool.
poolFor(int, boolean) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
port(int) - Method in interface org.eclipse.jetty.client.api.Request
 
port(int) - Method in class org.eclipse.jetty.client.HttpRequest
 
port(int) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
POST - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
POST(String) - Method in class org.eclipse.jetty.client.HttpClient
Creates a POST request to the specified URI.
POST(URI) - Method in class org.eclipse.jetty.client.HttpClient
Creates a POST request to the specified URI.
POST_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
postConfigure() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
postConfigure(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
Clear down after configuration.
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configurations
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.FragmentConfiguration
 
postConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
PostConstructAnnotationHandler - Class in org.eclipse.jetty.annotations
 
PostConstructAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.PostConstructAnnotationHandler
 
PostConstructCallback - Class in org.eclipse.jetty.plus.annotation
PostConstructCallback
PostConstructCallback(Class<?>, String) - Constructor for class org.eclipse.jetty.plus.annotation.PostConstructCallback
 
PostConstructCallback(String, String) - Constructor for class org.eclipse.jetty.plus.annotation.PostConstructCallback
 
POWERED_BY - Static variable in class org.eclipse.jetty.util.Jetty
 
PRAGMA - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
PREAMBLE - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.State
 
PrecompressedHttpContent - Class in org.eclipse.jetty.http
 
PrecompressedHttpContent(HttpContent, HttpContent, CompressedContentFormat) - Constructor for class org.eclipse.jetty.http.PrecompressedHttpContent
 
PRECONDITION_FAILED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PRECONDITION_FAILED_412 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
PRECONDITION_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PRECONDITION_REQUIRED_428 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
preconfigure(Resource, Resource, Resource) - Static method in class org.eclipse.jetty.quickstart.PreconfigureQuickStartWar
 
preConfigure() - Method in class org.eclipse.jetty.webapp.WebAppContext
Pre configure the web application.
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
Check to see if there have been any bundle symbolic names added of bundles that should be regarded as being on the container classpath, and scanned for fragments, tlds etc etc.
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
 
preConfigure(WebAppContext) - Method in interface org.eclipse.jetty.webapp.Configuration
Set up for configuration.
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configuration.Wrapper
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.Configurations
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.FragmentConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
preConfigure(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebXmlConfiguration
 
PreconfigureQuickStartWar - Class in org.eclipse.jetty.quickstart
 
PreconfigureQuickStartWar() - Constructor for class org.eclipse.jetty.quickstart.PreconfigureQuickStartWar
 
preCreateConnections(int) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
preCreateConnections(int) - Method in interface org.eclipse.jetty.client.ConnectionPool
Optionally pre-create up to connectionCount connections so they are immediately ready for use.
PreDestroyAnnotationHandler - Class in org.eclipse.jetty.annotations
 
PreDestroyAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.PreDestroyAnnotationHandler
 
PreDestroyCallback - Class in org.eclipse.jetty.plus.annotation
PreDestroyCallback
PreDestroyCallback(Class<?>, String) - Constructor for class org.eclipse.jetty.plus.annotation.PreDestroyCallback
 
PreDestroyCallback(String, String) - Constructor for class org.eclipse.jetty.plus.annotation.PreDestroyCallback
 
PreEncodedHttpField - Class in org.eclipse.jetty.http
Pre encoded HttpField.
PreEncodedHttpField(String, String) - Constructor for class org.eclipse.jetty.http.PreEncodedHttpField
 
PreEncodedHttpField(HttpHeader, String) - Constructor for class org.eclipse.jetty.http.PreEncodedHttpField
 
PreEncodedHttpField(HttpHeader, String, String) - Constructor for class org.eclipse.jetty.http.PreEncodedHttpField
 
PREFACE - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
PREFACE_BYTES - Static variable in class org.eclipse.jetty.http2.frames.PrefaceFrame
The HTTP/2 preface bytes.
PREFACE_PREAMBLE_BYTES - Static variable in class org.eclipse.jetty.http2.frames.PrefaceFrame
The bytes of the HTTP/2 preface that form a legal HTTP/1.1 request, used in the direct upgrade.
PrefaceFrame - Class in org.eclipse.jetty.http2.frames
 
PrefaceFrame() - Constructor for class org.eclipse.jetty.http2.frames.PrefaceFrame
 
PrefaceGenerator - Class in org.eclipse.jetty.http2.generator
 
PrefaceGenerator() - Constructor for class org.eclipse.jetty.http2.generator.PrefaceGenerator
 
PrefaceParser - Class in org.eclipse.jetty.http2.parser
 
PrefaceParser(Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.PrefaceParser
 
PREFIX_GLOB - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
For path specs that have a hardcoded prefix and a trailing wildcard glob.
prepare(HttpRequest) - Method in class org.eclipse.jetty.client.http.ProtocolHttpUpgrader
 
prepare(HttpRequest) - Method in interface org.eclipse.jetty.client.HttpUpgrader
Prepares the request for the upgrade, for example by setting the HTTP method or by setting HTTP headers required for the upgrade.
prepare(HttpRequest) - Method in class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP
 
prepare(HttpRequest) - Method in class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP2
 
prepare(Request, ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHolder
Prepare to service a request.
prepareConstraintInfo(String, Request) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Find constraints that apply to the given path.
prepareConstraintInfo(String, Request) - Method in class org.eclipse.jetty.security.SecurityHandler
 
prepareContext(HttpServletRequest, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
prepareRequest(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
prepareRequest(ServletRequest) - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
prepareRequest(ServletRequest) - Method in interface org.eclipse.jetty.security.Authenticator
Called prior to validateRequest.
prepareRequest(ServletRequest) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
prepareResponse(Response, WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
prepareResponse(Response, WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
prepareResponse(Response, WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
prepareTables() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
Set up the tables in the database
prepend(HTTP2Flusher.Entry) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
prependFilter(FilterHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a preconstructed FilterHolder
prependFilterMapping(FilterMapping) - Method in class org.eclipse.jetty.servlet.ServletHandler
Convenience method to add a preconstructed FilterMapping
prependHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
Prepends a handler.
prependHandler(Handler, HandlerCollection) - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
 
prependToArray(T, T[], Class<?>) - Static method in class org.eclipse.jetty.util.ArrayUtil
Add element to the start of an array
prevent(ClassLoader) - Method in class org.eclipse.jetty.util.preventers.AbstractLeakPreventer
 
prevent(ClassLoader) - Method in class org.eclipse.jetty.util.preventers.AppContextLeakPreventer
 
prevent(ClassLoader) - Method in class org.eclipse.jetty.util.preventers.AWTLeakPreventer
 
prevent(ClassLoader) - Method in class org.eclipse.jetty.util.preventers.DriverManagerLeakPreventer
 
preVisitDirectory(Path, BasicFileAttributes) - Method in class org.eclipse.jetty.start.PathFinder
 
PRI - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
PRI_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
primitive - Variable in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
primitive - Variable in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
print(boolean) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(char) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(char[]) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(double) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(float) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(int) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(long) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(Object) - Method in class org.eclipse.jetty.server.ResponseWriter
 
print(String) - Method in class org.eclipse.jetty.server.HttpOutput
 
print(String) - Method in class org.eclipse.jetty.server.ResponseWriter
 
printable(byte[]) - Static method in class org.eclipse.jetty.util.StringUtil
 
printable(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
printf(String, Object...) - Method in class org.eclipse.jetty.server.ResponseWriter
 
printf(Locale, String, Object...) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println() - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(boolean) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(char) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(char[]) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(double) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(float) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(int) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(long) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(Object) - Method in class org.eclipse.jetty.server.ResponseWriter
 
println(String) - Method in class org.eclipse.jetty.server.HttpOutput
 
println(String) - Method in class org.eclipse.jetty.server.ResponseWriter
 
printTextResource(String) - Static method in class org.eclipse.jetty.start.Main
 
priority(PriorityFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Session
Sends the given PRIORITY frame.
priority(PriorityFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
PRIORITY - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
PRIORITY - Static variable in interface org.eclipse.jetty.http2.Flags
 
PRIORITY_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.PriorityFrame
 
PriorityBodyParser - Class in org.eclipse.jetty.http2.parser
 
PriorityBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.PriorityBodyParser
 
PriorityFrame - Class in org.eclipse.jetty.http2.frames
 
PriorityFrame(int, int, boolean) - Constructor for class org.eclipse.jetty.http2.frames.PriorityFrame
 
PriorityFrame(int, int, int, boolean) - Constructor for class org.eclipse.jetty.http2.frames.PriorityFrame
 
PriorityGenerator - Class in org.eclipse.jetty.http2.generator
 
PriorityGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.PriorityGenerator
 
proceed() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
proceed(Throwable) - Method in class org.eclipse.jetty.client.HttpExchange
 
proceed(HttpExchange, Throwable) - Method in class org.eclipse.jetty.client.HttpChannel
 
proceed(HttpExchange, Throwable) - Method in class org.eclipse.jetty.client.HttpSender
 
process() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
process() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
process() - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
process() - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
process() - Method in class org.eclipse.jetty.util.IteratingCallback
Method called by IteratingCallback.iterate() to process the asynchronous sub-task.
process() - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
 
process() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
process(String) - Method in class org.eclipse.jetty.start.TextFile
 
process(SocketAddress, ByteBuffer) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
process(SocketAddress, ByteBuffer) - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
process(Frame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
process(Frame, Callback) - Method in interface org.eclipse.jetty.http2.IStream
Processes the given frame, belonging to this stream.
process(BaseHome) - Method in class org.eclipse.jetty.start.Module
 
process(WebAppContext, Descriptor) - Method in interface org.eclipse.jetty.webapp.DescriptorProcessor
 
process(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
processAfters(XmlParser.Node) - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
processAndSetProperty(String, String, String) - Method in class org.eclipse.jetty.start.StartArgs
 
processBefores(XmlParser.Node) - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
processBinding(Node, App) - Method in interface org.eclipse.jetty.deploy.AppLifeCycle.Binding
Event called to process a AppLifeCycle binding.
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.DebugBinding
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.DebugListenerBinding
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.GlobalWebappConfigBinding
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.OrderedGroupBinding
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.StandardDeployer
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.StandardStarter
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.StandardStopper
 
processBinding(Node, App) - Method in class org.eclipse.jetty.deploy.bindings.StandardUndeployer
 
processBinding(Node, App) - Method in class org.eclipse.jetty.osgi.boot.OSGiDeployer
 
processBinding(Node, App) - Method in class org.eclipse.jetty.osgi.boot.OSGiUndeployer
 
processCommandLine(String[]) - Method in class org.eclipse.jetty.start.Main
 
processCommandLine(List<String>) - Method in class org.eclipse.jetty.start.Main
Convenience for processCommandLine(cmdLine.toArray(new String[cmdLine.size()]))
processConnectionError(Throwable, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Process an Error that originated from the connection.
processConstraintMapping(ConstraintMapping) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Create and combine the constraint with the existing processed constraints.
processConstraintMappingWithMethodOmissions(ConstraintMapping, Map<String, RoleInfo>) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Constraints that name method omissions are dealt with differently.
processDistributable() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
processFilesInResourcesFolder(File, Map<String, File>) - Method in interface org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper.IFilesInJettyHomeResourcesProcessor
 
processFilesInResourcesFolder(File, Map<String, File>) - Static method in class org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper
When we find files typically used for central logging configuration we do what it takes in this method to do what the user expects.
processHandlerError(Throwable, Callback) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
Process an Error that originated from the handler.
processIncludeCipherSuites(String[], List<String>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Deprecated.
no replacement
PROCESSING - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
PROCESSING - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PROCESSING_102 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
processMetadata(Map<String, Object>) - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
Process the OpenID Connect metadata discovered by OpenIdConfiguration.fetchOpenIdConnectMetadata().
processName() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
processOrdering() - Method in class org.eclipse.jetty.webapp.FragmentDescriptor
 
processOrdering() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
ProcessorUtils - Class in org.eclipse.jetty.util
ProcessorUtils provides access to runtime info about processors, that may be overridden by system properties or environment variables.
ProcessorUtils() - Constructor for class org.eclipse.jetty.util.ProcessorUtils
 
processReadableStreams() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
processSystemProperty(String, String, String) - Method in class org.eclipse.jetty.start.StartArgs
 
processVersion() - Method in class org.eclipse.jetty.webapp.WebDescriptor
 
processWritableStreams() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
produce() - Method in class org.eclipse.jetty.http2.HTTP2Connection.HTTP2Producer
 
produce() - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
produce() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
produce() - Method in interface org.eclipse.jetty.util.thread.ExecutionStrategy
Initiates (or resumes) the task production and consumption.
produce() - Method in interface org.eclipse.jetty.util.thread.ExecutionStrategy.Producer
Produces a task to be executed.
produce() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
produce() - Method in class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
produce() - Method in class org.eclipse.jetty.util.thread.strategy.ProduceConsume
 
produce() - Method in class org.eclipse.jetty.util.thread.strategy.ProduceExecuteConsume
 
produce(ByteBuffer, boolean, Callback) - Method in interface org.eclipse.jetty.client.util.AbstractRequestContent.Producer
 
ProduceConsume - Class in org.eclipse.jetty.util.thread.strategy
A strategy where the caller thread iterates over task production, submitting each task to an Executor for execution.
ProduceConsume(ExecutionStrategy.Producer, Executor) - Constructor for class org.eclipse.jetty.util.thread.strategy.ProduceConsume
 
produceContent() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
produceContent() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
produceContent() - Method in class org.eclipse.jetty.server.HttpChannel
Produce a HttpInput.Content object with data currently stored within the channel.
produceContent() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
produceContent(AbstractRequestContent.Producer) - Method in class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
Subclasses implement this method to produce content, without worrying about demand or exception handling.
ProduceExecuteConsume - Class in org.eclipse.jetty.util.thread.strategy
A strategy where the caller thread iterates over task production, submitting each task to an Executor for execution.
ProduceExecuteConsume(ExecutionStrategy.Producer, Executor) - Constructor for class org.eclipse.jetty.util.thread.strategy.ProduceExecuteConsume
 
PROGRESS_102_INFO - Static variable in class org.eclipse.jetty.http.HttpGenerator
 
Promise<C> - Interface in org.eclipse.jetty.util
A callback abstraction that handles completed/failed events of asynchronous operations.
Promise.Adapter<U> - Class in org.eclipse.jetty.util
Empty implementation of Promise.
Promise.Completable<S> - Class in org.eclipse.jetty.util
A CompletableFuture that is also a Promise.
Promise.Wrapper<W> - Class in org.eclipse.jetty.util
 
Prop(String, String, String) - Constructor for class org.eclipse.jetty.start.Props.Prop
 
PROP_LOCAL_ADDRESS - Static variable in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
PROP_LOCALES - Static variable in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
PROP_REMOTE_ADDRESS - Static variable in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
PropertiesConfigurationManager - Class in org.eclipse.jetty.deploy
FileConfigurationManager Supplies properties defined in a file.
PropertiesConfigurationManager() - Constructor for class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
PropertiesConfigurationManager(String) - Constructor for class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
PROPERTY_THIS_JETTY_XML_FOLDER_URL - Static variable in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
The value of this property points to the parent director of the jetty.xml configuration file currently executed.
PROPERTY_WEB_INF - Static variable in class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
 
PROPERTY_WEB_INF_URI - Static variable in class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
 
PropertyFileLoginModule - Class in org.eclipse.jetty.jaas.spi
PropertyFileLoginModule
PropertyFileLoginModule() - Constructor for class org.eclipse.jetty.jaas.spi.PropertyFileLoginModule
 
PropertyUserStore - Class in org.eclipse.jetty.security
This class monitors a property file of the format mentioned below and notifies registered listeners of the changes to the the given file.
PropertyUserStore() - Constructor for class org.eclipse.jetty.security.PropertyUserStore
 
PropertyUserStore.UserListener - Interface in org.eclipse.jetty.security
 
PropertyUserStoreManager - Class in org.eclipse.jetty.jaas
PropertyUserStoreManager Maintains a map of PropertyUserStores, keyed off the location of the property file containing the authentication and authorization information.
PropertyUserStoreManager() - Constructor for class org.eclipse.jetty.jaas.PropertyUserStoreManager
 
PROPFIND - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
PROPPATCH - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
Props - Class in org.eclipse.jetty.start
Management of Properties.
Props() - Constructor for class org.eclipse.jetty.start.Props
 
Props.Prop - Class in org.eclipse.jetty.start
 
PropsException - Exception Class in org.eclipse.jetty.start
An non-recoverable error with Props usage
PropsException(String) - Constructor for exception class org.eclipse.jetty.start.PropsException
 
PropsException(String, Throwable) - Constructor for exception class org.eclipse.jetty.start.PropsException
 
PropsException(Throwable) - Constructor for exception class org.eclipse.jetty.start.PropsException
 
protect(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Protect classes from modification by the web application by adding them to the AbstractConfiguration.getSystemClasses()
protectAndExpose(String...) - Method in class org.eclipse.jetty.webapp.AbstractConfiguration
Protect classes from modification by the web application by adding them to the AbstractConfiguration.getSystemClasses() and expose them to the web application by adding them as exclusions to the AbstractConfiguration.getServerClasses()
Protocol(List<String>, boolean) - Constructor for class org.eclipse.jetty.client.Origin.Protocol
Creates a Protocol with the given list of protocol names and whether it should negotiate the protocol.
PROTOCOL - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1002 indicates that an endpoint is terminating the connection due to a protocol error.
PROTOCOL - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
PROTOCOL_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates a generic HTTP/2 protocol violation.
ProtocolException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Per spec, a protocol error should result in a Close frame of status code 1002 (PROTOCOL_ERROR)
ProtocolException - Exception Class in org.eclipse.jetty.websocket.core.exception
Per spec, a protocol error should result in a Close frame of status code 1002 (PROTOCOL_ERROR)
ProtocolException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.ProtocolException
 
ProtocolException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.ProtocolException
 
ProtocolException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.ProtocolException
 
ProtocolException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.ProtocolException
 
ProtocolException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.ProtocolException
 
ProtocolException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.ProtocolException
 
ProtocolHandler - Interface in org.eclipse.jetty.client
A protocol handler performs HTTP protocol operations on behalf of the application, typically like a browser would.
ProtocolHandlers - Class in org.eclipse.jetty.client
A container for ProtocolHandlers accessible from HttpClient.getProtocolHandlers().
ProtocolHandlers() - Constructor for class org.eclipse.jetty.client.ProtocolHandlers
 
ProtocolHttpUpgrader - Class in org.eclipse.jetty.client.http
A HttpUpgrader that upgrades to a given protocol.
ProtocolHttpUpgrader(HttpDestination, String) - Constructor for class org.eclipse.jetty.client.http.ProtocolHttpUpgrader
 
ProtocolSession - Class in org.eclipse.jetty.quic.common
Represents an established stateful connection with a remote peer for a specific QUIC connection ID.
ProtocolSession(QuicSession) - Constructor for class org.eclipse.jetty.quic.common.ProtocolSession
 
ProtocolSession.Factory - Interface in org.eclipse.jetty.quic.common
A factory for protocol specific instances of ProtocolSession.
proxied() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedAttribute
Does the managed field exist on a proxy object?
proxied() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedOperation
Does the managed field exist on a proxy object?
Proxy(Origin.Address, boolean, SslContextFactory.Client, Origin.Protocol) - Constructor for class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
Proxy(Origin, SslContextFactory.Client) - Constructor for class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
PROXY - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Command
 
PROXY - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
PROXY - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
PROXY_AUTHENTICATE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
PROXY_AUTHENTICATION_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
PROXY_AUTHENTICATION_REQUIRED_407 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
PROXY_AUTHORIZATION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
PROXY_CONNECTION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ProxyAuthenticationProtocolHandler - Class in org.eclipse.jetty.client
A protocol handler that handles the 401 response code in association with the Proxy-Authenticate header.
ProxyAuthenticationProtocolHandler(HttpClient) - Constructor for class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
ProxyAuthenticationProtocolHandler(HttpClient, int) - Constructor for class org.eclipse.jetty.client.ProxyAuthenticationProtocolHandler
 
ProxyConfiguration - Class in org.eclipse.jetty.client
The configuration of the forward proxy to use with HttpClient.
ProxyConfiguration() - Constructor for class org.eclipse.jetty.client.ProxyConfiguration
 
ProxyConfiguration.Proxy - Class in org.eclipse.jetty.client
 
ProxyConnection - Class in org.eclipse.jetty.proxy
 
ProxyConnection(EndPoint, Executor, ByteBufferPool, ConcurrentMap<String, Object>) - Constructor for class org.eclipse.jetty.proxy.ProxyConnection
 
ProxyConnectionFactory - Class in org.eclipse.jetty.server
ConnectionFactory for the PROXY Protocol.
ProxyConnectionFactory() - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory
 
ProxyConnectionFactory(String) - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory
 
ProxyConnectionFactory.ProxyEndPoint - Class in org.eclipse.jetty.server
 
ProxyCustomizer - Class in org.eclipse.jetty.server
Customizer that extracts the real local and remote address:port pairs from a ProxyConnectionFactory and sets them on the request with ServletRequest.setAttribute(String, Object).
ProxyCustomizer() - Constructor for class org.eclipse.jetty.server.ProxyCustomizer
 
ProxyEndPoint(EndPoint, InetSocketAddress, InetSocketAddress) - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
Deprecated.
ProxyEndPoint(EndPoint, SocketAddress, SocketAddress) - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
ProxyInputStreamRequestContent(HttpServletRequest, HttpServletResponse, Request, InputStream) - Constructor for class org.eclipse.jetty.proxy.ProxyServlet.ProxyInputStreamRequestContent
 
ProxyProtocolClientConnectionFactory - Class in org.eclipse.jetty.client
ClientConnectionFactory for the PROXY protocol.
ProxyProtocolClientConnectionFactory.ProxyProtocolConnection - Class in org.eclipse.jetty.client
 
ProxyProtocolClientConnectionFactory.V1 - Class in org.eclipse.jetty.client
A ClientConnectionFactory for the PROXY protocol version 1.
ProxyProtocolClientConnectionFactory.V1.Tag - Class in org.eclipse.jetty.client
PROXY protocol version 1 metadata holder to be used in conjunction with Request.tag(Object).
ProxyProtocolClientConnectionFactory.V2 - Class in org.eclipse.jetty.client
A ClientConnectionFactory for the PROXY protocol version 2.
ProxyProtocolClientConnectionFactory.V2.Tag - Class in org.eclipse.jetty.client
PROXY protocol version 2 metadata holder to be used in conjunction with Request.tag(Object).
ProxyProtocolClientConnectionFactory.V2.Tag.Command - Enum in org.eclipse.jetty.client
 
ProxyProtocolClientConnectionFactory.V2.Tag.Family - Enum in org.eclipse.jetty.client
 
ProxyProtocolClientConnectionFactory.V2.Tag.Protocol - Enum in org.eclipse.jetty.client
 
ProxyProtocolClientConnectionFactory.V2.Tag.TLV - Class in org.eclipse.jetty.client
 
ProxyReader(HttpServletRequest, HttpServletResponse, Request, AsyncRequestContent) - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyReader
 
proxyRequestContent(HttpServletRequest, HttpServletResponse, Request) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet
 
proxyRequestContent(HttpServletRequest, HttpServletResponse, Request) - Method in class org.eclipse.jetty.proxy.ProxyServlet
Wraps the client-to-proxy request content in a Request.Content for the proxy-to-server request.
ProxyResponseListener(HttpServletRequest, HttpServletResponse) - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
ProxyResponseListener(HttpServletRequest, HttpServletResponse) - Constructor for class org.eclipse.jetty.proxy.ProxyServlet.ProxyResponseListener
 
proxyResponseStatus(Throwable) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
ProxyServlet - Class in org.eclipse.jetty.proxy
Servlet 3.0 asynchronous proxy servlet.
ProxyServlet() - Constructor for class org.eclipse.jetty.proxy.ProxyServlet
 
ProxyServlet.ProxyInputStreamRequestContent - Class in org.eclipse.jetty.proxy
 
ProxyServlet.ProxyResponseListener - Class in org.eclipse.jetty.proxy
 
ProxyServlet.Transparent - Class in org.eclipse.jetty.proxy
Convenience extension of ProxyServlet that offers transparent proxy functionalities.
ProxyWriter(HttpServletRequest, Response) - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyWriter
 
purgeEntries(Field) - Method in class org.eclipse.jetty.servlet.listener.ELContextCleaner
Deprecated.
 
push() - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
push(MetaData.Request) - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
push(MetaData.Request) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
push(MetaData.Request) - Method in class org.eclipse.jetty.server.HttpConnection
 
push(MetaData.Request) - Method in interface org.eclipse.jetty.server.HttpTransport
 
push(PushPromiseFrame, Stream.Listener) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given PUSH_PROMISE frame.
push(PushPromiseFrame, Promise<Stream>, Stream.Listener) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given PUSH_PROMISE frame.
push(PushPromiseFrame, Promise<Stream>, Stream.Listener) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
push(IStream, Promise<Stream>, PushPromiseFrame, Stream.Listener) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
push(IStream, Promise<Stream>, PushPromiseFrame, Stream.Listener) - Method in interface org.eclipse.jetty.http2.ISession
Enqueues the given PUSH_PROMISE frame to be written to the connection.
push(Connector, IStream, MetaData.Request) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
PUSH_PROMISE - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
PUSH_PROMISE - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
PushBuilderImpl - Class in org.eclipse.jetty.server
 
PushBuilderImpl(Request, HttpFields, String, String, String) - Constructor for class org.eclipse.jetty.server.PushBuilderImpl
 
pushListener(BiFunction<Request, Request, Response.CompleteListener>) - Method in class org.eclipse.jetty.client.HttpRequest
Sets a listener for pushed resources.
PushPromiseBodyParser - Class in org.eclipse.jetty.http2.parser
 
PushPromiseBodyParser(HeaderParser, Parser.Listener, HeaderBlockParser) - Constructor for class org.eclipse.jetty.http2.parser.PushPromiseBodyParser
 
PushPromiseFrame - Class in org.eclipse.jetty.http2.frames
 
PushPromiseFrame(int, int, MetaData.Request) - Constructor for class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
PushPromiseFrame(int, MetaData.Request) - Constructor for class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
PushPromiseGenerator - Class in org.eclipse.jetty.http2.generator
 
PushPromiseGenerator(HeaderGenerator, HpackEncoder) - Constructor for class org.eclipse.jetty.http2.generator.PushPromiseGenerator
 
put(E) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
put(String, E) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
put(String, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
put(String, String) - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
put(String, String) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Set a field.
put(String, String) - Method in class org.eclipse.jetty.util.Fields
Inserts or replaces the given name/value pair as a single-valued Fields.Field.
put(String, List<String>) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Set a field.
put(String, Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
put(String, Session) - Method in interface org.eclipse.jetty.server.session.SessionCache
Deprecated.
put(String, TYPE) - Method in class org.eclipse.jetty.util.HostMap
 
put(String, V) - Method in interface org.eclipse.jetty.util.Index.Mutable
Put an entry into the index.
put(String, V) - Method in class org.eclipse.jetty.util.MultiMap
Put multi valued entry.
put(ByteBuffer, ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Put data from one buffer into another, avoiding over/under flows
put(ProtocolHandler) - Method in class org.eclipse.jetty.client.ProtocolHandlers
Stores the given protocolHandler in this container.
put(HttpField) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
put(HttpHeader, String) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Set a field.
put(HttpHeader, HttpHeaderValue) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
put(PathSpec, E) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
put(Fields.Field) - Method in class org.eclipse.jetty.util.Fields
Inserts or replaces the given Fields.Field, mapped to the field's name
put(V) - Method in interface org.eclipse.jetty.util.Index.Mutable
Put a value as both a key and a value.
PUT - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
PUT_AS_INT - Static variable in enum org.eclipse.jetty.http.HttpMethod
 
putAll(Map<? extends String, ?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
putAllAttributes(Map<String, Object>) - Method in class org.eclipse.jetty.server.session.SessionData
 
putAllValues(Map<String, V>) - Method in class org.eclipse.jetty.util.MultiMap
Shorthand version of putAll
putAttribute(String, Object) - Method in class org.eclipse.jetty.jmx.ConnectorServer
Puts an attribute into the environment Map.
putAuthenticationFactory(Socks5.Authentication.Factory) - Method in class org.eclipse.jetty.client.Socks5Proxy
Provides this class with the given SOCKS5 authentication method.
putConvertor(String, JSON.Convertor) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
Associates the given JSON.Convertor to the given class name.
putCRLF(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
putDateField(String, long) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Sets the value of a date field.
putDateField(HttpHeader, long) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Sets the value of a date field.
putDecInt(ByteBuffer, int) - Static method in class org.eclipse.jetty.util.BufferUtil
 
putDecLong(ByteBuffer, long) - Static method in class org.eclipse.jetty.util.BufferUtil
 
putHeaders(HttpServletResponse, HttpContent, long) - Method in class org.eclipse.jetty.server.ResourceService
 
putHeaders(HttpServletResponse, HttpContent, long, boolean) - Static method in class org.eclipse.jetty.server.Response
 
putHeaders(HttpContent, long, boolean) - Method in class org.eclipse.jetty.server.Response
 
putHexInt(ByteBuffer, int) - Static method in class org.eclipse.jetty.util.BufferUtil
 
putIntLittleEndian(ByteBuffer, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Put an integer little endian
PutListenerMap - Class in org.eclipse.jetty.websocket.jakarta.common
 
PutListenerMap(Map<String, Object>, BiConsumer<String, Object>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
putLongField(String, long) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Sets the value of an long field.
putLongField(HttpHeader, long) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Sets the value of an long field.
putTo(ByteBuffer, HttpVersion) - Method in class org.eclipse.jetty.http.PreEncodedHttpField
 
putTo(HttpField, ByteBuffer) - Static method in class org.eclipse.jetty.http.HttpGenerator
 
putTo(HttpFields.Mutable, ByteBuffer) - Static method in class org.eclipse.jetty.http.HttpGenerator
 
putValue(String, Object) - Method in class org.eclipse.jetty.server.session.Session
Deprecated.
putValues(String, List<V>) - Method in class org.eclipse.jetty.util.MultiMap
Put multi valued entry.
putValues(String, V...) - Method in class org.eclipse.jetty.util.MultiMap
Put multi valued entry.

Q

QPACK_DECODER_STREAM_ERROR - Static variable in exception class org.eclipse.jetty.http3.qpack.QpackException
 
QPACK_DECOMPRESSION_FAILED - Static variable in exception class org.eclipse.jetty.http3.qpack.QpackException
 
QPACK_ENCODER_STREAM_ERROR - Static variable in exception class org.eclipse.jetty.http3.qpack.QpackException
 
QpackDecoder - Class in org.eclipse.jetty.http3.qpack
 
QpackDecoder(Instruction.Handler) - Constructor for class org.eclipse.jetty.http3.qpack.QpackDecoder
 
QpackDecoder(Instruction.Handler, int) - Constructor for class org.eclipse.jetty.http3.qpack.QpackDecoder
Deprecated.
QpackDecoder.Handler - Interface in org.eclipse.jetty.http3.qpack
 
QpackEncoder - Class in org.eclipse.jetty.http3.qpack
 
QpackEncoder(Instruction.Handler) - Constructor for class org.eclipse.jetty.http3.qpack.QpackEncoder
 
QpackEncoder(Instruction.Handler, int) - Constructor for class org.eclipse.jetty.http3.qpack.QpackEncoder
Deprecated.
QpackException - Exception Class in org.eclipse.jetty.http3.qpack
 
QpackException.SessionException - Exception Class in org.eclipse.jetty.http3.qpack
A Session QPACK Exception.
QpackException.StreamException - Exception Class in org.eclipse.jetty.http3.qpack
A Stream QPACK exception.
QpackFieldPreEncoder - Class in org.eclipse.jetty.http3.qpack
 
QpackFieldPreEncoder() - Constructor for class org.eclipse.jetty.http3.qpack.QpackFieldPreEncoder
 
query(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
QUERY_STRING - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
queryExpiredSessions(SessionContext, long) - Method in interface org.eclipse.jetty.session.infinispan.QueryManager
 
queryExpiryByEntity() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
A less efficient query to find sessions whose expiry time has passed: retrieves the whole Entity.
queryExpiryByEntity(long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
A less efficient query to find sessions whose expiry time is before the given timeLimit.
queryExpiryByIndex() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
An efficient query to find sessions whose expiry time has passed: uses a projection query, which requires indexes to be uploaded.
queryExpiryByIndex(long) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
An efficient query to find sessions whose expiry time is before the given timeLimit: uses a projection query, which requires indexes to be uploaded.
QueryManager - Interface in org.eclipse.jetty.session.infinispan
 
QueryManagerFactory - Interface in org.eclipse.jetty.session.infinispan
 
queryString(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
QueuedThreadPool - Class in org.eclipse.jetty.util.thread
A thread pool with a queue of jobs to execute.
QueuedThreadPool() - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, int) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, int, int, BlockingQueue<Runnable>, ThreadGroup) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, int, int, BlockingQueue<Runnable>, ThreadGroup, ThreadFactory) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, int, BlockingQueue<Runnable>) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, int, BlockingQueue<Runnable>, ThreadGroup) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
QueuedThreadPool(int, int, BlockingQueue<Runnable>) - Constructor for class org.eclipse.jetty.util.thread.QueuedThreadPool
 
queuedToBegin(HttpExchange) - Method in class org.eclipse.jetty.client.HttpSender
 
QuicClientConnectorConfigurator - Class in org.eclipse.jetty.quic.client
QuicClientConnectorConfigurator() - Constructor for class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
QuicClientConnectorConfigurator(UnaryOperator<Connection>) - Constructor for class org.eclipse.jetty.quic.client.QuicClientConnectorConfigurator
 
QuicConfiguration - Class in org.eclipse.jetty.quic.common
A record that captures QUIC configuration parameters.
QuicConfiguration() - Constructor for class org.eclipse.jetty.quic.common.QuicConfiguration
 
QuicConnection - Class in org.eclipse.jetty.quic.common
A Connection implementation that receives and sends datagram packets via its associated DatagramChannelEndPoint.
QuicConnection(Executor, Scheduler, ByteBufferPool, EndPoint) - Constructor for class org.eclipse.jetty.quic.common.QuicConnection
 
quickStart(WebAppContext) - Method in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
QUICKSTART - Enum constant in enum org.eclipse.jetty.quickstart.QuickStartConfiguration.Mode
 
QUICKSTART_WEB_XML - Static variable in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
QuickStartConfiguration - Class in org.eclipse.jetty.quickstart
QuickStartConfiguration
QuickStartConfiguration() - Constructor for class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
QuickStartConfiguration.Mode - Enum in org.eclipse.jetty.quickstart
 
QuickStartDescriptorProcessor - Class in org.eclipse.jetty.quickstart
QuickStartDescriptorProcessor Handle extended elements for quickstart-web.xml
QuickStartDescriptorProcessor() - Constructor for class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
 
QuickStartGeneratorConfiguration - Class in org.eclipse.jetty.quickstart
QuickStartGeneratorConfiguration
QuickStartGeneratorConfiguration() - Constructor for class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
QuickStartGeneratorConfiguration(boolean) - Constructor for class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
QuicServerConnector - Class in org.eclipse.jetty.quic.server
A server side network connector that uses a DatagramChannel to listen on a network port for QUIC traffic.
QuicServerConnector(Server, Executor, Scheduler, ByteBufferPool, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.quic.server.QuicServerConnector
 
QuicServerConnector(Server, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.quic.server.QuicServerConnector
 
QuicSession - Class in org.eclipse.jetty.quic.common
Represents a logical connection with a remote peer, identified by a QUIC connection ID.
QuicSession(Executor, Scheduler, ByteBufferPool, QuicheConnection, QuicConnection, SocketAddress) - Constructor for class org.eclipse.jetty.quic.common.QuicSession
 
QuicSession.Listener - Interface in org.eclipse.jetty.quic.common
A listener for QuicSession events.
QuicSessionContainer - Class in org.eclipse.jetty.quic.common
A container that tracks QuicSession instances.
QuicSessionContainer() - Constructor for class org.eclipse.jetty.quic.common.QuicSessionContainer
 
QuicStreamEndPoint - Class in org.eclipse.jetty.quic.common
An EndPoint implementation on top of a QUIC stream.
QuicStreamEndPoint(Scheduler, QuicSession, long) - Constructor for class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
QuietException - Interface in org.eclipse.jetty.io
A Quiet Exception.
QuietServletException - Exception Class in org.eclipse.jetty.server
A ServletException that is logged less verbosely than a normal ServletException.
QuietServletException() - Constructor for exception class org.eclipse.jetty.server.QuietServletException
 
QuietServletException(String) - Constructor for exception class org.eclipse.jetty.server.QuietServletException
 
QuietServletException(String, Throwable) - Constructor for exception class org.eclipse.jetty.server.QuietServletException
 
QuietServletException(Throwable) - Constructor for exception class org.eclipse.jetty.server.QuietServletException
 
quote(Appendable, String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Quote a string into an Appendable.
quote(String) - Static method in class org.eclipse.jetty.start.CommandLineBuilder
quote(String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Quote a string.
quote(String) - Static method in class org.eclipse.jetty.websocket.core.internal.util.TextUtils
Create a hint of what the text is like.
QUOTED_PRINTABLE_TRANSFER_ENCODING - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
QuotedCSV - Class in org.eclipse.jetty.http
Implements a quoted comma separated list of values in accordance with RFC7230.
QuotedCSV(boolean, String...) - Constructor for class org.eclipse.jetty.http.QuotedCSV
 
QuotedCSV(String...) - Constructor for class org.eclipse.jetty.http.QuotedCSV
 
QuotedCSVParser - Class in org.eclipse.jetty.http
Implements a quoted comma separated list parser in accordance with RFC7230.
QuotedCSVParser(boolean) - Constructor for class org.eclipse.jetty.http.QuotedCSVParser
 
QuotedQualityCSV - Class in org.eclipse.jetty.http
Implements a quoted comma separated list of quality values in accordance with RFC7230 and RFC7231.
QuotedQualityCSV() - Constructor for class org.eclipse.jetty.http.QuotedQualityCSV
Sorts values with equal quality according to the length of the value String.
QuotedQualityCSV(String[]) - Constructor for class org.eclipse.jetty.http.QuotedQualityCSV
Sorts values with equal quality according to given order.
QuotedQualityCSV(ToIntFunction<String>) - Constructor for class org.eclipse.jetty.http.QuotedQualityCSV
Orders values with equal quality with the given function.
QuotedStringTokenizer - Class in org.eclipse.jetty.util
StringTokenizer with Quoting support.
QuotedStringTokenizer(String) - Constructor for class org.eclipse.jetty.util.QuotedStringTokenizer
 
QuotedStringTokenizer(String, String) - Constructor for class org.eclipse.jetty.util.QuotedStringTokenizer
 
QuotedStringTokenizer(String, String, boolean) - Constructor for class org.eclipse.jetty.util.QuotedStringTokenizer
 
QuotedStringTokenizer(String, String, boolean, boolean) - Constructor for class org.eclipse.jetty.util.QuotedStringTokenizer
 
quoteIfNeeded(StringBuilder, String) - Static method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
quoteIfNeeded(StringBuilder, String, String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Append into buf the provided string, adding quotes if needed.
quoteIfNeeded(String, String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Quote a string.
quoteOnly(Appendable, String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Quote a string into an Appendable.

R

RANDOM - Enum constant in enum org.eclipse.jetty.util.Pool.StrategyType
A strategy that looks for an entry by iterating from a random starting index.
RandomConnectionPool - Class in org.eclipse.jetty.client
A ConnectionPool that provides connections randomly among the ones that are available.
RandomConnectionPool(HttpDestination, int, Callback, int) - Constructor for class org.eclipse.jetty.client.RandomConnectionPool
 
RANGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
RANGE_NOT_SATISFIABLE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
RANGE_NOT_SATISFIABLE_416 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
RangeWriter - Interface in org.eclipse.jetty.server.resource
Interface for writing sections (ranges) of a single resource (SeekableByteChannel, Resource, etc) to an outputStream.
RateControl - Interface in org.eclipse.jetty.http2.parser
Controls rate of events via RateControl.onEvent(Object).
RateControl.Factory - Interface in org.eclipse.jetty.http2.parser
Factory to create RateControl instances.
rateControlOnEvent(Object) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
RateCounter - Class in org.eclipse.jetty.util.statistic
Counts the rate that Longs are added to this from the time of creation or the last call to RateCounter.reset().
RateCounter() - Constructor for class org.eclipse.jetty.util.statistic.RateCounter
 
RateStatistic - Class in org.eclipse.jetty.util.statistic
Statistics on a time sequence rate.
RateStatistic(long, TimeUnit) - Constructor for class org.eclipse.jetty.util.statistic.RateStatistic
 
RawArgs - Class in org.eclipse.jetty.start
 
RawArgs() - Constructor for class org.eclipse.jetty.start.RawArgs
 
RawArgs.Entry - Class in org.eclipse.jetty.start
 
RawHTTP2ServerConnectionFactory - Class in org.eclipse.jetty.http2.server
 
RawHTTP2ServerConnectionFactory(ServerSessionListener) - Constructor for class org.eclipse.jetty.http2.server.RawHTTP2ServerConnectionFactory
 
RawHTTP2ServerConnectionFactory(HttpConfiguration, ServerSessionListener) - Constructor for class org.eclipse.jetty.http2.server.RawHTTP2ServerConnectionFactory
 
RawHTTP2ServerConnectionFactory(HttpConfiguration, ServerSessionListener, String...) - Constructor for class org.eclipse.jetty.http2.server.RawHTTP2ServerConnectionFactory
 
RawHTTP3ServerConnectionFactory - Class in org.eclipse.jetty.http3.server
 
RawHTTP3ServerConnectionFactory(Session.Server.Listener) - Constructor for class org.eclipse.jetty.http3.server.RawHTTP3ServerConnectionFactory
 
RawHTTP3ServerConnectionFactory(HttpConfiguration, Session.Server.Listener) - Constructor for class org.eclipse.jetty.http3.server.RawHTTP3ServerConnectionFactory
 
read() - Method in class org.eclipse.jetty.server.HttpInput
 
read() - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
read() - Method in class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
read() - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
read(byte[]) - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
read(byte[], int, int) - Method in class org.eclipse.jetty.server.HttpInput
 
read(byte[], int, int) - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
read(byte[], int, int) - Method in class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
read(byte[], int, int) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
read(char[], int, int) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageReader
 
read(ByteBuffer) - Method in class org.eclipse.jetty.server.HttpInput
 
read(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
read(EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.proxy.ConnectHandler.DownstreamConnection
 
read(EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
read(EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
read(EndPoint, ByteBuffer, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Reads (with non-blocking semantic) into the given buffer from the given endPoint.
READ_CALLBACK - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
readBytes(InputStream) - Static method in class org.eclipse.jetty.util.IO
 
readData() - Method in interface org.eclipse.jetty.http3.api.Stream
Reads request content bytes or response content bytes.
ReaderDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
ReaderDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.ReaderDecoder
 
ReaderMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
ReaderMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.ReaderMessageSink
 
ReaderSource(Reader) - Constructor for class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
readFrom(File, ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
readFrom(InputStream, int, ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
readFrom(HttpInput.Content) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpInputInterceptor
 
readFrom(HttpInput.Content) - Method in interface org.eclipse.jetty.server.HttpInput.Interceptor
 
readFrom(MessageMarshaller.ProtoStreamReader) - Method in class org.eclipse.jetty.session.infinispan.SessionDataMarshaller
 
readLine() - Method in class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
ReadLineInputStream - Class in org.eclipse.jetty.util
Deprecated, for removal: This API element is subject to removal in a future version.
ReadLineInputStream(InputStream) - Constructor for class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
ReadLineInputStream(InputStream, int) - Constructor for class org.eclipse.jetty.util.ReadLineInputStream
Deprecated.
 
ReadLineInputStream.Termination - Enum in org.eclipse.jetty.util
Deprecated.
 
readObject(ClassLoader) - Method in class org.eclipse.jetty.util.ClassLoadingObjectInputStream
 
readonly() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedAttribute
Is the managed field read-only? Required only when a setter exists but should not be exposed via JMX
ReadyTask(Invocable.InvocationType, Runnable) - Constructor for class org.eclipse.jetty.util.thread.Invocable.ReadyTask
 
reason() - Method in class org.eclipse.jetty.quic.common.CloseInfo
 
reason(String) - Method in class org.eclipse.jetty.client.HttpResponse
 
REASON - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
rebind(String, Object) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
rebind(String, Object) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
rebind(String, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Overwrite or create a binding from Name to Object
rebind(Name, Object) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
rebind(Name, Object) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
rebind(Name, Object) - Method in class org.eclipse.jetty.jndi.NamingContext
Overwrite or create a binding
REBIND - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
receive() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
receive() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
receive() - Method in class org.eclipse.jetty.client.HttpReceiver
 
receive() - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
receive() - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
receive(ByteBuffer) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
Receives data into the given buffer from the returned address.
RECEIVED - Enum constant in enum org.eclipse.jetty.http2.CloseState.Event
 
reclaim(HttpInput.Content) - Method in interface org.eclipse.jetty.server.ContentProducer
Free up the content by calling Callback.succeeded() on it and updating this instance' internal state.
RECOGNIZED - Enum constant in enum org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting can work with the given bytes.
record() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
Records a sample value.
record(long) - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
Records a sample value.
recordBytesIn(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordBytesOut(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordDuration(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordLastOpCode(Frame, byte) - Method in class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
recordMessagesIn(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordMessagesOut(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordSessionTime(Session) - Method in class org.eclipse.jetty.server.session.SessionHandler
Record length of time session has been active.
recurseDepth - Variable in class org.eclipse.jetty.util.PathWatcher.Config
 
recycle() - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
recycle() - Method in class org.eclipse.jetty.fcgi.server.HttpChannelOverFCGI
 
recycle() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection.ServerHttpChannelOverHTTP2
 
recycle() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
recycle() - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
recycle() - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
recycle() - Method in interface org.eclipse.jetty.server.ContentProducer
Clear the interceptor and call Destroyable.destroy() on it if it implements Destroyable.
recycle() - Method in class org.eclipse.jetty.server.HttpChannel
 
recycle() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
recycle() - Method in class org.eclipse.jetty.server.HttpChannelState
 
recycle() - Method in class org.eclipse.jetty.server.HttpInput
 
recycle() - Method in class org.eclipse.jetty.server.HttpOutput
 
recycle() - Method in class org.eclipse.jetty.server.Request
 
recycle() - Method in class org.eclipse.jetty.server.Response
 
redeemAuthCode(OpenIdConfiguration) - Method in class org.eclipse.jetty.security.openid.OpenIdCredentials
 
redirect(Request, Response) - Method in class org.eclipse.jetty.client.HttpRedirector
Redirects the given response, blocking until the redirect is complete.
redirect(Request, Response, Response.CompleteListener) - Method in class org.eclipse.jetty.client.HttpRedirector
Redirects the given response asynchronously.
REDIRECT_PATH - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
redirectEntity(String, URL) - Method in class org.eclipse.jetty.xml.XmlParser
 
RedirectPatternRule - Class in org.eclipse.jetty.rewrite.handler
Issues a (3xx) Redirect response whenever the rule finds a match.
RedirectPatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
 
RedirectPatternRule(String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
 
RedirectProtocolHandler - Class in org.eclipse.jetty.client
A protocol handler that handles redirect status codes 301, 302, 303, 307 and 308.
RedirectProtocolHandler(HttpClient) - Constructor for class org.eclipse.jetty.client.RedirectProtocolHandler
 
RedirectRegexRule - Class in org.eclipse.jetty.rewrite.handler
Issues a (3xx) Redirect response whenever the rule finds a match via regular expression.
RedirectRegexRule() - Constructor for class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
 
RedirectRegexRule(String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
 
RedirectUtil - Class in org.eclipse.jetty.rewrite.handler
Utility for managing redirect based rules
RedirectUtil() - Constructor for class org.eclipse.jetty.rewrite.handler.RedirectUtil
 
REFERER - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
ReflectUtils - Class in org.eclipse.jetty.websocket.core.internal.util
 
ReflectUtils() - Constructor for class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
refresh() - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
refresh() - Method in class org.eclipse.jetty.security.jaspi.provider.JaspiAuthConfigProvider
 
refresh() - Method in class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
REFUSED_STREAM_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that a stream was rejected before application processing.
RegexPathSpec - Class in org.eclipse.jetty.http.pathmap
RegexPathSpec is a PathSpec implementation for a PathMappings instance.
RegexPathSpec(String) - Constructor for class org.eclipse.jetty.http.pathmap.RegexPathSpec
 
RegexRule - Class in org.eclipse.jetty.rewrite.handler
Abstract rule to use as a base class for rules that match with a regular expression.
RegexRule() - Constructor for class org.eclipse.jetty.rewrite.handler.RegexRule
 
RegexRule(String) - Constructor for class org.eclipse.jetty.rewrite.handler.RegexRule
 
RegexSet - Class in org.eclipse.jetty.util
A Set of Regular expressions strings.
RegexSet() - Constructor for class org.eclipse.jetty.util.RegexSet
 
register(int, LifeCycle...) - Static method in class org.eclipse.jetty.util.thread.ShutdownThread
 
register(Class<?>) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Add a WebSocket mapping at PathSpec "/" for a creator which creates the endpointClass
register(Class<? extends Encoder>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
register(String, Class<? extends Extension>) - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
register(Path, PathWatcher.Config) - Method in class org.eclipse.jetty.util.PathWatcher
 
register(Callback) - Method in class org.eclipse.jetty.io.FillInterest
Call to register interest in a callback when a read is possible.
register(LifeCycle...) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
register(LifeCycle...) - Static method in class org.eclipse.jetty.util.thread.ShutdownThread
 
registerAll() - Method in class org.eclipse.jetty.start.Modules
 
registerAll(Class<? extends Encoder>[]) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
registerAll(List<Class<? extends Encoder>>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
registerAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
registerAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ServiceApp
 
registerAsOSGiService() - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.ServiceApp
 
registerConfigProvider(AuthConfigProvider, String, String, String) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
registerConfigProvider(String, Map, String, String, String) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
RegisteredDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
 
RegisteredDecoder(Class<? extends Decoder>, Class<? extends Decoder>, Class<?>, EndpointConfig, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
RegisteredDecoder(Class<? extends Decoder>, Class<? extends Decoder>, Class<?>, EndpointConfig, WebSocketComponents, boolean) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
RegisteredEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
 
RegisteredEncoder(Class<? extends Encoder>, Class<? extends Encoder>, Class<?>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
RegisteredEncoder(Class<? extends Encoder>, Class<? extends Encoder>, Class<?>, boolean) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
registeredFilesInJettyHomeResourcesProcessors - Static variable in class org.eclipse.jetty.osgi.boot.internal.webapp.LibExtClassLoaderHelper
 
RegisteredMessageHandler - Class in org.eclipse.jetty.websocket.jakarta.common
 
RegisteredMessageHandler(byte, Class<?>, MessageHandler) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.RegisteredMessageHandler
 
registerHandler(AnnotationIntrospector.IntrospectableAnnotationHandler) - Method in class org.eclipse.jetty.annotations.AnnotationIntrospector
 
registerMarshallers(SerializationContext) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSerializationContextInitializer
 
registerSchema(SerializationContext) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSerializationContextInitializer
 
registerUserListener(PropertyUserStore.UserListener) - Method in class org.eclipse.jetty.security.PropertyUserStore
Registers a listener to be notified of the contents of the property file
registerVisitor(String, Method) - Method in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
Register a method to be called back when visiting the node with the given name.
Registration() - Constructor for class org.eclipse.jetty.servlet.FilterHolder.Registration
 
Registration() - Constructor for class org.eclipse.jetty.servlet.ServletHolder.Registration
 
RelativeOrdering - Class in org.eclipse.jetty.webapp
Relative Fragment Ordering
RelativeOrdering(MetaData) - Constructor for class org.eclipse.jetty.webapp.RelativeOrdering
 
relativePath(String, String, String) - Static method in class org.eclipse.jetty.http.pathmap.ServletPathSpec
Relative path.
relativize(String) - Method in class org.eclipse.jetty.client.HttpSender
 
release() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
release() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
release() - Method in class org.eclipse.jetty.client.HttpChannel
 
release() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
release() - Method in interface org.eclipse.jetty.http.HttpContent
 
release() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
release() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
release() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
release() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
Decrements the retained counter of this buffer.
release() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Unbind this NamingEntry entirely
release() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
release() - Method in class org.eclipse.jetty.util.compression.CompressionPool.Entry
 
release() - Method in class org.eclipse.jetty.util.Pool.Entry
Releases this Entry.
release(String, Session) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Finish using the Session object.
release(String, Session) - Method in interface org.eclipse.jetty.server.session.SessionCache
Finish using a Session.
release(ByteBuffer) - Method in interface org.eclipse.jetty.client.ContentDecoder
Releases the ByteBuffer returned by ContentDecoder.decode(ByteBuffer).
release(ByteBuffer) - Method in class org.eclipse.jetty.http.GZIPContentDecoder
Releases an allocated buffer.
release(ByteBuffer) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
release(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferPool.Lease
 
release(ByteBuffer) - Method in interface org.eclipse.jetty.io.ByteBufferPool
Returns a ByteBuffer, usually obtained with ByteBufferPool.acquire(int, boolean) (but not necessarily), making it available for recycling and reuse.
release(ByteBuffer) - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
release(ByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
release(ByteBuffer) - Method in class org.eclipse.jetty.io.NullByteBufferPool
 
release(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
release(Connection) - Method in interface org.eclipse.jetty.client.ConnectionPool
Returns the given connection, previously obtained via ConnectionPool.acquire(boolean), back to this ConnectionPool.
release(Connection) - Method in class org.eclipse.jetty.client.HttpDestination
 
release(Connection) - Method in class org.eclipse.jetty.client.ValidatingConnectionPool
 
release(HttpChannelOverFCGI) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
release(HttpChannelOverHTTP2) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
release(CompressionPool.Entry) - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
release(Pool.Entry) - Method in class org.eclipse.jetty.util.Pool
Releases an acquired entry to the pool.
released(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
released(Connection) - Method in class org.eclipse.jetty.client.LeakTrackingConnectionPool
 
released(T) - Method in class org.eclipse.jetty.util.LeakDetector
Tracks the resource as been released.
releaseDeflater() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
releaseExcessMemory(boolean, Consumer<Boolean>) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
releaseExcessMemory(boolean, Consumer<Boolean>) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
releaseExcessMemory(boolean, Consumer<Boolean>) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
releaseExcessMemory(boolean, Consumer<Boolean>) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
releaseInflater() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
releaseMemory(boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
releaseMemory(boolean) - Method in class org.eclipse.jetty.io.LogarithmicArrayByteBufferPool
 
releaseMemory(boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
reload() - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
reload(Consumer<SslContextFactory>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
remaining() - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
remaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
remaining() - Method in class org.eclipse.jetty.server.HttpInput.Content
Get the number of bytes remaining in the buffer.
remaining() - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
remaining(ByteBuffer...) - Static method in class org.eclipse.jetty.util.BufferUtil
Get the remaining bytes in 0 or more buffers.
remainingCapacity() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
REMOTE_ADDR - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
REMOTE_ADDRESS_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The remote address attribute name.
REMOTE_PORT - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
REMOTE_PORT_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The remote port attribute name.
REMOTE_SOCKET_ADDRESS_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
RemoteEndpoint - Interface in org.eclipse.jetty.websocket.api
 
REMOTELY_CLOSED - Enum constant in enum org.eclipse.jetty.http2.CloseState
A half-close frame has been received.
remove() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
remove() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
remove() - Method in class org.eclipse.jetty.util.Pool.Entry
Removes this Entry from the Pool.
remove(int) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
remove(Class<? extends Configuration>...) - Method in class org.eclipse.jetty.webapp.Configurations
 
remove(Object) - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
remove(Object) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
remove(Object) - Method in class org.eclipse.jetty.server.handler.InetAccessSet
 
remove(Object) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
remove(Object) - Method in class org.eclipse.jetty.util.InetAddressSet
 
remove(Object) - Method in class org.eclipse.jetty.util.RegexSet
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
remove(Object) - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
remove(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
remove(Object, int) - Static method in class org.eclipse.jetty.util.LazyList
 
remove(Object, Object) - Static method in class org.eclipse.jetty.util.LazyList
 
remove(String) - Method in class org.eclipse.jetty.client.ProtocolHandlers
Removes the protocol handler with the given name.
remove(String) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Remove a field.
remove(String) - Method in interface org.eclipse.jetty.security.PropertyUserStore.UserListener
 
remove(String) - Method in class org.eclipse.jetty.util.Fields
Removes the Fields.Field with the given name
remove(String) - Method in interface org.eclipse.jetty.util.Index.Mutable
Remove an entry from the index.
remove(String...) - Method in class org.eclipse.jetty.webapp.Configurations
 
remove(URI, HttpCookie) - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
remove(URI, HttpCookie) - Method in class org.eclipse.jetty.util.HttpCookieStore
 
remove(ByteBuffer) - Method in interface org.eclipse.jetty.io.ByteBufferPool
Removes a ByteBuffer that was previously obtained with ByteBufferPool.acquire(int, boolean).
remove(ByteBuffer) - Method in class org.eclipse.jetty.io.LeakTrackingByteBufferPool
 
remove(EnumSet<HttpHeader>) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
remove(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
remove(Connection) - Method in interface org.eclipse.jetty.client.ConnectionPool
Removes the given connection from this ConnectionPool.
remove(Connection) - Method in class org.eclipse.jetty.client.HttpDestination
 
remove(Connection) - Method in class org.eclipse.jetty.client.ValidatingConnectionPool
 
remove(Connection, boolean) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
Deprecated.
remove(HttpExchange) - Method in class org.eclipse.jetty.client.HttpDestination
 
remove(HttpHeader) - Method in class org.eclipse.jetty.http.HttpFields.Mutable
Remove a field.
remove(PathSpec) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
remove(QuicStreamEndPoint, Throwable) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
remove(Pool.Entry) - Method in class org.eclipse.jetty.util.Pool
Removes an entry from the pool.
remove(Sweeper.Sweepable) - Method in class org.eclipse.jetty.util.thread.Sweeper
 
remove(Configuration...) - Method in class org.eclipse.jetty.webapp.Configurations
 
removeAll() - Method in class org.eclipse.jetty.util.HttpCookieStore.Empty
 
removeAll() - Method in class org.eclipse.jetty.util.HttpCookieStore
 
removeApp(App) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Remove the app from the tracking of the DeploymentManager
removeAppProvider(AppProvider) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
removeAttribute(String) - Method in interface org.eclipse.jetty.http2.api.Stream
 
removeAttribute(String) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.HttpChannelState
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.Request
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.Server
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.ServletAttributes
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.session.Session
 
removeAttribute(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
removeAttribute(String) - Method in interface org.eclipse.jetty.util.Attributes
 
removeAttribute(String) - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
removeAttribute(String) - Method in class org.eclipse.jetty.util.AttributesMap
 
removeAttribute(String) - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
removeAttribute(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
removeAuthentication(Authentication) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
 
removeAuthentication(Authentication) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
removeAuthenticationFactory(byte) - Method in class org.eclipse.jetty.client.Socks5Proxy
Removes the authentication of the given method.
removeAuthenticationResult(Authentication.Result) - Method in interface org.eclipse.jetty.client.api.AuthenticationStore
 
removeAuthenticationResult(Authentication.Result) - Method in class org.eclipse.jetty.client.HttpAuthenticationStore
 
removeBean(Object) - Method in interface org.eclipse.jetty.util.component.Container
Removes the given bean.
removeBean(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
removeBean(Object, Object) - Static method in interface org.eclipse.jetty.util.component.Container
A utility method to remove a bean from a container.
removeBeans() - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Removes all bean
removeBinding(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
 
removeBinding(AppLifeCycle.Binding) - Method in class org.eclipse.jetty.deploy.AppLifeCycle
 
removeConfiguration(Class<? extends Configuration>...) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
removeConfiguration(Configuration...) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
removeConnectionFactory(String) - Method in class org.eclipse.jetty.server.AbstractConnector
 
removeConnector(Connector) - Method in class org.eclipse.jetty.server.Server
Convenience method which calls Server.getConnectors() and Server.setConnectors(Connector[]) to remove a connector.
removeConstraintMappingsForPath(String, List<ConstraintMapping>) - Static method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Take out of the constraint mappings those that match the given path.
removeContext(HttpContext) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
removeContext(String) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
removeContextAttribute(String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Remove a contextAttribute that will be set for every Context deployed by this provider.
removeContextAttribute(String) - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
removeConvertor(Class<?>) - Method in class org.eclipse.jetty.util.ajax.JSON
Unregisters a JSON.Convertor for a class.
removeConvertor(String) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
Removes the JSON.Convertor associated with the given class name.
removeConvertorFor(String) - Method in class org.eclipse.jetty.util.ajax.JSON
Unregisters a JSON.Convertor for a named class.
removed(Connection) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
removed(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Retained
 
removed(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
removed(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.MappedByteBufferPool.Retained
 
removedBundle(Bundle, BundleEvent, Object) - Method in class org.eclipse.jetty.osgi.boot.BundleContextProvider.ContextBundleTracker
 
removedBundle(Bundle, BundleEvent, Object) - Method in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider.WebAppTracker
 
removeDecorator(Decorator) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
removeDescriptorProcessor(DescriptorProcessor) - Method in class org.eclipse.jetty.webapp.MetaData
 
removeDestination(HttpDestination) - Method in class org.eclipse.jetty.client.HttpClient
 
removedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.JettyServerServiceTracker
 
removedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ContextTracker
 
removedService(ServiceReference, Object) - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.WebAppTracker
 
removeEdge(String, String) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
removeEdge(Edge) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.io.AbstractConnection
 
removeEventListener(EventListener) - Method in interface org.eclipse.jetty.io.Connection
Removes a listener of connection events.
removeEventListener(EventListener) - Method in class org.eclipse.jetty.io.SelectorManager
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.server.Request
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
removeEventListener(EventListener) - Method in interface org.eclipse.jetty.util.component.Container
Remove an event listener.
removeEventListener(EventListener) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
removeEventListener(EventListener) - Method in interface org.eclipse.jetty.util.component.LifeCycle
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
removeExcludedCipherSuites(List<String>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Deprecated.
no replacement
removeFile(File) - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
removeFile(String) - Method in class org.eclipse.jetty.util.component.FileDestroyable
 
removeFilterHolder(FilterHolder) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
removeFilterMapping(FilterMapping) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
removeFromArray(T[], Object) - Static method in class org.eclipse.jetty.util.ArrayUtil
 
removeFromEnvironment(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
removeFromEnvironment(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
removeFromEnvironment(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Remove a property from this Context's environment.
removeHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
removeHandshakeListener(SslHandshakeListener) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
removeHeader(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
removeIf(Predicate<MappedResource<E>>) - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
removeInternalParameters() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
removeListener(NamingContext.Listener) - Method in class org.eclipse.jetty.jndi.NamingContext
 
removeListener(HttpChannel.Listener) - Method in class org.eclipse.jetty.server.HttpChannel
Deprecated.
removeListener(PathWatcher.Listener) - Method in class org.eclipse.jetty.util.PathWatcher
Delete a listener
removeListener(Scanner.Listener) - Method in class org.eclipse.jetty.util.Scanner
Remove a registered listener
removeMapping(String) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Removes the mapping based on the given path spec.
removeMapping(PathSpec) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
removeMessageHandler(MessageHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
removeMessageHandler(MessageHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
removeNode(Node) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
removeNulls(T[]) - Static method in class org.eclipse.jetty.util.ArrayUtil
 
removeProxy(ProxyConfiguration.Proxy) - Method in class org.eclipse.jetty.client.ProxyConfiguration
Removes a proxy.
removeRegistration(String) - Method in class org.eclipse.jetty.security.jaspi.DefaultAuthConfigFactory
 
removeResourceAlias(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
removeSession(String, boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
Remove session from manager
removeSessionListener(WebSocketSessionListener) - Method in interface org.eclipse.jetty.websocket.api.WebSocketContainer
Remove a WebSocketSessionListener from the container
removeSessionListener(WebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
removeSessionListener(WebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
removeSessionListener(JakartaWebSocketSessionListener) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
Remove a WebSocketSessionListener from the container
removeStream(IStream) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
removeStream(IStream) - Method in interface org.eclipse.jetty.http2.ISession
Removes the given stream.
removeThread(Thread) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
removeTransformer(ClassFileTransformer) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
removeUser(String) - Method in class org.eclipse.jetty.security.UserStore
 
removeValue(String) - Method in class org.eclipse.jetty.server.session.Session
Deprecated.
removeValue(String, V) - Method in class org.eclipse.jetty.util.MultiMap
Remove value.
removeVirtualHosts(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Removes an array of virtual host entries, if this removes all entries the _vhosts will be set to null
rename(String, String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
rename(String, String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
rename(String, String) - Method in class org.eclipse.jetty.jndi.NamingContext
Not supported
rename(Name, Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
rename(Name, Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
rename(Name, Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Not supported
renameTo(Resource) - Method in class org.eclipse.jetty.util.resource.EmptyResource
 
renameTo(Resource) - Method in class org.eclipse.jetty.util.resource.PathResource
 
renameTo(Resource) - Method in class org.eclipse.jetty.util.resource.Resource
Rename the given resource
renameTo(Resource) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
renameTo(Resource) - Method in class org.eclipse.jetty.util.resource.URLResource
Rename the given resource
renewId(HttpServletRequest) - Method in class org.eclipse.jetty.server.session.Session
Force a change to the id of a session.
renewSession(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
Change the session id.
renewSessionId(String, String, HttpServletRequest) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Generate a new id for a session and update across all SessionManagers.
renewSessionId(String, String, HttpServletRequest) - Method in interface org.eclipse.jetty.server.SessionIdManager
Change the existing session id.
renewSessionId(String, String, String, String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
renewSessionId(String, String, String, String) - Method in interface org.eclipse.jetty.server.session.SessionCache
Change the id of a Session.
renewSessionId(String, String, String, String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Change the existing session id.
renewSessionId(Session, String, String) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
Swap the id on a session.
reopen() - Method in interface org.eclipse.jetty.server.ContentProducer
Reset all internal state, making this is instance logically equivalent to a freshly allocated one.
reopen() - Method in class org.eclipse.jetty.server.HttpInput
 
reopen() - Method in class org.eclipse.jetty.server.HttpOutput
 
reopen() - Method in class org.eclipse.jetty.server.Response
 
reopen() - Method in class org.eclipse.jetty.server.ResponseWriter
 
replace(String, char, char) - Static method in class org.eclipse.jetty.util.StringUtil
Replace chars within string.
replace(String, String, String) - Static method in class org.eclipse.jetty.util.StringUtil
Replace substrings within string.
replaceCookie(HttpCookie) - Method in class org.eclipse.jetty.server.Response
Replace (or add) a cookie.
replaceFirst(String, String, String) - Static method in class org.eclipse.jetty.util.StringUtil
Replace first substrings within string.
replaceKey(SelectionKey) - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when the SelectionKey is replaced because the channel has been moved to a new selector.
replaceKey(SelectionKey) - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
REPLACEMENT - Static variable in class org.eclipse.jetty.util.Utf8Appendable
 
REPLACEMENT_UTF8 - Static variable in class org.eclipse.jetty.util.Utf8Appendable
 
replaces() - Method in class org.eclipse.jetty.ant.AntMetaInfConfiguration
 
replaces() - Method in class org.eclipse.jetty.ant.AntWebInfConfiguration
 
replaces() - Method in class org.eclipse.jetty.ant.AntWebXmlConfiguration
 
replaces() - Method in class org.eclipse.jetty.osgi.annotations.AnnotationConfiguration
 
replaces() - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
replaces() - Method in class org.eclipse.jetty.osgi.boot.OSGiWebInfConfiguration
 
replaces() - Method in interface org.eclipse.jetty.webapp.Configuration
Get a class that this class replaces/extends.
REPORT - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
reportComplianceViolation(CookieCompliance.Violation, String) - Method in class org.eclipse.jetty.http.CookieCutter
Deprecated.
 
reportComplianceViolation(CookieCompliance.Violation, String) - Method in class org.eclipse.jetty.http.RFC6265CookieParser
 
reportComplianceViolation(HttpCompliance.Violation) - Method in class org.eclipse.jetty.http.HttpParser
 
reportComplianceViolation(HttpCompliance.Violation, String) - Method in class org.eclipse.jetty.http.HttpParser
 
Request - Class in org.eclipse.jetty.server
Jetty Request.
Request - Interface in org.eclipse.jetty.client.api
Request represents an HTTP request, and offers a fluent interface to customize various attributes such as the path, the headers, the content, etc.
Request() - Constructor for class org.eclipse.jetty.http.HttpTester.Request
 
Request(long, String, String, HostPortHttpField, String, HttpVersion, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(long, String, HttpURI, HttpVersion, HttpFields) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(long, String, HttpURI, HttpVersion, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(long, String, HttpURI, HttpVersion, HttpFields, long, Supplier<HttpFields>) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(String, String, HostPortHttpField, String, HttpVersion, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(String, HttpURI, HttpVersion, HttpFields) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(String, HttpURI, HttpVersion, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(String, HttpURI, HttpVersion, HttpFields, long, Supplier<HttpFields>) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(HttpFields) - Constructor for class org.eclipse.jetty.http.MetaData.Request
 
Request(HttpChannel, HttpInput) - Constructor for class org.eclipse.jetty.server.Request
 
REQUEST - Static variable in class org.eclipse.jetty.servlet.FilterMapping
 
REQUEST_HEADER_FIELDS_TOO_LARGE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
REQUEST_HEADER_FIELDS_TOO_LARGE_431 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
REQUEST_METHOD - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
REQUEST_RANGE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
REQUEST_TIMEOUT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
REQUEST_TIMEOUT_408 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
REQUEST_URI - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
REQUEST_VERSION - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
Request.BeginListener - Interface in org.eclipse.jetty.client.api
Listener for the request begin event.
Request.CommitListener - Interface in org.eclipse.jetty.client.api
Listener for the request committed event.
Request.Content - Interface in org.eclipse.jetty.client.api
A reactive model to produce request content, similar to Flow.Publisher.
Request.Content.Consumer - Interface in org.eclipse.jetty.client.api
A reactive model to consume request content, similar to Flow.Subscriber.
Request.Content.Subscription - Interface in org.eclipse.jetty.client.api
The link between a content producer and a content consumer.
Request.ContentListener - Interface in org.eclipse.jetty.client.api
Listener for the request content event.
Request.FailureListener - Interface in org.eclipse.jetty.client.api
Listener for the request failed event.
Request.HeadersListener - Interface in org.eclipse.jetty.client.api
Listener for the request headers event.
Request.Listener - Interface in org.eclipse.jetty.client.api
Listener for all request events.
Request.Listener.Adapter - Class in org.eclipse.jetty.client.api
An empty implementation of Request.Listener
Request.QueuedListener - Interface in org.eclipse.jetty.client.api
Listener for the request queued event.
Request.RequestListener - Interface in org.eclipse.jetty.client.api
Common, empty, super-interface for request listeners.
Request.SuccessListener - Interface in org.eclipse.jetty.client.api
Listener for the request succeeded event.
requestAppGoal(String, String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Move an App through the AppLifeCycle to the desired Node, executing each lifecycle step in the process to reach the desired state.
requestAppGoal(String, String) - Method in class org.eclipse.jetty.deploy.jmx.DeploymentManagerMBean
 
requestAppGoal(App, String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Move an App through the AppLifeCycle to the desired Node, executing each lifecycle step in the process to reach the desired state.
requestComplete() - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
requestComplete(Throwable) - Method in class org.eclipse.jetty.client.HttpExchange
 
RequestContentAdapter - Class in org.eclipse.jetty.client.internal
Implements the conversion from ContentProvider to Request.Content.
RequestContentAdapter(ContentProvider) - Constructor for class org.eclipse.jetty.client.internal.RequestContentAdapter
 
requestDestroyed(Request, HttpServletRequest) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
requestInitialized(Request, HttpServletRequest) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
RequestLog - Interface in org.eclipse.jetty.server
A RequestLog can be attached to a RequestLogHandler to enable logging of requests/responses.
RequestLog.Collection - Class in org.eclipse.jetty.server
 
RequestLog.Writer - Interface in org.eclipse.jetty.server
Writes the generated log string to a log sink
RequestLogHandler - Class in org.eclipse.jetty.server.handler
This handler provides an alternate way (other than Server.setRequestLog(RequestLog)) to log request, that can be applied to a particular handler (eg context).
RequestLogHandler() - Constructor for class org.eclipse.jetty.server.handler.RequestLogHandler
 
RequestLogWriter - Class in org.eclipse.jetty.server
Writer which outputs pre-formatted request log strings to a file using RolloverFileOutputStream.
RequestLogWriter() - Constructor for class org.eclipse.jetty.server.RequestLogWriter
 
RequestLogWriter(String) - Constructor for class org.eclipse.jetty.server.RequestLogWriter
 
RequestNotifier - Class in org.eclipse.jetty.client
 
RequestNotifier(HttpClient) - Constructor for class org.eclipse.jetty.client.RequestNotifier
 
RequestParameterCallback - Class in org.eclipse.jetty.jaas.callback
RequestParameterCallback
RequestParameterCallback() - Constructor for class org.eclipse.jetty.jaas.callback.RequestParameterCallback
 
REQUIRE_TLD_BUNDLE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Comma separated list of bundles that contain tld file used by the webapp.
required() - Method in class org.eclipse.jetty.websocket.core.internal.util.InvokerUtils.Arg
 
REQUIRED_EXTENSION - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1010 indicates that an endpoint (client) is terminating the connection because it has expected the server to negotiate one or more extension, but the server didn't return them in the response message of the WebSocket handshake.
requireValidRFC2616Token(String, String) - Static method in class org.eclipse.jetty.http.Syntax
Per RFC2616: Section 2.2, a token follows these syntax rules
requireValidRFC6265CookieValue(String) - Static method in class org.eclipse.jetty.http.Syntax
Per RFC6265, Cookie.value follows these syntax rules
reserve() - Method in class org.eclipse.jetty.util.Pool
Creates a new disabled slot into the pool.
reserve(int) - Method in class org.eclipse.jetty.util.Pool
Deprecated.
Use Pool.reserve() instead
RESERVED - Static variable in class org.eclipse.jetty.client.Socks5
The reserved byte value: 0x0.
RESERVED - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
RESERVED_NAMES_NOT_DOLLAR_PREFIXED - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Deprecated.
no replacement because was mistakenly considered a violation
ReservedThreadExecutor - Class in org.eclipse.jetty.util.thread
A TryExecutor using pre-allocated/reserved threads from an external Executor.
ReservedThreadExecutor(Executor, int) - Constructor for class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
reset() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
reset() - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
reset() - Method in class org.eclipse.jetty.client.HttpReceiver
Resets the state of this HttpReceiver.
reset() - Method in class org.eclipse.jetty.client.HttpSender
 
reset() - Method in class org.eclipse.jetty.fcgi.parser.HeaderParser
 
reset() - Method in class org.eclipse.jetty.http.compression.HuffmanDecoder
 
reset() - Method in class org.eclipse.jetty.http.compression.NBitIntegerDecoder
Reset the internal state of the parser.
reset() - Method in class org.eclipse.jetty.http.compression.NBitStringDecoder
 
reset() - Method in class org.eclipse.jetty.http.HttpGenerator
 
reset() - Method in class org.eclipse.jetty.http.HttpParser
 
reset() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
reset() - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
reset() - Method in class org.eclipse.jetty.http2.client.http.HttpReceiverOverHTTP2
 
reset() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
reset() - Method in class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
reset() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
reset() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
reset() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
reset() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
reset() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
reset() - Method in class org.eclipse.jetty.server.AsyncContextState
 
reset() - Method in class org.eclipse.jetty.server.Cookies
 
reset() - Method in class org.eclipse.jetty.server.MultiPartParser
 
reset() - Method in class org.eclipse.jetty.server.Response
 
reset() - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
reset() - Method in class org.eclipse.jetty.start.Props
 
reset() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.DecoderStringBuilder
 
reset() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.Iso88591StringBuilder
 
reset() - Method in interface org.eclipse.jetty.util.CharsetStringBuilder
 
reset() - Method in class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
reset() - Method in class org.eclipse.jetty.util.IteratingCallback
Resets this callback.
reset() - Method in class org.eclipse.jetty.util.PathWatcher
Remove all current configs and listeners.
reset() - Method in class org.eclipse.jetty.util.Scanner
Clear the list of scannables.
reset() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
Resets the max and total to the current value.
reset() - Method in class org.eclipse.jetty.util.statistic.RateCounter
 
reset() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
Resets the statistics.
reset() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
Resets the statistics.
reset() - Method in class org.eclipse.jetty.util.thread.MonitoredQueuedThreadPool
Resets the statistics.
reset() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
reset() - Method in class org.eclipse.jetty.util.thread.ThreadPoolBudget
 
reset() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
reset() - Method in class org.eclipse.jetty.util.Utf8StringBuffer
 
reset() - Method in class org.eclipse.jetty.util.Utf8StringBuilder
 
reset() - Method in class org.eclipse.jetty.websocket.core.Frame
 
reset() - Method in class org.eclipse.jetty.websocket.core.internal.Parser
 
reset() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
reset(int) - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
reset(long) - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
Resets the max, total and current value to the given parameter.
reset(long, Throwable) - Method in interface org.eclipse.jetty.http3.api.Stream
Abruptly terminates this stream with the given error.
reset(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Resets the buffer's endianness to ByteOrder.BIG_ENDIAN and clears the buffer to be empty in flush mode.
reset(Deflater) - Method in class org.eclipse.jetty.util.compression.DeflaterPool
 
reset(Inflater) - Method in class org.eclipse.jetty.util.compression.InflaterPool
 
reset(ResetFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Stream
Sends the given RST_STREAM frame.
reset(ResetFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
reset(T) - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
RESET_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
RESET_CONTENT_205 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
RESET_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.ResetFrame
 
ResetBodyParser - Class in org.eclipse.jetty.http2.parser
 
ResetBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.ResetBodyParser
 
resetBuffer() - Method in class org.eclipse.jetty.server.HttpChannel
 
resetBuffer() - Method in interface org.eclipse.jetty.server.HttpOutput.Interceptor
Reset the buffers.
resetBuffer() - Method in class org.eclipse.jetty.server.HttpOutput
 
resetBuffer() - Method in class org.eclipse.jetty.server.Response
 
resetBuffer() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
resetContent() - Method in class org.eclipse.jetty.server.Response
 
resetForForward() - Method in class org.eclipse.jetty.server.Response
 
ResetFrame - Class in org.eclipse.jetty.http2.frames
 
ResetFrame(int, int) - Constructor for class org.eclipse.jetty.http2.frames.ResetFrame
 
ResetGenerator - Class in org.eclipse.jetty.http2.generator
 
ResetGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.ResetGenerator
 
resetParameters() - Method in class org.eclipse.jetty.server.Request
 
resetParsedClasses() - Method in class org.eclipse.jetty.annotations.AnnotationParser
Remove any parsed class names.
resetResponse() - Method in class org.eclipse.jetty.client.HttpExchange
 
resetStats() - Method in class org.eclipse.jetty.io.ManagedSelector
 
resetStats() - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
resetWriter() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
resize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
resolve(String) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
resolve(String, int, Promise<List<InetSocketAddress>>) - Method in class org.eclipse.jetty.util.SocketAddressResolver.Async
 
resolve(String, int, Promise<List<InetSocketAddress>>) - Method in interface org.eclipse.jetty.util.SocketAddressResolver
Resolves via DNS the given host and port, within the connect timeout, returning a list of InetSocketAddress through the given Promise.
resolve(String, int, Promise<List<InetSocketAddress>>) - Method in class org.eclipse.jetty.util.SocketAddressResolver.Sync
 
resolve(Path) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
resolve(Path) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
resolve(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaData
Resolve all servlet/filter/listener metadata from all sources: descriptors and annotations.
resolveAlias(Resource) - Static method in class org.eclipse.jetty.util.resource.Resource
Attempt to resolve the real path of a Resource to potentially remove any symlinks causing the Resource to be an alias.
resolveClass(ObjectStreamClass) - Method in class org.eclipse.jetty.util.ClassLoadingObjectInputStream
 
resolveClasses(WebAppContext, Map<String, Set<String>>) - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
resolveDestination(Request) - Method in class org.eclipse.jetty.client.HttpClient
 
resolveDestination(Origin) - Method in class org.eclipse.jetty.client.HttpClient
Returns, creating it if absent, the destination with the given origin.
resolveEntity(String, String) - Method in class org.eclipse.jetty.xml.XmlParser
 
resolveExtraXmls() - Method in class org.eclipse.jetty.start.StartArgs
 
resolvePath(String, String) - Static method in class org.eclipse.jetty.xml.XmlConfiguration
Utility method to resolve a provided path against a directory.
resolvePropertyFiles() - Method in class org.eclipse.jetty.start.StartArgs
 
resolvePropertyValue(String) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
recursively substitute the ${sysprop} by their actual system property.
resolveProxyClass(String[]) - Method in class org.eclipse.jetty.util.ClassLoadingObjectInputStream
 
resolveStartupClasses() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.DiscoveredServletContainerInitializerHolder
 
resolveStartupClasses() - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
resolveTempDirectory(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
Get a temporary directory in which to unpack the war etc etc.
Resource - Class in org.eclipse.jetty.plus.jndi
Resource
Resource - Class in org.eclipse.jetty.util.resource
Abstract resource class.
Resource() - Constructor for class org.eclipse.jetty.util.resource.Resource
 
Resource(Object, String, Object) - Constructor for class org.eclipse.jetty.plus.jndi.Resource
 
Resource(String, Object) - Constructor for class org.eclipse.jetty.plus.jndi.Resource
 
RESOURCE_DIRS - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
If set, to a list of URLs, these resources are added to the context resource base as a resource collection.
ResourceAnnotationHandler - Class in org.eclipse.jetty.annotations
 
ResourceAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.ResourceAnnotationHandler
 
ResourceCollators - Class in org.eclipse.jetty.util.resource
 
ResourceCollators() - Constructor for class org.eclipse.jetty.util.resource.ResourceCollators
 
ResourceCollection - Class in org.eclipse.jetty.util.resource
A collection of resources (dirs).
ResourceCollection() - Constructor for class org.eclipse.jetty.util.resource.ResourceCollection
Instantiates an empty resource collection.
ResourceCollection(String) - Constructor for class org.eclipse.jetty.util.resource.ResourceCollection
Instantiates a new resource collection.
ResourceCollection(String[]) - Constructor for class org.eclipse.jetty.util.resource.ResourceCollection
Instantiates a new resource collection.
ResourceCollection(Collection<Resource>) - Constructor for class org.eclipse.jetty.util.resource.ResourceCollection
Instantiates a new resource collection.
ResourceCollection(Resource...) - Constructor for class org.eclipse.jetty.util.resource.ResourceCollection
Instantiates a new resource collection.
ResourceContentFactory - Class in org.eclipse.jetty.server
An HttpContent.Factory for transient content (not cached).
ResourceContentFactory(ResourceFactory, MimeTypes, CompressedContentFormat[]) - Constructor for class org.eclipse.jetty.server.ResourceContentFactory
 
ResourceFactory - Interface in org.eclipse.jetty.util.resource
ResourceFactory.
ResourceHandler - Class in org.eclipse.jetty.server.handler
Resource Handler.
ResourceHandler() - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler
 
ResourceHandler(ResourceService) - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler
 
ResourceHttpContent - Class in org.eclipse.jetty.http
HttpContent created from a Resource.
ResourceHttpContent(Resource, String) - Constructor for class org.eclipse.jetty.http.ResourceHttpContent
 
ResourceHttpContent(Resource, String, int) - Constructor for class org.eclipse.jetty.http.ResourceHttpContent
 
ResourceHttpContent(Resource, String, int, Map<CompressedContentFormat, HttpContent>) - Constructor for class org.eclipse.jetty.http.ResourceHttpContent
 
ResourcesAnnotationHandler - Class in org.eclipse.jetty.annotations
 
ResourcesAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.ResourcesAnnotationHandler
 
ResourceService - Class in org.eclipse.jetty.server
Abstract resource service, used by DefaultServlet and ResourceHandler
ResourceService() - Constructor for class org.eclipse.jetty.server.ResourceService
 
ResourceService.WelcomeFactory - Interface in org.eclipse.jetty.server
 
respond(HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Stream.Server
Responds to a request performed via Session.Client.newRequest(HeadersFrame, Client.Listener), sending the given HEADERS frame containing the response status code and response headers.
RESPONDER - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.Role
 
Response - Class in org.eclipse.jetty.server
Response provides the implementation for HttpServletResponse.
Response - Interface in org.eclipse.jetty.client.api
Response represents an HTTP response and offers methods to retrieve status code, HTTP version and headers.
Response() - Constructor for class org.eclipse.jetty.http.HttpTester.Response
 
Response(HttpVersion, int, String, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Response
 
Response(HttpVersion, int, String, HttpFields, long, Supplier<HttpFields>) - Constructor for class org.eclipse.jetty.http.MetaData.Response
 
Response(HttpVersion, int, HttpFields) - Constructor for class org.eclipse.jetty.http.MetaData.Response
 
Response(HttpVersion, int, HttpFields, long) - Constructor for class org.eclipse.jetty.http.MetaData.Response
 
Response(HttpChannel, HttpOutput) - Constructor for class org.eclipse.jetty.server.Response
 
RESPONSE - Static variable in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
RESPONSE_500_INFO - Static variable in class org.eclipse.jetty.http.HttpGenerator
 
RESPONSE_VERSION - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
Response.AsyncContentListener - Interface in org.eclipse.jetty.client.api
Asynchronous listener for the response content events.
Response.BeginListener - Interface in org.eclipse.jetty.client.api
Listener for the response begin event.
Response.CompleteListener - Interface in org.eclipse.jetty.client.api
Listener for the request and response completed event.
Response.ContentListener - Interface in org.eclipse.jetty.client.api
Synchronous listener for the response content events.
Response.DemandedContentListener - Interface in org.eclipse.jetty.client.api
Asynchronous listener for the response content events.
Response.FailureListener - Interface in org.eclipse.jetty.client.api
Listener for the response failure event.
Response.HeaderListener - Interface in org.eclipse.jetty.client.api
Listener for a response header event.
Response.HeadersListener - Interface in org.eclipse.jetty.client.api
Listener for the response headers event.
Response.Listener - Interface in org.eclipse.jetty.client.api
Listener for all response events.
Response.Listener.Adapter - Class in org.eclipse.jetty.client.api
An empty implementation of Response.Listener
Response.OutputType - Enum in org.eclipse.jetty.server
 
Response.ResponseListener - Interface in org.eclipse.jetty.client.api
Common, empty, super-interface for response listeners
Response.SuccessListener - Interface in org.eclipse.jetty.client.api
Listener for the response succeeded event.
responseBegin(int, String) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
responseBegin(HttpExchange) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked when the response status code is available.
responseBegin(HttpExchange) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
responseComplete(Throwable) - Method in class org.eclipse.jetty.client.HttpExchange
 
responseContent(HttpExchange, ByteBuffer, Callback) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked when response HTTP content is available.
responseContent(HttpExchange, ByteBuffer, Callback) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
ResponseContentParser - Class in org.eclipse.jetty.fcgi.parser
The parser for STDOUT frame content.
ResponseContentParser(HeaderParser, ClientParser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.ResponseContentParser
 
responseFailure(Throwable) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked when the response is failed.
responseFailure(Throwable) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
responseFailure(Throwable) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
responseHeader(HttpExchange, HttpField) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked when a response HTTP header is available.
responseHeader(HttpExchange, HttpField) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
responseHeader(HttpField) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
responseHeaders() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
responseHeaders(HttpExchange) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked after all response HTTP headers are available.
responseHeaders(HttpExchange) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
ResponseNotifier - Class in org.eclipse.jetty.client
 
ResponseNotifier() - Constructor for class org.eclipse.jetty.client.ResponseNotifier
 
ResponsePatternRule - Class in org.eclipse.jetty.rewrite.handler
Sends the response code whenever the rule finds a match.
ResponsePatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
 
ResponsePatternRule(String, String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
 
responseSuccess() - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
responseSuccess(HttpExchange) - Method in class org.eclipse.jetty.client.HttpReceiver
Method to be invoked when the response is successful.
responseSuccess(HttpExchange) - Method in class org.eclipse.jetty.fcgi.client.http.HttpReceiverOverFCGI
 
ResponseWriter - Class in org.eclipse.jetty.server
Specialized PrintWriter for servlet Responses
ResponseWriter(HttpWriter, Locale, String) - Constructor for class org.eclipse.jetty.server.ResponseWriter
 
Result - Class in org.eclipse.jetty.client.api
The result of a request / response exchange, containing the Request, the Response and eventual failures of either.
Result(Request, Throwable, Response) - Constructor for class org.eclipse.jetty.client.api.Result
 
Result(Request, Throwable, Response, Throwable) - Constructor for class org.eclipse.jetty.client.api.Result
 
Result(Request, Response) - Constructor for class org.eclipse.jetty.client.api.Result
 
Result(Request, Response, Throwable) - Constructor for class org.eclipse.jetty.client.api.Result
 
Result(Result, Throwable) - Constructor for class org.eclipse.jetty.client.api.Result
 
Result(ByteBufferPool, Callback) - Constructor for class org.eclipse.jetty.fcgi.generator.Generator.Result
 
resume() - Method in interface org.eclipse.jetty.websocket.api.SuspendToken
Resume a previously suspended connection.
resume() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
resume() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
retain() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
Increments the retained counter of this buffer.
retain() - Method in interface org.eclipse.jetty.util.Retainable
 
Retainable - Interface in org.eclipse.jetty.util
 
RetainableByteBuffer - Class in org.eclipse.jetty.io
A pooled ByteBuffer which maintains a reference count that is incremented with RetainableByteBuffer.retain() and decremented with RetainableByteBuffer.release().
RetainableByteBufferPool - Interface in org.eclipse.jetty.io
RetainableByteBufferPool.NotRetainedByteBufferPool - Class in org.eclipse.jetty.io
 
Retained(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Retained
 
Retained(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool.Retained
 
rethrow(ExecutionException) - Static method in class org.eclipse.jetty.util.FutureCallback
 
rethrow(ExecutionException) - Static method in class org.eclipse.jetty.util.FuturePromise
 
retry - Variable in class org.eclipse.jetty.client.SendFailure
 
RETRY_AFTER - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
reverseListIterator() - Method in class org.eclipse.jetty.start.config.ConfigSources
 
RewriteCustomizer - Class in org.eclipse.jetty.rewrite
 
RewriteCustomizer() - Constructor for class org.eclipse.jetty.rewrite.RewriteCustomizer
 
RewriteHandler - Class in org.eclipse.jetty.rewrite.handler
Rewrite handler is responsible for managing the rules.
RewriteHandler() - Constructor for class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
RewritePatternRule - Class in org.eclipse.jetty.rewrite.handler
Rewrite the URI by replacing the matched ServletPathSpec path with a fixed string.
RewritePatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.RewritePatternRule
 
RewritePatternRule(String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.RewritePatternRule
 
RewriteRegexRule - Class in org.eclipse.jetty.rewrite.handler
Rewrite the URI by matching with a regular expression.
RewriteRegexRule() - Constructor for class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
 
RewriteRegexRule(String, String) - Constructor for class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet.TransparentDelegate
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.Transparent
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.AsyncProxyServlet.Transparent
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.BalancerServlet
 
rewriteTarget(HttpServletRequest) - Method in class org.eclipse.jetty.proxy.ProxyServlet.Transparent
 
RFC2616 - Static variable in class org.eclipse.jetty.http.HttpCompliance
The HttpCompliance mode that supports RFC 7230 with only the violations that differ from HttpCompliance.RFC7230.
RFC2616_LEGACY - Static variable in class org.eclipse.jetty.http.HttpCompliance
A legacy HttpCompliance mode that supports HttpCompliance.RFC2616, but that also allows: case-insensitive methods; colons after field names; Transfer-Encoding with Content-Length fields; and multiple Content-Length values.
RFC2965 - Static variable in class org.eclipse.jetty.http.CookieCompliance
RFC2965_LEGACY - Static variable in class org.eclipse.jetty.http.CookieCompliance
A CookieCompliance mode that allows RFC 2965 compliance.
RFC3986 - Static variable in class org.eclipse.jetty.http.UriCompliance
Compliance mode that exactly follows RFC3986, including allowing all additional ambiguous URI Violations.
RFC3986_UNAMBIGUOUS - Static variable in class org.eclipse.jetty.http.UriCompliance
Compliance mode that follows RFC3986 plus it does not allow any ambiguous URI UriCompliance.Violations.
RFC6265 - Static variable in class org.eclipse.jetty.http.CookieCompliance
A CookieCompliance mode that enforces RFC 6265 compliance, but allows:
RFC6265_LEGACY - Static variable in class org.eclipse.jetty.http.CookieCompliance
A CookieCompliance mode that enforces RFC 6265 compliance, but allows:
RFC6265_STRICT - Static variable in class org.eclipse.jetty.http.CookieCompliance
A CookieCompliance mode that enforces RFC 6265 compliance.
RFC6265CookieParser - Class in org.eclipse.jetty.http
Cookie parser
RFC6265CookieParser(CookieParser.Handler, CookieCompliance, ComplianceViolation.Listener) - Constructor for class org.eclipse.jetty.http.RFC6265CookieParser
 
RFC6455Handshaker - Class in org.eclipse.jetty.websocket.core.server.internal
 
RFC6455Handshaker() - Constructor for class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
RFC6455Negotiation - Class in org.eclipse.jetty.websocket.core.server.internal
 
RFC6455Negotiation(Request, HttpServletRequest, HttpServletResponse, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.RFC6455Negotiation
 
RFC66_JSP_EXTRACT_LOCATION - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Name of the header that defines the path to the folder where the jsp files are extracted.
RFC66_OSGI_BUNDLE_CONTEXT - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Name of the servlet context attribute that points to the bundle context.
RFC66_WAR_URL_SCHEME - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
url scheme to deploy war file as bundled webapp
RFC66_WEB_CONTEXTPATH - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Name of the header that defines the context path for the embedded webapp.
RFC7230 - Static variable in class org.eclipse.jetty.http.HttpCompliance
The HttpCompliance mode that supports RFC 7230 with no known violations.
RFC7230_LEGACY - Static variable in class org.eclipse.jetty.http.HttpCompliance
A legacy HttpCompliance mode that supports HttpCompliance.RFC7230, but with case-insensitive methods allowed.
RFC7578 - Enum constant in enum org.eclipse.jetty.server.MultiPartFormDataCompliance
RFC7578 compliant parsing that is a fast but strict parser.
RFC8441Handshaker - Class in org.eclipse.jetty.websocket.core.server.internal
 
RFC8441Handshaker() - Constructor for class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
RFC8441Negotiation - Class in org.eclipse.jetty.websocket.core.server.internal
 
RFC8441Negotiation(Request, HttpServletRequest, HttpServletResponse, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.RFC8441Negotiation
 
RMI_REGISTRY_CLIENT_SOCKET_FACTORY_ATTRIBUTE - Static variable in class org.eclipse.jetty.jmx.ConnectorServer
 
RoleInfo - Class in org.eclipse.jetty.security
RoleInfo Badly named class that holds the role and user data constraint info for a path/http method combination, extracted and combined from security constraints.
RoleInfo() - Constructor for class org.eclipse.jetty.security.RoleInfo
 
RolePrincipal - Class in org.eclipse.jetty.security
RolePrincipal Represents a role.
RolePrincipal(String) - Constructor for class org.eclipse.jetty.security.RolePrincipal
 
RoleRunAsToken - Class in org.eclipse.jetty.security
 
RoleRunAsToken(String) - Constructor for class org.eclipse.jetty.security.RoleRunAsToken
 
rollover(File, File, File) - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
This method is called whenever a log file is rolled over
RolloverFileOutputStream - Class in org.eclipse.jetty.util
RolloverFileOutputStream.
RolloverFileOutputStream(String) - Constructor for class org.eclipse.jetty.util.RolloverFileOutputStream
 
RolloverFileOutputStream(String, boolean) - Constructor for class org.eclipse.jetty.util.RolloverFileOutputStream
 
RolloverFileOutputStream(String, boolean, int) - Constructor for class org.eclipse.jetty.util.RolloverFileOutputStream
 
RolloverFileOutputStream(String, boolean, int, TimeZone) - Constructor for class org.eclipse.jetty.util.RolloverFileOutputStream
 
RolloverFileOutputStream(String, boolean, int, TimeZone, String, String) - Constructor for class org.eclipse.jetty.util.RolloverFileOutputStream
 
ROOT - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
The root spec for accessing the Root behavior.
ROUND_ROBIN - Enum constant in enum org.eclipse.jetty.util.Pool.StrategyType
A strategy that looks for an entry by iterating from a starting point that is incremented on every search.
RoundRobinConnectionPool - Class in org.eclipse.jetty.client
A ConnectionPool that attempts to provide connections using a round-robin algorithm.
RoundRobinConnectionPool(HttpDestination, int, Callback) - Constructor for class org.eclipse.jetty.client.RoundRobinConnectionPool
 
RoundRobinConnectionPool(HttpDestination, int, Callback, int) - Constructor for class org.eclipse.jetty.client.RoundRobinConnectionPool
 
RST_STREAM - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
Rule - Class in org.eclipse.jetty.rewrite.handler
An abstract rule for creating rewrite rules.
Rule() - Constructor for class org.eclipse.jetty.rewrite.handler.Rule
 
Rule.ApplyURI - Interface in org.eclipse.jetty.rewrite.handler
Interface used to apply a changed target if RuleContainer.setRewriteRequestURI(boolean) is true.
RuleContainer - Class in org.eclipse.jetty.rewrite.handler
Base container to group rules.
RuleContainer() - Constructor for class org.eclipse.jetty.rewrite.handler.RuleContainer
 
run() - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
 
run() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
run() - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
run() - Method in class org.eclipse.jetty.server.HttpChannel
 
run() - Method in class org.eclipse.jetty.server.HttpConnection
 
run() - Method in class org.eclipse.jetty.server.HttpInput
 
run() - Method in class org.eclipse.jetty.server.HttpOutput
 
run() - Method in class org.eclipse.jetty.server.session.HouseKeeper.Runner
 
run() - Method in interface org.eclipse.jetty.util.component.Graceful.ThrowingRunnable
 
run() - Method in class org.eclipse.jetty.util.LeakDetector
 
run() - Method in class org.eclipse.jetty.util.PathWatcher
Forever loop.
run() - Method in class org.eclipse.jetty.util.PidFile
 
run() - Method in class org.eclipse.jetty.util.thread.Invocable.ReadyTask
 
run() - Method in class org.eclipse.jetty.util.thread.ShutdownThread
 
run() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
run() - Method in class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
run() - Method in class org.eclipse.jetty.util.thread.strategy.ProduceConsume
 
run() - Method in class org.eclipse.jetty.util.thread.Sweeper
 
run() - Method in class org.eclipse.jetty.util.thread.TimerScheduler
 
run() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
run(Runnable) - Method in class org.eclipse.jetty.server.session.SessionContext
Run a runnable in the context (with context classloader set) if there is one, otherwise just run it.
RunAs - Class in org.eclipse.jetty.plus.annotation
Deprecated.
unused as of 9.4.28 due for removal in 10.0.0
RunAs(String, String) - Constructor for class org.eclipse.jetty.plus.annotation.RunAs
Deprecated.
 
RUNAS_COLLECTION - Static variable in class org.eclipse.jetty.plus.annotation.RunAsCollection
Deprecated.
 
RunAsAnnotationHandler - Class in org.eclipse.jetty.annotations
 
RunAsAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.RunAsAnnotationHandler
 
RunAsCollection - Class in org.eclipse.jetty.plus.annotation
Deprecated.
class unused as of 9.4.28 due for removal in 10.0.0
RunAsCollection() - Constructor for class org.eclipse.jetty.plus.annotation.RunAsCollection
Deprecated.
 
RunAsToken - Interface in org.eclipse.jetty.security
marker interface for run-as-role tokens
runBindings(Node, App, DeploymentManager) - Method in class org.eclipse.jetty.deploy.AppLifeCycle
 
runJob(Runnable) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Runs the given job in the current thread.
Runner - Class in org.eclipse.jetty.runner
Deprecated.
No replacement provided or available. Migrate to jetty-home (and use ${jetty.base} directory).
Runner() - Constructor for class org.eclipse.jetty.runner.Runner
Deprecated.
 
Runner() - Constructor for class org.eclipse.jetty.server.session.HouseKeeper.Runner
 
Runner.Classpath - Class in org.eclipse.jetty.runner
Deprecated.
Classpath
RuntimeIOException - Exception Class in org.eclipse.jetty.io
Subclass of RuntimeException used to signal that there was an IOException thrown by underlying Writer
RuntimeIOException() - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
 
RuntimeIOException(String) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
 
RuntimeIOException(String, Throwable) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
 
RuntimeIOException(Throwable) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
 
runWithServerClassAccess(PrivilegedExceptionAction<T>) - Static method in class org.eclipse.jetty.webapp.WebAppClassLoader
Run an action with access to ServerClasses

S

SAFE - Static variable in class org.eclipse.jetty.http.UriCompliance
Deprecated.
equivalent to DEFAULT
SAME_SITE_DEFAULT_ATTRIBUTE - Static variable in class org.eclipse.jetty.http.HttpCookie
Name of context attribute with default SameSite cookie value
SAME_SITE_LAX_COMMENT - Static variable in class org.eclipse.jetty.http.HttpCookie
 
SAME_SITE_NONE_COMMENT - Static variable in class org.eclipse.jetty.http.HttpCookie
 
SAME_SITE_STRICT_COMMENT - Static variable in class org.eclipse.jetty.http.HttpCookie
 
SameFileAliasChecker - Class in org.eclipse.jetty.server
Deprecated.
SameFileAliasChecker() - Constructor for class org.eclipse.jetty.server.SameFileAliasChecker
Deprecated.
 
SampleStatistic - Class in org.eclipse.jetty.util.statistic
Statistics on a sampled value.
SampleStatistic() - Constructor for class org.eclipse.jetty.util.statistic.SampleStatistic
 
sanitizeFieldVchar(char) - Static method in class org.eclipse.jetty.http.HttpTokens
This is used when decoding to not decode illegal characters based on RFC9110.
sanitizeFileSystemName(String) - Static method in class org.eclipse.jetty.util.StringUtil
Replace all characters from input string that are known to have special meaning in various filesystems.
sanitizeXmlString(String) - Static method in class org.eclipse.jetty.util.StringUtil
 
satisfiableRanges(Enumeration<String>, long) - Static method in class org.eclipse.jetty.server.InclusiveByteRange
 
save(OutputStream, String, SessionData) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Save the session data.
save(Object) - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Save the NamingEntry for later use.
saveSnippet(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 
scan() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
scan(long) - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
scan(Callback) - Method in class org.eclipse.jetty.util.Scanner
Get the scanner to perform a scan cycle as soon as possible and call the Callback when the scan is finished or failed.
scanClass(Set<? extends AnnotationParser.Handler>, Resource, InputStream) - Method in class org.eclipse.jetty.annotations.AnnotationParser
Use ASM on a class
scanEnded(int) - Method in interface org.eclipse.jetty.util.Scanner.ScanCycleListener
 
scanForAnnotations(WebAppContext) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration
Perform scanning of classes for discoverable annotations such as WebServlet/WebFilter/WebListener
scanForFragment(WebAppContext, Resource, ConcurrentHashMap<Resource, Resource>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Scan for META-INF/web-fragment.xml file in the given jar.
scanForResources(WebAppContext, Resource, ConcurrentHashMap<Resource, Resource>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Scan for META-INF/resources dir in the given jar.
scanForTlds(WebAppContext, Resource, ConcurrentHashMap<Resource, Collection<URL>>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Discover META-INF/*.tld files in the given jar
scanJars() - Method in class org.eclipse.jetty.apache.jsp.JettyTldPreScanned
 
scanJars(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
 
scanJars(WebAppContext) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
scanJars(WebAppContext, Collection<Resource>, boolean) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
For backwards compatibility.
scanJars(WebAppContext, Collection<Resource>, boolean, List<String>) - Method in class org.eclipse.jetty.webapp.MetaInfConfiguration
Look into the jars to discover info in META-INF.
Scanner - Class in org.eclipse.jetty.util
Scanner Utility for scanning a directory for added, removed and changed files and reporting these events via registered Listeners.
Scanner() - Constructor for class org.eclipse.jetty.util.Scanner
 
Scanner(Scheduler) - Constructor for class org.eclipse.jetty.util.Scanner
 
Scanner(Scheduler, boolean) - Constructor for class org.eclipse.jetty.util.Scanner
 
Scanner.BulkListener - Interface in org.eclipse.jetty.util
Notification of files that changed in the last scan.
Scanner.DiscreteListener - Interface in org.eclipse.jetty.util
Notification of exact file changes in the last scan.
Scanner.Listener - Interface in org.eclipse.jetty.util
Listener Marker for notifications re file changes.
Scanner.ScanCycleListener - Interface in org.eclipse.jetty.util
Listener that notifies when a scan has started and when it has ended.
ScanningAppProvider - Class in org.eclipse.jetty.deploy.providers
 
ScanningAppProvider() - Constructor for class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
ScanningAppProvider(FilenameFilter) - Constructor for class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
scanStarted(int) - Method in interface org.eclipse.jetty.util.Scanner.ScanCycleListener
 
scavenge() - Method in class org.eclipse.jetty.server.session.HouseKeeper
Periodically do session housekeeping
scavenge() - Method in class org.eclipse.jetty.server.session.SessionHandler
Called periodically by the HouseKeeper to handle the list of sessions that have expired since the last call to scavenge.
schedule(long) - Method in class org.eclipse.jetty.server.session.Session.SessionInactivityTimer
 
schedule(long, TimeUnit) - Method in class org.eclipse.jetty.io.CyclicTimeout
Schedules a timeout, even if already set, cancelled or expired.
schedule(Runnable, long, TimeUnit) - Method in class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
schedule(Runnable, long, TimeUnit) - Method in interface org.eclipse.jetty.util.thread.Scheduler
 
schedule(Runnable, long, TimeUnit) - Method in class org.eclipse.jetty.util.thread.TimerScheduler
 
schedule(ServerQuicSession) - Method in class org.eclipse.jetty.quic.server.ServerQuicConnection
 
schedule(T) - Method in class org.eclipse.jetty.io.CyclicTimeouts
Manages the timeout of a new entity.
SCHEDULED - Enum constant in enum org.eclipse.jetty.util.IteratingCallback.Action
Indicates that IteratingCallback.process() has initiated an asynchronous sub-task, where the execution has started but the callback that signals the completion of the asynchronous sub-task may have not yet been invoked.
ScheduledExecutorScheduler - Class in org.eclipse.jetty.util.thread
Implementation of Scheduler based on JDK's ScheduledThreadPoolExecutor.
ScheduledExecutorScheduler() - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(String, boolean) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(String, boolean, int) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(String, boolean, ClassLoader) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(String, boolean, ClassLoader, ThreadGroup) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(String, boolean, ClassLoader, ThreadGroup, int) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
ScheduledExecutorScheduler(ScheduledExecutorService) - Constructor for class org.eclipse.jetty.util.thread.ScheduledExecutorScheduler
 
scheduleDispatch() - Method in class org.eclipse.jetty.server.HttpChannelState
 
Scheduler - Interface in org.eclipse.jetty.util.thread
 
Scheduler.Task - Interface in org.eclipse.jetty.util.thread
 
scheme(String) - Method in interface org.eclipse.jetty.client.api.Request
 
scheme(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
scheme(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
scheme(HttpScheme) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
scope(XmlConfiguration, Resource) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
ScopedHandler - Class in org.eclipse.jetty.server.handler
ScopedHandler.
ScopedHandler() - Constructor for class org.eclipse.jetty.server.handler.ScopedHandler
 
scratchBuffer() - Method in class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
scratchBuffer() - Method in interface org.eclipse.jetty.util.ajax.JSON.Source
 
scratchBuffer() - Method in class org.eclipse.jetty.util.ajax.JSON.StringSource
 
SCRIPT_FILENAME - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SCRIPT_NAME - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SCRIPT_PATTERN_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
SCRIPT_ROOT_INIT_PARAM - Static variable in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
SEARCH - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
SearchDir(String) - Constructor for class org.eclipse.jetty.start.BaseHome.SearchDir
 
SearchPattern - Class in org.eclipse.jetty.util
SearchPattern Fast search for patterns within strings and arrays of bytes.
SEC_WEBSOCKET_ACCEPT - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SEC_WEBSOCKET_ACCEPT - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SEC_WEBSOCKET_EXTENSIONS - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SEC_WEBSOCKET_EXTENSIONS - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SEC_WEBSOCKET_KEY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SEC_WEBSOCKET_KEY - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SEC_WEBSOCKET_ORIGIN - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SEC_WEBSOCKET_PROTOCOL - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SEC_WEBSOCKET_SUBPROTOCOL - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SEC_WEBSOCKET_VERSION - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SEC_WEBSOCKET_VERSION - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
secondsElapsed(long, long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the seconds elapsed between two nanoTimes.
secondsSince(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the seconds elapsed between a begin nanoTime and the current nanoTime.
secondsUntil(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the seconds remaining between the current nanoTime and an end nanoTime.
SecuredRedirectHandler - Class in org.eclipse.jetty.server.handler
SecuredRedirectHandler redirects from http to https.
SecuredRedirectHandler() - Constructor for class org.eclipse.jetty.server.handler.SecuredRedirectHandler
Uses moved temporarily code (302) as the redirect code.
SecuredRedirectHandler(int) - Constructor for class org.eclipse.jetty.server.handler.SecuredRedirectHandler
Use supplied code as the redirect code.
SecureRequestCustomizer - Class in org.eclipse.jetty.server
Customizer that extracts the attribute from an SSLContext and sets them on the request with ServletRequest.setAttribute(String, Object) according to Servlet Specification Requirements.
SecureRequestCustomizer() - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer
 
SecureRequestCustomizer(boolean) - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer
 
SecureRequestCustomizer(boolean, boolean, long, boolean) - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer
 
SecureRequestCustomizer(boolean, long, boolean) - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer
 
secureResponse(MessageInfo, Subject) - Method in class org.eclipse.jetty.security.jaspi.modules.BaseAuthModule
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in interface org.eclipse.jetty.security.Authenticator
is response secure
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
secureResponse(ServletRequest, ServletResponse, boolean, Authentication.User) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
secureResponse(JaspiMessageInfo, Authentication) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
SECURITY - Static variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
SecurityHandler - Class in org.eclipse.jetty.security
Abstract SecurityHandler.
SecurityHandler() - Constructor for class org.eclipse.jetty.security.SecurityHandler
 
SecurityHandler.NotChecked - Class in org.eclipse.jetty.security
 
SecurityUtils - Class in org.eclipse.jetty.util.security
Collections of utility methods to deal with the scheduled removal of the security classes defined by JEP 411.
SEE_OTHER - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
SEE_OTHER_303 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
SeekableByteChannelRangeWriter - Class in org.eclipse.jetty.server.resource
 
SeekableByteChannelRangeWriter(SeekableByteChannel, SeekableByteChannelRangeWriter.ChannelSupplier) - Constructor for class org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter
 
SeekableByteChannelRangeWriter(SeekableByteChannelRangeWriter.ChannelSupplier) - Constructor for class org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter
 
SeekableByteChannelRangeWriter.ChannelSupplier - Interface in org.eclipse.jetty.server.resource
 
seekTo(char, JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
seekTo(String, JSON.Source) - Method in class org.eclipse.jetty.util.ajax.JSON
 
select(Selector) - Method in class org.eclipse.jetty.io.ManagedSelector
 
select(List<String>) - Method in class org.eclipse.jetty.alpn.server.ALPNServerConnection
 
SelectableChannelEndPoint - Class in org.eclipse.jetty.io
A partial EndPoint implementation based on SelectableChannel.
SelectableChannelEndPoint(Scheduler, SelectableChannel, ManagedSelector, SelectionKey) - Constructor for class org.eclipse.jetty.io.SelectableChannelEndPoint
 
selectCipherSuites(String[], String[]) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Select cipher suites to be used by the connector based on configured inclusion and exclusion lists as well as enabled and supported cipher suite lists.
selected(String) - Method in class org.eclipse.jetty.alpn.client.ALPNClientConnection
 
SelectorManager - Class in org.eclipse.jetty.io
SelectorManager manages a number of ManagedSelectors that simplify the non-blocking primitives provided by the JVM via the java.nio package.
SelectorManager(Executor, Scheduler) - Constructor for class org.eclipse.jetty.io.SelectorManager
 
SelectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.io.SelectorManager
 
SelectorManager.AcceptListener - Interface in org.eclipse.jetty.io
A listener for accept events.
SelectorManager.SelectorManagerListener - Interface in org.eclipse.jetty.io
 
Selectors - Search tag in class org.eclipse.jetty.server.ServerConnector
Section
selectProtocols(String[], String[]) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Select protocols to be used by the connector based on configured inclusion and exclusion lists as well as enabled and supported protocols.
send() - Method in interface org.eclipse.jetty.client.api.Request
Sends this request and returns the response.
send() - Method in class org.eclipse.jetty.client.HttpChannel
 
send() - Method in class org.eclipse.jetty.client.HttpDestination
 
send() - Method in class org.eclipse.jetty.client.HttpRequest
 
send(String, Bundle, String) - Method in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
send(String, Bundle, String, Exception) - Method in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
send(SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
Sends to the given address the data in the given buffers.
send(Request, Response.CompleteListener) - Method in interface org.eclipse.jetty.client.api.Connection
Sends a request with an associated response listener.
send(Request, Response.CompleteListener) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
send(Request, Response.CompleteListener) - Method in class org.eclipse.jetty.client.HttpConnection
 
send(Request, Response.CompleteListener) - Method in class org.eclipse.jetty.client.HttpDestination
 
send(Request, Response.CompleteListener) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
send(Response.CompleteListener) - Method in interface org.eclipse.jetty.client.api.Request
Sends this request and asynchronously notifies the given listener for response events.
send(Response.CompleteListener) - Method in class org.eclipse.jetty.client.HttpRequest
 
send(Response.CompleteListener) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
send(HttpChannel, HttpExchange) - Method in class org.eclipse.jetty.client.HttpConnection
 
send(HttpExchange) - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
send(HttpExchange) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
send(HttpExchange) - Method in class org.eclipse.jetty.client.HttpChannel
 
send(HttpExchange) - Method in class org.eclipse.jetty.client.HttpDestination
 
send(HttpExchange) - Method in class org.eclipse.jetty.client.HttpSender
 
send(HttpExchange) - Method in interface org.eclipse.jetty.client.IConnection
 
send(HttpExchange) - Method in class org.eclipse.jetty.fcgi.client.http.HttpChannelOverFCGI
 
send(HttpExchange) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
send(HttpExchange) - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
send(HttpExchange) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
send(HttpRequest, List<Response.ResponseListener>) - Method in class org.eclipse.jetty.client.HttpClient
 
send(HttpRequest, List<Response.ResponseListener>) - Method in class org.eclipse.jetty.client.HttpDestination
 
send(IConnection, HttpExchange) - Method in class org.eclipse.jetty.client.HttpDestination
 
send(MetaData.Request, MetaData.Response, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.server.HttpTransportOverFCGI
 
send(MetaData.Request, MetaData.Response, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
send(MetaData.Request, MetaData.Response, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.server.HttpConnection
 
send(MetaData.Request, MetaData.Response, ByteBuffer, boolean, Callback) - Method in interface org.eclipse.jetty.server.HttpTransport
Asynchronous call to send a response (or part) over the transport
send(IStream.FrameList, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
send(IStream.FrameList, Callback) - Method in interface org.eclipse.jetty.http2.IStream
Sends the given list of frames.
SEND_CONTINUE - Static variable in interface org.eclipse.jetty.server.Authentication
Authentication challenge sent.
SEND_ERROR - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
SEND_FAILURE - Static variable in interface org.eclipse.jetty.server.Authentication
Authentication failure sent.
SEND_SUCCESS - Static variable in interface org.eclipse.jetty.server.Authentication
 
sendAsync() - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
sendBinary(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendBinary(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
sendBinary(ByteBuffer, boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
sendBinary(ByteBuffer, SendHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendBinary(ByteBuffer, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Send a ByteBuffer as a single binary frame.
sendBinary(Callback, boolean, ByteBuffer...) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Send a sequence of ByteBuffers as a sequences for fragmented text frame.
sendBytes(ByteBuffer) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Send a binary message, returning when all bytes of the message has been transmitted.
sendBytes(ByteBuffer) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendBytes(ByteBuffer, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Initiates the asynchronous transmission of a binary message.
sendBytes(ByteBuffer, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendContent(InputStream) - Method in class org.eclipse.jetty.server.HttpOutput
Blocking send of stream content.
sendContent(InputStream, Callback) - Method in class org.eclipse.jetty.server.HttpOutput
Asynchronous send of stream content.
sendContent(ByteBuffer) - Method in class org.eclipse.jetty.server.HttpOutput
Blocking send of whole content.
sendContent(ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.HttpOutput
Asynchronous send of whole content.
sendContent(ReadableByteChannel) - Method in class org.eclipse.jetty.server.HttpOutput
Blocking send of channel content.
sendContent(ReadableByteChannel, Callback) - Method in class org.eclipse.jetty.server.HttpOutput
Asynchronous send of channel content.
sendContent(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
sendContent(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.client.HttpSender
Implementations should send the given HTTP content over the wire.
sendContent(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.client.http.HttpSenderOverFCGI
 
sendContent(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.http2.client.http.HttpSenderOverHTTP2
 
sendContent(HttpContent) - Method in class org.eclipse.jetty.server.HttpOutput
Blocking send of HTTP content.
sendContent(HttpContent, Callback) - Method in class org.eclipse.jetty.server.HttpOutput
Asynchronous send of HTTP content.
sendContent(MetaData.Request, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
sendData(HttpServletRequest, HttpServletResponse, boolean, HttpContent, Enumeration<String>) - Method in class org.eclipse.jetty.server.ResourceService
 
sendDirectory(HttpServletRequest, HttpServletResponse, Resource, String) - Method in class org.eclipse.jetty.server.ResourceService
 
sendEarlyHint() - Method in class org.eclipse.jetty.server.Response
Sends a 103 Early Hint response.
sendError(int) - Method in class org.eclipse.jetty.server.Response
 
sendError(int) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
sendError(int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
sendError(int, String) - Method in class org.eclipse.jetty.server.HttpChannelState
 
sendError(int, String) - Method in class org.eclipse.jetty.server.Response
Send an error response.
sendError(int, String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
sendError(int, String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
sendError(int, String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
sendError(int, String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
sendError(int, String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Sends an error response to the client using the specified status.
sendErrorOrAbort(String) - Method in class org.eclipse.jetty.server.HttpChannel
 
SendFailure - Class in org.eclipse.jetty.client
 
SendFailure(Throwable, boolean) - Constructor for class org.eclipse.jetty.client.SendFailure
 
sendForbidden(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
sendForbidden(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
sendForbidden(String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Issue a forbidden upgrade response.
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.CoreSession.Empty
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FrameCaptureExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
sendFrame(Frame, Callback, boolean) - Method in interface org.eclipse.jetty.websocket.core.OutgoingFrames
A frame, and optional callback, intended for the network layer.
sendFrame(Frame, Callback, boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
SendHandlerCallback - Class in org.eclipse.jetty.websocket.jakarta.common
Wrapper of user provided SendHandler to Jetty internal Callback
SendHandlerCallback(SendHandler) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.SendHandlerCallback
 
sendHeaders(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
sendHeaders(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.client.HttpSender
Implementations should send the HTTP headers over the wire, possibly with some content, in a single write, and notify the given callback of the result of this operation.
sendHeaders(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.fcgi.client.http.HttpSenderOverFCGI
 
sendHeaders(HttpExchange, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.http2.client.http.HttpSenderOverHTTP2
 
sendHeaders(MetaData.Request, MetaData.Response, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
sendObject(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendObject(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
sendObject(Object, SendHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendObject(Object, Callback) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
sendPartialBytes(ByteBuffer, boolean) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Send a binary message in pieces, blocking until all of the message has been transmitted.
sendPartialBytes(ByteBuffer, boolean) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPartialBytes(ByteBuffer, boolean, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Initiates the asynchronous transmission of a partial binary message.
sendPartialBytes(ByteBuffer, boolean, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPartialString(String, boolean) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Send a text message in pieces, blocking until all of the message has been transmitted.
sendPartialString(String, boolean) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPartialString(String, boolean, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Initiates the asynchronous transmission of a partial text message.
sendPartialString(String, boolean, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPing(ByteBuffer) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Send a Ping message containing the given application data to the remote endpoint, blocking until all of the message has been transmitted.
sendPing(ByteBuffer) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPing(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
sendPing(ByteBuffer, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Asynchronously send a Ping message containing the given application data to the remote endpoint.
sendPing(ByteBuffer, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPong(ByteBuffer) - Method in interface org.eclipse.jetty.websocket.api.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, this will block until all of the message has been transmitted.
sendPong(ByteBuffer) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendPong(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
sendPong(ByteBuffer, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Allows the developer to asynchronously send an unsolicited Pong message containing the given application data in order to serve as a unidirectional heartbeat for the session.
sendPong(ByteBuffer, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendProcessing() - Method in class org.eclipse.jetty.server.Response
Sends a 102-Processing response.
sendProxyRequest(HttpServletRequest, HttpServletResponse, Request) - Method in class org.eclipse.jetty.fcgi.server.proxy.FastCGIProxyServlet
 
sendProxyRequest(HttpServletRequest, HttpServletResponse, Request) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
sendProxyResponseError(HttpServletRequest, HttpServletResponse, int) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
sendRedirect(int, String) - Method in class org.eclipse.jetty.server.Response
Sends a response with one of the 300 series redirection codes.
sendRedirect(int, String, boolean) - Method in class org.eclipse.jetty.server.Response
Sends a response with a given redirection code.
sendRedirect(String) - Method in class org.eclipse.jetty.server.Response
 
sendRedirect(String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
sendRedirect(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
sendRedirect(String, boolean) - Method in class org.eclipse.jetty.server.Response
Sends a response with a HTTP version appropriate 30x redirection.
sendResponse(MetaData.Response, ByteBuffer, boolean) - Method in class org.eclipse.jetty.server.HttpChannel
 
sendResponse(MetaData.Response, ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.server.HttpChannel
 
sendResponseAndComplete() - Method in class org.eclipse.jetty.server.HttpChannel
 
sendResponseHeaders(int, long) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
sendResponseHeaders(int, long) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
sendResponseHeaders(int, long) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
sendShutdown() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
sendStatus(HttpServletResponse, int, Supplier<String>) - Method in class org.eclipse.jetty.server.ResourceService
 
sendString(String) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Send a text message, blocking until all bytes of the message has been transmitted.
sendString(String) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendString(String, WriteCallback) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Initiates the asynchronous transmission of a text message.
sendString(String, WriteCallback) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
sendText(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendText(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
sendText(String, boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketBasicRemote
 
sendText(String, SendHandler) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
sendText(String, Callback, boolean) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Send a String as a single text frame.
sendText(Callback, boolean, String...) - Method in class org.eclipse.jetty.websocket.core.internal.MessageHandler
Send a sequence of Strings as a sequences for fragmented text frame.
sendWelcome(HttpContent, String, boolean, boolean, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.server.ResourceService
 
sendWindowUpdate(IStream, ISession, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
separators(String) - Static method in class org.eclipse.jetty.start.FS
 
serializeAttributes() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
serializeAttributes(SessionData, ObjectOutputStream) - Static method in class org.eclipse.jetty.server.session.SessionData
Serialize the attribute map of the session.
SerializedExecutor - Class in org.eclipse.jetty.util.thread
An executor than ensurers serial execution of submitted tasks.
SerializedExecutor() - Constructor for class org.eclipse.jetty.util.thread.SerializedExecutor
 
SerializedExecutor.ErrorHandlingTask - Interface in org.eclipse.jetty.util.thread
Error handling task
Server - Class in org.eclipse.jetty.server
Jetty HTTP Servlet Server.
Server() - Constructor for class org.eclipse.jetty.server.Server
 
Server() - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
Server(int) - Constructor for class org.eclipse.jetty.server.Server
Convenience constructor Creates server and a ServerConnector at the passed port.
Server(InetSocketAddress) - Constructor for class org.eclipse.jetty.server.Server
Convenience constructor
Server(ThreadPool) - Constructor for class org.eclipse.jetty.server.Server
 
SERVER - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SERVER - Enum constant in enum org.eclipse.jetty.websocket.api.WebSocketBehavior
 
SERVER - Enum constant in enum org.eclipse.jetty.websocket.core.Behavior
 
SERVER_ADDR - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SERVER_BIDIRECTIONAL - Enum constant in enum org.eclipse.jetty.quic.common.StreamType
 
SERVER_ERROR - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1011 indicates that a server is terminating the connection because it encountered an unexpected condition that prevented it from fulfilling the request.
SERVER_ERROR - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
SERVER_GRACEFUL - Static variable in class org.eclipse.jetty.http3.frames.GoAwayFrame
 
SERVER_NAME - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SERVER_PORT - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SERVER_PROTOCOL - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SERVER_SOFTWARE - Static variable in class org.eclipse.jetty.fcgi.FCGI.Headers
 
SERVER_SRV_CLASSES - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
SERVER_SYS_CLASSES - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
SERVER_UNIDIRECTIONAL - Enum constant in enum org.eclipse.jetty.quic.common.StreamType
 
SERVER_VERSION - Static variable in class org.eclipse.jetty.server.HttpConfiguration
 
ServerAuthException - Exception Class in org.eclipse.jetty.security
 
ServerAuthException() - Constructor for exception class org.eclipse.jetty.security.ServerAuthException
 
ServerAuthException(String) - Constructor for exception class org.eclipse.jetty.security.ServerAuthException
 
ServerAuthException(String, Throwable) - Constructor for exception class org.eclipse.jetty.security.ServerAuthException
 
ServerAuthException(Throwable) - Constructor for exception class org.eclipse.jetty.security.ServerAuthException
 
ServerConnectionStatistics - Class in org.eclipse.jetty.server
Deprecated.
ServerConnectionStatistics() - Constructor for class org.eclipse.jetty.server.ServerConnectionStatistics
Deprecated.
 
ServerConnector - Class in org.eclipse.jetty.server
This Connector implementation is the primary connector for the Jetty server over TCP/IP.
ServerConnector(Server) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a ServerConnector with a private instance of HttpConnectionFactory as the only factory.
ServerConnector(Server, int, int) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a ServerConnector with a private instance of HttpConnectionFactory as the only factory.
ServerConnector(Server, int, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a ServerConnector with a private instance of HttpConnectionFactory as the only factory.
ServerConnector(Server, int, int, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a ServerConnector with a private instance of HttpConnectionFactory as the primary protocol
ServerConnector(Server, Executor, Scheduler, ByteBufferPool, int, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.ServerConnector
 
ServerConnector(Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a Server Connector with the passed Connection factories.
ServerConnector(Server, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.server.ServerConnector
Construct a ServerConnector with a private instance of HttpConnectionFactory as the primary protocol
ServerConnector(Server, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.ServerConnector
 
ServerConnector.ServerConnectorManager - Class in org.eclipse.jetty.server
 
ServerConnectorListener - Class in org.eclipse.jetty.osgi.boot.utils
ServerConnectorListener This is for test support, where we need jetty to run on a random port, and we need a client to be able to find out which port was picked.
ServerConnectorListener() - Constructor for class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
ServerConnectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
ServerEndpointConfigWrapper - Class in org.eclipse.jetty.websocket.jakarta.common
 
ServerEndpointConfigWrapper() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
ServerEndpointConfigWrapper(ServerEndpointConfig) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.ServerEndpointConfigWrapper
 
ServerFCGIConnection - Class in org.eclipse.jetty.fcgi.server
 
ServerFCGIConnection(Connector, EndPoint, HttpConfiguration, boolean) - Constructor for class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
ServerFCGIConnectionFactory - Class in org.eclipse.jetty.fcgi.server
 
ServerFCGIConnectionFactory(HttpConfiguration) - Constructor for class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
ServerFCGIConnectionFactory(HttpConfiguration, boolean) - Constructor for class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
ServerGenerator - Class in org.eclipse.jetty.fcgi.generator
 
ServerGenerator(ByteBufferPool) - Constructor for class org.eclipse.jetty.fcgi.generator.ServerGenerator
 
ServerGenerator(ByteBufferPool, boolean, boolean) - Constructor for class org.eclipse.jetty.fcgi.generator.ServerGenerator
 
ServerHTTP2StreamEndPoint - Class in org.eclipse.jetty.http2.server
 
ServerHTTP2StreamEndPoint(IStream) - Constructor for class org.eclipse.jetty.http2.server.ServerHTTP2StreamEndPoint
 
ServerHttpChannelOverHTTP2(Connector, HttpConfiguration, EndPoint, HttpTransportOverHTTP2) - Constructor for class org.eclipse.jetty.http2.server.HTTP2ServerConnection.ServerHttpChannelOverHTTP2
 
ServerInstanceWrapper - Class in org.eclipse.jetty.osgi.boot.internal.serverfactory
ServerInstanceWrapper Configures and starts a jetty Server instance.
ServerInstanceWrapper(String) - Constructor for class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
ServerMBean - Class in org.eclipse.jetty.server.jmx
 
ServerMBean(Object) - Constructor for class org.eclipse.jetty.server.jmx.ServerMBean
 
ServerParser - Class in org.eclipse.jetty.fcgi.parser
 
ServerParser - Class in org.eclipse.jetty.http2.parser
 
ServerParser(ServerParser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.ServerParser
 
ServerParser(ByteBufferPool, int, int, RateControl) - Constructor for class org.eclipse.jetty.http2.parser.ServerParser
Deprecated.
ServerParser(ByteBufferPool, int, RateControl) - Constructor for class org.eclipse.jetty.http2.parser.ServerParser
 
ServerParser.Listener - Interface in org.eclipse.jetty.fcgi.parser
 
ServerParser.Listener - Interface in org.eclipse.jetty.http2.parser
 
ServerParser.Listener.Adapter - Class in org.eclipse.jetty.fcgi.parser
 
ServerParser.Listener.Adapter - Class in org.eclipse.jetty.http2.parser
 
ServerParser.Listener.Wrapper - Class in org.eclipse.jetty.http2.parser
 
ServerProtocolSession - Class in org.eclipse.jetty.quic.server
Server specific implementation of ProtocolSession.
ServerProtocolSession(ServerQuicSession) - Constructor for class org.eclipse.jetty.quic.server.ServerProtocolSession
 
ServerProxy - Interface in org.eclipse.jetty.ant.utils
 
ServerProxyImpl - Class in org.eclipse.jetty.ant
A proxy class for interaction with Jetty server object.
ServerProxyImpl() - Constructor for class org.eclipse.jetty.ant.ServerProxyImpl
Default constructor.
ServerProxyImpl.WebAppScannerListener - Class in org.eclipse.jetty.ant
WebAppScannerListener Handle notifications that files we are interested in have changed during execution.
ServerQuicConnection - Class in org.eclipse.jetty.quic.server
The server specific implementation of QuicConnection.
ServerQuicConnection(QuicServerConnector, EndPoint) - Constructor for class org.eclipse.jetty.quic.server.ServerQuicConnection
 
ServerQuicSession - Class in org.eclipse.jetty.quic.server
The server specific implementation of QuicSession.
ServerQuicSession(Executor, Scheduler, ByteBufferPool, QuicheConnection, QuicConnection, SocketAddress, Connector) - Constructor for class org.eclipse.jetty.quic.server.ServerQuicSession
 
ServerSessionListener - Interface in org.eclipse.jetty.http2.api.server
Server-side extension of Session.Listener that exposes additional events.
ServerSessionListener.Adapter - Class in org.eclipse.jetty.http2.api.server
Empty implementation of ServerSessionListener
ServerUpgradeRequest - Class in org.eclipse.jetty.websocket.core.server
Upgrade request used for websocket negotiation.
ServerUpgradeRequest(WebSocketNegotiation) - Constructor for class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
ServerUpgradeResponse - Class in org.eclipse.jetty.websocket.core.server
Upgrade response used for websocket negotiation.
ServerUpgradeResponse(WebSocketNegotiation) - Constructor for class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.jsp.JettyJspServlet
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.proxy.ProxyServlet
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.servlet.Invoker
 
service(HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServlet
 
service(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.servlet.JspPropertyGroupServlet
 
service(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
SERVICE_PROP_REQUIRE_TLD_BUNDLE - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
Comma separated list of bundles that contain tld file used by the webapp.
SERVICE_RESTART - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1012 indicates that the service is restarted.
SERVICE_RESTART - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
SERVICE_UNAVAILABLE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
SERVICE_UNAVAILABLE_503 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
serviceAdded(ServiceReference, ContextHandler) - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider
 
serviceAdded(ServiceReference, ContextHandler) - Method in interface org.eclipse.jetty.osgi.boot.ServiceProvider
 
serviceAdded(ServiceReference, ContextHandler) - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider
A webapp that was deployed as an osgi service has been added, and we want to deploy it.
ServiceApp(DeploymentManager, AppProvider, String, Bundle, String) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ServiceApp
 
ServiceApp(DeploymentManager, AppProvider, Bundle, String) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.ServiceApp
 
ServiceApp(DeploymentManager, AppProvider, Bundle, Dictionary<String, String>, String) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.ServiceApp
 
ServiceApp(DeploymentManager, AppProvider, Bundle, Dictionary, String, String) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceContextProvider.ServiceApp
 
serviceChanged(ServiceEvent) - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
Invokes the optional BundleActivator in each fragment.
ServiceContextProvider - Class in org.eclipse.jetty.osgi.boot
ServiceContextProvider Jetty DeploymentManager Provider that is able to deploy ContextHandlers discovered via OSGi as services.
ServiceContextProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceContextProvider
 
ServiceContextProvider.ContextTracker - Class in org.eclipse.jetty.osgi.boot
ContextTracker
ServiceContextProvider.ServiceApp - Class in org.eclipse.jetty.osgi.boot
ServiceApp
ServiceProvider - Interface in org.eclipse.jetty.osgi.boot
ServiceProvider Jetty DeploymentManager Provider api for webapps or ContextHandlers that are discovered as OSGi services.
serviceProviderStream(ServiceLoader<T>) - Static method in class org.eclipse.jetty.util.TypeUtil
Utility to create a stream which provides the same functionality as ServiceLoader.stream().
serviceRemoved(ServiceReference, ContextHandler) - Method in class org.eclipse.jetty.osgi.boot.ServiceContextProvider
 
serviceRemoved(ServiceReference, ContextHandler) - Method in interface org.eclipse.jetty.osgi.boot.ServiceProvider
 
serviceRemoved(ServiceReference, ContextHandler) - Method in class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider
 
serviceStream(ServiceLoader<T>) - Static method in class org.eclipse.jetty.util.TypeUtil
Utility method to provide a stream of the service type from a ServiceLoader.
ServiceWebAppProvider - Class in org.eclipse.jetty.osgi.boot
ServiceWebAppProvider
ServiceWebAppProvider(ServerInstanceWrapper) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider
 
ServiceWebAppProvider.ServiceApp - Class in org.eclipse.jetty.osgi.boot
ServiceApp
ServiceWebAppProvider.WebAppTracker - Class in org.eclipse.jetty.osgi.boot
WebAppTracker
SERVLET_CONTAINER_INITIALIZER_EXCLUSION_PATTERN - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
SERVLET_CONTAINER_INITIALIZER_ORDER - Static variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
SERVLET_ENGINE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SERVLET_LISTENER_TYPES - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
SERVLET_MAJOR_VERSION - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
SERVLET_MINOR_VERSION - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
ServletAttributes - Class in org.eclipse.jetty.server
An implementation of Attributes that supports the standard async attributes.
ServletAttributes() - Constructor for class org.eclipse.jetty.server.ServletAttributes
 
ServletCallbackHandler - Class in org.eclipse.jetty.security.jaspi
This CallbackHandler will bridge Callbacks to handle to the given to the Jetty LoginService.
ServletCallbackHandler(LoginService) - Constructor for class org.eclipse.jetty.security.jaspi.ServletCallbackHandler
 
ServletContainerInitializerComparator(AnnotationConfiguration.ServletContainerInitializerOrdering) - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerComparator
 
ServletContainerInitializerHolder - Class in org.eclipse.jetty.servlet
Holds a ServletContainerInitializer.
ServletContainerInitializerHolder() - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder(ServletContainerInitializer, Class<?>...) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder(Class<? extends ServletContainerInitializer>) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder(Class<? extends ServletContainerInitializer>, Class<?>...) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder(Source) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder(Source, ServletContainerInitializer, Class<?>...) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
ServletContainerInitializerHolder.WrapFunction - Interface in org.eclipse.jetty.servlet
Experimental Wrapper mechanism for ServletContainerInitializer objects.
ServletContainerInitializerHolder.Wrapper - Class in org.eclipse.jetty.servlet
 
ServletContainerInitializerOrdering(String) - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
 
ServletContainerInitializerServletContextListener(ServletContainerInitializer) - Constructor for class org.eclipse.jetty.servlet.listener.ContainerInitializer.ServletContainerInitializerServletContextListener
 
ServletContainerInitializersStarter - Class in org.eclipse.jetty.annotations
Deprecated. 
ServletContainerInitializersStarter(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.ServletContainerInitializersStarter
Deprecated.
 
ServletContainerInitializerStarter() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.ServletContainerInitializerStarter
 
ServletContextHandler - Class in org.eclipse.jetty.servlet
Servlet Context.
ServletContextHandler() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(int) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, String) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, String, boolean, boolean) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, String, int) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, String, SessionHandler, SecurityHandler, ServletHandler, ErrorHandler) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, String, SessionHandler, SecurityHandler, ServletHandler, ErrorHandler, int) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler(HandlerContainer, SessionHandler, SecurityHandler, ServletHandler, ErrorHandler) - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler
 
ServletContextHandler.Context - Class in org.eclipse.jetty.servlet
 
ServletContextHandler.Initializer - Class in org.eclipse.jetty.servlet
Deprecated. 
ServletContextHandler.JspConfig - Class in org.eclipse.jetty.servlet
 
ServletContextHandler.JspPropertyGroup - Class in org.eclipse.jetty.servlet
 
ServletContextHandler.ServletContainerInitializerCaller - Interface in org.eclipse.jetty.servlet
 
ServletContextHandler.ServletContainerInitializerStarter - Class in org.eclipse.jetty.servlet
Bean that is added to the ServletContextHandler to start all of the ServletContainerInitializers by starting their corresponding ServletContainerInitializerHolders when this bean is itself started.
ServletContextHandler.TagLib - Class in org.eclipse.jetty.servlet
 
ServletHandler - Class in org.eclipse.jetty.servlet
Servlet HttpHandler.
ServletHandler() - Constructor for class org.eclipse.jetty.servlet.ServletHandler
Constructor.
ServletHandler.Default404Servlet - Class in org.eclipse.jetty.servlet
 
ServletHandler.MappedServlet - Class in org.eclipse.jetty.servlet
A mapping of a servlet by pathSpec or by name
ServletHolder - Class in org.eclipse.jetty.servlet
Servlet Instance and Context Holder.
ServletHolder() - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor .
ServletHolder(Servlet) - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor for existing servlet.
ServletHolder(Class<? extends Servlet>) - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor for servlet class.
ServletHolder(String, Servlet) - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor for servlet class.
ServletHolder(String, Class<? extends Servlet>) - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor for servlet class.
ServletHolder(Source) - Constructor for class org.eclipse.jetty.servlet.ServletHolder
Constructor .
ServletHolder.Config - Class in org.eclipse.jetty.servlet
 
ServletHolder.JspContainer - Enum in org.eclipse.jetty.servlet
 
ServletHolder.Registration - Class in org.eclipse.jetty.servlet
 
ServletHolder.WrapFunction - Interface in org.eclipse.jetty.servlet
Experimental Wrapper mechanism for Servlet objects.
ServletHolder.Wrapper - Class in org.eclipse.jetty.servlet
 
ServletMapping - Class in org.eclipse.jetty.servlet
 
ServletMapping() - Constructor for class org.eclipse.jetty.servlet.ServletMapping
 
ServletMapping(Source) - Constructor for class org.eclipse.jetty.servlet.ServletMapping
 
ServletMappingMBean - Class in org.eclipse.jetty.servlet.jmx
 
ServletMappingMBean(Object) - Constructor for class org.eclipse.jetty.servlet.jmx.ServletMappingMBean
 
ServletPathMapping - Class in org.eclipse.jetty.server
Implementation of HttpServletMapping.
ServletPathMapping(PathSpec, String, String) - Constructor for class org.eclipse.jetty.server.ServletPathMapping
 
ServletPathMapping(PathSpec, String, String, MatchedPath) - Constructor for class org.eclipse.jetty.server.ServletPathMapping
 
ServletPathSpec - Class in org.eclipse.jetty.http.pathmap
 
ServletPathSpec(String) - Constructor for class org.eclipse.jetty.http.pathmap.ServletPathSpec
 
ServletRequestCallback - Class in org.eclipse.jetty.jaas.callback
ServletRequestCallback Provides access to the request associated with the authentication.
ServletRequestCallback() - Constructor for class org.eclipse.jetty.jaas.callback.ServletRequestCallback
 
ServletRequestHttpWrapper - Class in org.eclipse.jetty.server
ServletRequestHttpWrapper Class to tunnel a ServletRequest via an HttpServletRequest
ServletRequestHttpWrapper(ServletRequest) - Constructor for class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
ServletResponseHttpWrapper - Class in org.eclipse.jetty.server
ServletResponseHttpWrapper Wrapper to tunnel a ServletResponse via an HttpServletResponse
ServletResponseHttpWrapper(ServletResponse) - Constructor for class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
ServletsConfiguration - Class in org.eclipse.jetty.webapp
Jetty Servlets Configuration
ServletsConfiguration() - Constructor for class org.eclipse.jetty.webapp.ServletsConfiguration
 
ServletSecurityAnnotationHandler - Class in org.eclipse.jetty.annotations
ServletSecurityAnnotationHandler Inspect a class to see if it has an @ServletSecurity annotation on it, setting up the <security-constraint>s.
ServletSecurityAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.ServletSecurityAnnotationHandler
 
ServletTester - Class in org.eclipse.jetty.servlet
ServletTester is not best practice and may be deprecated and eventually removed in future Jetty versions.
ServletTester() - Constructor for class org.eclipse.jetty.servlet.ServletTester
 
ServletTester(String) - Constructor for class org.eclipse.jetty.servlet.ServletTester
 
ServletTester(String, int) - Constructor for class org.eclipse.jetty.servlet.ServletTester
 
servletUpgrade() - Method in class org.eclipse.jetty.http.HttpGenerator
 
servletUpgrade() - Method in class org.eclipse.jetty.http.HttpParser
 
servletUpgrade() - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
session - Variable in class org.eclipse.jetty.websocket.core.internal.messages.AbstractMessageSink
 
session - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
Session - Class in org.eclipse.jetty.server.session
Session A heavy-weight Session object representing an HttpSession.
Session - Interface in org.eclipse.jetty.http2.api
A Session represents the client-side endpoint of an HTTP/2 connection to a single origin server.
Session - Interface in org.eclipse.jetty.http3.api
The low-level HTTP/3 API representing a connection with a remote peer.
Session - Interface in org.eclipse.jetty.websocket.api
Session represents an active link of communications with a Remote WebSocket Endpoint.
Session(SessionHandler, HttpServletRequest, SessionData) - Constructor for class org.eclipse.jetty.server.session.Session
Create a new session
Session(SessionHandler, SessionData) - Constructor for class org.eclipse.jetty.server.session.Session
Re-inflate an existing session from some eg persistent store.
SESSION_CREATED_SECURE - Static variable in class org.eclipse.jetty.server.session.Session
 
SESSION_FAILURE - Static variable in class org.eclipse.jetty.http2.parser.HeaderBlockParser
 
SESSION_LISTENER_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http2.client.HTTP2ClientConnectionFactory
 
SESSION_LISTENER_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http3.client.HTTP3Client
 
SESSION_LISTENER_TYPES - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
SESSION_PROMISE_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http2.client.HTTP2ClientConnectionFactory
 
SESSION_PROMISE_CONTEXT_KEY - Static variable in class org.eclipse.jetty.http3.client.HTTP3Client
 
Session.Client - Interface in org.eclipse.jetty.http3.api
The client-side HTTP/3 API representing a connection with a server.
Session.Client.Listener - Interface in org.eclipse.jetty.http3.api
The client-side specific Session.Listener.
Session.IdState - Enum in org.eclipse.jetty.server.session
 
Session.Listener - Interface in org.eclipse.jetty.http2.api
A Session.Listener is the passive counterpart of a Session and receives events happening on an HTTP/2 connection.
Session.Listener - Interface in org.eclipse.jetty.http3.api
A Session.Listener is the passive counterpart of a Session and receives events happening on an HTTP/3 connection.
Session.Listener.Adapter - Class in org.eclipse.jetty.http2.api
Empty implementation of Stream.Listener.
Session.Server - Interface in org.eclipse.jetty.http3.api
The server-side HTTP/3 API representing a connection with a client.
Session.Server.Listener - Interface in org.eclipse.jetty.http3.api
The server-side specific Session.Listener.
Session.SessionInactivityTimer - Class in org.eclipse.jetty.server.session
SessionInactivityTimer Each Session has a timer associated with it that fires whenever it has been idle (ie not accessed by a request) for a configurable amount of time, or the Session expires.
Session.State - Enum in org.eclipse.jetty.server.session
State Validity states of a session
SessionAuthentication - Class in org.eclipse.jetty.security.authentication
SessionAuthentication When a user has been successfully authenticated with some types of Authenticator, the Authenticator stashes a SessionAuthentication into an HttpSession to remember that the user is authenticated.
SessionAuthentication(String, UserIdentity, Object) - Constructor for class org.eclipse.jetty.security.authentication.SessionAuthentication
 
SessionCache - Interface in org.eclipse.jetty.server.session
SessionCache A working set of Session objects for a context.
SessionCacheFactory - Interface in org.eclipse.jetty.server.session
SessionCacheFactory
SessionContext - Class in org.eclipse.jetty.server.session
SessionContext Information about the context to which sessions belong: the Context, the SessionHandler of the context, and the unique name of the node.
SessionContext(String, ContextHandler.Context) - Constructor for class org.eclipse.jetty.server.session.SessionContext
 
SessionData - Class in org.eclipse.jetty.server.session
SessionData The data associated with a session.
SessionData(String, String, String, long, long, long, long) - Constructor for class org.eclipse.jetty.server.session.SessionData
 
SessionData(String, String, String, long, long, long, long, Map<String, Object>) - Constructor for class org.eclipse.jetty.server.session.SessionData
 
SessionDataMap - Interface in org.eclipse.jetty.server.session
SessionDataMap A map style access to SessionData keyed by the session id.
SessionDataMapFactory - Interface in org.eclipse.jetty.server.session
SessionDataMapFactory
SessionDataMarshaller - Class in org.eclipse.jetty.session.infinispan
SessionDataMarshaller A marshaller for converting a SessionData object into protobuf format which gives greater control over serialization/deserialization.
SessionDataMarshaller() - Constructor for class org.eclipse.jetty.session.infinispan.SessionDataMarshaller
 
SessionDataStore - Interface in org.eclipse.jetty.server.session
SessionDataStore A store for the data contained in a Session object.
SessionDataStoreFactory - Interface in org.eclipse.jetty.server.session
SessionDataStoreFactory
SessionDataTranscoder() - Constructor for class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap.SessionDataTranscoder
 
sessionDidActivate(HttpSessionEvent) - Method in class org.eclipse.jetty.security.authentication.SessionAuthentication
 
SessionException(long, String) - Constructor for exception class org.eclipse.jetty.http3.qpack.QpackException.SessionException
 
SessionException(long, String, Throwable) - Constructor for exception class org.eclipse.jetty.http3.qpack.QpackException.SessionException
 
SessionException(String, Object...) - Constructor for exception class org.eclipse.jetty.http2.hpack.HpackException.SessionException
 
sessionFromEntity(Entity) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
Generate SessionData from an Entity retrieved from gcloud datastore.
SessionHandler - Class in org.eclipse.jetty.server.session
SessionHandler.
SessionHandler() - Constructor for class org.eclipse.jetty.server.session.SessionHandler
Constructor.
SessionHandler.CookieConfig - Class in org.eclipse.jetty.server.session
CookieConfig Implementation of the jakarta.servlet.SessionCookieConfig.
SessionHandler.SessionIf - Interface in org.eclipse.jetty.server.session
SessionIf Interface that any session wrapper should implement so that SessionManager may access the Jetty session implementation.
sessionId(String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
SessionIdManager - Interface in org.eclipse.jetty.server
Session ID Manager.
SessionInactivityTimer() - Constructor for class org.eclipse.jetty.server.session.Session.SessionInactivityTimer
 
sessionInactivityTimerExpired(Session, long) - Method in class org.eclipse.jetty.server.session.SessionHandler
Each session has a timer that is configured to go off when either the session has not been accessed for a configurable amount of time, or the session itself has passed its expiry.
SESSIONS - Static variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
SessionTableSchema() - Constructor for class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
sessionTracker - Variable in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
SessionTracker - Class in org.eclipse.jetty.websocket.common
 
SessionTracker - Class in org.eclipse.jetty.websocket.jakarta.common
 
SessionTracker() - Constructor for class org.eclipse.jetty.websocket.common.SessionTracker
 
SessionTracker() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
sessionWillPassivate(HttpSessionEvent) - Method in class org.eclipse.jetty.security.authentication.SessionAuthentication
 
set(int, int) - Method in class org.eclipse.jetty.util.AtomicBiInteger
Sets the hi and lo values.
set(int, E) - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
set(String...) - Method in class org.eclipse.jetty.webapp.Configurations
 
set(Configuration...) - Method in class org.eclipse.jetty.webapp.Configurations
 
SET - Enum constant in enum org.eclipse.jetty.server.session.Session.IdState
 
SET_COOKIE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SET_COOKIE2 - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
SET_INCLUDE_HEADER_PREFIX - Static variable in class org.eclipse.jetty.server.Response
If a header name starts with this string, the header (stripped of the prefix) can be set during include using only Response.setHeader(String, String) or Response.addHeader(String, String).
setAcceptedReceiveBufferSize(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAcceptedSendBufferSize(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAcceptedSubProtocol(String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
setAcceptedSubProtocol(String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
setAcceptedSubProtocol(String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Set the accepted WebSocket Protocol.
setAcceptedTcpNoDelay(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAccepting(boolean) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setAccepting(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAcceptingInLowResources(boolean) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setAcceptorPriorityDelta(int) - Method in class org.eclipse.jetty.server.AbstractConnector
Set the acceptor thread priority delta.
setAcceptQueueSize(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAcceptQueueSize(int) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
setAcceptRanges(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setAcceptRanges(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setAccessed(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setAccessed(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setAccessTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setAdd(boolean) - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Sets the Add flag.
setAdd(boolean) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
Sets the Add flag.
setAddresses(InetSocketAddress...) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
setAddressResolutionTimeout(long) - Method in class org.eclipse.jetty.client.HttpClient
Sets the socket address resolution timeout used by the default SocketAddressResolver created by this HttpClient at startup.
setAliasChecks(List<ContextHandler.AliasCheck>) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setAliasMapper(UnaryOperator<String>) - Method in class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
Sets a function that transforms the alias into a possibly different alias, invoked when the SNI logic must choose the alias to pick the right certificate.
setAllModules(Modules) - Method in class org.eclipse.jetty.start.StartArgs
 
setAllowDuplicateFragmentNames(boolean) - Method in class org.eclipse.jetty.webapp.MetaData
 
setAllowDuplicateFragmentNames(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setAllowDuplicateMappings(boolean) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setAllowNullPathInfo(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setAlwaysSaveUri(boolean) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
If true, uris that cause a redirect to a login page will always be remembered.
setAlwaysSaveUri(boolean) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
Deprecated.
setAnyAuth(boolean) - Method in class org.eclipse.jetty.security.RoleInfo
 
setAnyRole(boolean) - Method in class org.eclipse.jetty.security.RoleInfo
 
setAppend(boolean) - Method in class org.eclipse.jetty.server.RequestLogWriter
Set append to log flag.
setApplyToAsync(boolean) - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
Should the adjusted idle time be maintained for asynchronous requests
setAppProviders(Collection<AppProvider>) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Set the AppProviders.
setArrayConverter(Function<List<?>, Object>) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
Sets the function to convert JSON arrays from their default Java representation, a List<Object>, to another Java data structure such as an Object[].
setArrayConverter(Function<List<?>, Object>) - Method in class org.eclipse.jetty.util.ajax.JSON
Sets the function to convert JSON arrays from their default Java representation, a List<Object>, to another Java data structure such as an Object[].
setAssociate(Object) - Method in class org.eclipse.jetty.util.resource.Resource
 
setAsyncAttributes() - Method in class org.eclipse.jetty.server.Request
 
setAsyncAttributes(String, String, String, ServletPathMapping, String) - Method in class org.eclipse.jetty.server.ServletAttributes
 
setAsyncSendTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
setAsyncSupported(boolean) - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
setAsyncSupported(boolean) - Method in class org.eclipse.jetty.servlet.Holder
 
setAsyncSupported(boolean, Object) - Method in class org.eclipse.jetty.server.Request
 
setAttachment(Object) - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
setAttachment(Object) - Method in class org.eclipse.jetty.client.HttpConnection
 
setAttachment(Object) - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
setAttachment(Object) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
setAttachment(Object) - Method in interface org.eclipse.jetty.util.Attachable
Attaches the given object to this stream for later retrieval.
setAttribute(String, Object) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
setAttribute(String, Object) - Method in interface org.eclipse.jetty.http2.api.Stream
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.HttpChannelState
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.Request
Set a request attribute.
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.Server
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.ServletAttributes
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.session.Session
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.session.SessionData
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setAttribute(String, Object) - Method in interface org.eclipse.jetty.util.Attributes
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.util.Attributes.Wrapper
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.util.AttributesMap
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
setAttribute(Attribute) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
setAttribute(Attribute) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
setAttributes(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setAttributes(AttributeList) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
setAttributes(AttributeList) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
setAttributes(Attributes) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setAttributes(Attributes) - Method in class org.eclipse.jetty.server.Request
Set the attributes for the request.
setAuthenticate(boolean) - Method in class org.eclipse.jetty.util.security.Constraint
 
setAuthenticated(boolean) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
setAuthenticateNewUsers(boolean) - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
setAuthenticateNewUsers(boolean) - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
This setting is only meaningful if a wrapped LoginService has been set.
setAuthentication(Authentication) - Method in class org.eclipse.jetty.server.Request
Set the authentication.
setAuthenticationDuration(Duration) - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
Sets the duration of the authentication.
setAuthenticationStore(AuthenticationStore) - Method in class org.eclipse.jetty.client.HttpClient
 
setAuthenticator(Authenticator) - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
setAuthenticator(Authenticator) - Method in class org.eclipse.jetty.security.SecurityHandler
Set the authenticator.
setAuthenticatorFactory(Authenticator.Factory) - Method in class org.eclipse.jetty.security.SecurityHandler
 
setAuthMethod(String) - Method in class org.eclipse.jetty.security.SecurityHandler
 
setAutoFragment(boolean) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
If set to true, frames are automatically fragmented to respect the maximum frame size.
setAutoFragment(boolean) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setAutoFragment(boolean) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setAutoFragment(boolean) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setAutoFragment(boolean) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setAutoFragment(boolean) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setAutoFragment(boolean) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setAutoStartScanning(boolean) - Method in class org.eclipse.jetty.util.Scanner
Flag to control scanning auto start feature.
setAvailable(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set Available status.
setAvailableProcessors(int) - Static method in class org.eclipse.jetty.util.ProcessorUtils
 
setBackoffMs(int) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setBackoffMs(int) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setBase(Path) - Method in class org.eclipse.jetty.start.PathFinder
Set the active basePath, used for resolving relative paths.
setBaseResource(Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the base resource for this context.
setBaseResource(Resource) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setBaseResource(Resource) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setBatchingAllowed(boolean) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
setBatchMode(BatchMode) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Set the batch mode with which messages are sent.
setBatchMode(BatchMode) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setBatchMode(BatchMode) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
setBeans(Collection<Object>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
setBeginNanoTime(long) - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
setBeginNanoTimeSupplier(LongSupplier) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
setBidirectionalStreamRecvWindow(int) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setBinaryHandle(Class<? extends MessageSink>, MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setBinaryMetadata(JakartaWebSocketMessageMetadata, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setBindAddress(SocketAddress) - Method in class org.eclipse.jetty.client.HttpClient
 
setBindAddress(SocketAddress) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setBindAddress(SocketAddress) - Method in class org.eclipse.jetty.io.ClientConnector
Sets the bind address of sockets before the connect operation.
setBindAddress(SocketAddress) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setBlobType(String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
setBuffer(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setBufferRatio(float) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
setBufferSize(int) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setBufferSize(int) - Method in class org.eclipse.jetty.server.HttpOutput
 
setBufferSize(int) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
 
setBufferSize(int) - Method in class org.eclipse.jetty.server.Response
 
setBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.client.HttpClient
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.io.ClientConnector
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setCache(BasicCache<String, InfinispanSessionData>) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
Set the clustered cache instance.
setCache(BasicCache<String, InfinispanSessionData>) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
Set the clustered cache instance.
setCacheControl(String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Set the cacheControl.
setCacheControl(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setCacheControl(HttpField) - Method in class org.eclipse.jetty.server.ResourceService
 
setCallback(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
setCallback(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageWriter
 
setCallbackHandler(CallbackHandler) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
setCallbackHandlerClass(String) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
setCapacity(int) - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
setCatalogName(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setCertAlias(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the default certificate Alias.
setCharacterEncoding(String) - Method in class org.eclipse.jetty.server.Request
 
setCharacterEncoding(String) - Method in class org.eclipse.jetty.server.Response
 
setCharacterEncoding(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
setCharacterEncoding(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setCharacterEncodingUnchecked(String) - Method in class org.eclipse.jetty.server.Request
 
setCharset(Charset) - Method in class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
setChecked(boolean) - Method in class org.eclipse.jetty.security.RoleInfo
 
setCheckingRemoteSessionIdEncoding(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setCheckWelcomeFiles(boolean) - Method in class org.eclipse.jetty.security.SecurityHandler
 
setCipherComparator(Comparator<String>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setClassAssertionStatus(String, boolean) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
setClassLoader(ClassLoader) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setClassLoader(ClassLoader) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setClassLoader(ClassLoader) - Method in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
setClassLoader(ClassLoader) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setClassName(String) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
setClassName(String) - Method in class org.eclipse.jetty.servlet.Holder
 
setClassPathFiles(List) - Method in class org.eclipse.jetty.ant.AntWebXmlConfiguration
 
setCloseHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setCloseHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setCode(String) - Method in class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
Sets the response status code.
setCode(String) - Method in class org.eclipse.jetty.rewrite.handler.ValidUrlRule
Sets the response status code.
setCollectionName(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
setComment(String) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setCommitted(boolean) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
setCompactPath(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Deprecated.
setConfig(String) - Method in class org.eclipse.jetty.security.HashLoginService
Load users from properties file.
setConfig(String) - Method in class org.eclipse.jetty.security.JDBCLoginService
Load JDBC connection configuration from properties file.
setConfig(String) - Method in class org.eclipse.jetty.security.PropertyUserStore
Set the Config Path from a String reference to a file
setConfigFile(File) - Method in class org.eclipse.jetty.security.PropertyUserStore
Set the Config Path from a File reference
setConfigPath(Path) - Method in class org.eclipse.jetty.security.PropertyUserStore
Set the Config Path
setConfiguration(Configuration) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
setConfiguration(Authenticator.AuthConfiguration) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
setConfiguration(Authenticator.AuthConfiguration) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
setConfiguration(Authenticator.AuthConfiguration) - Method in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
setConfiguration(Authenticator.AuthConfiguration) - Method in interface org.eclipse.jetty.security.Authenticator
Configure the Authenticator
setConfiguration(Authenticator.AuthConfiguration) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
setConfiguration(Authenticator.AuthConfiguration) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
setConfiguration(Configuration.ConfigurationCustomizer) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
setConfigurationClasses(String[]) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
 
setConfigurationClasses(String[]) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setConfigurationClasses(List<String>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setConfigurationDiscovered(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the configuration discovery mode.
setConfigurationManager(ConfigurationManager) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Set the configurationManager.
setConfigurations(Configuration[]) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setConnectBlocking(boolean) - Method in class org.eclipse.jetty.client.HttpClient
Whether connect() operations are performed in blocking mode.
setConnectBlocking(boolean) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setConnectBlocking(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
 
setConnection(Connection) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
setConnection(Connection) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
setConnection(Connection) - Method in interface org.eclipse.jetty.io.EndPoint
 
setConnection(Connection) - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
setConnection(Connection) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
setConnection(ProxyConnection) - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
setConnectionFactories(Collection<ConnectionFactory>) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setConnectionId(QuicheConnectionId) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
setConnectionPoolFactory(ConnectionPool.Factory) - Method in class org.eclipse.jetty.client.AbstractHttpClientTransport
 
setConnectionPoolFactory(ConnectionPool.Factory) - Method in interface org.eclipse.jetty.client.HttpClientTransport
 
setConnectionString(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
setConnectors(List<Connector>) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setConnectors(Connector[]) - Method in class org.eclipse.jetty.server.Server
Set the connectors for this server.
setConnectProtocolEnabled(boolean) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setConnectProtocolEnabled(boolean) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setConnectTimeout(long) - Method in class org.eclipse.jetty.client.HttpClient
 
setConnectTimeout(long) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setConnectTimeout(long) - Method in class org.eclipse.jetty.io.SelectorManager
Set the connect timeout (in milliseconds)
setConnectTimeout(long) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setConnectTimeout(long) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
Set the timeout for connecting to the remote server.
setConnectTimeout(Duration) - Method in class org.eclipse.jetty.io.ClientConnector
 
setConstraint(Constraint) - Method in class org.eclipse.jetty.security.ConstraintMapping
 
setConstraintMappings(List<ConstraintMapping>) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Process the constraints following the combining rules in Servlet 3.0 EA spec section 13.7.1 Note that much of the logic is in the RoleInfo class.
setConstraintMappings(List<ConstraintMapping>, Set<String>) - Method in interface org.eclipse.jetty.security.ConstraintAware
Set Constraint Mappings and roles.
setConstraintMappings(List<ConstraintMapping>, Set<String>) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Process the constraints following the combining rules in Servlet 3.0 EA spec section 13.7.1 Note that much of the logic is in the RoleInfo class.
setConstraintMappings(ConstraintMapping[]) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Process the constraints following the combining rules in Servlet 3.0 EA spec section 13.7.1 Note that much of the logic is in the RoleInfo class.
setContent(byte[]) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
setContent(String) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
setContent(ByteBuffer) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
setContentFactory(HttpContent.ContentFactory) - Method in class org.eclipse.jetty.server.ResourceService
 
setContentLength(int) - Method in class org.eclipse.jetty.server.Response
 
setContentLength(int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setContentLengthLong(long) - Method in class org.eclipse.jetty.server.Response
 
setContentLengthLong(long) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setContentParameters(MultiMap<String>) - Method in class org.eclipse.jetty.server.Request
 
setContentType(String) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
setContentType(String) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
setContentType(String) - Method in class org.eclipse.jetty.server.Request
 
setContentType(String) - Method in class org.eclipse.jetty.server.Response
 
setContentType(String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setContext(ContextHandler.Context, String) - Method in class org.eclipse.jetty.server.Request
Set request context and path in the context.
setContextAttribute(String, Object) - Method in class org.eclipse.jetty.deploy.DeploymentManager
Set a contextAttribute that will be set for every Context deployed by this provider.
setContextAttribute(String, Object) - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
setContextAttribute(String, String) - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
setContextAttributes(AttributesMap) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
setContextHandlers(ContextHandlers) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setContextPath(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setContextPath(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
setContextPath(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
setContextPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setContextPath(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
setContextPath(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setContextPathColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setContexts(ContextHandlerCollection) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
setContextWhiteList(String...) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the context white list In certain circumstances you want may want to deny access of one webapp from another when you may not fully trust the webapp.
setContextXml(File) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
SetCookieHttpField(HttpCookie, CookieCompliance) - Constructor for class org.eclipse.jetty.http.HttpCookie.SetCookieHttpField
 
setCookies(Cookie[]) - Method in class org.eclipse.jetty.server.Cookies
 
setCookies(Cookie[]) - Method in class org.eclipse.jetty.server.Request
 
setCookies(List<HttpCookie>) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set the list of Cookies on the request
setCookieSet(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setCookieSetTime(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setCookieStore(CookieStore) - Method in class org.eclipse.jetty.client.HttpClient
 
setCookieStore(CookieStore) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setCookieTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setCopyWebDir(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setCopyWebInf(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setCoreSession(CoreSession) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
setCoreSession(CoreSession) - Method in interface org.eclipse.jetty.websocket.core.Extension
 
setCount(int) - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
setCreated(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setCreateTables(boolean) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setCreateTime(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setCreateTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setCreator(JettyWebSocketCreator) - Method in interface org.eclipse.jetty.websocket.server.JettyWebSocketServletFactory
Add a WebSocket mapping at PathSpec "/" for a creator
setCredential(Object) - Method in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
setCrlPath(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Set the crlPath.
setCrlPath(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setCurrentConnection(HttpConnection) - Static method in class org.eclipse.jetty.server.HttpConnection
 
setCurrentUser(AbstractLoginModule.JAASUser) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
setCustomizers(List<HttpConfiguration.Customizer>) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the HttpConfiguration.Customizers that are invoked for every request received.
setDaemon(boolean) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setDaemon(boolean) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setDaemon(boolean) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setDaemon(boolean) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setDatabaseAdaptor(DatabaseAdaptor) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setDatabaseAdaptor(DatabaseAdaptor) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
setDatabaseAdaptor(DatabaseAdaptor) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStoreFactory
 
setDataConstraint(int) - Method in class org.eclipse.jetty.util.security.Constraint
 
setDatasource(DataSource) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
setDatasourceName(String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
setDatastore(Datastore) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setDateHeader(String, long) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormResponse
 
setDateHeader(String, long) - Method in class org.eclipse.jetty.server.Response
 
setDateHeader(String, long) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
setDateHeader(String, long) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setDBCollection(DBCollection) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
setDbName(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
setDebug(boolean) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setDebugEnabled(boolean) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Mutator used to turn debug on programmatically.
setDecorators(List<? extends Decorator>) - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
setDefaultAssertionStatus(boolean) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
setDefaultContentType(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setDefaultContextPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the default context path.
setDefaultLifeCycleGoal(String) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
setDefaultMaxBinaryMessageBufferSize(int) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
setDefaultMaxSessionIdleTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
setDefaultMaxTextMessageBufferSize(int) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketContainer
 
setDefaultProtocol(String) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setDefaultProtocol(String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
setDefaultRequestCharacterEncoding(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setDefaultRequestContentType(String) - Method in class org.eclipse.jetty.client.HttpClient
 
setDefaultResponseCharacterEncoding(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setDefaultsDescriptor(String) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Set the defaultsDescriptor.
setDefaultsDescriptor(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
Set the defaultsDescriptor.
setDefaultsDescriptor(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
The default descriptor is a web.xml format file that is applied to the context before the standard WEB-INF/web.xml
setDefaultsDescriptor(DefaultsDescriptor) - Method in class org.eclipse.jetty.webapp.MetaData
Set the web-default.xml.
setDefaultSecurityHandlerClass(Class<? extends SecurityHandler>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Set the defaultSecurityHandlerClass.
setDefaultUseCaches(boolean) - Static method in class org.eclipse.jetty.util.resource.Resource
Change the default setting for url connection caches.
setDeferInitialScan(boolean) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
Flag to control initial scan behavior.
setDeferredSyntaxAllowedAsLiteral(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setDeflaterPool(DeflaterPool) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the DeflaterPool to be used.
setDeflaterPoolCapacity(int) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Deprecated.
for custom DeflaterPool settings use GzipHandler.setDeflaterPool(DeflaterPool).
setDelayDispatchUntilContent(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setDeleteOnExit(boolean) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Deprecated.
no replacement provided.
setDeleteOnExit(boolean) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
no replacement offered.
setDeleteUnrestorableFiles(boolean) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
setDeleteUnrestorableFiles(boolean) - Method in class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
setDenyUncoveredHttpMethods(boolean) - Method in interface org.eclipse.jetty.security.ConstraintAware
See Servlet Spec 31, sec 13.8.4, pg 145 When true, requests with http methods not explicitly covered either by inclusion or omissions in constraints, will have access denied.
setDenyUncoveredHttpMethods(boolean) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
 
setDeploymentManager(DeploymentManager) - Method in interface org.eclipse.jetty.deploy.AppProvider
Set the Deployment Manager
setDeploymentManager(DeploymentManager) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setDeploymentManager(DeploymentManager) - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider
 
setDeploymentManager(DeploymentManager) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
setDescription(String) - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
setDescriptor(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setDestinationIdleTimeout(long) - Method in class org.eclipse.jetty.client.HttpClient
Whether destinations that have no connections (nor active nor idle) and no exchanges should be removed after the specified timeout.
setDetailedDump(boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
setDetailedDump(boolean) - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
setDetailedDump(boolean) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setDetailedDump(boolean) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setDetailedParseException(boolean) - Method in class org.eclipse.jetty.util.ajax.AsyncJSON.Factory
 
setDir(File) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
setDir(String) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
setDir(Path) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
setDirAllowed(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setDirAllowed(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setDirectBuffersForDecryption(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setDirectBuffersForDecryption(boolean) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
setDirectBuffersForEncryption(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setDirectBuffersForEncryption(boolean) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
setDirectoriesListed(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
Set the directory.
setDirMatcher(PathMatcher) - Method in class org.eclipse.jetty.start.PathFinder
 
setDirty(boolean) - Method in class org.eclipse.jetty.server.session.SessionData
 
setDirty(String) - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
setDirty(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
setDisableActiveMigration(boolean) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setDiscardPathInfo(boolean) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setDiscardQuery(boolean) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setDispatchContext(ServletContext) - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
setDispatcherType(DispatcherType) - Method in class org.eclipse.jetty.server.Request
 
setDispatcherTypes(DispatcherType...) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
setDispatcherTypes(DispatcherType...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the list of supported DispatcherType that this filter will operate on.
setDispatcherTypes(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set of supported DispatcherType that this filter will operate on.
setDispatcherTypes(EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
setDispatcherTypes(EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set of supported DispatcherType that this filter will operate on.
setDispatcherTypes(EnumSet<DispatcherType>) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setDispatches(int) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setDispatchPath(String) - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
setDisplayName(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setDisplayName(String) - Method in class org.eclipse.jetty.servlet.Holder
 
setDisplayName(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setDistributable(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setDomain(String) - Method in class org.eclipse.jetty.jmx.MBeanContainer
Set domain to be used to add MBeans
setDomain(String) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setDouble(boolean) - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
setDriverInfo(String, String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
Configure jdbc connection information via a jdbc Driver
setDriverInfo(Driver, String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
Configure jdbc connection information via a jdbc Driver
setDryRun(boolean) - Method in class org.eclipse.jetty.server.Server
 
setDumpAfterStart(boolean) - Method in class org.eclipse.jetty.server.Server
 
setDumpBeforeStop(boolean) - Method in class org.eclipse.jetty.server.Server
 
setDumpContext(boolean) - Method in class org.eclipse.jetty.server.DebugListener
 
setEdges(Set<Edge>) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
setEffectiveMajorVersion(int) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setEffectiveMinorVersion(int) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setElIgnored(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setEnableCRLDP(boolean) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Enables CRL Distribution Points Support
setEnableCRLDP(boolean) - Method in class org.eclipse.jetty.util.security.CertificateValidator
Enables CRL Distribution Points Support
setEnableCRLDP(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Enables CRL Distribution Points Support
setEnabled(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
setEnabled(boolean) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
setEnabled(boolean) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
setEnableOCSP(boolean) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Enables On-Line Certificate Status Protocol support
setEnableOCSP(boolean) - Method in class org.eclipse.jetty.util.security.CertificateValidator
Enables On-Line Certificate Status Protocol support
setEnableOCSP(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Enables On-Line Certificate Status Protocol support
setEncoders(Class<? extends Encoder>[]) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setEncodingCacheSize(int) - Method in class org.eclipse.jetty.server.ResourceService
 
setEndpointIdentificationAlgorithm(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
When set to "HTTPS" hostname verification will be enabled.
setEndStream(boolean) - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
setEnsureDefaultServlet(boolean) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setEnsureSecureRequestCustomizer(boolean) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
setEntityDataModel(GCloudSessionDataStore.EntityDataModel) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setEntityDataModel(GCloudSessionDataStore.EntityDataModel) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setEnv(Hashtable<String, Object>) - Method in class org.eclipse.jetty.jndi.NamingContext
 
setError() - Method in class org.eclipse.jetty.server.ResponseWriter
 
setErrorHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setErrorHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setErrorHandler(ErrorHandler) - Method in class org.eclipse.jetty.server.Server
 
setErrorOnUndeclaredNamespace(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setErrorPage(String) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
setErrorPages(Map<String, String>) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
setEtags(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setEtags(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setEventListeners(Collection<EventListener>) - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
setEvictionPolicy(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
-1 means we never evict inactive sessions.
setEvictionPolicy(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setEvictionPolicy(int) - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
setEvictionPolicy(int) - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
setEvictionPolicy(int) - Method in interface org.eclipse.jetty.server.session.SessionCache
Sessions in this cache can be: never evicted evicted once the last request exits evicted after a configurable period of inactivity
setExcludeCipherSuites(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Cipher suite name or a a regular expression.
setExcludedInflatePaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of Path specs (replacing any previously set)
setExcludedMethodList(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of HTTP Methods (replacing any previously set)
setExcludedMethods(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of HTTP methods (replacing any previously set)
setExcludedMimeTypes(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of MIME types (replacing any previously set)
setExcludedMimeTypesList(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of MIME types (replacing any previously set)
setExcludedPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the excluded filter list of Path specs (replacing any previously set)
setExcludeProtocols(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Protocol name or a a regular expression.
setExecutor(Executor) - Method in class org.eclipse.jetty.client.HttpClient
 
setExecutor(Executor) - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
setExecutor(Executor) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
setExecutor(Executor) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setExecutor(Executor) - Method in class org.eclipse.jetty.io.ClientConnector
 
setExecutor(Executor) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setExitJvm(boolean) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
setExitVm(boolean) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setExpires(String) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setExpiry(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setExpiry(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setExpirySec(int) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
setExpirySec(int) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
setExpiryTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setExtendedId(String) - Method in class org.eclipse.jetty.server.session.Session
 
setExtendedListenerTypes(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
setExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set the list of WebSocket Extension configurations on the request.
setExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
setExtensions(List<ExtensionConfig>) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Set the list of extensions that are approved for use with this websocket.
setExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
setExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
setExtraClasspath(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the Extra ClassPath via delimited String.
setExtraClasspath(List<Resource>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setExtract(boolean) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
setExtractWAR(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setExtractWars(boolean) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Set the extractWars.
setFile(String) - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
setFileMatcher(String) - Method in class org.eclipse.jetty.start.PathFinder
 
setFileMatcher(PathMatcher) - Method in class org.eclipse.jetty.start.PathFinder
 
setFilename(String) - Method in class org.eclipse.jetty.server.RequestLogWriter
Set the output file name of the request log.
setFilenameDateFormat(String) - Method in class org.eclipse.jetty.server.RequestLogWriter
Set the log file name date format.
setFilenameFilter(FilenameFilter) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setFilenameFilter(FilenameFilter) - Method in class org.eclipse.jetty.util.Scanner
Deprecated.
setFilePath(Path) - Method in class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
setFilter(Filter) - Method in class org.eclipse.jetty.servlet.FilterHolder
 
setFilter(BiPredicate<Request, Response>) - Method in class org.eclipse.jetty.server.CustomRequestLog
This allows you to set a custom filter to decide whether to log a request or omit it from the request log.
setFilterChainsCached(boolean) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setFilterMappings(FilterMapping[]) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setFilterName(String) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setFilters(FilterHolder[]) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setFin(boolean) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setFlowControlStrategyFactory(FlowControlStrategy.Factory) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setFlowControlStrategyFactory(FlowControlStrategy.Factory) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setFlushOnResponseCommit(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
setFlushOnResponseCommit(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setFlushOnResponseCommit(boolean) - Method in interface org.eclipse.jetty.server.session.SessionCache
If true, a dirty session will be written to the SessionDataStore just before a response is returned to the client.
setFollowRedirects(boolean) - Method in class org.eclipse.jetty.client.HttpClient
 
setForbidden(boolean) - Method in class org.eclipse.jetty.security.RoleInfo
 
setForcedHost(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Set a forced valued for the host header to control what is returned by ServletRequest.getServerName() and ServletRequest.getServerPort().
setForcedPath(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
setForcedValue(String) - Method in class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
setFormEncodedMethods(String...) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the form encoded HTTP methods.
setForwardedCipherSuiteHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedForHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedHostHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedHttpsHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedOnly(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedPortAsAuthority(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Set if the X-Forwarded-Port header will be used for Authority
setForwardedPortHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedProtoHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Set the forwardedProtoHeader.
setForwardedServerHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setForwardedSslSessionIdHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setFrameHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setFromDefaultDescriptor(boolean) - Method in class org.eclipse.jetty.servlet.ServletMapping
 
setFullValidate(boolean) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
setGracefulShutdownWaitsForRequests(boolean) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
Set whether the graceful shutdown should wait for all requests to complete including async requests which are not currently dispatched, or whether it should only wait for all the actively dispatched requests to complete.
setGracePeriodSec(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
setGracePeriodSec(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStoreFactory
 
setGrowOutput(boolean) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
setGzipEquivalentFileExtensions(List<String>) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setGzipEquivalentFileExtensions(List<String>) - Method in class org.eclipse.jetty.server.ResourceService
 
setGzipHandler(GzipHandler) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
setHandled(boolean) - Method in class org.eclipse.jetty.server.Request
 
setHandler(HttpHandler) - Method in class org.eclipse.jetty.http.spi.JettyHttpContext
 
setHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HandlerWrapper
 
setHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
setHandler(Handler) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
setHandler(ContextHandler) - Method in class org.eclipse.jetty.osgi.boot.AbstractContextProvider.OSGiApp
 
setHandlers(Handler[]) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
setHandling(boolean) - Method in class org.eclipse.jetty.rewrite.handler.Rule
Set the handling flag value.
setHeader(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
setHeader(String, String) - Method in class org.eclipse.jetty.http.HttpTester.Request
 
setHeader(String, String) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormResponse
 
setHeader(String, String) - Method in class org.eclipse.jetty.server.PushBuilderImpl
 
setHeader(String, String) - Method in class org.eclipse.jetty.server.Response
 
setHeader(String, String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
setHeader(String, String) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set a specific header value
setHeader(String, String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setHeader(String, String) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
setHeader(String, String) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
setHeader(String, String) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Set a header
setHeader(String, List<String>) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set a specific header with multi-value field
setHeader(String, List<String>) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
setHeader(String, List<String>) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
setHeader(String, List<String>) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Set a header
setHeader(HttpHeader, String) - Method in class org.eclipse.jetty.server.Response
 
setHeaderCacheCaseSensitive(boolean) - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
setHeaderCacheCaseSensitive(boolean) - Method in class org.eclipse.jetty.http.HttpParser
 
setHeaderCacheCaseSensitive(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setHeaderCacheSize(int) - Method in class org.eclipse.jetty.client.http.HttpClientTransportOverHTTP
 
setHeaderCacheSize(int) - Method in class org.eclipse.jetty.http.HttpParser
 
setHeaderCacheSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setHeaderName(String) - Method in class org.eclipse.jetty.rewrite.handler.ForceRequestHeaderValueRule
 
setHeaders(Map<String, List<String>>) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Sets multiple headers on the request.
setHeaders(Map<String, List<String>>) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JsrHandshakeResponse
 
setHeaders(MultiMap<String>) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
setHeaders(MultiMap<String>) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
setHeaderTableSize(int) - Method in class org.eclipse.jetty.http2.generator.Generator
Deprecated.
setHeaderValue(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
setHeadResponse(boolean) - Method in class org.eclipse.jetty.http.HttpParser
Set if a HEAD response is expected
setHeartbeats(boolean) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
setHeartbeats(boolean) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
setHeldClass(Class<? extends T>) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
setHeldClass(Class<? extends T>) - Method in class org.eclipse.jetty.servlet.Holder
 
setHideStacks(boolean) - Method in class org.eclipse.jetty.logging.JettyLogger
 
setHost(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setHost(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setHost(String) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
setHost(String) - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
setHostHeader(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Set a forced valued for the host header to control what is returned by ServletRequest.getServerName() and ServletRequest.getServerPort().
setHostName(String) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
setHostnameVerifier(HostnameVerifier) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Sets a HostnameVerifier used by a client to verify host names in the server certificate.
setHotReload(boolean) - Method in class org.eclipse.jetty.security.HashLoginService
Enable Hot Reload of the Property File
setHotReload(boolean) - Method in class org.eclipse.jetty.security.PropertyUserStore
Enable Hot Reload of the Property File
setHttpClient(HttpClient) - Method in class org.eclipse.jetty.client.AbstractHttpClientTransport
 
setHttpClient(HttpClient) - Method in interface org.eclipse.jetty.client.HttpClientTransport
Sets the HttpClient instance on this transport.
setHttpCompliance(HttpCompliance) - Method in class org.eclipse.jetty.client.HttpClient
Sets the http compliance mode for parsing http responses.
setHttpCompliance(HttpCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setHttpFields(HttpFields) - Method in class org.eclipse.jetty.server.Request
 
setHttpHandler(HttpHandler) - Method in class org.eclipse.jetty.http.spi.HttpSpiContextHandler
 
setHttpOnly(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setHttpOnly(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
Set if Session cookies should use HTTP Only
setHttpParser(HttpParser) - Method in class org.eclipse.jetty.http.HttpTester.Input
 
setHttpURI(HttpURI) - Method in class org.eclipse.jetty.server.Request
 
setId(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setId(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
setIdChanged(boolean) - Method in class org.eclipse.jetty.server.session.Session
 
setIdColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.jaas.JAASLoginService
Set the identityService.
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.security.AbstractLoginService
Set the identityService.
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.security.EmptyLoginService
 
setIdentityService(IdentityService) - Method in interface org.eclipse.jetty.security.LoginService
Set the IdentityService associated with this Login Service.
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
setIdentityService(IdentityService) - Method in class org.eclipse.jetty.security.SecurityHandler
Set the identityService.
setIdleTimeout(int) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
Sets the maximum thread idle time in ms.
setIdleTimeout(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Set the maximum thread idle time in ms.
setIdleTimeout(long) - Method in class org.eclipse.jetty.client.HttpClient
 
setIdleTimeout(long) - Method in interface org.eclipse.jetty.http2.api.Stream
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
setIdleTimeout(long) - Method in interface org.eclipse.jetty.io.EndPoint
Set the idle timeout.
setIdleTimeout(long) - Method in class org.eclipse.jetty.io.IdleTimeout
Sets the idle timeout in milliseconds.
setIdleTimeout(long) - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.quic.server.ServerQuicSession
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.AbstractConnector
Sets the maximum Idle time for a connection, which roughly translates to the Socket.setSoTimeout(int) call, although with NIO implementations other mechanisms may be used to implement the timeout.
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.HttpChannel
Set the idle timeout.
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.HttpConfiguration
The max idle time is applied to an HTTP request for IO operations and delayed dispatch.
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
setIdleTimeout(long, TimeUnit) - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
Set the idle timeout for shrinking the reserved thread pool
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.io.ClientConnector
 
setIdleTimeout(Duration) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The duration that a websocket may be idle before being closed by the implementation
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setIdleTimeout(Duration) - Method in interface org.eclipse.jetty.websocket.core.Configuration
Set the Idle Timeout.
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setIdleTimeoutMs(long) - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
setIfNotSetAlready(Property) - Static method in class org.eclipse.jetty.ant.types.SystemProperties
Set a System.property with this value if it is not already set.
setIgnorePaths(String[]) - Method in class org.eclipse.jetty.server.CustomRequestLog
Set request paths that will not be logged.
setImpl(Uptime.Impl) - Method in class org.eclipse.jetty.util.Uptime
 
setIncludeCipherSuites(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Cipher suite name or a a regular expression.
setIncludedInflatePaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of Path specs (replacing any previously set)
setIncludeDirsInResults(boolean) - Method in class org.eclipse.jetty.start.PathFinder
 
setIncludedMethodList(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of HTTP Methods (replacing any previously set)
setIncludedMethods(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of HTTP methods (replacing any previously set)
setIncludedMimeTypes(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of MIME types (replacing any previously set)
setIncludedMimeTypesList(String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of MIME types (replacing any previously set)
setIncludedPaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of Path specs (replacing any previously set)
setIncludeProtocols(String...) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
You can either use the exact Protocol name or a a regular expression.
setInfinispanIdleTimeoutSec(int) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
setInfinispanIdleTimeoutSec(int) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
setInflateBufferSize(int) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the size (in bytes) of the Inflater buffer used to inflate comrpessed requests.
setInflaterPool(InflaterPool) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the InflaterPool to be used.
setInflaterPoolCapacity(int) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Deprecated.
for custom InflaterPool settings use GzipHandler.setInflaterPool(InflaterPool).
setInheritChannel(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
Sets whether this connector uses a channel inherited from the JVM.
setInitialBuffer(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Extra bytes from the initial HTTP upgrade that need to be processed by the websocket parser before starting to read bytes from the connection
setInitialSessionRecvWindow(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setInitialSessionRecvWindow(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setInitialSessionRecvWindow(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setInitialStreamRecvWindow(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setInitialStreamRecvWindow(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setInitOrder(int) - Method in class org.eclipse.jetty.servlet.ServletHolder
Set the initialize order.
setInitParameter(String, String) - Method in class org.eclipse.jetty.security.SecurityHandler
Set an initialization parameter.
setInitParameter(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.servlet.Holder
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setInitParameter(String, String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setInitParameters(Map<String, String>) - Method in class org.eclipse.jetty.servlet.Holder.HolderRegistration
 
setInitParameters(Map<String, String>) - Method in class org.eclipse.jetty.servlet.Holder
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the size of the buffer used for QUIC network reads.
setInputBufferSize(int) - Method in class org.eclipse.jetty.io.AbstractConnection
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
setInputBufferSize(int) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The input (read from network layer) buffer size.
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setInputBufferSize(int) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setInputFilePrefix(String) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
setInstance(T) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
setInstance(T) - Method in class org.eclipse.jetty.servlet.Holder
 
setInterceptor(HttpInput.Interceptor) - Method in interface org.eclipse.jetty.server.ContentProducer
Set the interceptor.
setInterceptor(HttpInput.Interceptor) - Method in class org.eclipse.jetty.server.HttpInput
Set the interceptor.
setInterceptor(HttpOutput.Interceptor) - Method in class org.eclipse.jetty.server.HttpOutput
 
setIntervalSec(long) - Method in class org.eclipse.jetty.server.session.HouseKeeper
Set the period between scavenge cycles
setIntHeader(String, int) - Method in class org.eclipse.jetty.server.Response
 
setIntHeader(String, int) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
setIntHeader(String, int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setInvalidateOnShutdown(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
setInvalidateOnShutdown(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setInvalidateOnShutdown(boolean) - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
setInvalidateOnShutdown(boolean) - Method in interface org.eclipse.jetty.server.session.SessionCache
If true, all existing sessions in the cache will be invalidated when the server shuts down.
setIsXml(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setJAASInfo(Subject) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
setJettyEnvResource(Resource) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
setJettyEnvXml(File) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
setJettyEnvXml(URL) - Method in class org.eclipse.jetty.plus.webapp.EnvConfiguration
 
setJettyPort(int) - Method in class org.eclipse.jetty.ant.JettyRunTask
Sets the port Jetty uses for the default connector.
setJettyStandardIdsAndProperties(Object, Resource) - Method in class org.eclipse.jetty.xml.XmlConfiguration
Set the standard IDs and properties expected in a jetty XML file: RefId Server Property jetty.home Property jetty.home.uri Property jetty.base Property jetty.base.uri Property jetty.webapps Property jetty.webapps.uri
setJettyVersion(String) - Static method in class org.eclipse.jetty.http.HttpGenerator
 
setJettyXml(File) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setJettyXml(File) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setJettyXml(String) - Method in class org.eclipse.jetty.deploy.bindings.GlobalWebappConfigBinding
 
setJndiName(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setJspConfigDescriptor(JspConfigDescriptor) - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
setJspConfigDescriptor(JspConfigDescriptor) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setKey(String) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setKeyManagerFactoryAlgorithm(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyManagerPassword(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyStore(KeyStore) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the key store.
setKeyStorePassword(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyStorePath(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyStoreProvider(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyStoreResource(Resource) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the key store resource.
setKeyStoreType(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setKeyTabPath(Path) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
setKind(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setKnown(String...) - Static method in class org.eclipse.jetty.webapp.Configurations
 
setLastAccessed(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setLastAccessed(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setLastAccessTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setLastDemand(LongConsumer) - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
setLastNode(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setLastNode(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
setLastNodeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setLastSaved(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setLastSaved(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setLastSavedTimeColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setLength(int) - Method in class org.eclipse.jetty.http.compression.HuffmanDecoder
 
setLength(int) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
setLevel(JettyLevel) - Method in class org.eclipse.jetty.logging.JettyLogger
 
setLifeCycleBindings(Collection<AppLifeCycle.Binding>) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
setListener(EventListener) - Method in class org.eclipse.jetty.servlet.ListenerHolder
Set an explicit instance.
setListener(AsyncContentProvider.Listener) - Method in interface org.eclipse.jetty.client.AsyncContentProvider
Deprecated.
 
setListener(AsyncContentProvider.Listener) - Method in class org.eclipse.jetty.client.util.DeferredContentProvider
Deprecated.
 
setListener(AsyncContentProvider.Listener) - Method in class org.eclipse.jetty.client.util.MultiPartContentProvider
Deprecated.
 
setListener(AsyncContentProvider.Listener) - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
setListener(Stream.Listener) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
setListener(Stream.Listener) - Method in interface org.eclipse.jetty.http2.IStream
 
setListeners(ListenerHolder[]) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setLoadOnStartup(int) - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
setLocalAddress(SocketAddress) - Method in class org.eclipse.jetty.server.HttpConfiguration
Specify the connection local address used within application API layer when identifying the local host name/port of a connected endpoint.
setLocale(Locale) - Method in class org.eclipse.jetty.server.Response
 
setLocale(Locale) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setLocalMaxDynamicTableSize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
Deprecated.
setLocalMaxDynamicTableSize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
Deprecated.
setLocation(String) - Method in class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
Sets the redirect location.
setLocation(String) - Method in class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
Sets the redirect location.
setLog(Logger) - Static method in class org.eclipse.jetty.util.log.Log
Deprecated.
setLogger(Logger) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setLoggerLevel(String, String) - Method in class org.eclipse.jetty.logging.JettyLoggerFactory
 
setLoggerName(String) - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
setLoginModuleName(String) - Method in class org.eclipse.jetty.jaas.JAASLoginService
Set the name to use to index into the config file of LoginModules.
setLoginService(LoginService) - Method in class org.eclipse.jetty.security.DefaultAuthenticatorFactory
 
setLoginService(LoginService) - Method in class org.eclipse.jetty.security.SecurityHandler
Set the loginService.
setLoginServices(List<LoginService>) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setLogoutRedirectPath(String) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
setLogoutWhenIdTokenIsExpired(boolean) - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
setLogUrlOnStart(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
Sets whether or not the web app name and URL is logged on startup
setLongContentLength(long) - Method in class org.eclipse.jetty.server.Response
 
setLongType(String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
setLowResourceChecks(Set<LowResourceMonitor.LowResourceCheck>) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setLowResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setLowResourcesIdleTimeout(int) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setLowResourcesReasons(String) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setLowResourcesStarted(long) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setLowThreadsThreshold(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setMapColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setMask(byte[]) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setMaxAge(int) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setMaxBidirectionalRemoteStreams(int) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setMaxBinaryMessageBufferSize(int) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
Maximum size of a whole BINARY message that this implementation can buffer.
setMaxBinaryMessageSize(long) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The maximum size of a binary message during parsing/generating.
setMaxBinaryMessageSize(long) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setMaxBinaryMessageSize(long) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setMaxBinaryMessageSize(long) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setMaxBinaryMessageSize(long) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setMaxBinaryMessageSize(long) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setMaxBinaryMessageSize(long) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setMaxBlockedStreams(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the local QPACK decoder max number of blocked streams.
setMaxBlockedStreams(int) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
setMaxBlockedStreams(int) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
setMaxCachedFiles(int) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
setMaxCachedFileSize(int) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
setMaxCacheSize(int) - Method in class org.eclipse.jetty.server.CachedContentFactory
 
setMaxCertPathLength(int) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setMaxCertPathLength(int) - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
setMaxCertPathLength(int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setMaxConcurrentPushedStreams(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxConcurrentStreams(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setMaxConnections(int) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
setMaxConnectionsPerDestination(int) - Method in class org.eclipse.jetty.client.HttpClient
Sets the max number of connections to open to each destinations.
setMaxDecoderTableCapacity(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxDecoderTableCapacity(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setMaxDecoderTableCapacity(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the local QPACK decoder max dynamic table capacity.
setMaxDuration(long) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
setMaxDynamicTableSize(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
Deprecated.
setMaxDynamicTableSize(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
setMaxEncoderTableCapacity(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
Sets the limit for the encoder HPACK dynamic table capacity.
setMaxEncoderTableCapacity(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setMaxEncoderTableCapacity(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
Sets the limit for the encoder HPACK dynamic table capacity.
setMaxEncoderTableCapacity(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the local QPACK encoder initial dynamic table capacity.
setMaxErrorDispatches(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setMaxEvictCount(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Returns the maximum number of idle threads that are evicted for every idle timeout period, thus shrinking this thread pool towards its minimum number of threads.
setMaxFilterChainsCacheSize(int) - Method in class org.eclipse.jetty.servlet.ServletHandler
Set the maximum filter chain cache size.
setMaxFormContentSize(int) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the maximum size of a form post, to protect against DOS attacks from large forms.
setMaxFormKeys(int) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the maximum number of form Keys to protect against DOS attack from crafted hash keys.
setMaxFrameLength(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
Deprecated.
setMaxFrameLength(int) - Method in class org.eclipse.jetty.http2.parser.Parser
Deprecated.
setMaxFrameLength(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
Deprecated.
setMaxFrameSize(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxFrameSize(int) - Method in class org.eclipse.jetty.http2.generator.Generator
 
setMaxFrameSize(int) - Method in class org.eclipse.jetty.http2.generator.HeaderGenerator
 
setMaxFrameSize(int) - Method in class org.eclipse.jetty.http2.parser.Parser
 
setMaxFrameSize(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setMaxFrameSize(long) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The maximum payload size of any WebSocket Frame which can be received.
setMaxFrameSize(long) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setMaxFrameSize(long) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setMaxFrameSize(long) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setMaxFrameSize(long) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setMaxFrameSize(long) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setMaxFrameSize(long) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setMaxHeaderBlockFragment(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxHeaderBlockFragment(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setMaxHeaderListSize(int) - Method in class org.eclipse.jetty.http2.generator.Generator
Deprecated.
setMaxHeaderListSize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
setMaxHeaderListSize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
setMaxHeadersSize(int) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
setMaxHeadersSize(int) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
setMaxIdleTime(int) - Method in class org.eclipse.jetty.ant.types.Connector
 
setMaxIdleTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
setMaximizeConnections(boolean) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
Sets whether the number of connections should be maximized.
setMaxInactive(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setMaxInactiveInterval(int) - Method in class org.eclipse.jetty.server.session.Session
 
setMaxInactiveInterval(int) - Method in class org.eclipse.jetty.server.session.SessionHandler
Sets the max period of inactivity, after which the session is invalidated, in seconds.
setMaxInactiveMs(long) - Method in class org.eclipse.jetty.server.session.SessionData
 
setMaxInputBufferSize(long) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
setMaxIntervalColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setMaxLocalStreams(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setMaxLowResourcesTime(int) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMaxMemory(long) - Method in class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
setMaxMemory(long) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMaxMessageSize(int) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
setMaxMultiplex(int) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
setMaxMultiplex(int) - Method in interface org.eclipse.jetty.client.ConnectionPool.Multiplexable
Deprecated.
do not use, as the maxMultiplex value is pulled, rather than pushed
setMaxMultiplex(int) - Method in class org.eclipse.jetty.client.MultiplexConnectionPool
 
setMaxMultiplex(int) - Method in class org.eclipse.jetty.util.Pool
Deprecated.
Multiplex functionalities will be removed
setMaxNonceAge(long) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
setMaxNonceCount(int) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
setMaxOutgoingFrames(int) - Method in interface org.eclipse.jetty.websocket.api.RemoteEndpoint
Set the maximum number of data frames allowed to be waiting to be sent at any one time.
setMaxOutgoingFrames(int) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketRemoteEndpoint
 
setMaxOutgoingFrames(int) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setMaxOutgoingFrames(int) - Method in interface org.eclipse.jetty.websocket.core.Configuration
Set the maximum number of data frames allowed to be waiting to be sent at any one time.
setMaxOutgoingFrames(int) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setMaxOutputBufferSize(long) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
setMaxProxyHeader(int) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory
 
setMaxRedirects(int) - Method in class org.eclipse.jetty.client.HttpClient
 
setMaxRemoteStreams(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setMaxRequestHeadersSize(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets max request headers size.
setMaxRequestsPerConnection(int) - Method in interface org.eclipse.jetty.client.HttpDestination.Multiplexed
 
setMaxRequestsPerConnection(int) - Method in class org.eclipse.jetty.client.MultiplexHttpDestination
 
setMaxRequestsQueuedPerDestination(int) - Method in class org.eclipse.jetty.client.HttpClient
Sets the max number of requests that may be queued to a destination.
setMaxResponseHeadersSize(int) - Method in class org.eclipse.jetty.client.HttpClient
 
setMaxResponseHeadersSize(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxResponseHeadersSize(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets max response headers size.
setMaxResults(int) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setMaxRetries(int) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setMaxRetries(int) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setMaxSettingsKeys(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setMaxSettingsKeys(int) - Method in class org.eclipse.jetty.http2.parser.Parser
 
setMaxSettingsKeys(int) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setMaxSize(int) - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
setMaxTableCapacity(int) - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
Sets the limit for the capacity of the dynamic header table.
setMaxTableCapacity(int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
Sets the limit for the capacity of the dynamic header table.
setMaxTableCapacity(int) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
setMaxTableCapacity(int) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
setMaxTextMessageBufferSize(int) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
Maximum size of a whole TEXT message that this implementation can buffer.
setMaxTextMessageSize(long) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The maximum size of a text message during parsing/generating.
setMaxTextMessageSize(long) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setMaxTextMessageSize(long) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setMaxTextMessageSize(long) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setMaxTextMessageSize(long) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setMaxTextMessageSize(long) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setMaxTextMessageSize(long) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setMaxThreads(int) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setMaxThreads(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setMaxThreads(int) - Method in interface org.eclipse.jetty.util.thread.ThreadPool.SizedThreadPool
 
setMaxUnidirectionalRemoteStreams(int) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setMaxUsageCount(int) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
setMaxUsageCount(int) - Method in class org.eclipse.jetty.client.DuplexConnectionPool
 
setMaxUsageCount(int) - Method in class org.eclipse.jetty.client.MultiplexConnectionPool
 
setMaxUsageCount(int) - Method in class org.eclipse.jetty.util.Pool
Deprecated.
MaxUsage functionalities will be removed
setMBeanContainer(MBeanContainer) - Method in class org.eclipse.jetty.jmx.ObjectMBean
 
setMessage(String) - Method in class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
Sets the message for the Response.sendError(int, String) method.
setMessage(String) - Method in class org.eclipse.jetty.rewrite.handler.ValidUrlRule
Sets the message for the Response.sendError(int, String) method.
setMetaData(MetaData.Request) - Method in class org.eclipse.jetty.server.Request
 
setMetaDataDirty(boolean) - Method in class org.eclipse.jetty.server.session.SessionData
 
setMethod(String) - Method in class org.eclipse.jetty.http.HttpTester.Request
 
setMethod(String) - Method in class org.eclipse.jetty.security.ConstraintMapping
 
setMethod(String) - Method in class org.eclipse.jetty.server.Request
 
setMethodHandle(MethodHandle) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
setMethodOmissions(String[]) - Method in class org.eclipse.jetty.security.ConstraintMapping
 
setMimeMap(Map<String, String>) - Method in class org.eclipse.jetty.http.MimeTypes
 
setMimeTypes(MimeTypes) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setMimeTypes(MimeTypes) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setMinGzipSize(int) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the minimum response size to trigger dynamic compression.
setMinRequestDataRate(long) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setMinResponseDataRate(long) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets an minimum response content data rate.
setMinThreads(int) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setMinThreads(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setMinThreads(int) - Method in interface org.eclipse.jetty.util.thread.ThreadPool.SizedThreadPool
 
setMonitoredConnectors(Collection<Connector>) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMonitoredDirectories(Collection<String>) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setMonitoredDirName(String) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setMonitoredDirResource(Resource) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setMonitoredResources(List<Resource>) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setMonitorThreads(boolean) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMultipartConfig(MultipartConfigElement) - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
setMultiPartFormDataCompliance(MultiPartFormDataCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the compliance level for multipart/form-data handling.
setName(String) - Method in class org.eclipse.jetty.ant.types.Attribute
 
setName(String) - Method in class org.eclipse.jetty.client.HttpClient
Sets the name of this HttpClient.
setName(String) - Method in class org.eclipse.jetty.jaas.JAASLoginService
Set the name of the realm
setName(String) - Method in class org.eclipse.jetty.rewrite.handler.CookiePatternRule
Assigns the cookie name.
setName(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Sets the header name.
setName(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
Sets the header name.
setName(String) - Method in class org.eclipse.jetty.security.AbstractLoginService
Set the name.
setName(String) - Method in class org.eclipse.jetty.server.AbstractConnector
Set a connector name.
setName(String) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setName(String) - Method in class org.eclipse.jetty.servlet.Holder
The name is a primary key for the held object.
setName(String) - Method in class org.eclipse.jetty.util.security.Constraint
 
setName(String) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setName(String) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
Sets the name of this thread pool, used as a prefix for the thread names.
setName(String) - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
setNameParser(NameParser) - Method in class org.eclipse.jetty.jndi.NamingContext
 
setNamespace(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setNamespace(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setNeedClientAuth(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
setNegotiatedExtensions(List<ExtensionConfig>) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
setNetworkTrafficListener(NetworkTrafficListener) - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
setNewContextURL(String) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setNextDemand(LongConsumer) - Method in interface org.eclipse.jetty.websocket.core.internal.DemandChain
 
setNextDemand(LongConsumer) - Method in class org.eclipse.jetty.websocket.core.internal.DemandingFlusher
 
setNextDemand(LongConsumer) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentExtension
 
setNextDemand(LongConsumer) - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
setNextIncomingFrames(IncomingFrames) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
setNextIncomingFrames(IncomingFrames) - Method in interface org.eclipse.jetty.websocket.core.Extension
Set the next IncomingFrames to call in the chain.
setNextOutgoingFrames(OutgoingFrames) - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
setNextOutgoingFrames(OutgoingFrames) - Method in interface org.eclipse.jetty.websocket.core.Extension
Set the next OutgoingFrames to call in the chain.
setNodes(Set<Node>) - Method in class org.eclipse.jetty.deploy.graph.Graph
 
setNotifyExistingOnStart(boolean) - Method in class org.eclipse.jetty.util.PathWatcher
Whether or not to issue notifications for directories and files that already exist when the watcher starts.
setNotifyRemoteAsyncErrors(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setObject(Object) - Method in class org.eclipse.jetty.jaas.callback.ObjectCallback
 
setObjectName(String) - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
setOcspResponderURL(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
Set the location of the OCSP Responder.
setOcspResponderURL(String) - Method in class org.eclipse.jetty.util.security.CertificateValidator
Set the location of the OCSP Responder.
setOcspResponderURL(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the location of the OCSP Responder.
setOpCode(byte) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setOpenHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setOpenHandler(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setOrdering(Ordering) - Method in class org.eclipse.jetty.webapp.MetaData
 
setOrigin(String, Annotation, Class<?>) - Method in class org.eclipse.jetty.webapp.MetaData
 
setOrigin(String, Descriptor) - Method in class org.eclipse.jetty.webapp.MetaData
 
setOriginalPathAttribute(String) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
setOriginalPathAttribute(String) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
setOriginAPI(String) - Method in class org.eclipse.jetty.webapp.MetaData
 
setOriginAttribute(String) - Method in class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 
setOriginAttribute(String) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
setOutput(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
setOutputAggregationSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set the max size of the response content write that is copied into the aggregate buffer.
setOutputBufferSize(int) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the size of the buffer used for QUIC network writes.
setOutputBufferSize(int) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set the size of the buffer into which response content is aggregated before being sent to the client.
setOutputBufferSize(int) - Method in interface org.eclipse.jetty.websocket.api.WebSocketPolicy
The output (write to network layer) buffer size.
setOutputBufferSize(int) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setOutputBufferSize(int) - Method in interface org.eclipse.jetty.websocket.core.Configuration
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setOutputBufferSize(int) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
 
setOutputFilePrefix(String) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
setOutputStream(OutputStream) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
setOverflowDirectory(Path) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
setOverrideDescriptor(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
The override descriptor is a web.xml format file that is applied to the context after the standard WEB-INF/web.xml
setOverrideDescriptors(List<String>) - Method in class org.eclipse.jetty.webapp.WebAppContext
The override descriptor is a web.xml format file that is applied to the context after the standard WEB-INF/web.xml
setPackageAssertionStatus(String, boolean) - Method in class org.eclipse.jetty.ant.AntWebAppContext.AntURLClassLoader
 
setPageEncoding(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setParameter(String) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
setParameter(String) - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
setParameter(String) - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
setParameter(String, int) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
setParameter(String, int) - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
setParameter(String, int) - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
setParameter(String, String) - Method in interface org.eclipse.jetty.websocket.api.ExtensionConfig
 
setParameter(String, String) - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
setParameter(String, String) - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
setParameterName(String) - Method in class org.eclipse.jetty.jaas.callback.RequestParameterCallback
 
setParameterValues(List<?>) - Method in class org.eclipse.jetty.jaas.callback.RequestParameterCallback
 
setParent(HandlerContainer) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
setParentLoaderPriority(boolean) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Set the parentLoaderPriority.
setParentLoaderPriority(boolean) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
Set the parentLoaderPriority.
setParentLoaderPriority(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setPartitioned(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
Sets whether session cookies should have the Partitioned attribute.
setPassword(String) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
setPassword(String) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference
 
setPath(String) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setPathInfoOnly(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setPathInfoOnly(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setPathSpec(String) - Method in class org.eclipse.jetty.security.ConstraintMapping
 
setPathSpec(String) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setPathSpec(String) - Method in class org.eclipse.jetty.servlet.ServletMapping
 
setPathSpecs(String[]) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setPathSpecs(String[]) - Method in class org.eclipse.jetty.servlet.ServletMapping
 
setPattern(String) - Method in class org.eclipse.jetty.rewrite.handler.PatternRule
Sets the rule pattern.
setPauseUntil(long) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
setPayload(byte[]) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setPayload(String) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setPayload(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.Frame
Set the data payload.
setPemWorkDirectory(Path) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setPeriod(int) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setPermanent(boolean) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setPermissions(PermissionCollection) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setPersistent(boolean) - Method in class org.eclipse.jetty.http.HttpGenerator
 
setPersistentConnectionsEnabled(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setPersistTempDirectory(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
If true the temp directory for this webapp will be kept when the webapp stops.
setPingHandle(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setPkixCertPathChecker(PKIXCertPathChecker) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setPongHandle(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setPongHandle(MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setPort(int) - Method in class org.eclipse.jetty.ant.types.Connector
 
setPort(int) - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStoreFactory
 
setPort(int) - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
setPort(int) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setPrecompressedFormats(CompressedContentFormat[]) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setPrecompressedFormats(CompressedContentFormat[]) - Method in class org.eclipse.jetty.server.ResourceService
 
setPrefix(int) - Method in class org.eclipse.jetty.http.compression.NBitIntegerDecoder
Set the prefix length in of the integer representation in bits.
setPrefix(int) - Method in class org.eclipse.jetty.http.compression.NBitStringDecoder
Set the prefix length in of the string representation in bits.
setPrincipal(HttpPrincipal) - Method in interface org.eclipse.jetty.http.spi.JettyExchange
 
setPrincipal(HttpPrincipal) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
setPrincipal(HttpPrincipal) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
setPrincipal(HttpPrincipal) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
setPriorityFrame(PriorityFrame) - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
setProjectId(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
setProjectId(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStoreFactory
 
setProperties(Properties) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference
 
setProperty(String, String, String) - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
setProperty(String, String, String) - Method in class org.eclipse.jetty.start.Props
 
setProperty(String, String, String) - Method in class org.eclipse.jetty.start.StartArgs
 
setProperty(Dictionary<String, Object>, String, Object) - Static method in class org.eclipse.jetty.osgi.boot.utils.Util
 
setProperty(Props.Prop) - Method in class org.eclipse.jetty.start.Props
 
setProtectedTargets(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setProtocol(String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
setProtocol(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setProtocols(List<String>) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setProtocols(List<String>) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setProvider(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the optional Security Provider name.
setProxyAsAuthority(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setQueryEncoding(String) - Method in class org.eclipse.jetty.server.Request
Set the character encoding used for the query string.
setQueryManager(QueryManager) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
setQueryManager(QueryManager) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
setQueryParameters(MultiMap<String>) - Method in class org.eclipse.jetty.server.Request
 
setQuickStartWebXml(Resource) - Method in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
setRandom(Random) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
setRateControlFactory(RateControl.Factory) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
Sets the factory that creates a per-connection RateControl object.
setRawEndpoint(Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.ConfiguredEndpoint
 
setReader(Reader) - Method in class org.eclipse.jetty.util.ajax.JSON.ReaderSource
 
setReadListener(ReadListener) - Method in class org.eclipse.jetty.server.HttpInput
 
setRealmName(String) - Method in class org.eclipse.jetty.security.SecurityHandler
 
setReasons(String) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setReceiveBufferSize(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setRecordHttpComplianceViolations(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setRecurseDepth(int) - Method in class org.eclipse.jetty.util.PathWatcher.Config
Set the recurse depth for the directory scanning.
setRecycleHttpChannels(boolean) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
setRecycleHttpChannels(boolean) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
setRedirectPath(String) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
setRedirectWelcome(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setRedirectWelcome(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setRefreshCookieAge(int) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setRegex(String) - Method in class org.eclipse.jetty.rewrite.handler.RegexRule
Sets the regular expression string used to match with string URI.
setRegisteredDecoders(List<RegisteredDecoder>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
setRegistration(ServiceRegistration) - Method in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
setRelativeRedirectAllowed(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setRemoteAddr(InetSocketAddress) - Method in class org.eclipse.jetty.server.Request
 
setRemoteMaxDynamicTableSize(int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
Deprecated.
setRemoveIdleDestinations(boolean) - Method in class org.eclipse.jetty.client.HttpClient
Deprecated.
replaced by HttpClient.setDestinationIdleTimeout(long), calls the latter with a value of 10000 ms.
setRemoveUnloadableSessions(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
If a session's data cannot be loaded from the store without error, remove it from the persistent store.
setRemoveUnloadableSessions(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setRemoveUnloadableSessions(boolean) - Method in interface org.eclipse.jetty.server.session.SessionCache
If the data for a session exists but is unreadable, the SessionCache can instruct the SessionDataStore to delete it.
setRenameThread(boolean) - Method in class org.eclipse.jetty.server.DebugListener
 
setRenegotiationAllowed(boolean) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
setRenegotiationAllowed(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setRenegotiationLimit(int) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
setRenegotiationLimit(int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setRenewTGT(boolean) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setReplacement(String) - Method in class org.eclipse.jetty.rewrite.handler.RewritePatternRule
Whenever a match is found, it replaces with this value.
setReplacement(String) - Method in class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
Whenever a match is found, it replaces with this value.
setReportDirs(boolean) - Method in class org.eclipse.jetty.util.Scanner
Set if found directories should be reported.
setReportExistingFilesOnStartup(boolean) - Method in class org.eclipse.jetty.util.Scanner
Whether or not an initial scan will report all files as being added.
setRequest(ServletRequest) - Method in class org.eclipse.jetty.jaas.callback.ServletRequestCallback
 
setRequest(Request) - Method in class org.eclipse.jetty.jaas.callback.DefaultCallbackHandler
 
setRequestBufferSize(int) - Method in class org.eclipse.jetty.client.HttpClient
 
setRequestCharacterEncoding(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setRequestCharacterEncoding(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setRequestCookieCompliance(CookieCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setRequestedSessionId(String) - Method in class org.eclipse.jetty.server.Request
 
setRequestedSessionIdFromCookie(boolean) - Method in class org.eclipse.jetty.server.Request
 
setRequestHeaderSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the maximum allowed size in bytes for the HTTP request line and HTTP request headers.
setRequestLog(String) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setRequestLog(RequestLog) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setRequestLog(RequestLog) - Method in class org.eclipse.jetty.server.handler.RequestLogHandler
 
setRequestLog(RequestLog) - Method in class org.eclipse.jetty.server.HttpChannel
 
setRequestLog(RequestLog) - Method in class org.eclipse.jetty.server.Server
 
setRequestMessage(Object) - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
setRequireCloseMessage(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setRequireCloseMessage(boolean) - Method in class org.eclipse.jetty.io.ssl.SslConnection
Sets whether it is required that a peer send the TLS close_notify message to indicate the will to close the connection, otherwise it may be interpreted as a truncation attack.
setReseed(long) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Set the reseed probability.
setReservedThreads(int) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
Sets the number of reserved threads.
setReservedThreads(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setResident(boolean) - Method in class org.eclipse.jetty.server.session.Session
 
setResourceAlias(String, String) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set Resource Alias.
setResourceAliases(Map<String, String>) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setResourceBase(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the base resource for this context.
setResourceBase(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setResourceBase(String) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setResources(String) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
Sets the resources as string of comma-separated values.
setResources(List<Resource>) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
Sets the resource collection's resources.
setResources(Resource[]) - Method in class org.eclipse.jetty.util.resource.ResourceCollection
Sets the resource collection's resources.
setResponseBufferSize(int) - Method in class org.eclipse.jetty.client.HttpClient
 
setResponseCharacterEncoding(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setResponseCharacterEncoding(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setResponseCookieCompliance(CookieCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setResponseHeaderSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Larger headers will allow for more and/or larger cookies and longer HTTP headers (eg for redirection).
setResponseMessage(Object) - Method in class org.eclipse.jetty.security.jaspi.JaspiMessageInfo
 
setResponseStatus(int) - Method in class org.eclipse.jetty.http.HttpParser
 
setResult(boolean) - Method in class org.eclipse.jetty.security.jaspi.callback.CredentialValidationCallback
 
setRetainDays(int) - Method in class org.eclipse.jetty.server.RequestLogWriter
Set the number of days before rotated log files are deleted.
setReuseAddress(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
Sets whether it is allowed to bind a socket to a socket address that may be in use by another socket in tear-down state, for example in TIME_WAIT state.
setReuseAddress(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
 
setReuseAddress(boolean) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
setReusePort(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
Sets whether it is allowed to bind multiple sockets to the same socket address (same host and same port).
setReusePort(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
 
setRewritePathInfo(boolean) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
setRewritePathInfo(boolean) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
setRewriteRequestURI(boolean) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
 
setRewriteRequestURI(boolean) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
setRoleClassNames(String[]) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
setRoles(String[]) - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
setRoles(String[]) - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
setRoles(String[]) - Method in class org.eclipse.jetty.util.security.Constraint
 
setRoles(Set<String>) - Method in class org.eclipse.jetty.security.ConstraintSecurityHandler
Set the known roles.
setRoleTableKey(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setRoleTableName(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setRoleTableRoleField(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setRsv1(boolean) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setRsv2(boolean) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setRsv3(boolean) - Method in class org.eclipse.jetty.websocket.core.Frame
 
setRuleContainer(RuleContainer) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
Assigns the rules to process.
setRules(Rule[]) - Method in class org.eclipse.jetty.rewrite.handler.RewriteHandler
Assigns the rules to process.
setRules(Rule[]) - Method in class org.eclipse.jetty.rewrite.handler.RuleContainer
Assigns the rules to process.
setRun(boolean) - Method in class org.eclipse.jetty.start.StartArgs
 
setRunAs(Object) - Method in class org.eclipse.jetty.plus.annotation.RunAsCollection
Deprecated.
 
setRunAs(UserIdentity, RunAsToken) - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
setRunAs(UserIdentity, RunAsToken) - Method in interface org.eclipse.jetty.security.IdentityService
Associate a runas Token with the current user and thread.
setRunAs(ServletHolder) - Method in class org.eclipse.jetty.plus.annotation.RunAs
Deprecated.
 
setRunAsRole(String) - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
setRunAsRole(String) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
setSameSite(HttpCookie.SameSite) - Method in class org.eclipse.jetty.server.session.SessionHandler
Set Session cookie sameSite mode.
setSaveOnCreate(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
setSaveOnCreate(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setSaveOnCreate(boolean) - Method in interface org.eclipse.jetty.server.session.SessionCache
Whether or not a session that is newly created should be immediately saved.
setSaveOnInactiveEvict(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCacheFactory
 
setSaveOnInactiveEvict(boolean) - Method in class org.eclipse.jetty.server.session.NullSessionCacheFactory
 
setSaveOnInactiveEviction(boolean) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
setSaveOnInactiveEviction(boolean) - Method in interface org.eclipse.jetty.server.session.SessionCache
Whether or not a a session that is about to be evicted should be saved before being evicted.
setSavePeriodSec(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
The minimum time in seconds between save operations.
setSavePeriodSec(int) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStoreFactory
 
setScanDepth(int) - Method in class org.eclipse.jetty.util.Scanner
Set the scanDepth.
setScanDirs(List<File>) - Method in class org.eclipse.jetty.util.Scanner
 
setScanInterval(int) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setScanInterval(int) - Method in class org.eclipse.jetty.util.Scanner
Set the scan interval
setScanInterval(int) - Method in class org.eclipse.jetty.util.ssl.KeyStoreScanner
 
setScanIntervalSeconds(int) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setScanIntervalSecs(int) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setScheduler(Scheduler) - Method in class org.eclipse.jetty.client.HttpClient
 
setScheduler(Scheduler) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setScheduler(Scheduler) - Method in class org.eclipse.jetty.io.ClientConnector
 
setScheduler(Scheduler) - Method in class org.eclipse.jetty.proxy.ConnectHandler
 
setSchemaName(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setScheme(String) - Method in class org.eclipse.jetty.rewrite.handler.ForwardedSchemeHeaderRule
 
setScriptingInvalid(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setSecure(boolean) - Method in class org.eclipse.jetty.server.Request
 
setSecure(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler.CookieConfig
 
setSecurePort(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the TCP/IP port used for CONFIDENTIAL and INTEGRAL redirections.
setSecureRandomAlgorithm(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setSecureRequestOnly(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
HTTPS request.
setSecureScheme(String) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set the URI scheme used for CONFIDENTIAL and INTEGRAL redirections.
setSecurityHandler(SecurityHandler) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
setSelectors(int) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setSelectors(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSendBufferSize(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSendDateHeader(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
Indicates if the Date header should be sent in responses.
setSendServerVersion(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setSendShutdownAtStart(boolean) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
setSendTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketAsyncRemote
 
setSendXPoweredBy(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setSerialization(boolean) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
setSerialization(boolean) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
setSerializedAttributes(byte[]) - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
setServeIcon(boolean) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
setServer(Server) - Static method in class org.eclipse.jetty.http.spi.JettyHttpServerProvider
 
setServer(Server) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.AbstractHandler
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.AbstractHandlerContainer
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setServer(Server) - Method in interface org.eclipse.jetty.server.Handler
 
setServer(Server) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
setServer(Server) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setServerAuthority(HostPort) - Method in class org.eclipse.jetty.server.HttpConfiguration
Specify the connection server authority (name/port) used within application API layer when identifying the server host name/port of a connected endpoint.
setServerClassMatcher(ClassMatcher) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the server classes patterns.
setServerDefault(Server) - Static method in class org.eclipse.jetty.webapp.Configurations
Get/Set/Create the server default Configuration ClassList.
setServerInfo(String) - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
setServerInstanceWrapper(ServerInstanceWrapper) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
setServerName(String) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
setServiceName(String) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setServiceName(String) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
setServiceSubject(Subject) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticatorFactory
 
setServlet(Servlet) - Method in class org.eclipse.jetty.servlet.ServletHolder
 
setServletAttribute(String, Object) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeRequest
 
setServletAttribute(String, Object) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeRequest
 
setServletAttribute(String, Object) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeRequest
 
setServletHandler(ServletHandler) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
setServletHandler(ServletHandler) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
setServletMappings(ServletMapping[]) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setServletName(String) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setServletName(String) - Method in class org.eclipse.jetty.servlet.ServletMapping
 
setServletNames(String[]) - Method in class org.eclipse.jetty.servlet.FilterMapping
 
setServletPathMapping(ServletPathMapping) - Method in class org.eclipse.jetty.server.Request
Set the servletPathMapping, the servletPath and the pathInfo.
setServlets(ServletHolder[]) - Method in class org.eclipse.jetty.servlet.ServletHandler
Set Servlets.
setServletSecurity(ServletRegistration.Dynamic, ServletSecurityElement) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Delegate for ServletRegistration.Dynamic.setServletSecurity method
setServletSecurity(ServletRegistration.Dynamic, ServletSecurityElement) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setServletSecurity(ServletRegistration.Dynamic, ServletSecurityElement) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setServletSecurity(ServletSecurityElement) - Method in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
setSession(HttpSession) - Method in class org.eclipse.jetty.server.Request
 
setSessionCache(SessionCache) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setSessionCachingEnabled(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the flag to enable SSL Session caching.
setSessionCookie(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setSessionDataMapFactory(SessionDataMapFactory) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
setSessionDataStore(SessionDataStore) - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
setSessionDataStore(SessionDataStore) - Method in interface org.eclipse.jetty.server.session.SessionCache
A SessionDataStore that is the authoritative source of session information.
setSessionHandler(SessionHandler) - Method in class org.eclipse.jetty.server.Request
 
setSessionHandler(SessionHandler) - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
setSessionHouseKeeper(HouseKeeper) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
setSessionHouseKeeper(HouseKeeper) - Method in interface org.eclipse.jetty.server.SessionIdManager
 
setSessionIdManager(SessionIdManager) - Method in class org.eclipse.jetty.server.Server
 
setSessionIdManager(SessionIdManager) - Method in class org.eclipse.jetty.server.session.HouseKeeper
SessionIdManager associated with this scavenger
setSessionIdManager(SessionIdManager) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setSessionIdPathParameterName(String) - Method in class org.eclipse.jetty.server.session.SessionHandler
Sets the session id URL path parameter name.
setSessionMaxInactiveIntervalOnAuthentication(int) - Method in class org.eclipse.jetty.security.SecurityHandler
Set the interval in seconds, which if non-zero, will be set with HttpSession.setMaxInactiveInterval(int) when a session is newly authenticated.
setSessionRecvWindow(int) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setSessionRenewedOnAuthentication(boolean) - Method in class org.eclipse.jetty.security.SecurityHandler
Set renew the session on Authentication.
setSessionStoreFactory(SessionDataStoreFactory) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
setSessionTableSchema(JDBCSessionDataStore.SessionTableSchema) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
setSessionTableSchema(JDBCSessionDataStore.SessionTableSchema) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStoreFactory
 
setSessionTimeout(int) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setSessionTimeout(int) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setSessionTrackingModes(Set<SessionTrackingMode>) - Method in class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
setSessionTrackingModes(Set<SessionTrackingMode>) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setSessionTrackingModes(Set<SessionTrackingMode>) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.Context
 
setShowContexts(boolean) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
setShowHeaders(boolean) - Method in class org.eclipse.jetty.server.DebugListener
 
setShowMessageInTitle(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShowServlet(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShowStacks(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShutdownContainer(ContainerLifeCycle) - Static method in class org.eclipse.jetty.websocket.jakarta.client.internal.JakartaWebSocketClientContainer
 
setShutdownIdleTimeout(long) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setSingle(boolean) - Method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
setSinkClass(Class<? extends MessageSink>) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketMessageMetadata
 
setSkipFilesValidation(boolean) - Method in class org.eclipse.jetty.start.Module
 
setSniHostCheck(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setSNIProvider(SslContextFactory.Client.SniProvider) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Client
 
setSniRequired(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setSniRequired(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
Sets whether an SNI match is required when choosing the alias that identifies the certificate to send to the client.
setSNISelector(SniX509ExtendedKeyManager.SniSelector) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
Sets a custom function to select certificates based on SNI information.
setSocketAddressResolver(SocketAddressResolver) - Method in class org.eclipse.jetty.client.HttpClient
 
setSslContext(SSLContext) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setSslContextFactory(SslContextFactory.Client) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSslContextFactory(SslContextFactory.Server) - Method in class org.eclipse.jetty.jmx.ConnectorServer
 
setSslIsSecure(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setSslSessionAttribute(String) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setSslSessionCacheSize(int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set SSL session cache size.
setSslSessionTimeout(int) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set SSL session timeout.
setStartWithUnavailable(boolean) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
setState(HttpParser.FieldState) - Method in class org.eclipse.jetty.http.HttpParser
 
setState(HttpParser.State) - Method in class org.eclipse.jetty.http.HttpParser
 
setStatistic(AnnotationConfiguration.TimeStatistic) - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
setStatus(int) - Method in class org.eclipse.jetty.server.Response
 
setStatus(int) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
 
setStatus(int) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setStatus(int, String) - Method in class org.eclipse.jetty.server.Response
Deprecated.
setStatus(int, String) - Method in class org.eclipse.jetty.server.ServletResponseHttpWrapper
Deprecated.
setStatus(int, String) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
setStatusCode(int) - Method in class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
Sets the redirect status code.
setStatusCode(int) - Method in class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
Sets the redirect status code.
setStatusCode(int) - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
setStatusCode(int) - Method in class org.eclipse.jetty.websocket.server.internal.DelegatedServerUpgradeResponse
 
setStatusCode(int) - Method in interface org.eclipse.jetty.websocket.server.JettyServerUpgradeResponse
Set the HTTP Response status code
setStatusWithReason(int, String) - Method in class org.eclipse.jetty.server.Response
 
setStopAtShutdown(boolean) - Method in class org.eclipse.jetty.server.Server
Set stop server at shutdown behaviour.
setStopAtShutdown(boolean) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
Set JVM shutdown behavior.
setStopKey(String) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setStopKey(String) - Method in class org.eclipse.jetty.ant.JettyStopTask
 
setStopKey(String) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setStopPort(int) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setStopPort(int) - Method in class org.eclipse.jetty.ant.JettyStopTask
 
setStopPort(int) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setStopTimeout(long) - Method in class org.eclipse.jetty.server.Server
 
setStopTimeout(long) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setStopTimeout(long) - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
The timeout to allow all remaining open Sessions to be closed gracefully using the close code StatusCode.SHUTDOWN.
setStopWait(int) - Method in class org.eclipse.jetty.ant.JettyStopTask
 
setStoreDir(File) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
setStoreDir(File) - Method in class org.eclipse.jetty.server.session.FileSessionDataStoreFactory
 
setStream(PrintStream) - Method in class org.eclipse.jetty.logging.StdErrAppender
 
setStream(PrintStream) - Static method in class org.eclipse.jetty.start.StartLog
 
setStream(Stream) - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
setStream(IStream) - Method in class org.eclipse.jetty.http2.server.HttpTransportOverHTTP2
 
setStreamId(int) - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
setStreamIdleTimeout(long) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setStreamIdleTimeout(long) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setStreamIdleTimeout(long) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
Sets the HTTP/2 stream idle timeout.
setStreamIdleTimeout(long) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets the stream idle timeout in milliseconds.
setStreams(InputStream, OutputStream) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
setStreams(InputStream, OutputStream) - Method in class org.eclipse.jetty.http.spi.JettyHttpExchangeDelegate
 
setStreams(InputStream, OutputStream) - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
setStrictEventOrdering(boolean) - Method in class org.eclipse.jetty.client.HttpClient
Whether request/response events must be strictly ordered with respect to connection usage.
setStringBufferSize(int) - Method in class org.eclipse.jetty.util.ajax.JSON
 
setStringType(String) - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
setStsIncludeSubDomains(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setStsMaxAge(long) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Set the Strict-Transport-Security max age.
setStsMaxAge(long, TimeUnit) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
setStylesheet(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setSubject(Subject) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule
 
setSubprotocol(String) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
setSubProtocols(String...) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set the offered WebSocket Sub-Protocol list.
setSubProtocols(String...) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
setSubProtocols(List<String>) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
Set the offered WebSocket Sub-Protocol list.
setSubProtocols(List<String>) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
setSuccess(boolean) - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
setSuccess(boolean) - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
setSyncFlush(boolean) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the Deflater flush mode to use.
setSysPropertyName(String) - Method in class org.eclipse.jetty.osgi.boot.utils.ServerConnectorListener
 
setSystemClassMatcher(ClassMatcher) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the system classes patterns.
setSystemProperty(String, String) - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
setSystemProperty(String, String) - Method in class org.eclipse.jetty.start.Props
 
setTableCapacity(int) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
Sets the capacity of the dynamic header table.
setTableCapacity(int) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
Set the capacity of the DynamicTable and send a instruction to set the capacity on the remote Decoder.
setTableName(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setTaglibLocation(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
setTaglibURI(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
setTask(Task) - Static method in class org.eclipse.jetty.ant.utils.TaskLog
 
setTCPNoDelay(boolean) - Method in class org.eclipse.jetty.client.HttpClient
setTCPNoDelay(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
 
setTempDir(File) - Method in class org.eclipse.jetty.deploy.providers.WebAppProvider
Set the Work directory where unpacked WAR files are managed from.
setTempDir(Path) - Method in class org.eclipse.jetty.server.handler.FileBufferedResponseHandler
 
setTempDirectory(File) - Method in class org.eclipse.jetty.ant.JettyRunTask
 
setTempDirectory(File) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setTempDirectory(File) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set temporary directory for context.
setter() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedAttribute
If is a field references a setter that doesn't conform to standards for discovery it can be set here.
Setter(String, Method) - Constructor for class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
setTerminating(boolean) - Method in class org.eclipse.jetty.rewrite.handler.Rule
Sets terminating to true or false.
setTerminating(boolean) - Method in class org.eclipse.jetty.rewrite.handler.TerminatingPatternRule
 
setTerminating(boolean) - Method in class org.eclipse.jetty.rewrite.handler.TerminatingRegexRule
 
setTextHandler(Class<? extends MessageSink>, MethodHandle, Object) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandlerMetadata
 
setTextMetadata(JakartaWebSocketMessageMetadata, Object) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setThreadLimit(int) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
setThreadPoolBudget(ThreadPoolBudget) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setThreadsPriority(int) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setThreadsPriority(int) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setThrowUnavailableOnStartupException(boolean) - Method in class org.eclipse.jetty.webapp.WebAppContext
 
setTicketCachePath(Path) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setTimeout(long) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
setTimeout(long) - Method in class org.eclipse.jetty.server.AsyncContextState
 
setTimeout(long) - Method in class org.eclipse.jetty.server.HttpChannelState
 
setTimeout(long) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageInputStream
 
setTimeout(long, TimeUnit) - Method in class org.eclipse.jetty.websocket.client.ClientUpgradeRequest
 
setTimeoutTask(Scheduler.Task) - Method in class org.eclipse.jetty.server.AsyncContextEvent
 
setTimeStamp(long) - Method in class org.eclipse.jetty.server.Request
 
setTimeZone(String) - Method in class org.eclipse.jetty.server.RequestLogWriter
 
settings(SettingsFrame, Callback) - Method in interface org.eclipse.jetty.http2.api.Session
Sends the given SETTINGS frame to configure the session.
settings(SettingsFrame, Callback) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
SETTINGS - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
SETTINGS - Enum constant in enum org.eclipse.jetty.http3.frames.FrameType
 
SETTINGS_TIMEOUT_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that a SETTINGS frame did not receive a reply in a timely manner.
SettingsBodyParser - Class in org.eclipse.jetty.http2.parser
 
SettingsBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
SettingsBodyParser(HeaderParser, Parser.Listener, int) - Constructor for class org.eclipse.jetty.http2.parser.SettingsBodyParser
 
SettingsFrame - Class in org.eclipse.jetty.http2.frames
 
SettingsFrame - Class in org.eclipse.jetty.http3.frames
 
SettingsFrame(Map<Integer, Integer>, boolean) - Constructor for class org.eclipse.jetty.http2.frames.SettingsFrame
 
SettingsFrame(Map<Long, Long>) - Constructor for class org.eclipse.jetty.http3.frames.SettingsFrame
 
SettingsGenerator - Class in org.eclipse.jetty.http2.generator
 
SettingsGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.SettingsGenerator
 
setTldBundles(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider
 
setTrailerFields(Supplier<Map<String, String>>) - Method in class org.eclipse.jetty.server.Response
 
setTrailerHttpFields(HttpFields) - Method in class org.eclipse.jetty.server.Request
 
setTrailers(Supplier<HttpFields>) - Method in class org.eclipse.jetty.server.Response
 
setTrimDirectiveWhitespaces(String) - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
setTrustAll(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setTrustManagerFactoryAlgorithm(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setTrustStore(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setTrustStore(KeyStore) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the trust store.
setTrustStorePassword(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setTrustStorePassword(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setTrustStorePath(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setTrustStoreProvider(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setTrustStoreProvider(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setTrustStoreResource(Resource) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
Set the trust store resource.
setTrustStoreType(String) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setTrustStoreType(String) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setUndecoratable(Set<String>) - Method in class org.eclipse.jetty.cdi.CdiSpiDecorator
 
setUnidirectionalStreamRecvWindow(int) - Method in class org.eclipse.jetty.quic.common.QuicConfiguration
 
setUnixSocket(String) - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
setUnwrapServletException(boolean) - Method in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
setUpdateQuietTime(long, TimeUnit) - Method in class org.eclipse.jetty.util.PathWatcher
Set the quiet time.
setUpgradeRequest(UpgradeRequest) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
setUpgradeResponse(UpgradeResponse) - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
setURI(String) - Method in class org.eclipse.jetty.http.HttpTester.Request
 
setUriCompliance(UriCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setUriTemplatePathSpec(UriTemplatePathSpec) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerMetadata
 
setUseALPN(boolean) - Method in class org.eclipse.jetty.http2.client.http.HttpClientTransportOverHTTP2
 
setUseALPN(boolean) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setUseCipherSuitesOrder(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setUseDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.client.util.PathContentProvider
Deprecated.
 
setUseDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.client.util.PathRequestContent
 
setUseDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.client.HttpClient
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets whether to use direct buffers for QUIC network reads.
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnection
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.client.HttpClient
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnection
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.fcgi.server.ServerFCGIConnectionFactory
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.client.HTTP2Client
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.HTTP2Connection
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.http3.HTTP3Configuration
Sets whether to use direct buffers for QUIC network writes.
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnection
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
setUser(String) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference.PasswordAuthenticator
 
setUser(String) - Method in class org.eclipse.jetty.jndi.factories.MailSessionReference
 
setUserAgentField(HttpField) - Method in class org.eclipse.jetty.client.HttpClient
 
setUserDataConstraint(UserDataConstraint) - Method in class org.eclipse.jetty.security.RoleInfo
 
setUseRealPaths(boolean) - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
setUserIdentityScope(UserIdentity.Scope) - Method in class org.eclipse.jetty.server.Request
 
setUserKeyTabPath(Path) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setUserName(String) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setUserName(String) - Method in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
setUserPassword(String) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setUserPrincipal(Principal) - Method in interface org.eclipse.jetty.security.authentication.LoginCallback
 
setUserPrincipal(Principal) - Method in class org.eclipse.jetty.security.authentication.LoginCallbackImpl
 
setUserRoleLink(String, String) - Method in class org.eclipse.jetty.servlet.ServletHolder
Link a user role.
setUserRoleTableName(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserRoleTableRoleKey(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserRoleTableUserKey(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserStore(UserStore) - Method in class org.eclipse.jetty.security.HashLoginService
Configure the UserStore implementation to use.
setUserTableKey(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserTableName(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserTablePasswordField(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUserTableUserField(String) - Method in class org.eclipse.jetty.plus.security.DataSourceLoginService
 
setUseStandardBindings(boolean) - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
setUseTicketCache(boolean) - Method in class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
setUseVirtualThreads(boolean) - Method in interface org.eclipse.jetty.util.VirtualThreads.Configurable
Deprecated, for removal: This API element is subject to removal in a future version.
setUsingCookies(boolean) - Method in class org.eclipse.jetty.server.session.SessionHandler
 
setUsingSecurityManager(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setValidateCerts(boolean) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
setValidateCerts(boolean) - Method in class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
setValidateCerts(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setValidateEncoding(boolean) - Method in class org.eclipse.jetty.http2.hpack.HpackEncoder
 
setValidateHpackEncoding(boolean) - Method in class org.eclipse.jetty.http2.generator.Generator
Deprecated.
setValidatePeerCerts(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
setValidateXml(boolean) - Method in class org.eclipse.jetty.webapp.MetaData
 
setValidating(boolean) - Method in class org.eclipse.jetty.xml.XmlParser
 
setValue(String) - Method in class org.eclipse.jetty.ant.types.Attribute
 
setValue(String) - Method in class org.eclipse.jetty.rewrite.handler.CookiePatternRule
Assigns the cookie value.
setValue(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Sets the header value.
setValue(String) - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
Sets the header value.
setVary(HttpField) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
setVersion(Object) - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
setVersion(String) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
setVersion(HttpVersion) - Method in class org.eclipse.jetty.http.HttpTester.Message
 
setVhost(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
setVhost(String) - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.ExpiryInfo
 
setVhost(String) - Method in class org.eclipse.jetty.server.session.SessionData
 
setVirtualHostColumn(String) - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
setVirtualHosts(String[]) - Method in class org.eclipse.jetty.rewrite.handler.VirtualHostRuleContainer
Set the virtual hosts that the rules within this container will apply to
setVirtualHosts(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the virtual hosts for the context.
setVirtualHosts(String[]) - Method in class org.eclipse.jetty.servlet.ServletTester
 
setVirtualThreadsExecutor(Executor) - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
setVirtualThreadsExecutor(Executor) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
setVirtualThreadsExecutor(Executor) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
setVirtualThreadsExecutor(Executor) - Method in interface org.eclipse.jetty.util.VirtualThreads.Configurable
 
setWantClientAuth(boolean) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
setWar(String) - Method in class org.eclipse.jetty.ant.AntWebAppContext
 
setWar(String) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the war of the webapp.
setWarResource(Resource) - Method in class org.eclipse.jetty.webapp.WebAppContext
Set the war of the webapp as a Resource.
setWebAppBaseDir(File) - Method in class org.eclipse.jetty.ant.AntWebXmlConfiguration
 
setWebAppContext(WebAppContext) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
setWebApplications(List<AntWebAppContext>) - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
setWebAppPath(String) - Method in class org.eclipse.jetty.osgi.boot.AbstractWebAppProvider.OSGiApp
 
setWebDescriptor(WebDescriptor) - Method in class org.eclipse.jetty.webapp.MetaData
 
setWebInfClassesResources(List<Resource>) - Method in class org.eclipse.jetty.webapp.MetaData
 
setWebSocketConnection(WebSocketConnection) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setWeights(int[]) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
setWelcomeFactory(ResourceService.WelcomeFactory) - Method in class org.eclipse.jetty.server.ResourceService
 
setWelcomeFiles(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setWelcomeFiles(String[]) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setWorkerName(String) - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
Set the workername.
setWriteFilesWithFilenames(boolean) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
 
setWriteFilesWithFilenames(boolean) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
setWriteListener(WriteListener) - Method in class org.eclipse.jetty.server.HttpOutput
 
setWriteThreshold(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
setWriteTimeout(long) - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketRemoteEndpoint
 
setWriteTimeout(Duration) - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
setWriteTimeout(Duration) - Method in interface org.eclipse.jetty.websocket.core.Configuration
Set the Write Timeout.
setWriteTimeout(Duration) - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
setXpath(String) - Method in class org.eclipse.jetty.xml.XmlParser
Set an XPath A very simple subset of xpath is supported to select a partial tree.
shallowCopy(Hashtable<String, Object>) - Method in class org.eclipse.jetty.jndi.NamingContext
 
SharedBlockingCallback - Class in org.eclipse.jetty.util
Provides a reusable Callback that can block the thread while waiting to be completed.
SharedBlockingCallback() - Constructor for class org.eclipse.jetty.util.SharedBlockingCallback
 
SharedBlockingCallback.Blocker - Class in org.eclipse.jetty.util
A Closeable Callback.
shellQuoteIfNeeded(String) - Static method in class org.eclipse.jetty.start.CommandLineBuilder
This method applies single quotes suitable for a POSIX compliant shell if necessary.
ShortDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to Short decoder
ShortDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.ShortDecoder
 
ShortEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for Short to Encoder.Text Message encoder
ShortEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.ShortEncoder
 
shouldBuffer(HttpChannel, boolean) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
shouldHuffmanEncode(HttpField) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
shouldIndex(HttpField) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
 
showModules(PrintStream, List<String>) - Method in class org.eclipse.jetty.start.Modules
 
showModules(PrintStream, StartArgs) - Method in class org.eclipse.jetty.start.Main
 
shutdown() - Method in class org.eclipse.jetty.fcgi.generator.Flusher
 
shutdown() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
shutdown() - Method in interface org.eclipse.jetty.http2.ISession
Gracefully closes the session, returning a CompletableFuture that is completed when all the streams currently being processed are completed.
shutdown() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
shutdown() - Method in class org.eclipse.jetty.http3.client.HTTP3Client
 
shutdown() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
shutdown() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
shutdown() - Method in class org.eclipse.jetty.quic.common.QuicSessionContainer
 
shutdown() - Method in class org.eclipse.jetty.quic.server.QuicServerConnector
 
shutdown() - Method in class org.eclipse.jetty.server.AbstractConnector
 
shutdown() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
shutdown() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set shutdown status.
shutdown() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
shutdown() - Method in class org.eclipse.jetty.server.session.DefaultSessionCache
 
shutdown() - Method in class org.eclipse.jetty.server.session.NullSessionCache
 
shutdown() - Method in interface org.eclipse.jetty.server.session.SessionCache
 
shutdown() - Method in interface org.eclipse.jetty.util.component.Graceful
Shutdown the component.
shutdown() - Method in class org.eclipse.jetty.util.component.Graceful.Shutdown
 
shutdown() - Method in class org.eclipse.jetty.websocket.common.SessionTracker
 
shutdown() - Method in class org.eclipse.jetty.websocket.jakarta.common.SessionTracker
 
shutdown(Container) - Static method in interface org.eclipse.jetty.util.component.Graceful
Utility method to shutdown all Gracefuls within a container.
shutdown(Graceful.ThrowingRunnable) - Static method in interface org.eclipse.jetty.util.component.Graceful
Utility method to execute a Graceful.ThrowingRunnable in a new daemon thread and be notified of the result in a CompletableFuture.
Shutdown(Object) - Constructor for class org.eclipse.jetty.util.component.Graceful.Shutdown
 
SHUTDOWN - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
 
SHUTDOWN - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1001 indicates that an endpoint is "going away", such as a server going down or a browser having navigated away from a page.
SHUTDOWN - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
SHUTDOWN_OUT - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.Result
 
ShutdownHandler - Class in org.eclipse.jetty.server.handler
A handler that shuts the server down on a valid request.
ShutdownHandler(String) - Constructor for class org.eclipse.jetty.server.handler.ShutdownHandler
Creates a listener that lets the server be shut down remotely (but only from localhost).
ShutdownHandler(String, boolean, boolean) - Constructor for class org.eclipse.jetty.server.handler.ShutdownHandler
 
shutdownInput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
shutdownInput(long) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
shutdownInput(long, long) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
ShutdownMonitor - Class in org.eclipse.jetty.server
Shutdown/Stop Monitor thread.
shutdownOutput() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
shutdownOutput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
shutdownOutput() - Method in interface org.eclipse.jetty.io.EndPoint
Shutdown the output.
shutdownOutput() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
shutdownOutput(long) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
shutdownOutput(long, long) - Method in class org.eclipse.jetty.quic.common.QuicSession
 
shutdownSessions() - Method in class org.eclipse.jetty.server.session.SessionHandler
Prepare sessions for session manager shutdown
ShutdownThread - Class in org.eclipse.jetty.util.thread
ShutdownThread is a shutdown hook thread implemented as singleton that maintains a list of lifecycle instances that are registered with it and provides ability to stop these lifecycles upon shutdown of the Java Virtual Machine
signal() - Method in class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
signalAll() - Method in class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
SimpleAuthConfig - Class in org.eclipse.jetty.security.jaspi
Deprecated.
SimpleAuthConfig(String, ServerAuthContext) - Constructor for class org.eclipse.jetty.security.jaspi.SimpleAuthConfig
Deprecated.
 
SimpleFlowControlStrategy - Class in org.eclipse.jetty.http2
 
SimpleFlowControlStrategy() - Constructor for class org.eclipse.jetty.http2.SimpleFlowControlStrategy
 
SimpleFlowControlStrategy(int) - Constructor for class org.eclipse.jetty.http2.SimpleFlowControlStrategy
 
since(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the nanoseconds elapsed since a begin nanoTime and the current nanoTime.
Sink() - Constructor for class org.eclipse.jetty.proxy.AfterContentTransformer.Sink
 
size() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
size() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
size() - Method in interface org.eclipse.jetty.http.HttpFields
 
size() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
size() - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
size() - Method in class org.eclipse.jetty.http.QuotedCSV
 
size() - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
size() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
size() - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
size() - Method in class org.eclipse.jetty.io.ManagedSelector
 
size() - Method in class org.eclipse.jetty.server.handler.InetAccessSet
 
size() - Method in class org.eclipse.jetty.start.Props
 
size() - Method in class org.eclipse.jetty.start.RawArgs
 
size() - Method in class org.eclipse.jetty.util.AttributesMap
 
size() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
size() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
size() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
size() - Method in interface org.eclipse.jetty.util.Index
Get the number of entries in the index.
size() - Method in class org.eclipse.jetty.util.InetAddressSet
 
size() - Method in exception class org.eclipse.jetty.util.MultiException
 
size() - Method in class org.eclipse.jetty.util.Pool
 
size() - Method in class org.eclipse.jetty.util.RegexSet
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
size() - Method in class org.eclipse.jetty.webapp.ClassMatcher
 
size() - Method in class org.eclipse.jetty.webapp.Configurations
 
size() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
size() - Method in class org.eclipse.jetty.xml.XmlParser.Node
Get the number of children nodes.
size(Object) - Static method in class org.eclipse.jetty.util.LazyList
The size of a lazy List
skip(int) - Method in class org.eclipse.jetty.server.HttpInput.Content
Skip some bytes from the buffer.
skip(int) - Method in class org.eclipse.jetty.server.HttpInput.SpecialContent
 
skip(long) - Method in class org.eclipse.jetty.session.infinispan.BoundDelegatingInputStream
 
SLASH - Static variable in class org.eclipse.jetty.util.URIUtil
 
Slf4jRequestLogWriter - Class in org.eclipse.jetty.server
Request log writer using a Slf4jLog Logger
Slf4jRequestLogWriter() - Constructor for class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
Snapshot() - Constructor for class org.eclipse.jetty.start.fileinits.MavenMetadata.Snapshot
 
SNI_HOST - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
sniSelect(String, Principal[], SSLSession, String, Collection<X509>) - Method in interface org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager.SniSelector
Selects a certificate based on SNI information.
sniSelect(String, Principal[], SSLSession, String, Collection<X509>) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory.Server
 
SniX509ExtendedKeyManager - Class in org.eclipse.jetty.util.ssl
A X509ExtendedKeyManager that selects a key with an alias retrieved from SNI information, delegating other processing to a nested X509ExtendedKeyManager.
SniX509ExtendedKeyManager(X509ExtendedKeyManager, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.util.ssl.SniX509ExtendedKeyManager
 
SniX509ExtendedKeyManager.SniSelector - Interface in org.eclipse.jetty.util.ssl
Selects a certificate based on SNI information.
SocketAddressResolver - Interface in org.eclipse.jetty.util
Creates SocketAddress instances, returning them through a Promise.
SocketAddressResolver.Async - Class in org.eclipse.jetty.util
Creates InetSocketAddress instances asynchronously in a different thread.
SocketAddressResolver.Sync - Class in org.eclipse.jetty.util
Creates InetSocketAddress instances synchronously in the caller thread.
SocketChannelEndPoint - Class in org.eclipse.jetty.io
An EndPoint implementation based on SocketChannel.
SocketChannelEndPoint(SocketChannel, ManagedSelector, SelectionKey, Scheduler) - Constructor for class org.eclipse.jetty.io.SocketChannelEndPoint
 
SocketCustomizationListener - Class in org.eclipse.jetty.server
A Connection Lister for customization of SocketConnections.
SocketCustomizationListener() - Constructor for class org.eclipse.jetty.server.SocketCustomizationListener
Construct with SSL unwrapping on.
SocketCustomizationListener(boolean) - Constructor for class org.eclipse.jetty.server.SocketCustomizationListener
 
Socks4Proxy - Class in org.eclipse.jetty.client
 
Socks4Proxy(String, int) - Constructor for class org.eclipse.jetty.client.Socks4Proxy
 
Socks4Proxy(Origin.Address, boolean) - Constructor for class org.eclipse.jetty.client.Socks4Proxy
 
Socks4Proxy.Socks4ProxyClientConnectionFactory - Class in org.eclipse.jetty.client
 
Socks4ProxyClientConnectionFactory(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.client.Socks4Proxy.Socks4ProxyClientConnectionFactory
 
Socks5 - Class in org.eclipse.jetty.client
Helper class for SOCKS5 proxying.
Socks5.Authentication - Interface in org.eclipse.jetty.client
A SOCKS5 authentication method.
Socks5.Authentication.Factory - Interface in org.eclipse.jetty.client
A factory for Socks5.Authentications.
Socks5.NoAuthenticationFactory - Class in org.eclipse.jetty.client
The implementation of the NO AUTH authentication method defined in RFC 1928.
Socks5.UsernamePasswordAuthenticationFactory - Class in org.eclipse.jetty.client
The implementation of the USERNAME/PASSWORD authentication method defined in RFC 1929.
Socks5Proxy - Class in org.eclipse.jetty.client
Client-side proxy configuration for SOCKS5, defined by RFC 1928.
Socks5Proxy(String, int) - Constructor for class org.eclipse.jetty.client.Socks5Proxy
 
Socks5Proxy(Origin.Address, boolean) - Constructor for class org.eclipse.jetty.client.Socks5Proxy
 
softClose() - Method in class org.eclipse.jetty.server.HttpOutput
 
someToContent(HttpExchange, ByteBuffer) - Method in class org.eclipse.jetty.client.HttpSender
 
someToSuccess(HttpExchange) - Method in class org.eclipse.jetty.client.HttpSender
 
sort() - Method in class org.eclipse.jetty.http.QuotedQualityCSV
 
sort() - Method in class org.eclipse.jetty.webapp.Configurations
 
sort(Collection<T>) - Method in class org.eclipse.jetty.util.TopologicalSort
Sort the passed list according to dependencies previously set with TopologicalSort.addDependency(Object, Object[]).
sort(List<Configuration>) - Static method in class org.eclipse.jetty.webapp.Configurations
 
sort(T[]) - Method in class org.eclipse.jetty.util.TopologicalSort
Sort the passed array according to dependencies previously set with TopologicalSort.addDependency(Object, Object[]).
source - Variable in class org.eclipse.jetty.start.Props.Prop
 
Source - Class in org.eclipse.jetty.servlet
Source The source of a web artifact: servlet, filter, mapping etc
Source(Source.Origin, String) - Constructor for class org.eclipse.jetty.servlet.Source
 
Source.Origin - Enum in org.eclipse.jetty.servlet
 
space(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Get the space from the limit to the capacity
SPACE - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
SPACE_IN_VALUES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Allow spaces within values without quotes.
SPACE1 - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
SPACE2 - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
spareCapacity() - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
SPEC_VERSION - Static variable in class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
SPEC_VERSION - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
 
SPEC_VERSION_STRING - Static variable in class org.eclipse.jetty.websocket.core.WebSocketConstants
 
SPECIAL_CHARS_IN_QUOTES - Enum constant in enum org.eclipse.jetty.http.CookieCompliance.Violation
Special characters were found in a quoted cookie value.
SpecialContent() - Constructor for class org.eclipse.jetty.server.HttpInput.SpecialContent
 
spinWait(long) - Static method in class org.eclipse.jetty.util.NanoTime
Spin waits for the specified number of nanoseconds.
SPNEGOAuthentication - Class in org.eclipse.jetty.client.util
Implementation of the SPNEGO (or "Negotiate") authentication defined in RFC 4559.
SPNEGOAuthentication(URI) - Constructor for class org.eclipse.jetty.client.util.SPNEGOAuthentication
 
SPNEGOAuthentication.SPNEGOResult - Class in org.eclipse.jetty.client.util
 
SPNEGOResult(URI, String) - Constructor for class org.eclipse.jetty.client.util.SPNEGOAuthentication.SPNEGOResult
 
SPNEGOResult(URI, HttpHeader, String) - Constructor for class org.eclipse.jetty.client.util.SPNEGOAuthentication.SPNEGOResult
 
SpnegoUserIdentity - Class in org.eclipse.jetty.security
 
SpnegoUserIdentity(Subject, Principal, UserIdentity) - Constructor for class org.eclipse.jetty.security.SpnegoUserIdentity
 
SpnegoUserPrincipal - Class in org.eclipse.jetty.security
 
SpnegoUserPrincipal(String, byte[]) - Constructor for class org.eclipse.jetty.security.SpnegoUserPrincipal
 
SpnegoUserPrincipal(String, String) - Constructor for class org.eclipse.jetty.security.SpnegoUserPrincipal
 
SSL_ENGINE_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
SslClientCertAuthenticator - Class in org.eclipse.jetty.security.authentication
CLIENT-CERT authenticator.
SslClientCertAuthenticator(SslContextFactory) - Constructor for class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
SslClientConnectionFactory - Class in org.eclipse.jetty.io.ssl
A ClientConnectionFactory that creates client-side SslConnection instances.
SslClientConnectionFactory(SslContextFactory, ByteBufferPool, Executor, ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
SslClientConnectionFactory.SslEngineFactory - Interface in org.eclipse.jetty.io.ssl
A factory for SSLEngine objects.
SslConnection - Class in org.eclipse.jetty.io.ssl
A Connection that acts as an interceptor between an EndPoint providing SSL encrypted data and another consumer of an EndPoint (typically an Connection like HttpConnection) that wants unencrypted data.
SslConnection(ByteBufferPool, Executor, EndPoint, SSLEngine) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
 
SslConnection(ByteBufferPool, Executor, EndPoint, SSLEngine, boolean, boolean) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
 
SslConnection(RetainableByteBufferPool, ByteBufferPool, Executor, EndPoint, SSLEngine, boolean, boolean) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
 
SslConnection.DecryptedEndPoint - Class in org.eclipse.jetty.io.ssl
 
SslConnectionFactory - Class in org.eclipse.jetty.server
 
SslConnectionFactory() - Constructor for class org.eclipse.jetty.server.SslConnectionFactory
 
SslConnectionFactory(String) - Constructor for class org.eclipse.jetty.server.SslConnectionFactory
 
SslConnectionFactory(SslContextFactory.Server, String) - Constructor for class org.eclipse.jetty.server.SslConnectionFactory
 
SslContextFactory - Class in org.eclipse.jetty.util.ssl
SslContextFactory is used to configure SSL parameters to be used by server and client connectors.
SslContextFactory() - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory
Construct an instance of SslContextFactory with the default configuration.
SslContextFactory(boolean) - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory
Construct an instance of SslContextFactory that trusts all certificates
SslContextFactory.Client - Class in org.eclipse.jetty.util.ssl
 
SslContextFactory.Client.SniProvider - Interface in org.eclipse.jetty.util.ssl
A provider for SNI names to send to the server during the TLS handshake.
SslContextFactory.Server - Class in org.eclipse.jetty.util.ssl
 
SslContextFactory.X509ExtendedKeyManagerWrapper - Class in org.eclipse.jetty.util.ssl
A wrapper that delegates to another (if not null) X509ExtendedKeyManager.
SslContextFactory.X509ExtendedTrustManagerWrapper - Class in org.eclipse.jetty.util.ssl
A wrapper that delegates to another (if not null) X509ExtendedTrustManager.
SslHandshakeListener - Interface in org.eclipse.jetty.io.ssl
Implementations of this interface are notified of TLS handshake events.
SslHandshakeListener.Event - Class in org.eclipse.jetty.io.ssl
The event object carrying information about TLS handshake events.
STABLE - Static variable in class org.eclipse.jetty.util.Jetty
 
StacklessLogging - Class in org.eclipse.jetty.logging
A try-with-resources compatible layer for hiding stacktraces within the scope of the try block when logging with JettyLogger implementation.
StacklessLogging(Class<?>...) - Constructor for class org.eclipse.jetty.logging.StacklessLogging
 
StacklessLogging(Package...) - Constructor for class org.eclipse.jetty.logging.StacklessLogging
 
StacklessLogging(Logger...) - Constructor for class org.eclipse.jetty.logging.StacklessLogging
 
stale() - Method in class org.eclipse.jetty.client.HttpDestination
 
STANDARD_PROCESSOR - Static variable in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
StandardDeployer - Class in org.eclipse.jetty.deploy.bindings
 
StandardDeployer() - Constructor for class org.eclipse.jetty.deploy.bindings.StandardDeployer
 
StandardDescriptorProcessor - Class in org.eclipse.jetty.webapp
StandardDescriptorProcessor.
StandardDescriptorProcessor() - Constructor for class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
StandardStarter - Class in org.eclipse.jetty.deploy.bindings
 
StandardStarter() - Constructor for class org.eclipse.jetty.deploy.bindings.StandardStarter
 
StandardStopper - Class in org.eclipse.jetty.deploy.bindings
 
StandardStopper() - Constructor for class org.eclipse.jetty.deploy.bindings.StandardStopper
 
StandardUndeployer - Class in org.eclipse.jetty.deploy.bindings
 
StandardUndeployer() - Constructor for class org.eclipse.jetty.deploy.bindings.StandardUndeployer
 
standardUpgrade() - Method in class org.eclipse.jetty.http2.parser.ServerParser
The standard HTTP/1.1 upgrade path.
standardUpgrade() - Method in class org.eclipse.jetty.http2.server.HTTP2ServerSession
 
start() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
start() - Method in class org.eclipse.jetty.ant.ServerProxyImpl
 
start() - Method in interface org.eclipse.jetty.ant.utils.ServerProxy
Starts this server.
start() - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
start() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
start() - Method in class org.eclipse.jetty.start.Main
 
start() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
start() - Method in interface org.eclipse.jetty.util.component.LifeCycle
Starts the component.
start(Object) - Static method in interface org.eclipse.jetty.util.component.LifeCycle
Utility to start an object if it is a LifeCycle and to convert any exception thrown to a RuntimeException
start(Runnable) - Method in class org.eclipse.jetty.server.AsyncContextState
 
start(Server, Dictionary<String, Object>) - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
start(StartArgs) - Method in class org.eclipse.jetty.start.Main
 
start(LifeCycle) - Method in class org.eclipse.jetty.server.Server
 
start(LifeCycle) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
start(LifeCycle) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Starts the given lifecycle.
start(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
 
start(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.quickstart.ExtraXmlDescriptorProcessor
 
start(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
 
start(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
start(WebAppContext, Descriptor) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
start(BundleContext) - Method in class org.eclipse.jetty.osgi.boot.JettyBootstrapActivator
Setup a new jetty Server, registers it as a service.
START - Enum constant in enum org.eclipse.jetty.http.HttpGenerator.State
 
START - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
StartArgs - Class in org.eclipse.jetty.start
The Arguments required to start Jetty.
StartArgs(BaseHome) - Constructor for class org.eclipse.jetty.start.StartArgs
 
startAsync() - Method in class org.eclipse.jetty.server.Request
 
startAsync() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
startAsync(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.server.Request
 
startAsync(ServletRequest, ServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
startAsync(AsyncContextEvent) - Method in class org.eclipse.jetty.server.HttpChannelState
 
startContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Extensible startContext.
startContext() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
Finish constructing handlers and link them together.
startContext() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
StartDirBuilder - Class in org.eclipse.jetty.start.builders
Management of the ${jetty.base}/start.d/ based configuration.
StartDirBuilder(BaseBuilder) - Constructor for class org.eclipse.jetty.start.builders.StartDirBuilder
 
STARTED - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
STARTED - Static variable in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
startHandling(Request, boolean) - Method in class org.eclipse.jetty.server.handler.AsyncDelayHandler
Called to indicate that a request has been presented for handling
STARTING - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
 
STARTING - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
STARTING - Static variable in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
StartIni - Class in org.eclipse.jetty.start
Simple Start .INI handler
StartIni(Path) - Constructor for class org.eclipse.jetty.start.StartIni
 
StartIniBuilder - Class in org.eclipse.jetty.start.builders
Management of the ${jetty.base}/start.ini based configuration.
StartIniBuilder(BaseBuilder) - Constructor for class org.eclipse.jetty.start.builders.StartIniBuilder
 
startJettyAtJettyHome(BundleContext) - Static method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.DefaultJettyAtJettyHomeHelper
Called by the JettyBootStrapActivator.
StartLog - Class in org.eclipse.jetty.start
Centralized Place for logging.
StartLog() - Constructor for class org.eclipse.jetty.start.StartLog
 
startPart() - Method in interface org.eclipse.jetty.server.MultiPartParser.Handler
 
startPart(String) - Method in class org.eclipse.jetty.util.MultiPartOutputStream
Start creation of the next Content.
startPart(String) - Method in class org.eclipse.jetty.util.MultiPartWriter
Start creation of the next Content.
startPart(String, String[]) - Method in class org.eclipse.jetty.util.MultiPartOutputStream
Start creation of the next Content.
startPart(String, String[]) - Method in class org.eclipse.jetty.util.MultiPartWriter
Start creation of the next Content.
startRequest(String, String, HttpVersion) - Method in interface org.eclipse.jetty.http.HttpParser.RequestHandler
This is the method called by parser when the HTTP request line is parsed
startRequest(String, String, HttpVersion) - Method in class org.eclipse.jetty.http.HttpTester.Request
 
startRequest(String, String, HttpVersion) - Method in class org.eclipse.jetty.server.HttpChannelOverHttp
 
startResponse(HttpVersion, int, String) - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
startResponse(HttpVersion, int, String) - Method in interface org.eclipse.jetty.http.HttpParser.ResponseHandler
This is the method called by parser when the HTTP request line is parsed
startResponse(HttpVersion, int, String) - Method in class org.eclipse.jetty.http.HttpTester.Response
 
startScanning() - Method in class org.eclipse.jetty.util.Scanner
Start scanning.
startScavenging() - Method in class org.eclipse.jetty.server.session.HouseKeeper
If scavenging is not scheduled, schedule it.
startsWith(byte[], int, int, int) - Method in class org.eclipse.jetty.util.SearchPattern
Search for a possibly partial match of the pattern at the start of the data.
startsWith(String) - Method in class org.eclipse.jetty.start.RawArgs.Entry
 
startsWithIgnoreCase(String, String) - Static method in class org.eclipse.jetty.util.StringUtil
 
startThread() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
StateLifeCycleListener - Class in org.eclipse.jetty.server
A LifeCycle Listener that writes state changes to a file.
StateLifeCycleListener(String) - Constructor for class org.eclipse.jetty.server.StateLifeCycleListener
 
STATIC_SIZE - Static variable in class org.eclipse.jetty.http2.hpack.HpackContext
 
STATIC_TABLE - Static variable in class org.eclipse.jetty.http2.hpack.HpackContext
 
StaticContext() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler.StaticContext
 
StaticException - Exception Class in org.eclipse.jetty.util
This exception can safely be stored in a static variable as suppressed exceptions are disabled, meaning calling Throwable.addSuppressed(Throwable) has no effect.
StaticException(String) - Constructor for exception class org.eclipse.jetty.util.StaticException
Create an instance with writable stack trace and suppression disabled.
StaticException(String, boolean) - Constructor for exception class org.eclipse.jetty.util.StaticException
Create an instance with suppression disabled.
staticIndex(HttpHeader) - Static method in class org.eclipse.jetty.http2.hpack.HpackContext
 
StaticTableHttpField - Class in org.eclipse.jetty.http2.hpack
 
StaticTableHttpField(String, String, Object) - Constructor for class org.eclipse.jetty.http2.hpack.StaticTableHttpField
 
StaticTableHttpField(HttpHeader, String, Object) - Constructor for class org.eclipse.jetty.http2.hpack.StaticTableHttpField
 
StaticTableHttpField(HttpHeader, String, String, Object) - Constructor for class org.eclipse.jetty.http2.hpack.StaticTableHttpField
 
StatisticsHandler - Class in org.eclipse.jetty.server.handler
 
StatisticsHandler() - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler
 
StatisticsServlet - Class in org.eclipse.jetty.servlet
Collect and report statistics about requests / responses / connections and more.
StatisticsServlet() - Constructor for class org.eclipse.jetty.servlet.StatisticsServlet
 
Stats(String) - Constructor for class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
statsReset() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
Resets the current request statistics.
statsReset() - Method in class org.eclipse.jetty.server.session.SessionHandler
Reset statistics values
status(int) - Method in class org.eclipse.jetty.client.HttpResponse
 
STATUS - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
StatusCode - Class in org.eclipse.jetty.websocket.api
StatusCode() - Constructor for class org.eclipse.jetty.websocket.api.StatusCode
 
STD_ERR - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.StreamType
 
STD_IN - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.StreamType
 
STD_OUT - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.StreamType
 
STDERR - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
StdErrAppender - Class in org.eclipse.jetty.logging
 
StdErrAppender(JettyLoggerConfiguration) - Constructor for class org.eclipse.jetty.logging.StdErrAppender
 
StdErrAppender(JettyLoggerConfiguration, PrintStream) - Constructor for class org.eclipse.jetty.logging.StdErrAppender
 
StdErrAppender(JettyLoggerConfiguration, PrintStream, TimeZone) - Constructor for class org.eclipse.jetty.logging.StdErrAppender
 
STDIN - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
STDOUT - Enum constant in enum org.eclipse.jetty.fcgi.FCGI.FrameType
 
stop() - Method in class org.eclipse.jetty.osgi.boot.internal.serverfactory.ServerInstanceWrapper
 
stop() - Method in class org.eclipse.jetty.osgi.boot.utils.internal.PackageAdminServiceTracker
 
stop() - Method in class org.eclipse.jetty.start.Main
 
stop() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
stop() - Method in interface org.eclipse.jetty.util.component.LifeCycle
Stops the component.
stop(int) - Method in class org.eclipse.jetty.http.spi.JettyHttpServer
 
stop(WebSocketContainer) - Static method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketClientContainerProvider
 
stop(Object) - Static method in interface org.eclipse.jetty.util.component.LifeCycle
Utility to stop an object if it is a LifeCycle and to convert any exception thrown to a RuntimeException
stop(String, int, String) - Method in class org.eclipse.jetty.start.Main
Stop a running jetty instance.
stop(String, int, String, int) - Method in class org.eclipse.jetty.start.Main
 
stop(LifeCycle) - Method in class org.eclipse.jetty.servlet.ServletHandler
 
stop(LifeCycle) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Stops the given lifecycle.
stop(BundleContext) - Method in class org.eclipse.jetty.osgi.boot.JettyBootstrapActivator
Stop the activator.
stopContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
stopContext() - Method in class org.eclipse.jetty.servlet.ServletContextHandler
 
stopContext() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
StopException() - Constructor for exception class org.eclipse.jetty.util.component.AbstractLifeCycle.StopException
 
StopLifeCycle - Class in org.eclipse.jetty.util.component
A LifeCycle that when started will stop another LifeCycle
StopLifeCycle(LifeCycle) - Constructor for class org.eclipse.jetty.util.component.StopLifeCycle
 
STOPPED - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
 
STOPPED - Static variable in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
STOPPING - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
STOPPING - Static variable in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
stopScavenging() - Method in class org.eclipse.jetty.server.session.HouseKeeper
If scavenging is scheduled, stop it.
store(OutputStream, String) - Method in class org.eclipse.jetty.start.Props
 
store(String, SessionData) - Method in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
store(String, SessionData) - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
store(String, SessionData) - Method in class org.eclipse.jetty.server.session.CachingSessionDataStore
 
store(String, SessionData) - Method in interface org.eclipse.jetty.server.session.SessionDataMap
Store the session data.
storeCookie(URI, HttpField) - Method in class org.eclipse.jetty.client.HttpReceiver
 
storeFragment(ByteBuffer, int, boolean) - Method in class org.eclipse.jetty.http2.parser.HeaderBlockFragments
 
stream - Variable in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
stream() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
stream() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
stream() - Method in interface org.eclipse.jetty.http.HttpFields
 
stream() - Method in class org.eclipse.jetty.start.Modules
 
stream() - Method in class org.eclipse.jetty.start.TextFile
 
stream() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
 
stream() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.AvailableDecoders
 
Stream - Interface in org.eclipse.jetty.http2.api
A Stream represents a bidirectional exchange of data on top of a Session.
Stream - Interface in org.eclipse.jetty.http3.api
A Stream represents a bidirectional exchange of data within a Session.
Stream(CoreSession, MethodHandle, List<RegisteredDecoder>) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink.Stream
 
STREAM - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Protocol
 
STREAM - Enum constant in enum org.eclipse.jetty.server.Response.OutputType
 
STREAM_CLOSED_ERROR - Enum constant in enum org.eclipse.jetty.http2.ErrorCode
Indicates that a stream frame has been received after the stream was closed.
STREAM_FAILURE - Static variable in class org.eclipse.jetty.http2.parser.HeaderBlockParser
 
Stream.Client - Interface in org.eclipse.jetty.http3.api
The client side version of Stream.
Stream.Client.Listener - Interface in org.eclipse.jetty.http3.api
A Stream.Client.Listener is the passive counterpart of a Stream.Client and receives client-side events happening on an HTTP/3 stream.
Stream.Data - Class in org.eclipse.jetty.http3.api
A Stream.Data instance associates a ByteBuffer containing request bytes or response bytes with a completion event that applications must trigger when the bytes have been processed.
Stream.Listener - Interface in org.eclipse.jetty.http2.api
A Stream.Listener is the passive counterpart of a Stream and receives events happening on an HTTP/2 stream.
Stream.Listener.Adapter - Class in org.eclipse.jetty.http2.api
Empty implementation of Stream.Listener
Stream.Server - Interface in org.eclipse.jetty.http3.api
The server side version of Stream.
Stream.Server.Listener - Interface in org.eclipse.jetty.http3.api
A Stream.Server.Listener is the passive counterpart of a Stream.Server and receives server-side events happening on an HTTP/3 stream.
streamCancellation(long) - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
Tells the QpackDecoder that a particular stream has been cancelled.
streamCancellation(long) - Method in class org.eclipse.jetty.http3.qpack.QpackEncoder
Tells the QpackEncoder that a particular stream has been cancelled.
StreamContentParser - Class in org.eclipse.jetty.fcgi.parser
A stream content parser parses frame bodies of type STDIN, STDOUT and STDERR.
StreamContentParser(HeaderParser, FCGI.StreamType, Parser.Listener) - Constructor for class org.eclipse.jetty.fcgi.parser.StreamContentParser
 
streamException(String, Object...) - Method in class org.eclipse.jetty.http2.hpack.MetaDataBuilder
 
StreamException(long, String) - Constructor for exception class org.eclipse.jetty.http3.qpack.QpackException.StreamException
 
StreamException(long, String, Throwable) - Constructor for exception class org.eclipse.jetty.http3.qpack.QpackException.StreamException
 
StreamException(String, Object...) - Constructor for exception class org.eclipse.jetty.http2.hpack.HpackException.StreamException
 
streamFailure(int, int, String) - Method in class org.eclipse.jetty.http2.parser.BodyParser
 
StreamFrame - Class in org.eclipse.jetty.http2.frames
 
StreamFrame(FrameType, int) - Constructor for class org.eclipse.jetty.http2.frames.StreamFrame
 
StreamReader(HttpServletRequest, HttpServletResponse, Request, AsyncRequestContent) - Constructor for class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamReader
 
StreamType - Enum in org.eclipse.jetty.quic.common
The QUIC stream type, either client or server initiated, and either unidirectional or bidirectional.
StreamWriter(HttpServletRequest, Response) - Constructor for class org.eclipse.jetty.proxy.AsyncProxyServlet.StreamWriter
 
STRICT - Enum constant in enum org.eclipse.jetty.http.HttpCookie.SameSite
 
STRICT - Static variable in class org.eclipse.jetty.http.UriCompliance
Deprecated.
equivalent to RFC3986
STRICT_TRANSPORT_SECURITY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
StringContentProvider - Class in org.eclipse.jetty.client.util
Deprecated.
StringContentProvider(String) - Constructor for class org.eclipse.jetty.client.util.StringContentProvider
Deprecated.
 
StringContentProvider(String, String) - Constructor for class org.eclipse.jetty.client.util.StringContentProvider
Deprecated.
 
StringContentProvider(String, String, Charset) - Constructor for class org.eclipse.jetty.client.util.StringContentProvider
Deprecated.
 
StringContentProvider(String, Charset) - Constructor for class org.eclipse.jetty.client.util.StringContentProvider
Deprecated.
 
StringDecoder - Class in org.eclipse.jetty.websocket.jakarta.common.decoders
Default implementation of the Decoder.Text Message to String decoder
StringDecoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.decoders.StringDecoder
 
StringEncoder - Class in org.eclipse.jetty.websocket.jakarta.common.encoders
Default encoder for String to Encoder.Text Message encoder
StringEncoder() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.encoders.StringEncoder
 
stringEquals(String, String) - Static method in class org.eclipse.jetty.util.security.Credential
Utility method that replaces String.equals() to avoid timing attacks.
stringFrom(String, int) - Static method in class org.eclipse.jetty.util.StringUtil
Generate a string from another string repeated n times.
StringMessageSink - Class in org.eclipse.jetty.websocket.core.internal.messages
 
StringMessageSink(CoreSession, MethodHandle) - Constructor for class org.eclipse.jetty.websocket.core.internal.messages.StringMessageSink
 
StringRequestContent - Class in org.eclipse.jetty.client.util
A Request.Content for strings.
StringRequestContent(String) - Constructor for class org.eclipse.jetty.client.util.StringRequestContent
 
StringRequestContent(String, String) - Constructor for class org.eclipse.jetty.client.util.StringRequestContent
 
StringRequestContent(String, String, Charset) - Constructor for class org.eclipse.jetty.client.util.StringRequestContent
 
StringRequestContent(String, Charset) - Constructor for class org.eclipse.jetty.client.util.StringRequestContent
 
Strings() - Constructor for class org.eclipse.jetty.start.NaturalSort.Strings
 
StringSource(String) - Constructor for class org.eclipse.jetty.util.ajax.JSON.StringSource
 
StringUtil - Class in org.eclipse.jetty.util
Fast String Utilities.
StringUtil() - Constructor for class org.eclipse.jetty.util.StringUtil
 
strip(String, String) - Static method in class org.eclipse.jetty.util.StringUtil
 
stripParameters(String) - Static method in class org.eclipse.jetty.http.HttpField
Get field value without parameters.
stripProtocol(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
stripProtocol(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
stripSuffixes(String) - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
strToLevel(String) - Static method in enum org.eclipse.jetty.logging.JettyLevel
 
submit(ManagedSelector.SelectorUpdate) - Method in class org.eclipse.jetty.io.ManagedSelector
Submit an ManagedSelector.SelectorUpdate to be acted on between calls to Selector.select()
subscribe(Request.Content.Consumer, boolean) - Method in interface org.eclipse.jetty.client.api.Request.Content
Initializes this content producer with the content consumer, and with the indication of whether initial content, if present, must be emitted upon the initial demand of content (to support delaying the send of the request content in case of Expect: 100-Continue when emitInitialContent is false).
subscribe(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
subscribe(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.AbstractRequestContent
 
subscribe(Request.Content.Consumer, boolean) - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
succeeded() - Method in class org.eclipse.jetty.client.HttpDestination
 
succeeded() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
succeeded() - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
succeeded() - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
succeeded() - Method in class org.eclipse.jetty.fcgi.generator.Generator.Result
 
succeeded() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
succeeded() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
succeeded() - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.ProxyResponseListener
 
succeeded() - Method in class org.eclipse.jetty.server.HttpInput.WrappingContent
 
succeeded() - Method in class org.eclipse.jetty.util.Callback.Completable
 
succeeded() - Method in class org.eclipse.jetty.util.Callback.Completing
 
succeeded() - Method in class org.eclipse.jetty.util.Callback.Nested
 
succeeded() - Method in interface org.eclipse.jetty.util.Callback
Callback invoked when the operation completes.
succeeded() - Method in class org.eclipse.jetty.util.CountingCallback
 
succeeded() - Method in class org.eclipse.jetty.util.FutureCallback
 
succeeded() - Method in class org.eclipse.jetty.util.IteratingCallback
Method to invoke when the asynchronous sub-task succeeds.
succeeded() - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
 
succeeded() - Method in class org.eclipse.jetty.websocket.jakarta.common.SendHandlerCallback
 
succeeded(C) - Method in class org.eclipse.jetty.util.FuturePromise
 
succeeded(C) - Method in interface org.eclipse.jetty.util.Promise
Callback invoked when the operation completes.
succeeded(S) - Method in class org.eclipse.jetty.util.Promise.Completable
 
succeeded(W) - Method in class org.eclipse.jetty.util.Promise.Wrapper
 
SUCCEEDED - Enum constant in enum org.eclipse.jetty.util.IteratingCallback.Action
Indicates that IteratingCallback.process() has completed the whole iteration successfully.
SUCCEEDED - Static variable in class org.eclipse.jetty.util.FutureCallback
 
SUFFIX_GLOB - Enum constant in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
For path specs that have a wildcard glob with a hardcoded suffix
sumOverflows(int, int) - Static method in class org.eclipse.jetty.util.MathUtils
Returns whether the sum of the arguments overflows an int.
supporting(Class<? extends Encoder>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
supportsPostConstruct(Class) - Method in class org.eclipse.jetty.annotations.PostConstructAnnotationHandler
Check if the given class is permitted to have PostConstruct annotation.
supportsPreDestroy(Class) - Method in class org.eclipse.jetty.annotations.PreDestroyAnnotationHandler
Check if the spec permits the given class to use the PreDestroy annotation.
supportsResourceInjection(Class<?>) - Method in class org.eclipse.jetty.annotations.ResourceAnnotationHandler
Check if the given Class is one that the specification allows to have a Resource annotation.
suspend() - Method in interface org.eclipse.jetty.websocket.api.Session
Suspend the delivery of incoming WebSocket frames.
suspend() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
suspend() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
SuspendToken - Interface in org.eclipse.jetty.websocket.api
Connection suspend token
sweep() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
sweep() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
sweep() - Method in class org.eclipse.jetty.client.HttpDestination
 
sweep() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
sweep() - Method in interface org.eclipse.jetty.util.thread.Sweeper.Sweepable
 
sweepDisk(long) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Check all session files for any context and remove any that expired at or before the time limit.
Sweeper - Class in org.eclipse.jetty.util.thread
A utility class to perform periodic sweeping of resources.
Sweeper(Scheduler, long) - Constructor for class org.eclipse.jetty.util.thread.Sweeper
 
Sweeper.Sweepable - Interface in org.eclipse.jetty.util.thread
A Sweeper.Sweepable resource implements this interface to signal to a Sweeper or to a parent container if it needs to be swept or not.
sweepFile(long, Path) - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
Delete file (from any context) that expired at or before the given time
SWITCHING_PROTOCOLS - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
SWITCHING_PROTOCOLS_101 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
SymlinkAllowedResourceAliasChecker - Class in org.eclipse.jetty.server
An extension of AllowedResourceAliasChecker which will allow symlinks alias to arbitrary targets, so long as the symlink file itself is an allowed resource.
SymlinkAllowedResourceAliasChecker(ContextHandler) - Constructor for class org.eclipse.jetty.server.SymlinkAllowedResourceAliasChecker
 
SymlinkAllowedResourceAliasChecker(ContextHandler, Resource) - Constructor for class org.eclipse.jetty.server.SymlinkAllowedResourceAliasChecker
 
Sync() - Constructor for class org.eclipse.jetty.util.SocketAddressResolver.Sync
 
Synchronizable - Interface in org.eclipse.jetty.client
Implementations of this interface expose a lock object via Synchronizable.getLock() so that callers can synchronize externally on that lock:
Syntax - Class in org.eclipse.jetty.http
Collection of Syntax validation methods.
Syntax() - Constructor for class org.eclipse.jetty.http.Syntax
 
SYS_PROP_TLD_BUNDLES - Static variable in class org.eclipse.jetty.osgi.boot.OSGiMetaInfConfiguration
Comma separated list of symbolic names of bundles that contain tlds that should be considered as on the container classpath
SystemProperties - Class in org.eclipse.jetty.ant.types
SystemProperties
SystemProperties() - Constructor for class org.eclipse.jetty.ant.types.SystemProperties
 

T

tag(Object) - Method in interface org.eclipse.jetty.client.api.Request
Tags this request with the given metadata tag.
tag(Object) - Method in class org.eclipse.jetty.client.HttpRequest
 
tag(String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
tag(String, String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
tag(String, Map<String, String>) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
tag(String, Map<String, String>, String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
Tag() - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
Creates a Tag whose metadata will be derived from the underlying EndPoint.
Tag() - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
Creates a Tag whose metadata will be derived from the underlying EndPoint.
Tag(String, int) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
Creates a Tag with the given source metadata.
Tag(String, int) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
Creates a Tag with the given source metadata.
Tag(String, int, List<ProxyProtocolClientConnectionFactory.V2.Tag.TLV>) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
Creates a Tag with the given source metadata and Type-Length-Value (TLV) objects.
Tag(String, String, int, String, int) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
Creates a Tag with the given metadata.
Tag(ProxyProtocolClientConnectionFactory.V2.Tag.Command, ProxyProtocolClientConnectionFactory.V2.Tag.Family, ProxyProtocolClientConnectionFactory.V2.Tag.Protocol, String, int, String, int, List<ProxyProtocolClientConnectionFactory.V2.Tag.TLV>) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag
Creates a Tag with the given metadata.
tagCDATA(String, String) - Method in class org.eclipse.jetty.xml.XmlAppendable
 
tagEquals(String, String) - Static method in class org.eclipse.jetty.http.CompressedContentFormat
Check etags for equality, accounting for quoting and compression suffixes.
Tagged() - Constructor for class org.eclipse.jetty.io.MappedByteBufferPool.Tagged
 
TagLib() - Constructor for class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
take() - Method in class org.eclipse.jetty.util.BlockingArrayQueue
 
takeByteArray() - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
takeByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Take the combined buffer containing all content written to the accumulator.
takeByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Take the combined buffer containing all content written to the OutputStream.
takeDirtyAttributes() - Method in class org.eclipse.jetty.nosql.NoSqlSessionDataStore.NoSqlSessionData
 
takeHttpParser() - Method in class org.eclipse.jetty.http.HttpTester.Input
 
takeInt(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to an integer.
takeNewContext() - Method in class org.eclipse.jetty.server.Request
 
takeOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takeOutputString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takeOutputString(Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takePartialString() - Method in class org.eclipse.jetty.util.Utf8Appendable
Take the partial string an reset in internal buffer, but retain partial code points.
TaskLog - Class in org.eclipse.jetty.ant.utils
Provides logging functionality for classes without access to the Ant project variable.
TaskLog() - Constructor for class org.eclipse.jetty.ant.utils.TaskLog
 
TCHAR - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
TE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
TE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
TEMPDIR - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
TEMPDIR_CONFIGURED - Static variable in class org.eclipse.jetty.webapp.WebInfConfiguration
 
TEMPORARY_REDIRECT - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
TEMPORARY_REDIRECT_307 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
TEMPORARY_RESOURCE_BASE - Static variable in class org.eclipse.jetty.webapp.WebInfConfiguration
 
TERMINATED - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
terminateRequest() - Method in class org.eclipse.jetty.client.HttpExchange
 
terminateResponse() - Method in class org.eclipse.jetty.client.HttpExchange
 
TerminatingPatternRule - Class in org.eclipse.jetty.rewrite.handler
If this rule matches, terminate the processing of other rules.
TerminatingPatternRule() - Constructor for class org.eclipse.jetty.rewrite.handler.TerminatingPatternRule
 
TerminatingPatternRule(String) - Constructor for class org.eclipse.jetty.rewrite.handler.TerminatingPatternRule
 
TerminatingRegexRule - Class in org.eclipse.jetty.rewrite.handler
If this rule matches, terminate the processing of other rules.
TerminatingRegexRule() - Constructor for class org.eclipse.jetty.rewrite.handler.TerminatingRegexRule
 
TerminatingRegexRule(String) - Constructor for class org.eclipse.jetty.rewrite.handler.TerminatingRegexRule
 
test(Class<?>) - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.AvailableEncoders
 
test(String) - Method in class org.eclipse.jetty.http.pathmap.PathSpecSet
 
test(String) - Method in class org.eclipse.jetty.util.RegexSet
 
test(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByClass
 
test(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackage
 
test(String) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByPackageOrName
 
test(InetAddress) - Method in class org.eclipse.jetty.util.InetAddressSet
 
test(URI) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocation
 
test(URI) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByLocationOrModule
 
test(URI) - Method in class org.eclipse.jetty.webapp.ClassMatcher.ByModule
 
test(Path) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
test(Path) - Method in class org.eclipse.jetty.util.PathWatcher.PathMatcherSet
 
test(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
test(InetAccessSet.AccessTuple) - Method in class org.eclipse.jetty.server.handler.InetAccessSet.PatternTuple
 
test(InetAccessSet.AccessTuple) - Method in class org.eclipse.jetty.server.handler.InetAccessSet
 
test(P) - Method in class org.eclipse.jetty.util.IncludeExcludeSet
Test includes and excludes for match.
TestFileInitializer - Class in org.eclipse.jetty.start.fileinits
In a start testing scenario, it is often not important to actually download or initialize a file, this implementation is merely a no-op for the FileInitializer
TestFileInitializer(BaseHome) - Constructor for class org.eclipse.jetty.start.fileinits.TestFileInitializer
 
TEXT - Enum constant in enum org.eclipse.jetty.websocket.api.Frame.Type
 
TEXT - Static variable in class org.eclipse.jetty.websocket.core.OpCode
OpCode for a Text Frame
TEXT_HTML - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_HTML_8859_1 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_HTML_UTF_8 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_JSON - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_JSON_8859_1 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_JSON_UTF_8 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_PLAIN - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_PLAIN_8859_1 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_PLAIN_UTF_8 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_XML - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_XML_8859_1 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TEXT_XML_UTF_8 - Enum constant in enum org.eclipse.jetty.http.MimeTypes.Type
 
TextFile - Class in org.eclipse.jetty.start
Simple common abstraction for Text files, that consist of a series of lines.
TextFile(Path) - Constructor for class org.eclipse.jetty.start.TextFile
 
TextUtils - Class in org.eclipse.jetty.websocket.core.internal.util
Collection of utility methods for Text content
TextUtils() - Constructor for class org.eclipse.jetty.websocket.core.internal.util.TextUtils
 
THREAD_ID - Enum constant in enum org.eclipse.jetty.util.Pool.StrategyType
A strategy that uses the Thread.getId() of the current thread to select a starting point for an entry search.
ThreadClassLoaderScope - Class in org.eclipse.jetty.util.thread
 
ThreadClassLoaderScope(ClassLoader) - Constructor for class org.eclipse.jetty.util.thread.ThreadClassLoaderScope
 
ThreadLimitHandler - Class in org.eclipse.jetty.server.handler
Handler to limit the threads per IP address for DOS protection
ThreadLimitHandler() - Constructor for class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
ThreadLimitHandler(String) - Constructor for class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
ThreadLimitHandler(String, boolean) - Constructor for class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
ThreadPool - Interface in org.eclipse.jetty.util.thread
A pool for threads.
ThreadPool.SizedThreadPool - Interface in org.eclipse.jetty.util.thread
Specialized sub-interface of ThreadPool that allows to get/set the minimum and maximum number of threads of the pool.
ThreadPoolBudget - Class in org.eclipse.jetty.util.thread
A budget of required thread usage, used to warn or error for insufficient configured threads.
ThreadPoolBudget(ThreadPool.SizedThreadPool) - Constructor for class org.eclipse.jetty.util.thread.ThreadPoolBudget
Construct a budget for a SizedThreadPool.
ThreadPoolBudget.Lease - Interface in org.eclipse.jetty.util.thread
 
ThreadPoolBudget.Leased - Class in org.eclipse.jetty.util.thread
An allocation of threads
throwIfError() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream
Throws an exception if one has been latched.
throwIfError() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
Throws an exception if one has been latched.
tick() - Method in class org.eclipse.jetty.util.DateCache
Deprecated.
Tick(long, String, String) - Constructor for class org.eclipse.jetty.util.DateCache.Tick
 
timeout() - Method in class org.eclipse.jetty.server.HttpChannelState
 
timeout(long, TimeUnit) - Method in interface org.eclipse.jetty.client.api.Request
 
timeout(long, TimeUnit) - Method in class org.eclipse.jetty.client.HttpRequest
 
TimeoutCompleteListener - Class in org.eclipse.jetty.client
Deprecated.
Do not use it, use CyclicTimeouts instead.
TimeoutCompleteListener(Scheduler) - Constructor for class org.eclipse.jetty.client.TimeoutCompleteListener
Deprecated.
 
timeoutExpired() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
TimerScheduler - Class in org.eclipse.jetty.util.thread
A scheduler based on the the JVM Timer class
TimerScheduler() - Constructor for class org.eclipse.jetty.util.thread.TimerScheduler
 
TimerScheduler(String, boolean) - Constructor for class org.eclipse.jetty.util.thread.TimerScheduler
 
TimeStatistic() - Constructor for class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
TldBundleDiscoverer - Interface in org.eclipse.jetty.osgi.boot.utils
TldBundleDiscoverer Convert bundles that contain tlds into URL locations for consumption by jasper.
TLS_VERSION - Static variable in class org.eclipse.jetty.server.ProxyConnectionFactory
 
TLV(int, byte[]) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.TLV
 
to416HeaderRangeString(long) - Static method in class org.eclipse.jetty.server.InclusiveByteRange
 
toArray() - Method in class org.eclipse.jetty.webapp.Configurations
 
toArray(Object, Class<?>) - Static method in class org.eclipse.jetty.util.LazyList
Convert a lazylist to an array
toArray(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert a ByteBuffer to a byte array.
toBuffer() - Method in enum org.eclipse.jetty.http.HttpHeader
 
toBuffer() - Method in enum org.eclipse.jetty.http.HttpHeaderValue
 
toBuffer() - Method in enum org.eclipse.jetty.http.HttpVersion
 
toBuffer(byte[]) - Static method in class org.eclipse.jetty.util.BufferUtil
Create a new ByteBuffer using provided byte array.
toBuffer(byte[], int, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Create a new ByteBuffer using the provided byte array.
toBuffer(int) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toBuffer(long) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toBuffer(String) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toBuffer(String, Charset) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toBuffer(Resource, boolean) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toByteArray() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
toByteArray() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
toByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Take the combined buffer containing all content written to the accumulator.
toByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Take the combined buffer containing all content written to the OutputStream.
toBytes() - Method in enum org.eclipse.jetty.http.HttpVersion
 
toCanonicalName(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Remove leading or trailing empty components from name.
toCanonicalPath(String) - Static method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
toCanonicalURI(String) - Static method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
toCanonicalURI(URI) - Static method in class org.eclipse.jetty.quickstart.AttributeNormalizer
 
toCentralURI() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
toCentralURI(String) - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
toClassReference(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
Return the Classpath / Classloader reference for the provided class file.
toClassReference(String) - Static method in class org.eclipse.jetty.util.TypeUtil
Return the Classpath / Classloader reference for the provided class file.
toCommandLine() - Method in class org.eclipse.jetty.start.CommandLineBuilder
A version of CommandLineBuilder.toString() where every arg is evaluated for potential ' (single-quote tick) wrapping.
toConnectionString() - Method in class org.eclipse.jetty.client.http.HttpConnectionOverHTTP
 
toConnectionString() - Method in class org.eclipse.jetty.fcgi.client.http.HttpConnectionOverFCGI
 
toConnectionString() - Method in class org.eclipse.jetty.io.AbstractConnection
 
toConnectionString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toConnectionString() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
toConnectionString() - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
toConnectionString() - Method in class org.eclipse.jetty.server.HttpConnection
 
toConnectionString() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
 
toDetailString(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert Buffer to a detail debug string of pointers and content
toDetailString(ByteBuffer[]) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toDirectBuffer(String) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toDirectBuffer(String, Charset) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toEndPointString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toEndPointString() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
toFrame() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
toFrame(int) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
toFrame(int, String) - Static method in class org.eclipse.jetty.websocket.core.CloseStatus
 
toHeaderRangeString(long) - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
toHeaderValue(List<ExtensionConfig>) - Static method in class org.eclipse.jetty.websocket.core.ExtensionConfig
Convert a list of ExtensionConfig to a header value
toHex(byte, Appendable) - Static method in class org.eclipse.jetty.util.TypeUtil
 
toHex(int, Appendable) - Static method in class org.eclipse.jetty.util.TypeUtil
 
toHex(long, Appendable) - Static method in class org.eclipse.jetty.util.TypeUtil
 
toHexString(byte) - Static method in class org.eclipse.jetty.util.StringUtil
 
toHexString(byte) - Static method in class org.eclipse.jetty.util.TypeUtil
Deprecated.
toHexString(byte[]) - Static method in class org.eclipse.jetty.util.StringUtil
 
toHexString(byte[]) - Static method in class org.eclipse.jetty.util.TypeUtil
Deprecated.
toHexString(byte[], int, int) - Static method in class org.eclipse.jetty.util.StringUtil
 
toHexString(byte[], int, int) - Static method in class org.eclipse.jetty.util.TypeUtil
toHexString(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to a Hex String.
toHexSummary(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to a Hex Summary String.
toHttp(URI) - Static method in class org.eclipse.jetty.websocket.api.util.WSURI
Convert to HTTP http or https scheme URIs.
toIDString(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert Buffer to string ID independent of content
toInt() - Method in enum org.eclipse.jetty.logging.JettyLevel
 
toInt(String, int) - Static method in class org.eclipse.jetty.util.StringUtil
Convert String to an integer.
toInt(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to an integer.
toInt(ByteBuffer, int, int) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to an integer.
toISO88591String(ByteBuffer, int) - Static method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
toJSON(Object) - Method in class org.eclipse.jetty.util.ajax.JSON
Converts any object to JSON.
toJSON(Object, JSON.Output) - Method in interface org.eclipse.jetty.util.ajax.JSON.Convertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONCollectionConvertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONDateConvertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONEnumConvertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONObjectConvertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
toJSON(Object, JSON.Output) - Method in class org.eclipse.jetty.util.ajax.JSONPojoConvertorFactory
 
toJSON(JSON.Output) - Method in interface org.eclipse.jetty.util.ajax.JSON.Convertible
 
TOKENS - Static variable in class org.eclipse.jetty.http.HttpTokens
 
toLevel() - Method in enum org.eclipse.jetty.logging.JettyLevel
 
toLong(String) - Static method in class org.eclipse.jetty.util.StringUtil
Convert String to an long.
toLong(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert buffer to an long.
toMappedBuffer(File) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toMappedBuffer(Path, long, long) - Static method in class org.eclipse.jetty.util.BufferUtil
 
toMetadataPath() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
toMidnight(ZonedDateTime) - Static method in class org.eclipse.jetty.util.RolloverFileOutputStream
Get the "start of day" for the provided DateTime at the zone specified.
toName(Class<?>) - Static method in class org.eclipse.jetty.util.TypeUtil
Canonical name for a type.
TOO_MANY_REQUESTS - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
TOO_MANY_REQUESTS_429 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
toPath() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
toPath(String) - Static method in class org.eclipse.jetty.start.FS
 
TopologicalSort<T> - Class in org.eclipse.jetty.util
Topological sort a list or array.
TopologicalSort() - Constructor for class org.eclipse.jetty.util.TopologicalSort
 
toQuietCheck(long, long) - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
toQuotedString() - Method in class org.eclipse.jetty.start.CommandLineBuilder
toRealPath(Path) - Static method in class org.eclipse.jetty.start.FS
 
toRedirectURI(HttpServletRequest, String) - Static method in class org.eclipse.jetty.server.Response
Common point to generate a proper "Location" header for redirects.
toRedirectURL(HttpServletRequest, String) - Static method in class org.eclipse.jetty.rewrite.handler.RedirectUtil
Common point to generate a proper "Location" header for redirects.
toRelativePath(File, File) - Static method in class org.eclipse.jetty.start.FS
 
toReplacedString() - Method in class org.eclipse.jetty.util.Utf8Appendable
 
toRequestContent(ContentProvider) - Static method in interface org.eclipse.jetty.client.api.ContentProvider
Deprecated.
Converts a ContentProvider to a Request.Content.
toShortForm(File) - Method in class org.eclipse.jetty.start.BaseHome
Convenience method for toShortForm(file.toPath())
toShortForm(String) - Method in class org.eclipse.jetty.start.BaseHome
Replace/Shorten arbitrary path with property strings "${jetty.home}" or "${jetty.base}" where appropriate.
toShortForm(Path) - Method in class org.eclipse.jetty.start.BaseHome.SearchDir
 
toShortForm(Path) - Method in class org.eclipse.jetty.start.BaseHome
Replace/Shorten arbitrary path with property strings "${jetty.home}" or "${jetty.base}" where appropriate.
toShortName(Type) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
toShortPath(Path) - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
toShortString() - Method in class org.eclipse.jetty.start.Version
Return short string form (without suffix)
toSnapshotMetadataXmlURI() - Method in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
toStarString() - Method in class org.eclipse.jetty.util.security.Password
 
toStateString() - Method in class org.eclipse.jetty.io.FillInterest
 
toStateString() - Method in class org.eclipse.jetty.io.WriteFlusher
 
toStatsHTML() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
toString() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ClassInheritanceMap
 
toString() - Method in class org.eclipse.jetty.annotations.AnnotationConfiguration.ServletContainerInitializerOrdering
 
toString() - Method in class org.eclipse.jetty.client.AbstractConnectionPool
 
toString() - Method in class org.eclipse.jetty.client.api.Result
 
toString() - Method in class org.eclipse.jetty.client.http.HttpChannelOverHTTP
 
toString() - Method in class org.eclipse.jetty.client.http.HttpReceiverOverHTTP
 
toString() - Method in class org.eclipse.jetty.client.http.HttpSenderOverHTTP
 
toString() - Method in class org.eclipse.jetty.client.HttpChannel
 
toString() - Method in class org.eclipse.jetty.client.HttpConnection
 
toString() - Method in class org.eclipse.jetty.client.HttpContentResponse
 
toString() - Method in class org.eclipse.jetty.client.HttpConversation
 
toString() - Method in class org.eclipse.jetty.client.HttpDestination
 
toString() - Method in class org.eclipse.jetty.client.HttpExchange
 
toString() - Method in class org.eclipse.jetty.client.HttpReceiver
 
toString() - Method in class org.eclipse.jetty.client.HttpRequest
 
toString() - Method in class org.eclipse.jetty.client.HttpResponse
 
toString() - Method in class org.eclipse.jetty.client.HttpSender
 
toString() - Method in class org.eclipse.jetty.client.internal.RequestContentAdapter
 
toString() - Method in class org.eclipse.jetty.client.Origin.Address
 
toString() - Method in class org.eclipse.jetty.client.Origin.Protocol
 
toString() - Method in class org.eclipse.jetty.client.Origin
 
toString() - Method in class org.eclipse.jetty.client.ProxyConfiguration.Proxy
 
toString() - Method in class org.eclipse.jetty.client.SendFailure
 
toString() - Method in class org.eclipse.jetty.client.util.AbstractRequestContent.AbstractSubscription
 
toString() - Method in class org.eclipse.jetty.client.util.AsyncRequestContent
 
toString() - Method in class org.eclipse.jetty.client.util.BasicAuthentication.BasicResult
 
toString() - Method in class org.eclipse.jetty.client.util.DeferredContentProvider.Chunk
Deprecated.
 
toString() - Method in class org.eclipse.jetty.client.ValidatingConnectionPool
 
toString() - Method in class org.eclipse.jetty.deploy.App
 
toString() - Method in class org.eclipse.jetty.deploy.graph.Edge
 
toString() - Method in class org.eclipse.jetty.deploy.graph.Node
 
toString() - Method in class org.eclipse.jetty.deploy.graph.Path
 
toString() - Method in class org.eclipse.jetty.deploy.PropertiesConfigurationManager
 
toString() - Method in class org.eclipse.jetty.deploy.providers.ScanningAppProvider
 
toString() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
toString() - Method in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
toString() - Method in class org.eclipse.jetty.http.CompressedContentFormat
 
toString() - Method in class org.eclipse.jetty.http.CookieCompliance
 
toString() - Method in class org.eclipse.jetty.http.HttpCompliance
 
toString() - Method in class org.eclipse.jetty.http.HttpField
 
toString() - Method in class org.eclipse.jetty.http.HttpFields.Immutable
 
toString() - Method in class org.eclipse.jetty.http.HttpFields.Mutable
 
toString() - Method in class org.eclipse.jetty.http.HttpGenerator
 
toString() - Method in enum org.eclipse.jetty.http.HttpHeader
 
toString() - Method in enum org.eclipse.jetty.http.HttpHeaderValue
 
toString() - Method in enum org.eclipse.jetty.http.HttpMethod
 
toString() - Method in class org.eclipse.jetty.http.HttpParser
 
toString() - Method in enum org.eclipse.jetty.http.HttpScheme
 
toString() - Method in enum org.eclipse.jetty.http.HttpStatus.Code
 
toString() - Method in class org.eclipse.jetty.http.HttpTester.Request
 
toString() - Method in class org.eclipse.jetty.http.HttpTester.Response
 
toString() - Method in class org.eclipse.jetty.http.HttpTokens.Token
 
toString() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
toString() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
toString() - Method in enum org.eclipse.jetty.http.HttpVersion
 
toString() - Method in class org.eclipse.jetty.http.MetaData.Request
 
toString() - Method in class org.eclipse.jetty.http.MetaData.Response
 
toString() - Method in class org.eclipse.jetty.http.MetaData
 
toString() - Method in enum org.eclipse.jetty.http.MimeTypes.Type
 
toString() - Method in class org.eclipse.jetty.http.pathmap.AbstractPathSpec
 
toString() - Method in class org.eclipse.jetty.http.pathmap.MappedResource
 
toString() - Method in class org.eclipse.jetty.http.pathmap.PathMappings
 
toString() - Method in class org.eclipse.jetty.http.PrecompressedHttpContent
 
toString() - Method in class org.eclipse.jetty.http.QuotedCSV
 
toString() - Method in class org.eclipse.jetty.http.ResourceHttpContent
 
toString() - Method in class org.eclipse.jetty.http.spi.JettyHttpExchange
 
toString() - Method in class org.eclipse.jetty.http.spi.JettyHttpsExchange
 
toString() - Method in class org.eclipse.jetty.http.UriCompliance
 
toString() - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
toString() - Method in class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2.HTTP2
 
toString() - Method in class org.eclipse.jetty.http2.client.http.HttpChannelOverHTTP2
 
toString() - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
toString() - Method in class org.eclipse.jetty.http2.frames.ContinuationFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.Frame
 
toString() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.HeadersFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.PriorityFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.ResetFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.SettingsFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.UnknownFrame
 
toString() - Method in class org.eclipse.jetty.http2.frames.WindowUpdateFrame
 
toString() - Method in class org.eclipse.jetty.http2.hpack.AuthorityHttpField
 
toString() - Method in class org.eclipse.jetty.http2.hpack.HpackContext.Entry
 
toString() - Method in class org.eclipse.jetty.http2.hpack.HpackContext
 
toString() - Method in class org.eclipse.jetty.http2.hpack.HpackDecoder
 
toString() - Method in class org.eclipse.jetty.http2.hpack.StaticTableHttpField
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2Connection.HTTP2Producer
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2Flusher.Entry
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2Session
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
toString() - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
toString() - Method in class org.eclipse.jetty.http2.parser.HeaderParser
 
toString() - Method in class org.eclipse.jetty.http2.server.AbstractHTTP2ServerConnectionFactory.HTTP2SessionContainer
 
toString() - Method in class org.eclipse.jetty.http2.server.HttpChannelOverHTTP2
 
toString() - Method in class org.eclipse.jetty.http3.api.Stream.Data
 
toString() - Method in class org.eclipse.jetty.http3.client.http.ClientConnectionFactoryOverHTTP3.HTTP3
 
toString() - Method in class org.eclipse.jetty.http3.frames.DataFrame
 
toString() - Method in class org.eclipse.jetty.http3.frames.Frame
 
toString() - Method in class org.eclipse.jetty.http3.frames.GoAwayFrame
 
toString() - Method in class org.eclipse.jetty.http3.frames.HeadersFrame
 
toString() - Method in class org.eclipse.jetty.http3.frames.SettingsFrame
 
toString() - Method in class org.eclipse.jetty.http3.qpack.QpackDecoder
 
toString() - Method in class org.eclipse.jetty.io.AbstractConnection
 
toString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toString() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
toString() - Method in class org.eclipse.jetty.io.ArrayRetainableByteBufferPool
 
toString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
toString() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
toString() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
toString() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
toString() - Method in class org.eclipse.jetty.io.FillInterest
 
toString() - Method in class org.eclipse.jetty.io.ManagedSelector
 
toString() - Method in class org.eclipse.jetty.io.MappedByteBufferPool
 
toString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer
 
toString() - Method in class org.eclipse.jetty.io.RetainableByteBufferPool.NotRetainedByteBufferPool
 
toString() - Method in class org.eclipse.jetty.io.SelectorManager
 
toString() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
toString() - Method in class org.eclipse.jetty.io.WriteFlusher
 
toString() - Method in class org.eclipse.jetty.jaas.JAASPrincipal
 
toString() - Method in class org.eclipse.jetty.jaas.JAASUserPrincipal
 
toString() - Method in class org.eclipse.jetty.jndi.NamingContext
 
toString() - Method in enum org.eclipse.jetty.logging.JettyLevel
 
toString() - Method in class org.eclipse.jetty.logging.JettyLogger
 
toString() - Method in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
toString() - Method in class org.eclipse.jetty.osgi.boot.utils.FakeURLClassLoader
 
toString() - Method in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
toString() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
 
toString() - Method in class org.eclipse.jetty.quic.common.CloseInfo
 
toString() - Method in class org.eclipse.jetty.quic.common.ProtocolSession
 
toString() - Method in class org.eclipse.jetty.quic.common.QuicSession
 
toString() - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
toString() - Method in class org.eclipse.jetty.rewrite.handler.CookiePatternRule
Returns the cookie contents.
toString() - Method in class org.eclipse.jetty.rewrite.handler.HeaderPatternRule
Returns the header contents.
toString() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRegexRule
 
toString() - Method in class org.eclipse.jetty.rewrite.handler.HeaderRule
 
toString() - Method in class org.eclipse.jetty.rewrite.handler.PatternRule
Returns the rule pattern.
toString() - Method in class org.eclipse.jetty.rewrite.handler.RedirectPatternRule
Returns the redirect status code and location.
toString() - Method in class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
Returns the redirect status code and replacement.
toString() - Method in class org.eclipse.jetty.rewrite.handler.RegexRule
Returns the regular expression string.
toString() - Method in class org.eclipse.jetty.rewrite.handler.ResponsePatternRule
Returns the code and reason string.
toString() - Method in class org.eclipse.jetty.rewrite.handler.RewritePatternRule
Returns the replacement string.
toString() - Method in class org.eclipse.jetty.rewrite.handler.RewriteRegexRule
Returns the replacement string.
toString() - Method in class org.eclipse.jetty.rewrite.handler.Rule
Returns the handling and terminating flag values.
toString() - Method in class org.eclipse.jetty.rewrite.handler.ValidUrlRule
 
toString() - Method in class org.eclipse.jetty.security.AbstractLoginService
 
toString() - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator.FormAuthentication
 
toString() - Method in class org.eclipse.jetty.security.authentication.SessionAuthentication
 
toString() - Method in class org.eclipse.jetty.security.DefaultUserIdentity
 
toString() - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator.OpenIdAuthentication
 
toString() - Method in class org.eclipse.jetty.security.openid.OpenIdConfiguration
 
toString() - Method in class org.eclipse.jetty.security.openid.OpenIdUserPrincipal
 
toString() - Method in class org.eclipse.jetty.security.PropertyUserStore
 
toString() - Method in class org.eclipse.jetty.security.RoleInfo
 
toString() - Method in class org.eclipse.jetty.security.RoleRunAsToken
 
toString() - Method in class org.eclipse.jetty.security.SecurityHandler.NotChecked
 
toString() - Method in class org.eclipse.jetty.security.UserAuthentication
 
toString() - Method in class org.eclipse.jetty.security.UserPrincipal
 
toString() - Method in class org.eclipse.jetty.security.UserStore
 
toString() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
toString() - Method in class org.eclipse.jetty.server.AbstractConnector
 
toString() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
toString() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
toString() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedHttpContent
 
toString() - Method in class org.eclipse.jetty.server.CachedContentFactory.CachedPrecompressedHttpContent
 
toString() - Method in class org.eclipse.jetty.server.CachedContentFactory
 
toString() - Method in class org.eclipse.jetty.server.Dispatcher
 
toString() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
toString() - Method in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
toString() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
toString() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
toString() - Method in class org.eclipse.jetty.server.handler.InetAccessSet.PatternTuple
 
toString() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
toString() - Method in class org.eclipse.jetty.server.HttpChannel
 
toString() - Method in class org.eclipse.jetty.server.HttpChannelState
 
toString() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
toString() - Method in class org.eclipse.jetty.server.HttpInput.Content
 
toString() - Method in class org.eclipse.jetty.server.HttpInput.EofContent
 
toString() - Method in class org.eclipse.jetty.server.HttpInput.ErrorContent
 
toString() - Method in class org.eclipse.jetty.server.HttpInput
 
toString() - Method in class org.eclipse.jetty.server.HttpOutput
 
toString() - Method in class org.eclipse.jetty.server.InclusiveByteRange
 
toString() - Method in class org.eclipse.jetty.server.LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck
 
toString() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MainThreadPoolLowResourceCheck
 
toString() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MaxConnectionsLowResourceCheck
 
toString() - Method in class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
toString() - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
toString() - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
toString() - Method in class org.eclipse.jetty.server.MultiPartParser
 
toString() - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
toString() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
toString() - Method in class org.eclipse.jetty.server.Request
 
toString() - Method in class org.eclipse.jetty.server.ResourceContentFactory
 
toString() - Method in class org.eclipse.jetty.server.Response
 
toString() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
toString() - Method in class org.eclipse.jetty.server.Server
 
toString() - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
toString() - Method in class org.eclipse.jetty.server.ServletPathMapping
 
toString() - Method in class org.eclipse.jetty.server.session.AbstractSessionCache
 
toString() - Method in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
toString() - Method in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
toString() - Method in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
toString() - Method in class org.eclipse.jetty.server.session.FileSessionDataStore
 
toString() - Method in class org.eclipse.jetty.server.session.HouseKeeper
 
toString() - Method in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
toString() - Method in class org.eclipse.jetty.server.session.Session
 
toString() - Method in class org.eclipse.jetty.server.session.SessionContext
 
toString() - Method in class org.eclipse.jetty.server.session.SessionData
 
toString() - Method in class org.eclipse.jetty.server.session.SessionHandler
 
toString() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
toString() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
toString() - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
toString() - Method in class org.eclipse.jetty.servlet.FilterHolder
 
toString() - Method in class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
toString() - Method in class org.eclipse.jetty.servlet.FilterMapping
 
toString() - Method in class org.eclipse.jetty.servlet.Holder
 
toString() - Method in class org.eclipse.jetty.servlet.ListenerHolder
 
toString() - Method in class org.eclipse.jetty.servlet.ListenerHolder.Wrapper
 
toString() - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
toString() - Method in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder.Wrapper
 
toString() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspConfig
 
toString() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.JspPropertyGroup
 
toString() - Method in class org.eclipse.jetty.servlet.ServletContextHandler.TagLib
 
toString() - Method in class org.eclipse.jetty.servlet.ServletHandler.MappedServlet
 
toString() - Method in class org.eclipse.jetty.servlet.ServletHolder
 
toString() - Method in class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
toString() - Method in class org.eclipse.jetty.servlet.ServletMapping
 
toString() - Method in class org.eclipse.jetty.servlet.Source
 
toString() - Method in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStore
 
toString() - Method in class org.eclipse.jetty.start.Classpath
 
toString() - Method in class org.eclipse.jetty.start.CommandLineBuilder
 
toString() - Method in class org.eclipse.jetty.start.config.CommandLineConfigSource
 
toString() - Method in class org.eclipse.jetty.start.config.ConfigSources
 
toString() - Method in class org.eclipse.jetty.start.config.DirConfigSource
 
toString() - Method in class org.eclipse.jetty.start.FileArg
 
toString() - Method in class org.eclipse.jetty.start.Module
 
toString() - Method in class org.eclipse.jetty.start.Modules
 
toString() - Method in class org.eclipse.jetty.start.Props.Prop
 
toString() - Method in class org.eclipse.jetty.start.Props
 
toString() - Method in class org.eclipse.jetty.start.StartArgs
 
toString() - Method in class org.eclipse.jetty.start.TextFile
 
toString() - Method in class org.eclipse.jetty.start.Version
 
toString() - Method in class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
 
toString() - Method in class org.eclipse.jetty.util.ajax.JSON.Literal
 
toString() - Method in class org.eclipse.jetty.util.ajax.JSON.StringSource
 
toString() - Method in class org.eclipse.jetty.util.AtomicBiInteger
 
toString() - Method in class org.eclipse.jetty.util.AttributesMap
 
toString() - Method in class org.eclipse.jetty.util.component.AbstractLifeCycle
 
toString() - Method in class org.eclipse.jetty.util.component.AttributeContainerMap
 
toString() - Method in class org.eclipse.jetty.util.compression.CompressionPool
 
toString() - Method in exception class org.eclipse.jetty.util.ConstantThrowable
 
toString() - Method in class org.eclipse.jetty.util.CountingCallback
 
toString() - Method in class org.eclipse.jetty.util.DecoratedObjectFactory
 
toString() - Method in class org.eclipse.jetty.util.Fields.Field
 
toString() - Method in class org.eclipse.jetty.util.Fields
 
toString() - Method in class org.eclipse.jetty.util.FutureCallback
 
toString() - Method in class org.eclipse.jetty.util.FuturePromise
 
toString() - Method in class org.eclipse.jetty.util.HostPort
 
toString() - Method in class org.eclipse.jetty.util.IncludeExcludeSet
 
toString() - Method in class org.eclipse.jetty.util.Index.Builder
 
toString() - Method in class org.eclipse.jetty.util.InetAddressPattern
 
toString() - Method in class org.eclipse.jetty.util.IteratingCallback
 
toString() - Method in class org.eclipse.jetty.util.IteratingNestedCallback
 
toString() - Method in class org.eclipse.jetty.util.JavaVersion
 
toString() - Method in class org.eclipse.jetty.util.LeakDetector.LeakInfo
 
toString() - Method in exception class org.eclipse.jetty.util.MultiException
 
toString() - Method in class org.eclipse.jetty.util.MultiMap
 
toString() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile
 
toString() - Method in class org.eclipse.jetty.util.MultiReleaseJarFile.VersionedJarEntry
 
toString() - Method in class org.eclipse.jetty.util.PathWatcher.Config
 
toString() - Method in class org.eclipse.jetty.util.PathWatcher.PathWatchEvent
 
toString() - Method in class org.eclipse.jetty.util.PathWatcher
 
toString() - Method in class org.eclipse.jetty.util.Pool
 
toString() - Method in class org.eclipse.jetty.util.resource.PathResource
 
toString() - Method in class org.eclipse.jetty.util.resource.ResourceCollection
 
toString() - Method in class org.eclipse.jetty.util.resource.URLResource
 
toString() - Method in class org.eclipse.jetty.util.security.Constraint
 
toString() - Method in class org.eclipse.jetty.util.security.Password
 
toString() - Method in class org.eclipse.jetty.util.SharedBlockingCallback.Blocker
 
toString() - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
toString() - Method in class org.eclipse.jetty.util.ssl.X509
 
toString() - Method in class org.eclipse.jetty.util.statistic.CounterStatistic
 
toString() - Method in class org.eclipse.jetty.util.statistic.RateStatistic
 
toString() - Method in class org.eclipse.jetty.util.statistic.SampleStatistic
 
toString() - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
toString() - Method in class org.eclipse.jetty.util.thread.Invocable.ReadyTask
 
toString() - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
toString() - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
 
toString() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
toString() - Method in class org.eclipse.jetty.util.thread.strategy.ExecuteProduceConsume
 
toString() - Method in class org.eclipse.jetty.util.thread.TryExecutor.NoTryExecutor
 
toString() - Method in class org.eclipse.jetty.util.TopologicalSort
 
toString() - Method in class org.eclipse.jetty.util.Utf8StringBuffer
 
toString() - Method in class org.eclipse.jetty.util.Utf8StringBuilder
 
toString() - Method in class org.eclipse.jetty.webapp.CachingWebAppClassLoader
 
toString() - Method in class org.eclipse.jetty.webapp.ClassMatcher.Entry
 
toString() - Method in class org.eclipse.jetty.webapp.Configurations
 
toString() - Method in class org.eclipse.jetty.webapp.Descriptor
 
toString() - Method in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
toString() - Method in class org.eclipse.jetty.webapp.MetaData.OriginInfo
 
toString() - Method in class org.eclipse.jetty.webapp.WebAppClassLoader
 
toString() - Method in class org.eclipse.jetty.webapp.WebAppContext
 
toString() - Method in enum org.eclipse.jetty.websocket.api.Frame.Type
 
toString() - Method in class org.eclipse.jetty.websocket.client.WebSocketClient
 
toString() - Method in class org.eclipse.jetty.websocket.common.JettyExtensionConfig
 
toString() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrame
 
toString() - Method in class org.eclipse.jetty.websocket.common.JettyWebSocketFrameHandler
 
toString() - Method in class org.eclipse.jetty.websocket.common.WebSocketSession
 
toString() - Method in class org.eclipse.jetty.websocket.core.AbstractExtension
 
toString() - Method in class org.eclipse.jetty.websocket.core.CloseStatus
 
toString() - Method in class org.eclipse.jetty.websocket.core.Configuration.ConfigurationCustomizer
 
toString() - Method in class org.eclipse.jetty.websocket.core.ExtensionConfig
 
toString() - Method in class org.eclipse.jetty.websocket.core.Frame
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.ExtensionStack
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.FrameEntry
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.FrameFlusher
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.IdentityExtension
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.Negotiated
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.Parser.ParsedFrame
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.Parser
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.PerMessageDeflateExtension
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
toString() - Method in class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
toString() - Method in class org.eclipse.jetty.websocket.core.server.internal.CreatorNegotiator
 
toString() - Method in class org.eclipse.jetty.websocket.core.server.ServerUpgradeResponse
 
toString() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.client.JakartaWebSocketShutdownContainer
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.RegisteredDecoder
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.common.encoders.RegisteredEncoder
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketExtension
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandler
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketSession
 
toString() - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketCreator
 
toString() - Method in class org.eclipse.jetty.xml.XmlConfiguration
 
toString() - Method in class org.eclipse.jetty.xml.XmlParser.Node
 
toString(boolean) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Convert to a string.
toString(boolean, boolean) - Method in class org.eclipse.jetty.xml.XmlParser.Node
Convert to a string.
toString(byte[], int) - Static method in class org.eclipse.jetty.util.TypeUtil
 
toString(byte[], int, int, String) - Static method in class org.eclipse.jetty.util.StringUtil
Deprecated, for removal: This API element is subject to removal in a future version.
toString(int, String) - Static method in enum org.eclipse.jetty.http2.ErrorCode
 
toString(InputStream) - Static method in class org.eclipse.jetty.util.IO
Read input stream to string.
toString(InputStream, String) - Static method in class org.eclipse.jetty.util.IO
Read input stream to string.
toString(InputStream, Charset) - Static method in class org.eclipse.jetty.util.IO
Read input stream to string.
toString(Reader) - Static method in class org.eclipse.jetty.util.IO
Read input stream to string.
toString(Class<?>, Method) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
toString(Object) - Static method in class org.eclipse.jetty.util.LazyList
 
toString(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert the buffer to an ISO-8859-1 String
toString(ByteBuffer, int, int, Charset) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert a partial buffer to a String.
toString(ByteBuffer, Charset) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert the buffer to an ISO-8859-1 String
toString(Charset) - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
toString(Path, Charset) - Static method in class org.eclipse.jetty.util.IO
Read Path to string.
toStringArray(Object) - Static method in class org.eclipse.jetty.util.LazyList
 
toStringArrayMap() - Method in class org.eclipse.jetty.util.MultiMap
 
toStringLocked() - Method in class org.eclipse.jetty.util.thread.strategy.AdaptiveExecutionStrategy
 
toStringMetaData() - Method in class org.eclipse.jetty.plus.jndi.EnvEntry
 
toStringMetaData() - Method in class org.eclipse.jetty.plus.jndi.Link
 
toStringMetaData() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
 
toSummaryString(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
 
touch(Path) - Static method in class org.eclipse.jetty.start.FS
 
toURI() - Method in class org.eclipse.jetty.http.HttpURI.Immutable
 
toURI() - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
toURI() - Method in interface org.eclipse.jetty.http.HttpURI
 
toURL(File) - Static method in class org.eclipse.jetty.util.resource.Resource
Generate a properly encoded URL from a File instance.
toUTF8String(byte[], int, int) - Static method in class org.eclipse.jetty.util.StringUtil
 
toUTF8String(ByteBuffer) - Static method in class org.eclipse.jetty.util.BufferUtil
Convert the buffer to an UTF-8 String
toWebsocket(CharSequence) - Static method in class org.eclipse.jetty.websocket.api.util.WSURI
Convert to WebSocket ws or wss scheme URIs
toWebsocket(CharSequence, String) - Static method in class org.eclipse.jetty.websocket.api.util.WSURI
Convert to WebSocket ws or wss scheme URIs
toWebsocket(URI) - Static method in class org.eclipse.jetty.websocket.api.util.WSURI
Convert to WebSocket ws or wss scheme URIs
toWebsocket(URI) - Static method in class org.eclipse.jetty.websocket.core.internal.Negotiated
Convert to WebSocket ws or wss scheme URIs
trace(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
trace(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
trace(String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(String, Object...) - Static method in class org.eclipse.jetty.start.StartLog
 
trace(String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(Marker, String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(Marker, String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(Marker, String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(Marker, String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
trace(Marker, String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
TRACE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
TRACE - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
trailer(HttpField) - Method in class org.eclipse.jetty.client.HttpResponse
 
trailer(HeadersFrame) - Method in interface org.eclipse.jetty.http3.api.Stream
Sends the given HEADERS frame containing the trailer headers.
TRAILER - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
TRAILER - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
trailers(Supplier<HttpFields>) - Method in class org.eclipse.jetty.client.HttpRequest
 
Transaction - Class in org.eclipse.jetty.plus.jndi
Transaction Class to represent a JTA UserTransaction impl.
Transaction(UserTransaction) - Constructor for class org.eclipse.jetty.plus.jndi.Transaction
 
TRANSFER_ENCODING - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
TRANSFER_ENCODING - Enum constant in enum org.eclipse.jetty.server.MultiParts.NonCompliance
 
TRANSFER_ENCODING_WITH_CONTENT_LENGTH - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the HTTP protocol has required that a request is invalid if it contains both a Transfer-Encoding field and Content-Length field.
transform(ByteBuffer, boolean, List<ByteBuffer>) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
 
transform(ByteBuffer, boolean, List<ByteBuffer>) - Method in interface org.eclipse.jetty.proxy.AsyncMiddleManServlet.ContentTransformer
Transforms the given input byte buffers into (possibly multiple) byte buffers.
transform(ByteBuffer, boolean, List<ByteBuffer>) - Method in class org.eclipse.jetty.proxy.AsyncMiddleManServlet.GZIPContentTransformer
 
transform(AfterContentTransformer.Source, AfterContentTransformer.Sink) - Method in class org.eclipse.jetty.proxy.AfterContentTransformer
Transforms the original content read from the source into transformed content written to the sink.
transform(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.FragmentingFlusher
 
transform(Callback) - Method in class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
Called to transform the frame given in TransformingFlusher.onFrame(Frame, Callback, boolean).
TransformingFlusher - Class in org.eclipse.jetty.websocket.core.internal
This is used to iteratively transform or process a frame into one or more other frames.
TransformingFlusher() - Constructor for class org.eclipse.jetty.websocket.core.internal.TransformingFlusher
 
TransientListeners() - Constructor for class org.eclipse.jetty.server.HttpChannel.TransientListeners
Deprecated.
 
Transparent() - Constructor for class org.eclipse.jetty.proxy.AsyncMiddleManServlet.Transparent
 
Transparent() - Constructor for class org.eclipse.jetty.proxy.AsyncProxyServlet.Transparent
 
Transparent() - Constructor for class org.eclipse.jetty.proxy.ProxyServlet.Transparent
 
TransparentDelegate(AbstractProxyServlet) - Constructor for class org.eclipse.jetty.proxy.AbstractProxyServlet.TransparentDelegate
 
trimClassName(String) - Static method in class org.eclipse.jetty.websocket.core.internal.util.ReflectUtils
 
True - Enum constant in enum org.eclipse.jetty.webapp.MetaData.Complete
 
truncate(String, int) - Static method in class org.eclipse.jetty.util.StringUtil
Truncate a string to a max size.
TRUST_ALL_CERTS - Static variable in class org.eclipse.jetty.util.ssl.SslContextFactory
 
TRY_AGAIN_LATER - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
1013 indicates that the service is experiencing overload.
TRY_AGAIN_LATER - Static variable in class org.eclipse.jetty.websocket.core.CloseStatus
 
tryConvertPayload() - Method in class org.eclipse.jetty.http2.frames.GoAwayFrame
 
tryCreate(boolean) - Method in class org.eclipse.jetty.client.AbstractConnectionPool
Tries to create a new connection.
tryExecute(Runnable) - Method in class org.eclipse.jetty.http.spi.DelegatingThreadPool
 
tryExecute(Runnable) - Method in class org.eclipse.jetty.util.thread.ExecutorThreadPool
 
tryExecute(Runnable) - Method in class org.eclipse.jetty.util.thread.QueuedThreadPool
 
tryExecute(Runnable) - Method in class org.eclipse.jetty.util.thread.ReservedThreadExecutor
Executes the given task if and only if a reserved thread is available.
tryExecute(Runnable) - Method in class org.eclipse.jetty.util.thread.TryExecutor.NoTryExecutor
 
tryExecute(Runnable) - Method in interface org.eclipse.jetty.util.thread.TryExecutor
Attempt to execute a task.
TryExecutor - Interface in org.eclipse.jetty.util.thread
A variation of Executor that can confirm if a thread is available immediately
TryExecutor.NoTryExecutor - Class in org.eclipse.jetty.util.thread
 
TryFilesFilter - Class in org.eclipse.jetty.fcgi.server.proxy
Inspired by nginx's try_files functionality.
TryFilesFilter() - Constructor for class org.eclipse.jetty.fcgi.server.proxy.TryFilesFilter
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractConnection
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
tryFillInterested(Callback) - Method in interface org.eclipse.jetty.io.EndPoint
Requests callback methods to be invoked when a call to EndPoint.fill(ByteBuffer) would return data or EOF.
tryFillInterested(Callback) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
tryRegister(Callback) - Method in class org.eclipse.jetty.io.FillInterest
Call to register interest in a callback when a read is possible.
type - Variable in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
type() - Method in enum org.eclipse.jetty.http3.frames.FrameType
 
type() - Method in enum org.eclipse.jetty.quic.common.StreamType
 
TypeUtil - Class in org.eclipse.jetty.util
TYPE Utilities.
TypeUtil() - Constructor for class org.eclipse.jetty.util.TypeUtil
 

U

UNAUTHENTICATED - Static variable in interface org.eclipse.jetty.server.Authentication
Unauthenticated state.
UNAUTHENTICATED_IDENTITY - Static variable in interface org.eclipse.jetty.server.UserIdentity
 
UNAUTHORIZED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
UNAUTHORIZED_401 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
UNAVAILABLE - Enum constant in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
 
UNAVAILABLE_FOR_LEGAL_REASONS - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
UNAVAILABLE_FOR_LEGAL_REASONS_451 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
unbind(String) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
unbind(String) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
unbind(String) - Method in class org.eclipse.jetty.jndi.NamingContext
Not supported.
unbind(Context) - Static method in class org.eclipse.jetty.jndi.NamingUtil
 
unbind(Name) - Method in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
unbind(Name) - Method in class org.eclipse.jetty.jndi.local.localContextRoot
 
unbind(Name) - Method in class org.eclipse.jetty.jndi.NamingContext
Not supported.
unbind(NamingContext, Binding) - Method in interface org.eclipse.jetty.jndi.NamingContext.Listener
 
UNBIND - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
unbindENC() - Method in class org.eclipse.jetty.plus.jndi.NamingEntry
Unbind this NamingEntry from a java:comp/env
unbindENC() - Method in class org.eclipse.jetty.plus.jndi.Transaction
Unbind this Transaction from a java:comp
unbindValue(String, Object) - Method in class org.eclipse.jetty.server.session.Session
Unbind value if value implements HttpSessionBindingListener (calls HttpSessionBindingListener.valueUnbound(HttpSessionBindingEvent))
UNCHECKOUT - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
UNDEFINED - Static variable in class org.eclipse.jetty.websocket.api.StatusCode
Reserved.
UNDEFINED - Static variable in class org.eclipse.jetty.websocket.core.OpCode
An undefined OpCode
undeployAll() - Method in class org.eclipse.jetty.deploy.DeploymentManager
 
UNDEPLOYED - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
UNDEPLOYED_EVENT - Static variable in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
undeployHandler(Handler, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Thread safe undeploy of a Handler.
UNDEPLOYING - Static variable in class org.eclipse.jetty.deploy.AppLifeCycle
 
UNDEPLOYING_EVENT - Static variable in class org.eclipse.jetty.osgi.boot.utils.EventSender
 
unhandle() - Method in class org.eclipse.jetty.server.HttpChannelState
Signal that the HttpConnection has finished handling the request.
UNIX - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
 
UnixCrypt - Class in org.eclipse.jetty.util.security
Unix Crypt.
UnixSocketConnector - Class in org.eclipse.jetty.unixsocket.server
Deprecated, for removal: This API element is subject to removal in a future version.
Use UnixDomainServerConnector from the jetty-unixdomain-server module instead (requires Java 16 or later).
UnixSocketConnector(Server) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the default configuration.
UnixSocketConnector(Server, int) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given number of selectors
UnixSocketConnector(Server, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given selectors and ConnectionFactories.
UnixSocketConnector(Server, int, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given selectors and SslContextFactory.
UnixSocketConnector(Server, Executor, Scheduler, ByteBufferPool, int, ConnectionFactory...) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given parameters.
UnixSocketConnector(Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given ConnectionFactories.
UnixSocketConnector(Server, SslContextFactory.Server) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given SslContextFactory.
UnixSocketConnector(Server, SslContextFactory.Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector
Deprecated.
Constructs a UnixSocketConnector with the given SslContextFactory and ConnectionFactories.
UnixSocketConnector.UnixSocketConnectorManager - Class in org.eclipse.jetty.unixsocket.server
Deprecated.
 
UnixSocketConnectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.unixsocket.server.UnixSocketConnector.UnixSocketConnectorManager
Deprecated.
 
UnixSocketEndPoint - Class in org.eclipse.jetty.unixsocket.common
Deprecated, for removal: This API element is subject to removal in a future version.
UnixSocketEndPoint(UnixSocketChannel, ManagedSelector, SelectionKey, Scheduler) - Constructor for class org.eclipse.jetty.unixsocket.common.UnixSocketEndPoint
Deprecated.
 
UNKNOWN - Enum constant in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
 
UNKNOWN - Static variable in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1.Tag
The PROXY V1 Tag typically used to "ping" the server.
UNKNOWN_CONTENT - Enum constant in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
 
UnknownBodyParser - Class in org.eclipse.jetty.http2.parser
 
UnknownBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.UnknownBodyParser
 
UnknownFrame - Class in org.eclipse.jetty.http2.frames
 
UnknownFrame(int) - Constructor for class org.eclipse.jetty.http2.frames.UnknownFrame
 
unlimit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
unlimit() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
UNLIMITED_DEPTH - Static variable in class org.eclipse.jetty.util.PathWatcher.Config
 
UNLINK - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
UNLOCK - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
UNLOCK_PROPERTY - Static variable in class org.eclipse.jetty.jndi.NamingContext
 
unlockCompEnv(WebAppContext) - Method in class org.eclipse.jetty.plus.webapp.PlusConfiguration
 
unmanage(Object) - Method in interface org.eclipse.jetty.util.component.Container
Unmanages a bean already contained by this aggregate, so that it is not started/stopped/destroyed with this aggregate.
unmanage(Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
Unmanages a bean already contained by this aggregate, so that it is not started/stopped/destroyed with this aggregate.
unpack(WebAppContext) - Method in class org.eclipse.jetty.webapp.WebInfConfiguration
 
UNPROCESSABLE_ENTITY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
UNPROCESSABLE_ENTITY_422 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
unquote(String) - Static method in class org.eclipse.jetty.http.QuotedCSVParser
 
unquote(String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
unquote(String, boolean) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Unquote a string.
unquoteOnly(String) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
 
unquoteOnly(String, boolean) - Static method in class org.eclipse.jetty.util.QuotedStringTokenizer
Unquote a string, NOT converting unicode sequences
UnreadableSessionDataException - Exception Class in org.eclipse.jetty.server.session
UnreadableSessionDataException
UnreadableSessionDataException(String, SessionContext, Throwable) - Constructor for exception class org.eclipse.jetty.server.session.UnreadableSessionDataException
 
unregister(String) - Method in class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
unsafe(String) - Static method in class org.eclipse.jetty.util.HostPort
Create a HostPort from an unsafe (and not validated) authority.
UNSAFE - Static variable in class org.eclipse.jetty.http.UriCompliance
Compliance mode that allows all URI Violations, including allowing ambiguous paths in non canonicalized form.
UNSAFE_HOST_HEADER - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the HTTP protocol should reject a request if the Host headers contains an invalid / unsafe authority.
UNSET - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
UNSET - Static variable in class org.eclipse.jetty.util.ClassLoadingObjectInputStream.ClassLoaderThreadLocal
 
unsetJAASInfo(Subject) - Method in class org.eclipse.jetty.jaas.spi.AbstractLoginModule.JAASUser
 
unsetRunAs(Object) - Method in class org.eclipse.jetty.security.DefaultIdentityService
 
unsetRunAs(Object) - Method in interface org.eclipse.jetty.security.IdentityService
Disassociate the current runAsToken from the thread and reassociate the previous token.
UNSPEC - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
 
UNSPEC - Enum constant in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Protocol
 
unsupported() - Method in class org.eclipse.jetty.alpn.server.ALPNServerConnection
 
UNSUPPORTED_MEDIA_TYPE - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
UNSUPPORTED_MEDIA_TYPE_415 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
until(long) - Static method in class org.eclipse.jetty.util.NanoTime
Calculates the nanoseconds remaining from the current nanoTime until an end nanoTime.
unwrap() - Method in interface org.eclipse.jetty.io.EndPoint.Wrapper
 
unwrap() - Method in class org.eclipse.jetty.io.ssl.SslConnection.DecryptedEndPoint
 
unwrap() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
unwrap() - Method in class org.eclipse.jetty.util.Promise.Wrapper
 
unwrap(ServletRequest) - Static method in class org.eclipse.jetty.server.Request
 
unwrap(ServletResponse) - Static method in class org.eclipse.jetty.server.Response
 
unwrap(Throwable, Class<?>...) - Method in class org.eclipse.jetty.server.HttpChannel
Unwrap failure causes to find target class
unwrap(SSLEngine, ByteBuffer, ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
unwrap(Attributes) - Static method in interface org.eclipse.jetty.util.Attributes
Unwrap all Attributes.Wrappers of the attributes
unwrap(Attributes, Class<T>) - Static method in interface org.eclipse.jetty.util.Attributes
Unwrap attributes to a specific attribute Attributes.Wrapper.
unwrap(T) - Method in class org.eclipse.jetty.servlet.BaseHolder
 
UnwriteableSessionDataException - Exception Class in org.eclipse.jetty.server.session
UnwriteableSessionDataException
UnwriteableSessionDataException(String, SessionContext, Throwable) - Constructor for exception class org.eclipse.jetty.server.session.UnwriteableSessionDataException
 
update(String, Credential, String[]) - Method in interface org.eclipse.jetty.security.PropertyUserStore.UserListener
 
update(Selector) - Method in interface org.eclipse.jetty.io.ManagedSelector.SelectorUpdate
 
update(BaseHome, Props) - Method in class org.eclipse.jetty.start.StartIni
 
UPDATE - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
updateBean(Object, Object) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
updateBean(Object, Object, boolean) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
updateBean(String, Object, Object) - Method in class org.eclipse.jetty.server.handler.ManagedAttributeListener
 
updateBeans(Object[], Object[]) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
updateBeans(Collection<?>, Collection<?>) - Method in class org.eclipse.jetty.util.component.ContainerLifeCycle
 
updateClose(boolean, CloseState.Event) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
updateClose(boolean, CloseState.Event) - Method in interface org.eclipse.jetty.http2.IStream
Updates the close state of this stream.
updateHandlers(HandlerCollection.Handlers, HandlerCollection.Handlers) - Method in class org.eclipse.jetty.server.handler.HandlerCollection
 
updateInitialStreamWindow(ISession, int, boolean) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
updateInitialStreamWindow(ISession, int, boolean) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
updateKey() - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when all the keys selected by the ManagedSelector for this endpoint have been processed.
updateKey() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
updateLastRemoteStreamId(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
updateMappings() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
updateMax(AtomicInteger, int) - Static method in class org.eclipse.jetty.util.Atomics
 
updateMax(AtomicLong, long) - Static method in class org.eclipse.jetty.util.Atomics
 
updateMin(AtomicInteger, int) - Static method in class org.eclipse.jetty.util.Atomics
 
updateMin(AtomicLong, long) - Static method in class org.eclipse.jetty.util.Atomics
 
updateNameMappings() - Method in class org.eclipse.jetty.servlet.ServletHandler
 
updateRecvWindow(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
updateRecvWindow(int) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
updateRecvWindow(int) - Method in interface org.eclipse.jetty.http2.ISession
Updates the session receive window by the given delta.
updateRecvWindow(int) - Method in interface org.eclipse.jetty.http2.IStream
Updates the stream receive window by the given delta.
UPDATEREDIRECTREF - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
updateResponse(Request, boolean) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
updateResponseListeners(Response.ResponseListener) - Method in class org.eclipse.jetty.client.HttpConversation
Requests to update the response listener, eventually using the given override response listener, that must be notified instead of the first exchange response listeners.
updateSendWindow(int) - Method in class org.eclipse.jetty.http2.HTTP2Session
 
updateSendWindow(int) - Method in class org.eclipse.jetty.http2.HTTP2Stream
 
updateSendWindow(int) - Method in interface org.eclipse.jetty.http2.ISession
Updates the session send window by the given delta.
updateSendWindow(int) - Method in interface org.eclipse.jetty.http2.IStream
Updates the stream send window by the given delta.
upgrade() - Method in class org.eclipse.jetty.server.HttpChannelState
 
upgrade() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
upgrade() - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
upgrade() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
upgrade(HttpServletRequest, HttpServletResponse, Configuration.Customizer) - Method in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
upgrade(Class<T>) - Method in class org.eclipse.jetty.server.Request
 
upgrade(Class<T>) - Method in class org.eclipse.jetty.server.ServletRequestHttpWrapper
 
upgrade(Class<T>) - Method in class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
upgrade(Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.HttpConnectionOverHTTP2
 
upgrade(HttpResponse, EndPoint) - Method in class org.eclipse.jetty.websocket.client.impl.JettyClientUpgradeRequest
 
upgrade(HttpResponse, EndPoint) - Method in class org.eclipse.jetty.websocket.core.client.CoreClientUpgradeRequest
 
upgrade(HttpResponse, EndPoint, Callback) - Method in class org.eclipse.jetty.client.http.ProtocolHttpUpgrader
 
upgrade(HttpResponse, EndPoint, Callback) - Method in interface org.eclipse.jetty.client.HttpUpgrader
Upgrades the given endPoint to a different protocol.
upgrade(HttpResponse, EndPoint, Callback) - Method in class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP
 
upgrade(HttpResponse, EndPoint, Callback) - Method in class org.eclipse.jetty.websocket.core.client.internal.HttpUpgraderOverHTTP2
 
upgrade(MetaData.Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.http2.server.HTTP2ServerConnection
 
upgrade(Connection) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
upgrade(Connection) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
upgrade(Connection) - Method in interface org.eclipse.jetty.io.EndPoint
Upgrades this EndPoint from the current connection to the given new connection.
upgrade(Connection) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
upgrade(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.client.dynamic.HttpClientTransportDynamic
 
upgrade(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.http2.client.http.ClientConnectionFactoryOverHTTP2.HTTP2
 
upgrade(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
upgrade(JettyWebSocketCreator, HttpServletRequest, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.server.JettyWebSocketServerContainer
An immediate programmatic WebSocket upgrade that does not register a mapping or create a WebSocketUpgradeFilter.
UPGRADE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
UPGRADE - Enum constant in enum org.eclipse.jetty.http.HttpHeaderValue
 
UPGRADE_CONNECTION_ATTRIBUTE - Static variable in interface org.eclipse.jetty.server.HttpTransport
 
UPGRADE_REQUIRED - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
UPGRADE_REQUIRED_426 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
upgradeConnection(Connector, EndPoint, MetaData.Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.http2.server.HTTP2CServerConnectionFactory
 
upgradeConnection(Connector, EndPoint, MetaData.Request, HttpFields.Mutable) - Method in interface org.eclipse.jetty.server.ConnectionFactory.Upgrading
Create a connection for an upgrade request.
UPGRADED - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.State
 
UpgradeException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Exception during WebSocket Upgrade Handshake.
UpgradeException - Exception Class in org.eclipse.jetty.websocket.core.exception
Exception during WebSocket Upgrade Handshake.
UpgradeException(URI, int, String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
UpgradeException(URI, int, String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.UpgradeException
 
UpgradeException(URI, int, String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
UpgradeException(URI, int, String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.UpgradeException
 
UpgradeException(URI, int, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
UpgradeException(URI, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.UpgradeException
 
UpgradeException(URI, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.UpgradeException
 
UpgradeHttpServletRequest - Class in org.eclipse.jetty.websocket.core.server.internal
An immutable, feature limited, HttpServletRequest that will not be recycled by Jetty.
UpgradeHttpServletRequest(HttpServletRequest) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletRequest
 
UpgradeHttpServletResponse - Class in org.eclipse.jetty.websocket.core.server.internal
 
UpgradeHttpServletResponse(HttpServletResponse) - Constructor for class org.eclipse.jetty.websocket.core.server.internal.UpgradeHttpServletResponse
 
upgradeHttpToWebSocket(Object, Object, ServerEndpointConfig, Map<String, String>) - Method in class org.eclipse.jetty.websocket.jakarta.server.internal.JakartaWebSocketServerContainer
 
UpgradeListener - Interface in org.eclipse.jetty.websocket.core.client
 
upgradeProtocol(String) - Method in class org.eclipse.jetty.client.HttpRequest
 
UpgradeProtocolHandler - Class in org.eclipse.jetty.client
A protocol handler that handles HTTP 101 responses.
UpgradeProtocolHandler() - Constructor for class org.eclipse.jetty.client.UpgradeProtocolHandler
 
upgradeRequest(WebSocketNegotiator, HttpServletRequest, HttpServletResponse, WebSocketComponents, Configuration.Customizer) - Method in interface org.eclipse.jetty.websocket.core.server.Handshaker
 
upgradeRequest(WebSocketNegotiator, HttpServletRequest, HttpServletResponse, WebSocketComponents, Configuration.Customizer) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
upgradeRequest(WebSocketNegotiator, HttpServletRequest, HttpServletResponse, WebSocketComponents, Configuration.Customizer) - Method in class org.eclipse.jetty.websocket.core.server.internal.HandshakerSelector
 
UpgradeRequest - Interface in org.eclipse.jetty.websocket.api
The HTTP Upgrade to WebSocket Request
UpgradeRequest - Interface in org.eclipse.jetty.websocket.jakarta.common
 
UpgradeRequestAdapter - Class in org.eclipse.jetty.websocket.jakarta.common
 
UpgradeRequestAdapter() - Constructor for class org.eclipse.jetty.websocket.jakarta.common.UpgradeRequestAdapter
 
UpgradeRequestAdapter(URI, String) - Constructor for class org.eclipse.jetty.websocket.jakarta.common.UpgradeRequestAdapter
 
UpgradeResponse - Interface in org.eclipse.jetty.websocket.api
The HTTP Upgrade to WebSocket Response
upgradeToConnectionFactory(ConnectionFactory, Connector, EndPoint) - Static method in class org.eclipse.jetty.server.DetectorConnectionFactory
Utility method that performs an upgrade to the specified connection factory, disposing of the given resources when needed.
UpstreamConnection(EndPoint, Executor, ByteBufferPool, ConnectHandler.ConnectContext) - Constructor for class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
Uptime - Class in org.eclipse.jetty.util
Provide for a Uptime class that is compatible with Android, GAE, and the new Java 8 compact profiles
Uptime.DefaultImpl - Class in org.eclipse.jetty.util
 
Uptime.Impl - Interface in org.eclipse.jetty.util
 
uptimeMethod - Variable in class org.eclipse.jetty.util.Uptime.DefaultImpl
 
uri - Variable in class org.eclipse.jetty.start.FileArg
 
uri(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
uri(String, int, int) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
uri(String, String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
uri(HttpURI) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
URI - Enum constant in enum org.eclipse.jetty.http.HttpParser.State
 
URI_TOO_LONG - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
URI_TOO_LONG_414 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
UriCompliance - Class in org.eclipse.jetty.http
URI compliance modes for Jetty request handling.
UriCompliance(String, Set<UriCompliance.Violation>) - Constructor for class org.eclipse.jetty.http.UriCompliance
 
UriCompliance.Violation - Enum in org.eclipse.jetty.http
These are URI compliance "violations", which may be allowed by the compliance mode.
UriFileInitializer - Class in org.eclipse.jetty.start.fileinits
 
UriFileInitializer(StartArgs, BaseHome) - Constructor for class org.eclipse.jetty.start.fileinits.UriFileInitializer
 
UriTemplatePathSpec - Class in org.eclipse.jetty.http.pathmap
PathSpec for URI Template based declarations
UriTemplatePathSpec(String) - Constructor for class org.eclipse.jetty.http.pathmap.UriTemplatePathSpec
 
URIUtil - Class in org.eclipse.jetty.util
URI Utility methods.
URL_PREFIX - Static variable in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
UrlEncoded - Class in org.eclipse.jetty.util
Handles coding of MIME "x-www-form-urlencoded".
URLResource - Class in org.eclipse.jetty.util.resource
URL resource class.
URLResource(URL, URLConnection) - Constructor for class org.eclipse.jetty.util.resource.URLResource
 
URLResource(URL, URLConnection, boolean) - Constructor for class org.eclipse.jetty.util.resource.URLResource
 
usage() - Static method in class org.eclipse.jetty.session.infinispan.InfinispanSessionLegacyConverter
 
usage(boolean) - Method in class org.eclipse.jetty.start.Main
 
usage(String) - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
Generate helpful usage message and exit
UsageException - Exception Class in org.eclipse.jetty.start
A Usage Error has occurred.
UsageException(int, String) - Constructor for exception class org.eclipse.jetty.start.UsageException
 
UsageException(int, String, Object...) - Constructor for exception class org.eclipse.jetty.start.UsageException
 
UsageException(int, Throwable) - Constructor for exception class org.eclipse.jetty.start.UsageException
 
UsageException(String, Object...) - Constructor for exception class org.eclipse.jetty.start.UsageException
 
UsAsciiStringBuilder() - Constructor for class org.eclipse.jetty.util.CharsetStringBuilder.UsAsciiStringBuilder
 
use() - Method in class org.eclipse.jetty.server.session.Session
 
USE_CONTAINER_METAINF_CACHE - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
USE_KNOWN_CONTENT_LENGTH - Static variable in class org.eclipse.jetty.server.Response
 
USE_PROXY - Enum constant in enum org.eclipse.jetty.http.HttpStatus.Code
 
USE_PROXY_305 - Static variable in class org.eclipse.jetty.http.HttpStatus
 
user(String) - Method in class org.eclipse.jetty.http.HttpURI.Mutable
 
User(String, Credential, String[]) - Constructor for class org.eclipse.jetty.security.UserStore.User
 
USER_AGENT - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
USER_AGENT - Static variable in class org.eclipse.jetty.client.HttpClient
 
USER_TRANSACTION - Static variable in class org.eclipse.jetty.plus.jndi.Transaction
 
UserAuthentication - Class in org.eclipse.jetty.security
 
UserAuthentication(String, UserIdentity) - Constructor for class org.eclipse.jetty.security.UserAuthentication
 
UserDataConstraint - Enum in org.eclipse.jetty.security
 
UserIdentity - Interface in org.eclipse.jetty.server
User object that encapsulates user identity and operations such as run-as-role actions, checking isUserInRole and getUserPrincipal.
UserIdentity.Scope - Interface in org.eclipse.jetty.server
A UserIdentity Scope.
UserIdentity.UnauthenticatedUserIdentity - Interface in org.eclipse.jetty.server
 
UsernamePasswordAuthenticationFactory(String, String) - Constructor for class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
UsernamePasswordAuthenticationFactory(String, String, Charset) - Constructor for class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
UserPrincipal - Class in org.eclipse.jetty.security
UserPrincipal Represents a user with a credential.
UserPrincipal(String, Credential) - Constructor for class org.eclipse.jetty.security.UserPrincipal
 
UserStore - Class in org.eclipse.jetty.security
Store of user authentication and authorization information.
UserStore() - Constructor for class org.eclipse.jetty.security.UserStore
 
UserStore.User - Class in org.eclipse.jetty.security
 
UTF16_ENCODINGS - Enum constant in enum org.eclipse.jetty.http.UriCompliance.Violation
Allow UTF-16 encoding eg /foo%u2192bar.
Utf8Appendable - Class in org.eclipse.jetty.util
Utf8 Appendable abstract base class This abstract class wraps a standard Appendable and provides methods to append UTF-8 encoded bytes, that are converted into characters.
Utf8Appendable(Appendable) - Constructor for class org.eclipse.jetty.util.Utf8Appendable
 
Utf8Appendable.NotUtf8Exception - Exception Class in org.eclipse.jetty.util
 
Utf8HttpWriter - Class in org.eclipse.jetty.server
OutputWriter.
Utf8HttpWriter(HttpOutput) - Constructor for class org.eclipse.jetty.server.Utf8HttpWriter
 
Utf8LineParser - Class in org.eclipse.jetty.util
Stateful parser for lines of UTF8 formatted text, looking for "\n" as a line termination character.
Utf8LineParser() - Constructor for class org.eclipse.jetty.util.Utf8LineParser
 
Utf8StringBuffer - Class in org.eclipse.jetty.util
UTF-8 StringBuffer.
Utf8StringBuffer() - Constructor for class org.eclipse.jetty.util.Utf8StringBuffer
 
Utf8StringBuffer(int) - Constructor for class org.eclipse.jetty.util.Utf8StringBuffer
 
Utf8StringBuilder - Class in org.eclipse.jetty.util
UTF-8 StringBuilder.
Utf8StringBuilder() - Constructor for class org.eclipse.jetty.util.Utf8StringBuilder
 
Utf8StringBuilder(int) - Constructor for class org.eclipse.jetty.util.Utf8StringBuilder
 
Util - Class in org.eclipse.jetty.osgi.boot.utils
Various useful functions utility methods for OSGi wide use.
Util() - Constructor for class org.eclipse.jetty.osgi.boot.utils.Util
 
Utils - Class in org.eclipse.jetty.start
 
Utils() - Constructor for class org.eclipse.jetty.start.Utils
 

V

V1(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V1
 
V2(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2
 
VALID - Enum constant in enum org.eclipse.jetty.server.session.Session.State
 
validate(Class<?>, Method) - Method in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
validate(Class<?>, Method) - Method in class org.eclipse.jetty.plus.annotation.PostConstructCallback
Commons Annotation Specification section 2.5 - no params - must be void return - no checked exceptions - cannot be static
validate(Class<?>, Method) - Method in class org.eclipse.jetty.plus.annotation.PreDestroyCallback
Commons Annotations Specification section 2.6: - no params to method - returns void - no checked exceptions - not static
validate(Certificate[]) - Method in class org.eclipse.jetty.util.security.CertificateValidator
 
validate(KeyStore) - Method in class org.eclipse.jetty.util.security.CertificateValidator
validates all aliases inside of a given keystore
validate(KeyStore, String) - Method in class org.eclipse.jetty.util.security.CertificateValidator
validates a specific alias inside of the keystore being passed in
validate(KeyStore, Certificate) - Method in class org.eclipse.jetty.util.security.CertificateValidator
validates a specific certificate inside of the keystore being passed in
validate(UserIdentity) - Method in class org.eclipse.jetty.jaas.JAASLoginService
 
validate(UserIdentity) - Method in class org.eclipse.jetty.security.AbstractLoginService
 
validate(UserIdentity) - Method in class org.eclipse.jetty.security.ConfigurableSpnegoLoginService
 
validate(UserIdentity) - Method in class org.eclipse.jetty.security.EmptyLoginService
 
validate(UserIdentity) - Method in interface org.eclipse.jetty.security.LoginService
Validate a user identity.
validate(UserIdentity) - Method in class org.eclipse.jetty.security.openid.OpenIdLoginService
 
VALIDATE_XML - Static variable in class org.eclipse.jetty.webapp.MetaData
 
validateCerts(X509Certificate[]) - Method in class org.eclipse.jetty.util.ssl.SslContextFactory
 
validateDestination(String, int) - Method in class org.eclipse.jetty.proxy.AbstractProxyServlet
Checks the given host and port against whitelist and blacklist.
validateDestination(String, int) - Method in class org.eclipse.jetty.proxy.BalancerServlet
 
validateDestination(String, int) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Checks the given host and port against whitelist and blacklist.
validateFrameHandler(FrameHandler, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
validateFrameHandler(FrameHandler, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
validateFrameHandler(FrameHandler, HttpServletResponse) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
validateHeaders() - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Negotiation
 
validateHeaders() - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Negotiation
 
validateHeaders() - Method in class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
validateMethod(String) - Static method in class org.eclipse.jetty.util.security.Constraint
 
validateNegotiation(WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
validateNegotiation(WebSocketNegotiation) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
validateRequest(MessageInfo, Subject, Subject) - Method in class org.eclipse.jetty.security.jaspi.modules.BasicAuthenticationAuthModule
 
validateRequest(HttpServletRequest) - Method in class org.eclipse.jetty.websocket.core.server.internal.AbstractHandshaker
 
validateRequest(HttpServletRequest) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC6455Handshaker
 
validateRequest(HttpServletRequest) - Method in class org.eclipse.jetty.websocket.core.server.internal.RFC8441Handshaker
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.BasicAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.ClientCertAuthenticator
Deprecated.
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.ConfigurableSpnegoAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.DigestAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.authentication.SslClientCertAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in interface org.eclipse.jetty.security.Authenticator
Validate a request
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
validateRequest(ServletRequest, ServletResponse, boolean) - Method in class org.eclipse.jetty.security.openid.OpenIdAuthenticator
 
validateRequest(JaspiMessageInfo) - Method in class org.eclipse.jetty.security.jaspi.JaspiAuthenticator
 
validateType(Class<?>) - Static method in class org.eclipse.jetty.websocket.jakarta.server.internal.PathParamIdentifier
The JSR356 rules for @PathParam only support String, Primitive Types (and their Boxed version)
ValidatingConnectionPool - Class in org.eclipse.jetty.client
A connection pool that validates connections before making them available for use.
ValidatingConnectionPool(HttpDestination, int, Callback, Scheduler, long) - Constructor for class org.eclipse.jetty.client.ValidatingConnectionPool
 
ValidationExtension - Class in org.eclipse.jetty.websocket.core.internal
 
ValidationExtension() - Constructor for class org.eclipse.jetty.websocket.core.internal.ValidationExtension
 
ValidUrlRule - Class in org.eclipse.jetty.rewrite.handler
This rule can be used to protect against invalid unicode characters in a url making it into applications.
ValidUrlRule() - Constructor for class org.eclipse.jetty.rewrite.handler.ValidUrlRule
 
value - Variable in class org.eclipse.jetty.start.Props.Prop
 
value() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedAttribute
Description of the Managed Attribute
value() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedObject
Description of the Managed Object
value() - Element in annotation type org.eclipse.jetty.util.annotation.ManagedOperation
Description of the Managed Object
value() - Element in annotation type org.eclipse.jetty.util.annotation.Name
the name of the parameter
VALUE - Enum constant in enum org.eclipse.jetty.http.HttpParser.FieldState
 
VALUE - Enum constant in enum org.eclipse.jetty.server.MultiPartParser.FieldState
 
valueOf(Class<?>, String) - Static method in class org.eclipse.jetty.util.TypeUtil
Convert String value to instance.
valueOf(Object) - Static method in class org.eclipse.jetty.util.StringUtil
The String value of an Object
valueOf(String) - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Command
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.fcgi.FCGI.FrameType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.fcgi.FCGI.Role
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.fcgi.FCGI.StreamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.fcgi.parser.ContentParser.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.eclipse.jetty.http.CookieCompliance
 
valueOf(String) - Static method in enum org.eclipse.jetty.http.CookieCompliance.Violation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.eclipse.jetty.http.HttpCompliance
Get a known compliance mode by name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpCompliance.Violation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpCookie.SameSite
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpGenerator.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpGenerator.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpHeader
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpHeaderValue
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpParser.FieldState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpParser.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpScheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpStatus.Code
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpTokens.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.HttpVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.MimeTypes.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class org.eclipse.jetty.http.UriCompliance
 
valueOf(String) - Static method in enum org.eclipse.jetty.http.UriCompliance.Violation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http2.CloseState.Event
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http2.CloseState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http2.ErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http2.frames.FrameType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.http3.frames.FrameType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.logging.JettyLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.quic.common.StreamType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.quickstart.QuickStartConfiguration.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.security.UserDataConstraint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.handler.ContextHandler.ContextStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.HttpChannelState.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.HttpChannelState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.MultiPartFormDataCompliance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.MultiPartParser.FieldState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.MultiPartParser.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.MultiParts.NonCompliance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.Response.OutputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.session.Session.IdState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.server.session.Session.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.servlet.ServletHolder.JspContainer
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.servlet.Source.Origin
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.IteratingCallback.Action
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.PathWatcher.DirAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.Pool.StrategyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.util.thread.Invocable.InvocationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.webapp.FragmentDescriptor.OtherType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.webapp.MetaData.Complete
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.webapp.Origin
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.websocket.api.BatchMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.websocket.api.Frame.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.websocket.api.WebSocketBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.eclipse.jetty.websocket.core.Behavior
Returns the enum constant of this type with the specified name.
valueOf(String, String) - Static method in class org.eclipse.jetty.util.TypeUtil
Convert String value to instance.
valueParameters(String, Map<String, String>) - Static method in class org.eclipse.jetty.http.HttpField
 
values() - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Command
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Family
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.V2.Tag.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.fcgi.FCGI.FrameType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.fcgi.FCGI.Role
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.fcgi.FCGI.StreamType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.fcgi.parser.ContentParser.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.CookieCompliance.Violation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpCompliance.Violation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpCookie.SameSite
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpGenerator.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpGenerator.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpHeader
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpHeaderValue
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpParser.FieldState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpParser.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpScheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpStatus.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpTokens.EndOfContent
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpTokens.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.HttpVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.MimeTypes.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.pathmap.PathSpecGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http.UriCompliance.Violation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http2.CloseState.Event
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http2.CloseState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http2.ErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http2.frames.FrameType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.http3.frames.FrameType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.logging.JettyLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.quic.common.StreamType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.quickstart.QuickStartConfiguration.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.security.UserDataConstraint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.handler.ContextHandler.Availability
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.handler.ContextHandler.ContextStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.HttpChannelState.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.HttpChannelState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.MultiPartFormDataCompliance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.MultiPartParser.FieldState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.MultiPartParser.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.MultiParts.NonCompliance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.Response.OutputType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.session.Session.IdState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.server.session.Session.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.servlet.ServletHolder.JspContainer
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.servlet.Source.Origin
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.util.IteratingCallback.Action
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.util.PathWatcher.DirAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.util.PathWatcher.PathWatchEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.util.Pool.StrategyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.jetty.util.Pool
 
values() - Static method in enum org.eclipse.jetty.util.ReadLineInputStream.Termination
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.util.thread.Invocable.InvocationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.webapp.FragmentDescriptor.OtherType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.webapp.MetaData.Complete
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.webapp.Origin
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.websocket.api.BatchMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.websocket.api.Frame.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.websocket.api.WebSocketBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.eclipse.jetty.websocket.core.Behavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.eclipse.jetty.websocket.jakarta.common.PutListenerMap
 
VARY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
VARY_ACCEPT_ENCODING - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
VCHAR - Enum constant in enum org.eclipse.jetty.http.HttpTokens.Type
 
version - Variable in class org.eclipse.jetty.start.fileinits.MavenLocalRepoFileInitializer.Coordinates
 
version() - Method in class org.eclipse.jetty.runner.Runner
Deprecated.
Generate version message and exit
version(HttpVersion) - Method in interface org.eclipse.jetty.client.api.Request
 
version(HttpVersion) - Method in class org.eclipse.jetty.client.HttpRequest
 
version(HttpVersion) - Method in class org.eclipse.jetty.client.HttpResponse
 
Version - Class in org.eclipse.jetty.start
Utility class for parsing and comparing version strings.
Version(String) - Constructor for class org.eclipse.jetty.start.Version
 
VERSION - Static variable in class org.eclipse.jetty.client.Socks5.UsernamePasswordAuthenticationFactory
 
VERSION - Static variable in class org.eclipse.jetty.client.Socks5
The SOCKS protocol version: 0x5.
VERSION - Static variable in class org.eclipse.jetty.start.StartArgs
 
VERSION - Static variable in class org.eclipse.jetty.util.JavaVersion
 
VERSION - Static variable in class org.eclipse.jetty.util.Jetty
 
VERSION_CONTROL - Enum constant in enum org.eclipse.jetty.http.HttpMethod
 
VHOST - Static variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
VIA - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
VIOLATIONS_ATTR - Static variable in class org.eclipse.jetty.http.HttpCompliance
The request attribute which may be set to record any allowed HTTP violations.
VirtualHostRuleContainer - Class in org.eclipse.jetty.rewrite.handler
Groups rules that apply only to a specific virtual host or sets of virtual hosts
VirtualHostRuleContainer() - Constructor for class org.eclipse.jetty.rewrite.handler.VirtualHostRuleContainer
 
VirtualThreads - Class in org.eclipse.jetty.util
Utility class to use to query the runtime for virtual thread support, and, if virtual threads are supported, to start virtual threads.
VirtualThreads.Configurable - Interface in org.eclipse.jetty.util
Implementations of this interface can be configured to use virtual threads.
visit(int, int, String, String, String, String[]) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyClassVisitor
 
visit(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
visitAnnotation(String, boolean) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyClassVisitor
Visit an annotation on a Class
visitAnnotation(String, boolean) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyFieldVisitor
Parse an annotation found on a Field.
visitAnnotation(String, boolean) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyMethodVisitor
We are only interested in finding the annotations on methods.
visitContainerInitializer(WebAppContext, ContainerInitializer) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
Deprecated.
visitContextParam(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
Process a context-param element
visitContextParam(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitDefaultContextPath(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
When specified, this element provides a default context path of the web application.
visitDenyUncoveredHttpMethods(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
Servlet spec 3.1.
visitDisplayName(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitEnvEntry(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
JavaEE 5.4.1.3
visitErrorPage(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitField(int, String, String, String, Object) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyClassVisitor
Visit a field to extract its annotations
visitFile(Path, BasicFileAttributes) - Method in class org.eclipse.jetty.start.PathFinder
 
visitFileFailed(Path, IOException) - Method in class org.eclipse.jetty.start.PathFinder
 
visitFilter(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitFilterMapping(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitJspConfig(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitListener(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitLocaleEncodingList(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitLoginConfig(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitMessageDestinationRef(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Common Annotations Spec section 2.3:
visitMetaInfResource(WebAppContext, Resource) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
 
visitMethod(int, String, String, String, String[]) - Method in class org.eclipse.jetty.annotations.AnnotationParser.MyClassVisitor
Visit a method to extract its annotations
visitMimeMapping(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitPostConstruct(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
If web.xml has at least 1 post-construct, then all post-constructs in fragments are ignored.
visitPreDestroy(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
pre-destroy is the name of a class and method to call just as the instance is being destroyed
visitRequestCharacterEncoding(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
When specified, this element provides a default request encoding of the web application.
visitResourceEnvRef(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Common Annotations Spec section 2.3:
visitResourceRef(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.plus.webapp.PlusDescriptorProcessor
Common Annotations Spec section 2.3:
visitResponseCharacterEncoding(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
When specified, this element provides a default response encoding of the web application.
visitSecurityConstraint(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitSecurityRole(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitServlet(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitServletContainerInitializerHolder(WebAppContext, ServletContainerInitializerHolder) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
Ensure the ServletContainerInitializerHolder will be started by adding it to the context.
visitServletMapping(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.quickstart.QuickStartDescriptorProcessor
Process a servlet-mapping element
visitServletMapping(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitSessionConfig(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitTagLib(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 
visitWelcomeFileList(WebAppContext, Descriptor, XmlParser.Node) - Method in class org.eclipse.jetty.webapp.StandardDescriptorProcessor
 

W

WAIT - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
waitForOutput(long, TimeUnit) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
Wait for some output
waitForResponse(boolean, long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
Wait for a response using a parser to detect the end of message
WAITING - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.State
 
waitUntilClosed() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
waitUntilClosedOrIdleFor(long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
warn(Object) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
warn(Object, Throwable) - Method in class org.eclipse.jetty.apache.jsp.JuliLog
 
warn(String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(String, Object...) - Static method in class org.eclipse.jetty.start.StartLog
 
warn(String, Object...) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Formats and logs at warn level.
warn(String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(String, Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given message at warn level, with Throwable information.
warn(Throwable) - Static method in class org.eclipse.jetty.start.StartLog
 
warn(Throwable) - Method in interface org.eclipse.jetty.util.log.Logger
Deprecated.
Logs the given Throwable information at warn level
warn(Marker, String) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(Marker, String, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(Marker, String, Object...) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(Marker, String, Object, Object) - Method in class org.eclipse.jetty.logging.JettyLogger
 
warn(Marker, String, Throwable) - Method in class org.eclipse.jetty.logging.JettyLogger
 
WARN - Enum constant in enum org.eclipse.jetty.logging.JettyLevel
 
WARNING - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
watch(Path) - Method in class org.eclipse.jetty.util.PathWatcher
Request watch on a the given path (either file or dir) using all Config defaults.
watch(PathWatcher.Config) - Method in class org.eclipse.jetty.util.PathWatcher
Request watch on a path with custom Config provided.
WATCH - Enum constant in enum org.eclipse.jetty.util.PathWatcher.DirAction
 
WATERMARK - Static variable in class org.eclipse.jetty.osgi.boot.OSGiWebappConstants
 
WEB_DEFAULTS_XML - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
WebAppClassLoader - Class in org.eclipse.jetty.webapp
ClassLoader for HttpContext.
WebAppClassLoader(ClassLoader, WebAppClassLoader.Context) - Constructor for class org.eclipse.jetty.webapp.WebAppClassLoader
Constructor.
WebAppClassLoader(WebAppClassLoader.Context) - Constructor for class org.eclipse.jetty.webapp.WebAppClassLoader
Constructor.
WebAppClassLoader.Context - Interface in org.eclipse.jetty.webapp
The Context in which the classloader operates.
WebAppConfiguration - Class in org.eclipse.jetty.webapp
WebApp Configuration
WebAppConfiguration() - Constructor for class org.eclipse.jetty.webapp.WebAppConfiguration
 
WebAppContext - Class in org.eclipse.jetty.webapp
Web Application Context Handler.
WebAppContext() - Constructor for class org.eclipse.jetty.webapp.WebAppContext
 
WebAppContext(String, String) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
 
WebAppContext(HandlerContainer, String, String) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
 
WebAppContext(HandlerContainer, String, SessionHandler, SecurityHandler, ServletHandler, ErrorHandler, int) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
This constructor is used in the geronimo integration.
WebAppContext(HandlerContainer, Resource, String) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
 
WebAppContext(SessionHandler, SecurityHandler, ServletHandler, ErrorHandler) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
This constructor is used in the geronimo integration.
WebAppContext(Resource, String) - Constructor for class org.eclipse.jetty.webapp.WebAppContext
 
WebAppContext.Context - Class in org.eclipse.jetty.webapp
 
WebAppPathNameMatcher(WebAppContext, String) - Constructor for class org.eclipse.jetty.webapp.MetaInfConfiguration.WebAppPathNameMatcher
 
WebAppProvider - Class in org.eclipse.jetty.deploy.providers
The webapps directory scanning provider.
WebAppProvider() - Constructor for class org.eclipse.jetty.deploy.providers.WebAppProvider
 
WebAppProvider.Filter - Class in org.eclipse.jetty.deploy.providers
 
WebAppProviderMBean - Class in org.eclipse.jetty.deploy.providers.jmx
 
WebAppProviderMBean(Object) - Constructor for class org.eclipse.jetty.deploy.providers.jmx.WebAppProviderMBean
 
WebAppScannerListener(AntWebAppContext) - Constructor for class org.eclipse.jetty.ant.ServerProxyImpl.WebAppScannerListener
 
WebAppTracker(BundleContext, String) - Constructor for class org.eclipse.jetty.osgi.boot.BundleWebAppProvider.WebAppTracker
 
WebAppTracker(BundleContext, Filter) - Constructor for class org.eclipse.jetty.osgi.boot.ServiceWebAppProvider.WebAppTracker
 
WebDefaults - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
WebDescriptor - Class in org.eclipse.jetty.webapp
Descriptor A web descriptor (web.xml/web-defaults.xml/web-overrides.xml).
WebDescriptor(Resource) - Constructor for class org.eclipse.jetty.webapp.WebDescriptor
 
WebFilterAnnotation - Class in org.eclipse.jetty.annotations
WebFilterAnnotation
WebFilterAnnotation(WebAppContext, String) - Constructor for class org.eclipse.jetty.annotations.WebFilterAnnotation
 
WebFilterAnnotation(WebAppContext, String, Resource) - Constructor for class org.eclipse.jetty.annotations.WebFilterAnnotation
 
WebFilterAnnotationHandler - Class in org.eclipse.jetty.annotations
WebFilterAnnotationHandler
WebFilterAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.WebFilterAnnotationHandler
 
WebFragment - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
WEBINF_JAR_PATTERN - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
WebInfConfiguration - Class in org.eclipse.jetty.webapp
 
WebInfConfiguration() - Constructor for class org.eclipse.jetty.webapp.WebInfConfiguration
 
WebListenerAnnotation - Class in org.eclipse.jetty.annotations
WebListenerAnnotation
WebListenerAnnotation(WebAppContext, String) - Constructor for class org.eclipse.jetty.annotations.WebListenerAnnotation
 
WebListenerAnnotation(WebAppContext, String, Resource) - Constructor for class org.eclipse.jetty.annotations.WebListenerAnnotation
 
WebListenerAnnotationHandler - Class in org.eclipse.jetty.annotations
 
WebListenerAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.WebListenerAnnotationHandler
 
WebOverride - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
WebServletAnnotation - Class in org.eclipse.jetty.annotations
WebServletAnnotation
WebServletAnnotation(WebAppContext, String) - Constructor for class org.eclipse.jetty.annotations.WebServletAnnotation
 
WebServletAnnotation(WebAppContext, String, Resource) - Constructor for class org.eclipse.jetty.annotations.WebServletAnnotation
 
WebServletAnnotationHandler - Class in org.eclipse.jetty.annotations
WebServletAnnotationHandler Process a WebServlet annotation on a class.
WebServletAnnotationHandler(WebAppContext) - Constructor for class org.eclipse.jetty.annotations.WebServletAnnotationHandler
 
WebSocket - Annotation Type in org.eclipse.jetty.websocket.api.annotations
Tags a POJO as being a WebSocket class.
WEBSOCKET_BUFFER_POOL_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
 
WEBSOCKET_COMPONENTS_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
 
WEBSOCKET_CORECLIENT_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
WEBSOCKET_DEFLATER_POOL_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
 
WEBSOCKET_INFLATER_POOL_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.server.WebSocketServerComponents
 
WEBSOCKET_MAPPING_ATTRIBUTE - Static variable in class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
WebSocketAdapter - Class in org.eclipse.jetty.websocket.api
Default implementation of the WebSocketListener.
WebSocketAdapter() - Constructor for class org.eclipse.jetty.websocket.api.WebSocketAdapter
 
WebSocketBehavior - Enum in org.eclipse.jetty.websocket.api
Behavior for how the WebSocket should operate.
WebSocketClient - Class in org.eclipse.jetty.websocket.client
 
WebSocketClient() - Constructor for class org.eclipse.jetty.websocket.client.WebSocketClient
Instantiates a WebSocketClient with a default HttpClient.
WebSocketClient(HttpClient) - Constructor for class org.eclipse.jetty.websocket.client.WebSocketClient
Instantiates a WebSocketClient with the given HttpClient.
WebSocketComponents - Class in org.eclipse.jetty.websocket.core
A collection of components which are the resources needed for websockets such as ByteBufferPool, WebSocketExtensionRegistry, and DecoratedObjectFactory.
WebSocketComponents() - Constructor for class org.eclipse.jetty.websocket.core.WebSocketComponents
 
WebSocketComponents(WebSocketExtensionRegistry, DecoratedObjectFactory, ByteBufferPool, InflaterPool, DeflaterPool) - Constructor for class org.eclipse.jetty.websocket.core.WebSocketComponents
 
WebSocketComponents(WebSocketExtensionRegistry, DecoratedObjectFactory, ByteBufferPool, InflaterPool, DeflaterPool, Executor) - Constructor for class org.eclipse.jetty.websocket.core.WebSocketComponents
 
WebSocketConnection - Class in org.eclipse.jetty.websocket.core.internal
Provides the implementation of Connection that is suitable for WebSocket
WebSocketConnection(EndPoint, Executor, Scheduler, ByteBufferPool, RetainableByteBufferPool, WebSocketCoreSession) - Constructor for class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Create a WSConnection.
WebSocketConnection(EndPoint, Executor, Scheduler, ByteBufferPool, RetainableByteBufferPool, WebSocketCoreSession, Random) - Constructor for class org.eclipse.jetty.websocket.core.internal.WebSocketConnection
Create a WSConnection.
WebSocketConnectionListener - Interface in org.eclipse.jetty.websocket.api
Core WebSocket Connection Listener
WebSocketConstants - Class in org.eclipse.jetty.websocket.api.util
 
WebSocketConstants - Class in org.eclipse.jetty.websocket.core
 
WebSocketConstants() - Constructor for class org.eclipse.jetty.websocket.api.util.WebSocketConstants
 
WebSocketContainer - Interface in org.eclipse.jetty.websocket.api
Generic interface to the Container (server or client)
WebSocketCore - Class in org.eclipse.jetty.websocket.core.internal
 
WebSocketCore() - Constructor for class org.eclipse.jetty.websocket.core.internal.WebSocketCore
 
WebSocketCoreClient - Class in org.eclipse.jetty.websocket.core.client
 
WebSocketCoreClient() - Constructor for class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
WebSocketCoreClient(HttpClient, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
WebSocketCoreClient(WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.client.WebSocketCoreClient
 
WebSocketCoreSession - Class in org.eclipse.jetty.websocket.core.internal
The Core WebSocket Session.
WebSocketCoreSession(FrameHandler, Behavior, Negotiated, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.internal.WebSocketCoreSession
 
WebSocketCreator - Interface in org.eclipse.jetty.websocket.core.server
Abstract WebSocket creator interface.
WebSocketException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
A recoverable exception within the websocket framework.
WebSocketException - Exception Class in org.eclipse.jetty.websocket.core.exception
A recoverable exception within the websocket framework.
WebSocketException() - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketException
 
WebSocketException() - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketException
 
WebSocketException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketException
 
WebSocketException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketException
 
WebSocketException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketException
 
WebSocketException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketException
 
WebSocketException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketException
 
WebSocketException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketException
 
WebSocketExtensionRegistry - Class in org.eclipse.jetty.websocket.core
 
WebSocketExtensionRegistry() - Constructor for class org.eclipse.jetty.websocket.core.WebSocketExtensionRegistry
 
WebSocketFrameListener - Interface in org.eclipse.jetty.websocket.api
WebSocket Frame Listener interface for incoming WebSocket frames.
WebSocketListener - Interface in org.eclipse.jetty.websocket.api
Basic WebSocket Listener interface for incoming WebSocket message events.
WebSocketMappings - Class in org.eclipse.jetty.websocket.core.server
Mapping of pathSpec to a tupple of WebSocketCreator, FrameHandlerFactory and Configuration.Customizer.
WebSocketMappings() - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
WebSocketMappings(WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketMappings
 
WebSocketNegotiation - Class in org.eclipse.jetty.websocket.core.server
 
WebSocketNegotiation(Request, HttpServletRequest, HttpServletResponse, WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketNegotiation
 
WebSocketNegotiator - Interface in org.eclipse.jetty.websocket.core.server
 
WebSocketNegotiator.AbstractNegotiator - Class in org.eclipse.jetty.websocket.core.server
 
WebSocketPartialListener - Interface in org.eclipse.jetty.websocket.api
WebSocket Partial Message Listener interface for incoming WebSocket TEXT/BINARY/CONTINUATION frames.
WebSocketPingPongListener - Interface in org.eclipse.jetty.websocket.api
WebSocket PING/PONG Listener interface for incoming WebSocket PING/PONG frames.
WebSocketPolicy - Interface in org.eclipse.jetty.websocket.api
Settings for WebSocket operations.
WebSocketServerComponents - Class in org.eclipse.jetty.websocket.core.server
A collection of components which are the resources needed for websockets such as ByteBufferPool, WebSocketExtensionRegistry, and DecoratedObjectFactory.
WebSocketSession - Class in org.eclipse.jetty.websocket.common
 
WebSocketSession(WebSocketContainer, CoreSession, JettyWebSocketFrameHandler) - Constructor for class org.eclipse.jetty.websocket.common.WebSocketSession
 
WebSocketSessionListener - Interface in org.eclipse.jetty.websocket.api
Interface for Listeners that are interested in knowing about the Session history.
WebSocketSessionState - Class in org.eclipse.jetty.websocket.core.internal
Atomic Connection State
WebSocketSessionState() - Constructor for class org.eclipse.jetty.websocket.core.internal.WebSocketSessionState
 
WebSocketTimeoutException - Exception Class in org.eclipse.jetty.websocket.api.exceptions
Exception thrown to indicate a connection I/O timeout.
WebSocketTimeoutException - Exception Class in org.eclipse.jetty.websocket.core.exception
Exception thrown to indicate a connection I/O timeout.
WebSocketTimeoutException(String) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketTimeoutException
 
WebSocketTimeoutException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketTimeoutException
 
WebSocketTimeoutException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketTimeoutException
 
WebSocketTimeoutException(String, Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketTimeoutException
 
WebSocketTimeoutException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.api.exceptions.WebSocketTimeoutException
 
WebSocketTimeoutException(Throwable) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketTimeoutException
 
WebSocketUpgradeFilter - Class in org.eclipse.jetty.websocket.servlet
Inline Servlet Filter to capture WebSocket upgrade requests.
WebSocketUpgradeFilter() - Constructor for class org.eclipse.jetty.websocket.servlet.WebSocketUpgradeFilter
 
WebSocketUpgradeHandler - Class in org.eclipse.jetty.websocket.core.server
 
WebSocketUpgradeHandler() - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
WebSocketUpgradeHandler(WebSocketComponents) - Constructor for class org.eclipse.jetty.websocket.core.server.WebSocketUpgradeHandler
 
WebSocketWriteTimeoutException - Exception Class in org.eclipse.jetty.websocket.core.exception
 
WebSocketWriteTimeoutException(String) - Constructor for exception class org.eclipse.jetty.websocket.core.exception.WebSocketWriteTimeoutException
 
WebXml - Enum constant in enum org.eclipse.jetty.webapp.Origin
 
WebXmlConfiguration - Class in org.eclipse.jetty.webapp
Configure by parsing default web.xml and web.xml
WebXmlConfiguration() - Constructor for class org.eclipse.jetty.webapp.WebXmlConfiguration
 
WHITESPACE_AFTER_FIELD_NAME - Enum constant in enum org.eclipse.jetty.http.HttpCompliance.Violation
Since RFC 7230, the HTTP protocol has required that a request header field has no white space after the field name and before the ':'.
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.BooleanDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.CharacterDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.DoubleDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.FloatDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.IntegerDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.LongDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ShortDecoder
 
willDecode(String) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.StringDecoder
 
willDecode(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteArrayDecoder
 
willDecode(ByteBuffer) - Method in class org.eclipse.jetty.websocket.jakarta.common.decoders.ByteBufferDecoder
 
willPassivate() - Method in class org.eclipse.jetty.server.session.Session
Call the passivation listeners.
window(IStream, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.HTTP2Flusher
 
WINDOW_UPDATE - Enum constant in enum org.eclipse.jetty.http2.frames.FrameType
 
WINDOW_UPDATE_LENGTH - Static variable in class org.eclipse.jetty.http2.frames.WindowUpdateFrame
 
WindowRateControl - Class in org.eclipse.jetty.http2.parser
An implementation of RateControl that limits the number of events within a time period.
WindowRateControl(int, Duration) - Constructor for class org.eclipse.jetty.http2.parser.WindowRateControl
 
WindowRateControl.Factory - Class in org.eclipse.jetty.http2.parser
 
windowUpdate(ISession, IStream, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.AbstractFlowControlStrategy
 
windowUpdate(ISession, IStream, WindowUpdateFrame) - Method in class org.eclipse.jetty.http2.BufferingFlowControlStrategy
 
windowUpdate(ISession, IStream, WindowUpdateFrame) - Method in interface org.eclipse.jetty.http2.FlowControlStrategy
 
WindowUpdateBodyParser - Class in org.eclipse.jetty.http2.parser
 
WindowUpdateBodyParser(HeaderParser, Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.WindowUpdateBodyParser
 
WindowUpdateFrame - Class in org.eclipse.jetty.http2.frames
 
WindowUpdateFrame(int, int) - Constructor for class org.eclipse.jetty.http2.frames.WindowUpdateFrame
 
WindowUpdateGenerator - Class in org.eclipse.jetty.http2.generator
 
WindowUpdateGenerator(HeaderGenerator) - Constructor for class org.eclipse.jetty.http2.generator.WindowUpdateGenerator
 
with(String, HttpCompliance.Violation...) - Method in class org.eclipse.jetty.http.HttpCompliance
Create a new HttpCompliance mode that includes the passed HttpCompliance.Violations.
with(String, UriCompliance.Violation...) - Method in class org.eclipse.jetty.http.UriCompliance
Create a new UriCompliance mode that includes the passed UriCompliance.Violations.
with(String, V) - Method in class org.eclipse.jetty.util.Index.Builder
Configure a pre-existing entry.
with(V) - Method in class org.eclipse.jetty.util.Index.Builder
Configure a pre-existing entry with a key that is the Index.Builder.toString() representation of the value.
withAll(Supplier<Map<String, V>>) - Method in class org.eclipse.jetty.util.Index.Builder
Configure some pre-existing entries.
withAll(V[], Function<V, String>) - Method in class org.eclipse.jetty.util.Index.Builder
Configure some pre-existing entries.
WithCondition() - Constructor for class org.eclipse.jetty.util.thread.AutoLock.WithCondition
 
without(String, HttpCompliance.Violation...) - Method in class org.eclipse.jetty.http.HttpCompliance
Create a new HttpCompliance mode that excludes the passed HttpCompliance.Violations.
without(String, UriCompliance.Violation...) - Method in class org.eclipse.jetty.http.UriCompliance
Create a new UriCompliance mode that excludes the passed UriCompliance.Violations.
withStreamId(int) - Method in class org.eclipse.jetty.http2.frames.DataFrame
 
withStreamId(int) - Method in class org.eclipse.jetty.http2.frames.HeadersFrame
 
withStreamId(int) - Method in class org.eclipse.jetty.http2.frames.PriorityFrame
 
withStreamId(int) - Method in class org.eclipse.jetty.http2.frames.PushPromiseFrame
 
withStreamId(int) - Method in class org.eclipse.jetty.http2.frames.StreamFrame
 
WOKEN - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.State
 
wrap(SSLEngine, ByteBuffer[], ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
wrap(T, Class<W>, BiFunction<W, T, T>) - Method in class org.eclipse.jetty.servlet.BaseHolder
Wrap component using component specific Wrapper Function beans.
wrapConfiguration(Configuration) - Method in interface org.eclipse.jetty.webapp.Configuration.WrapperFunction
 
wrapEventListener(EventListener) - Method in interface org.eclipse.jetty.servlet.ListenerHolder.WrapFunction
Optionally wrap the Servlet EventListener.
wrapFilter(Filter) - Method in interface org.eclipse.jetty.servlet.FilterHolder.WrapFunction
Optionally wrap the Filter.
wrapNonVoidReturnType(MethodHandle, JakartaWebSocketSession) - Static method in class org.eclipse.jetty.websocket.jakarta.common.JakartaWebSocketFrameHandlerFactory
 
WrappedAsyncListener(AsyncListener, ServletRequest, ServletResponse) - Constructor for class org.eclipse.jetty.server.AsyncContextState.WrappedAsyncListener
 
WrappedAuthConfiguration - Class in org.eclipse.jetty.security
WrappedAuthConfiguration(Authenticator.AuthConfiguration) - Constructor for class org.eclipse.jetty.security.WrappedAuthConfiguration
 
Wrapper(Filter) - Constructor for class org.eclipse.jetty.servlet.FilterHolder.Wrapper
 
Wrapper(Servlet) - Constructor for class org.eclipse.jetty.servlet.ServletHolder.Wrapper
 
Wrapper(ServletContainerInitializer) - Constructor for class org.eclipse.jetty.servlet.ServletContainerInitializerHolder.Wrapper
 
Wrapper(EventListener) - Constructor for class org.eclipse.jetty.servlet.ListenerHolder.Wrapper
 
Wrapper(Parser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.Parser.Listener.Wrapper
 
Wrapper(ServerParser.Listener) - Constructor for class org.eclipse.jetty.http2.parser.ServerParser.Listener.Wrapper
 
Wrapper(Attributes) - Constructor for class org.eclipse.jetty.util.Attributes.Wrapper
 
Wrapper(Promise<W>) - Constructor for class org.eclipse.jetty.util.Promise.Wrapper
 
Wrapper(Configuration) - Constructor for class org.eclipse.jetty.webapp.Configuration.Wrapper
 
WrappingContent(HttpInput.Content, boolean) - Constructor for class org.eclipse.jetty.server.HttpInput.WrappingContent
 
wrapServlet(Servlet) - Method in interface org.eclipse.jetty.servlet.ServletHolder.WrapFunction
Optionally wrap the Servlet.
wrapServletContainerInitializer(ServletContainerInitializer) - Method in interface org.eclipse.jetty.servlet.ServletContainerInitializerHolder.WrapFunction
Optionally wrap the ServletContainerInitializer.
write(byte[]) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(byte[]) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(byte[]) - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.server.HttpOutput
 
write(byte[], int, int) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
write(byte[], int, int) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
write(byte[], int, int) - Method in class org.eclipse.jetty.util.MultiPartOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
write(char) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
write(char[]) - Method in class org.eclipse.jetty.server.ResponseWriter
 
write(char[]) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
write(char[], int, int) - Method in class org.eclipse.jetty.server.EncodingHttpWriter
 
write(char[], int, int) - Method in class org.eclipse.jetty.server.HttpWriter
 
write(char[], int, int) - Method in class org.eclipse.jetty.server.Iso88591HttpWriter
 
write(char[], int, int) - Method in class org.eclipse.jetty.server.ResponseWriter
 
write(char[], int, int) - Method in class org.eclipse.jetty.server.Utf8HttpWriter
 
write(char[], int, int) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
write(char[], int, int) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageWriter
 
write(int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
write(int) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(int) - Method in class org.eclipse.jetty.server.HttpOutput
 
write(int) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
write(int) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
write(int) - Method in class org.eclipse.jetty.server.ResponseWriter
 
write(int) - Method in class org.eclipse.jetty.util.RolloverFileOutputStream
 
write(int) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
write(Writer, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
write(String) - Method in class org.eclipse.jetty.server.AsyncRequestLogWriter
 
write(String) - Method in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
write(String) - Method in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
write(String) - Method in interface org.eclipse.jetty.server.RequestLog.Writer
 
write(String) - Method in class org.eclipse.jetty.server.RequestLogWriter
 
write(String) - Method in class org.eclipse.jetty.server.ResponseWriter
 
write(String) - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
write(String) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
write(String, int, int) - Method in class org.eclipse.jetty.server.HttpWriter
 
write(String, int, int) - Method in class org.eclipse.jetty.server.ResponseWriter
 
write(String, int, int) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
write(ByteBuffer) - Method in class org.eclipse.jetty.client.util.OutputStreamContentProvider
Deprecated.
 
write(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
write(ByteBuffer) - Method in class org.eclipse.jetty.server.HttpOutput
 
write(ByteBuffer) - Method in class org.eclipse.jetty.websocket.core.internal.messages.MessageOutputStream
 
write(ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHttpOutputInterceptor
 
write(ByteBuffer, boolean, Callback) - Method in class org.eclipse.jetty.server.HttpChannel
Non-Blocking write, committing the response if needed.
write(ByteBuffer, boolean, Callback) - Method in interface org.eclipse.jetty.server.HttpOutput.Interceptor
Write content.
write(GatheringByteChannel, ByteBuffer[], int, int) - Static method in class org.eclipse.jetty.util.IO
A gathering write utility wrapper.
write(Graph, File) - Static method in class org.eclipse.jetty.deploy.graph.GraphOutputDot
 
write(EndPoint, ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.ConnectHandler.DownstreamConnection
 
write(EndPoint, ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.ConnectHandler.UpstreamConnection
 
write(EndPoint, ByteBuffer, Callback) - Method in class org.eclipse.jetty.proxy.ProxyConnection
 
write(EndPoint, ByteBuffer, Callback, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.proxy.ConnectHandler
Writes (with non-blocking semantic) the given buffer of data onto the given endPoint.
write(Modules, Path) - Method in class org.eclipse.jetty.start.ModuleGraphWriter
 
write(Callback, SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
Writes to the given address the data contained in the given buffers, and invokes the given callback when either all the data has been sent, or a failure occurs.
write(Callback, SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.WriteFlusher
 
write(Callback, SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.quic.common.QuicConnection
 
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.http2.HTTP2StreamEndPoint
 
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
write(Callback, ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Writes the given buffers via EndPoint.flush(ByteBuffer...) and invokes callback methods when either all the data has been flushed or an error occurs.
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.io.WriteFlusher
Tries to switch state to WRITING.
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
write(Callback, List<ByteBuffer>, boolean) - Method in class org.eclipse.jetty.quic.common.QuicStreamEndPoint
 
WRITE_CALLBACK - Enum constant in enum org.eclipse.jetty.server.HttpChannelState.Action
 
WriteCallback - Interface in org.eclipse.jetty.websocket.api
Callback for Write events.
WriteCallback.Adaptor - Class in org.eclipse.jetty.websocket.api
Deprecated.
writeErrorPage(HttpServletRequest, Writer, int, String, boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorPageBody(HttpServletRequest, Writer, int, String, boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorPageHead(HttpServletRequest, Writer, int, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorPageMessage(HttpServletRequest, Writer, int, String, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorPageStacks(HttpServletRequest, Writer) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeFailed(Throwable) - Method in class org.eclipse.jetty.websocket.api.WriteCallback.Adaptor
Deprecated.
 
writeFailed(Throwable) - Method in interface org.eclipse.jetty.websocket.api.WriteCallback
Callback invoked when the write fails.
WriteFlusher - Class in org.eclipse.jetty.io
A Utility class to help implement EndPoint.write(Callback, ByteBuffer...) by calling EndPoint.flush(ByteBuffer...) until all content is written.
WriteFlusher(EndPoint) - Constructor for class org.eclipse.jetty.io.WriteFlusher
 
WriteFlusher.Listener - Interface in org.eclipse.jetty.io
A listener of WriteFlusher events.
writeIniSection(BufferedWriter, Props) - Method in class org.eclipse.jetty.start.Module
 
writePoweredBy(Appendable, String, String) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
writePROXYBytes(EndPoint, Callback) - Method in class org.eclipse.jetty.client.ProxyProtocolClientConnectionFactory.ProxyProtocolConnection
 
WRITER - Enum constant in enum org.eclipse.jetty.server.Response.OutputType
 
WriterOutputStream - Class in org.eclipse.jetty.io
Wrap a Writer as an OutputStream.
WriterOutputStream(Writer) - Constructor for class org.eclipse.jetty.io.WriterOutputStream
 
WriterOutputStream(Writer, String) - Constructor for class org.eclipse.jetty.io.WriterOutputStream
 
writeSuccess() - Method in class org.eclipse.jetty.websocket.api.WriteCallback.Adaptor
Deprecated.
 
writeSuccess() - Method in interface org.eclipse.jetty.websocket.api.WriteCallback
Callback invoked when the write succeeds.
writeTo(OutputStream) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
writeTo(OutputStream) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
writeTo(OutputStream) - Method in class org.eclipse.jetty.util.ByteArrayISO8859Writer
 
writeTo(OutputStream, long, long) - Method in class org.eclipse.jetty.server.resource.ByteBufferRangeWriter
 
writeTo(OutputStream, long, long) - Method in class org.eclipse.jetty.server.resource.InputStreamRangeWriter
 
writeTo(OutputStream, long, long) - Method in interface org.eclipse.jetty.server.resource.RangeWriter
Write the specific range (start, size) to the outputStream.
writeTo(OutputStream, long, long) - Method in class org.eclipse.jetty.server.resource.SeekableByteChannelRangeWriter
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
 
writeTo(ByteBuffer, OutputStream) - Static method in class org.eclipse.jetty.util.BufferUtil
 
writeTo(MessageMarshaller.ProtoStreamWriter, InfinispanSessionData) - Method in class org.eclipse.jetty.session.infinispan.SessionDataMarshaller
 
writeUnchecked(int) - Method in class org.eclipse.jetty.util.ByteArrayOutputStream2
 
WS - Enum constant in enum org.eclipse.jetty.http.HttpScheme
 
WS_AFTER_NAME - Enum constant in enum org.eclipse.jetty.http.HttpParser.FieldState
 
WSS - Enum constant in enum org.eclipse.jetty.http.HttpScheme
 
WSURI - Class in org.eclipse.jetty.websocket.api.util
Utility methods for converting a URI between a HTTP(S) and WS(S) URI.
WSURI() - Constructor for class org.eclipse.jetty.websocket.api.util.WSURI
 
WWW_AUTHENTICATE - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
WWWAuthenticationProtocolHandler - Class in org.eclipse.jetty.client
A protocol handler that handles the 401 response code in association with the WWW-Authenticate header.
WWWAuthenticationProtocolHandler(HttpClient) - Constructor for class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 
WWWAuthenticationProtocolHandler(HttpClient, int) - Constructor for class org.eclipse.jetty.client.WWWAuthenticationProtocolHandler
 

X

X_FORWARDED_FOR - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X_FORWARDED_HOST - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X_FORWARDED_PORT - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X_FORWARDED_PROTO - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X_FORWARDED_SERVER - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X_POWERED_BY - Enum constant in enum org.eclipse.jetty.http.HttpHeader
 
X509 - Class in org.eclipse.jetty.util.ssl
 
X509(String, X509Certificate) - Constructor for class org.eclipse.jetty.util.ssl.X509
 
X509_CERT - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
X509ExtendedKeyManagerWrapper(X509ExtendedKeyManager) - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedKeyManagerWrapper
 
X509ExtendedTrustManagerWrapper(X509ExtendedTrustManager) - Constructor for class org.eclipse.jetty.util.ssl.SslContextFactory.X509ExtendedTrustManagerWrapper
 
XFORWARDED_FOR - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_HOST - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_PORT - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_PROTO - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_SERVER - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XML_CONFIGURATION - Static variable in class org.eclipse.jetty.webapp.JettyWebXmlConfiguration
 
XmlAppendable - Class in org.eclipse.jetty.xml
 
XmlAppendable(OutputStream, String) - Constructor for class org.eclipse.jetty.xml.XmlAppendable
 
XmlAppendable(Appendable) - Constructor for class org.eclipse.jetty.xml.XmlAppendable
 
XmlAppendable(Appendable, int) - Constructor for class org.eclipse.jetty.xml.XmlAppendable
 
XmlAppendable(Appendable, int, String) - Constructor for class org.eclipse.jetty.xml.XmlAppendable
 
XmlAppendable(Appendable, String) - Constructor for class org.eclipse.jetty.xml.XmlAppendable
 
XmlConfiguration - Class in org.eclipse.jetty.xml
Configures objects from XML.
XmlConfiguration(Resource) - Constructor for class org.eclipse.jetty.xml.XmlConfiguration
Reads and parses the XML configuration file.
XmlHttpClientProvider - Class in org.eclipse.jetty.websocket.core.client.internal
 
XmlHttpClientProvider() - Constructor for class org.eclipse.jetty.websocket.core.client.internal.XmlHttpClientProvider
 
XmlParser - Class in org.eclipse.jetty.xml
XML Parser wrapper.
XmlParser() - Constructor for class org.eclipse.jetty.xml.XmlParser
Construct
XmlParser(boolean) - Constructor for class org.eclipse.jetty.xml.XmlParser
 
XmlParser.Attribute - Class in org.eclipse.jetty.xml
XML Attribute.
XmlParser.Node - Class in org.eclipse.jetty.xml
XML Node.
XPROXIED_HTTPS - Enum constant in enum org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 

_

__01Jan1970 - Static variable in class org.eclipse.jetty.http.DateGenerator
 
__ACCESSED - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Last access time of session
__allScanTypes - Static variable in class org.eclipse.jetty.webapp.MetaInfConfiguration
 
__ATTRIBUTES - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
__BASIC_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__CERT_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__CERT_AUTH2 - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__CHARSET - Static variable in class org.eclipse.jetty.util.URIUtil
 
__CheckRemoteSessionEncoding - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
__CONTEXT - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Name of nested document field containing 1 sub document per context for which the session id is in use
__contextName - Static variable in class org.eclipse.jetty.plus.jndi.NamingEntry
 
__CREATED - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Time of session creation
__DEFAULT_MULTIPART_CONFIG - Static variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
__DefaultSessionCookie - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
__DefaultSessionDomain - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
__DefaultSessionIdPathParameterName - Static variable in class org.eclipse.jetty.server.session.SessionHandler
 
__defaultUseCaches - Static variable in class org.eclipse.jetty.util.resource.Resource
 
__dftServerClasses - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
__dftSystemClasses - Static variable in class org.eclipse.jetty.webapp.WebAppContext
 
__DIGEST_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__EMPTY_ARGS - Static variable in class org.eclipse.jetty.plus.annotation.LifeCycleCallback
 
__EXPIRY - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Time this session will expire, based on last access time and maxIdle
__FORM_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__FORM_DISPATCH - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__FORM_ERROR_PAGE - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__FORM_LOGIN_PAGE - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__FORWARD_PREFIX - Static variable in class org.eclipse.jetty.server.Dispatcher
Dispatch include attribute names
__ID - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Session id
__INCLUDE_PREFIX - Static variable in class org.eclipse.jetty.server.Dispatcher
Dispatch include attribute names
__ISO_8859_1 - Static variable in class org.eclipse.jetty.util.StringUtil
 
__J_AUTHENTICATED - Static variable in class org.eclipse.jetty.security.authentication.SessionAuthentication
 
__J_METHOD - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__J_PASSWORD - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__J_POST - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__J_SECURITY_CHECK - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__J_URI - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__J_USERNAME - Static variable in class org.eclipse.jetty.security.authentication.FormAuthenticator
 
__javaNameParser - Static variable in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
__LAST_ACCESSED - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
__LASTNODE - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
__LASTSAVED - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
 
__MAX_IDLE - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
The max idle time of a session (smallest value across all contexts which has a session with the same id)
__MaxAgeProperty - Static variable in class org.eclipse.jetty.server.session.SessionHandler
Session Max Age.
__METADATA - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Special attribute for a session that is context-specific
__MULTIPART_CONFIG_ELEMENT - Static variable in class org.eclipse.jetty.server.Request
 
__nameRoot - Static variable in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
__NEGOTIATE_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__NEW_SESSION_ID - Static variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
__NO_USER - Static variable in class org.eclipse.jetty.security.SecurityHandler
 
__NOBODY - Static variable in class org.eclipse.jetty.security.SecurityHandler
Nobody user.
__nonBlocking - Static variable in interface org.eclipse.jetty.util.thread.Invocable
 
__nonValidatingStaticParser - Static variable in class org.eclipse.jetty.webapp.WebDescriptor
 
__OBFUSCATE - Static variable in class org.eclipse.jetty.util.security.Password
 
__OPENID_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__pattern - Static variable in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
__replacedConfigurations - Static variable in class org.eclipse.jetty.quickstart.QuickStartConfiguration
 
__root - Static variable in class org.eclipse.jetty.jndi.local.localContextRoot
 
__SessionCookieProperty - Static variable in class org.eclipse.jetty.server.session.SessionHandler
Session cookie name.
__SessionDomainProperty - Static variable in class org.eclipse.jetty.server.session.SessionHandler
Session Domain.
__SessionIdPathParameterNameProperty - Static variable in class org.eclipse.jetty.server.session.SessionHandler
Session id path parameter name.
__SessionPathProperty - Static variable in class org.eclipse.jetty.server.session.SessionHandler
Session Path.
__signature - Static variable in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
__SPNEGO_AUTH - Static variable in class org.eclipse.jetty.util.security.Constraint
 
__STRICT - Static variable in class org.eclipse.jetty.http.HttpGenerator
 
__UTF16 - Static variable in class org.eclipse.jetty.util.StringUtil
 
__UTF8 - Static variable in class org.eclipse.jetty.util.StringUtil
 
__VALID - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Whether or not session is valid
__VERSION - Static variable in class org.eclipse.jetty.nosql.mongodb.MongoSessionDataStore
Special attribute per session per context, incremented each time attributes are modified
_abort - Variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
_accessed - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_accessed - Variable in class org.eclipse.jetty.server.session.SessionData
 
_accessTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_addresses - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
_afters - Variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
_allowDuplicateFragmentNames - Variable in class org.eclipse.jetty.webapp.MetaData
 
_allowInsecureHttpDownloads - Variable in class org.eclipse.jetty.start.fileinits.UriFileInitializer
 
_annotatedTypeNames - Variable in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
_annotations - Variable in class org.eclipse.jetty.webapp.MetaData
 
_appendable - Variable in class org.eclipse.jetty.util.Utf8Appendable
 
_applicableTypeNames - Variable in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
_attributes - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_attributes - Variable in class org.eclipse.jetty.server.session.SessionData
 
_attributes - Variable in class org.eclipse.jetty.util.Attributes.Wrapper
 
_authenticator - Variable in class org.eclipse.jetty.security.authentication.DeferredAuthentication
 
_backoff - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_base - Variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
_basehome - Variable in class org.eclipse.jetty.start.FileInitializer
 
_befores - Variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
_bindings - Variable in class org.eclipse.jetty.jndi.NamingContext
 
_blobType - Variable in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
_bout - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_bout - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_buffer - Variable in class org.eclipse.jetty.http.HttpTester.Input
 
_builder - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
_bundle - Variable in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
_cache - Variable in class org.eclipse.jetty.server.session.CachingSessionDataStore
The fronting cache
_callbackHandlerClass - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_candidateSessionIdsForExpiry - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_catalogName - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_chainCache - Variable in class org.eclipse.jetty.servlet.ServletHandler
 
_checkingRemoteSessionIdEncoding - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_classInheritanceHandler - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_classLoader - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_className - Variable in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
_classNames - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_classpath - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_clazz - Variable in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
_client - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
_componentType - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
_con - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_config - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_config - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_configFiles - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_configPath - Variable in class org.eclipse.jetty.security.PropertyUserStore
 
_configuration - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_configurations - Variable in class org.eclipse.jetty.webapp.Configurations
 
_connection - Variable in class org.eclipse.jetty.util.resource.URLResource
 
_containerInitializerAnnotationHandlers - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_containerPathStats - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_content - Variable in class org.eclipse.jetty.server.HttpInput.Content
 
_contentType - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_contentType - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_contentType - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_context - Variable in class org.eclipse.jetty.annotations.AbstractDiscoverableAnnotationHandler
 
_context - Variable in class org.eclipse.jetty.annotations.AnnotationDecorator
 
_context - Variable in class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
_context - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
_context - Variable in class org.eclipse.jetty.plus.webapp.PlusDecorator
 
_context - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
Information about the context to which this SessionCache pertains
_context - Variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
_context - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_context - Variable in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
_context - Variable in class org.eclipse.jetty.webapp.MetaInfConfiguration.ContainerPathNameMatcher
 
_context - Variable in class org.eclipse.jetty.webapp.MetaInfConfiguration.WebAppPathNameMatcher
 
_contextPath - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_contextPath - Variable in class org.eclipse.jetty.server.session.SessionData
 
_contextPathColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_contexts - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_contextStatus - Variable in class org.eclipse.jetty.server.handler.ContextHandler
 
_contextString - Variable in class org.eclipse.jetty.server.session.FileSessionDataStore
 
_contextTmpDir - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_cookieList - Variable in class org.eclipse.jetty.server.Cookies
 
_cookieSet - Variable in class org.eclipse.jetty.server.session.SessionData
 
_cookieSetTime - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_cookieTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_count - Variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
_counter - Static variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
_created - Variable in class org.eclipse.jetty.server.session.SessionData
 
_createTime - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_createTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_credential - Variable in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
_credential - Variable in class org.eclipse.jetty.security.UserPrincipal
 
_datastore - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_dbAdaptor - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
_dbAdaptor - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_decoder - Variable in class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink.Stream
 
_decoders - Variable in class org.eclipse.jetty.websocket.jakarta.common.messages.AbstractDecodedMessageSink.Basic
 
_defaultSecurityHandlerClass - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_defaultUser - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_deleteUnrestorableFiles - Variable in class org.eclipse.jetty.server.session.FileSessionDataStore
 
_descriptorProcessors - Variable in class org.eclipse.jetty.webapp.MetaData
 
_dftMaxIdleSecs - Variable in class org.eclipse.jetty.server.session.SessionHandler
Setting of max inactive interval for new sessions -1 means no timeout
_dirty - Variable in class org.eclipse.jetty.server.session.SessionData
 
_discoverableAnnotationHandlers - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_distributable - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_dsProvided - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_dtd - Variable in class org.eclipse.jetty.webapp.Descriptor
 
_enabled - Variable in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
_enableStats - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_encoding - Variable in class org.eclipse.jetty.io.WriterOutputStream
 
_end - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
_env - Variable in class org.eclipse.jetty.jndi.java.javaRootURLContext
 
_env - Variable in class org.eclipse.jetty.jndi.NamingContext
 
_eof - Variable in class org.eclipse.jetty.http.HttpTester.Input
 
_err - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_evictionPolicy - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
When, if ever, to evict sessions: never; only when the last request for them finishes; after inactivity time (expressed as secs)
_exception - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
_excluded - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
_expiry - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_expiry - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
_expiry - Variable in class org.eclipse.jetty.server.session.SessionData
 
_expirySec - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
_expiryTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_extendedId - Variable in class org.eclipse.jetty.server.session.Session
 
_extendedListenerTypes - Variable in class org.eclipse.jetty.server.handler.ContextHandler.Context
 
_file - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_file - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_filename - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_filename - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_firstLoad - Variable in class org.eclipse.jetty.security.PropertyUserStore
 
_flushOnResponseCommit - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
If true, when a response is about to be committed back to the client, a dirty session will be flushed to the session store.
_fromJSON - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
_fullValidate - Variable in class org.eclipse.jetty.security.AbstractLoginService
 
_getters - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
_gracePeriodSec - Variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
_handler - Variable in class org.eclipse.jetty.server.handler.HandlerWrapper
 
_handler - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
The SessionHandler related to this SessionCache
_handler - Variable in class org.eclipse.jetty.server.session.Session
 
_handlers - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
_handlers - Variable in class org.eclipse.jetty.server.handler.HandlerCollection
 
_handling - Variable in class org.eclipse.jetty.rewrite.handler.Rule
 
_hasOther - Variable in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
_headers - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_headers - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_heartbeats - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMap
 
_heartbeats - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
_hotReload - Variable in class org.eclipse.jetty.security.PropertyUserStore
 
_houseKeeper - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_httpOnly - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_id - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_id - Variable in class org.eclipse.jetty.server.session.SessionData
 
_idChanged - Variable in class org.eclipse.jetty.server.session.Session
 
_idColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_identityService - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_identityService - Variable in class org.eclipse.jetty.security.AbstractLoginService
 
_identityService - Variable in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
_in - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_in - Variable in class org.eclipse.jetty.util.resource.URLResource
 
_indexesPresent - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_initialized - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
_interestedTypes - Variable in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
_introspectAncestors - Variable in class org.eclipse.jetty.annotations.AnnotationIntrospector.AbstractIntrospectableAnnotationHandler
 
_introspector - Variable in class org.eclipse.jetty.annotations.AnnotationDecorator
 
_invalidateOnShutdown - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
If true, when the server shuts down, all sessions in the cache will be invalidated before being removed.
_isOrdered - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_jarConnection - Variable in class org.eclipse.jetty.util.resource.JarResource
 
_jdbcDriver - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_jndiName - Variable in class org.eclipse.jetty.plus.jndi.NamingEntry
 
_jspConfig - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_keepQuotes - Variable in class org.eclipse.jetty.http.QuotedCSVParser
 
_keyFactory - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_kind - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_lastAccessed - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_lastAccessed - Variable in class org.eclipse.jetty.server.session.SessionData
 
_lastAccessTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_lastExpiryCheckTime - Variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
_lastNode - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_lastNode - Variable in class org.eclipse.jetty.server.session.SessionData
 
_lastNodeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_lastOrphanSweepTime - Variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
_lastSaved - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_lastSaved - Variable in class org.eclipse.jetty.server.session.SessionData
 
_lastSavedTimeColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_lastSweepTime - Variable in class org.eclipse.jetty.server.session.FileSessionDataStore
 
_listeners - Variable in class org.eclipse.jetty.security.PropertyUserStore
 
_loader - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_location - Variable in class org.eclipse.jetty.rewrite.handler.RedirectRegexRule
 
_lock - Variable in class org.eclipse.jetty.server.session.Session
 
_lock - Variable in class org.eclipse.jetty.util.resource.URLResource
 
_log - Variable in class org.eclipse.jetty.proxy.AbstractProxyServlet
 
_logFile - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_loginModuleName - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_loginService - Variable in class org.eclipse.jetty.security.authentication.LoginAuthenticator
 
_longType - Variable in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
_majorVersion - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_managed - Variable in class org.eclipse.jetty.jmx.ObjectMBean
 
_managedServerName - Variable in class org.eclipse.jetty.osgi.boot.BundleContextProvider.ContextBundleTracker
 
_managedServerName - Variable in class org.eclipse.jetty.osgi.boot.BundleWebAppProvider.WebAppTracker
 
_mapColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_mapFactory - Variable in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
 
_maxCookieAge - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_maxInactive - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_maxInactiveMs - Variable in class org.eclipse.jetty.server.session.SessionData
 
_maxIntervalColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_maxResults - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_maxRetries - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_metaData - Variable in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
_metaData - Variable in class org.eclipse.jetty.webapp.RelativeOrdering
 
_metaDataComplete - Variable in class org.eclipse.jetty.webapp.MetaData
 
_metaDataComplete - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_metaDataDirty - Variable in class org.eclipse.jetty.server.session.SessionData
 
_method - Variable in class org.eclipse.jetty.security.AbstractUserAuthentication
 
_minorVersion - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_model - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_modelProvided - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore
 
_multipartConfig - Variable in class org.eclipse.jetty.servlet.ServletHolder.Registration
 
_name - Variable in class org.eclipse.jetty.jndi.NamingContext
 
_name - Variable in class org.eclipse.jetty.security.AbstractLoginService
 
_name - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_name - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_name - Variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
_namingEntryNameString - Variable in class org.eclipse.jetty.plus.jndi.NamingEntry
 
_newSession - Variable in class org.eclipse.jetty.server.session.Session
 
_nextScope - Variable in class org.eclipse.jetty.server.handler.ScopedHandler
 
_numberType - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
_object - Variable in class org.eclipse.jetty.jaas.callback.ObjectCallback
 
_objectNameString - Variable in class org.eclipse.jetty.plus.jndi.NamingEntry
 
_objFactory - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_options - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_order - Variable in class org.eclipse.jetty.webapp.AbsoluteOrdering
 
_orderedContainerResources - Variable in class org.eclipse.jetty.webapp.MetaData
 
_orderedWebInfResources - Variable in class org.eclipse.jetty.webapp.MetaData
 
_ordering - Variable in class org.eclipse.jetty.webapp.MetaData
 
_ordering - Variable in class org.eclipse.jetty.webapp.WebDescriptor
 
_origin - Variable in class org.eclipse.jetty.servlet.Source
 
_originalPathAttribute - Variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
_originalQueryStringAttribute - Variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
_originAttribute - Variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
_origins - Variable in class org.eclipse.jetty.webapp.MetaData
 
_otherType - Variable in class org.eclipse.jetty.webapp.FragmentDescriptor
 
_out - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_out - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_outerScope - Variable in class org.eclipse.jetty.server.handler.ScopedHandler
 
_ownHouseKeeper - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_ownScheduler - Variable in class org.eclipse.jetty.server.session.HouseKeeper
 
_ownScheduler - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_parent - Variable in class org.eclipse.jetty.jndi.NamingContext
 
_parsed - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_parsedClassNames - Variable in class org.eclipse.jetty.annotations.AnnotationParser
Map of classnames scanned and the first location from which scan occurred
_parser - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
_parser - Variable in class org.eclipse.jetty.http.HttpTester.Input
 
_parser - Variable in class org.eclipse.jetty.jndi.NamingContext
 
_parserTasks - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_parts - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_password - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_pathWatcher - Variable in class org.eclipse.jetty.security.PropertyUserStore
 
_pattern - Variable in class org.eclipse.jetty.rewrite.handler.PatternRule
 
_pattern - Variable in class org.eclipse.jetty.util.InetAddressPattern
 
_pattern - Variable in class org.eclipse.jetty.webapp.MetaInfConfiguration.ContainerPathNameMatcher
 
_pattern - Variable in class org.eclipse.jetty.webapp.MetaInfConfiguration.WebAppPathNameMatcher
 
_pojoClass - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
_preUnpackBaseResource - Variable in class org.eclipse.jetty.webapp.WebInfConfiguration
 
_properties - Variable in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
_propertyName - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
_queryManager - Variable in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
_quickStartWebXml - Variable in class org.eclipse.jetty.quickstart.QuickStartGeneratorConfiguration
 
_random - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_rawFields - Variable in class org.eclipse.jetty.server.Cookies
 
_realmName - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_refreshCookieAge - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_regex - Variable in class org.eclipse.jetty.rewrite.handler.RegexRule
 
_registration - Variable in class org.eclipse.jetty.osgi.boot.AbstractOSGiApp
 
_removeUnloadableSessions - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
If true, a Session whose data cannot be read will be deleted from the SessionDataStore.
_request - Variable in class org.eclipse.jetty.jaas.callback.ServletRequestCallback
 
_requests - Variable in class org.eclipse.jetty.server.session.Session
 
_reseed - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_resident - Variable in class org.eclipse.jetty.server.session.Session
 
_resource - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
_resource - Variable in class org.eclipse.jetty.servlet.Source
 
_resource - Variable in class org.eclipse.jetty.webapp.DiscoveredAnnotation
 
_rewritePathInfo - Variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
_rewriteRequestURI - Variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
_roleClassNames - Variable in class org.eclipse.jetty.jaas.JAASLoginService
 
_rolePrincipals - Variable in class org.eclipse.jetty.security.UserStore.User
 
_roleSql - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_roleTableRoleField - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_root - Variable in class org.eclipse.jetty.webapp.Descriptor
 
_rules - Variable in class org.eclipse.jetty.rewrite.handler.RuleContainer
 
_runner - Variable in class org.eclipse.jetty.server.session.HouseKeeper
 
_saveOnCreate - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
If true, as soon as a new session is created, it will be persisted to the SessionDataStore
_saveOnInactiveEviction - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
If true, a session that will be evicted from the cache because it has been inactive too long will be saved before being evicted.
_savePeriodSec - Variable in class org.eclipse.jetty.server.session.AbstractSessionDataStore
 
_scheduler - Variable in class org.eclipse.jetty.server.session.HouseKeeper
 
_scheduler - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_schemaName - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_schemaProvided - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
_scheme - Variable in class org.eclipse.jetty.start.FileInitializer
 
_sciExcludePattern - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_sciHolders - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_scontext - Variable in class org.eclipse.jetty.server.handler.ContextHandler
 
_scope - Variable in class org.eclipse.jetty.plus.jndi.NamingEntry
 
_secureCookies - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_secureRequestOnly - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_securityHandler - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_serialization - Variable in class org.eclipse.jetty.session.infinispan.InfinispanSessionDataStoreFactory
 
_serializedAttributes - Variable in class org.eclipse.jetty.session.infinispan.InfinispanSessionData
 
_server - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_server - Variable in class org.eclipse.jetty.server.LowResourceMonitor
 
_server - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_serverUriFile - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_servletContext - Variable in class org.eclipse.jetty.servlet.ErrorPageErrorHandler
 
_servletHandler - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_sessionAttributeListeners - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionCache - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionComment - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionContext - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionCookie - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionData - Variable in class org.eclipse.jetty.server.session.Session
 
_sessionDataStore - Variable in class org.eclipse.jetty.server.session.AbstractSessionCache
The authoritative source of session data
_sessionDomain - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionFileMap - Variable in class org.eclipse.jetty.server.session.FileSessionDataStore
 
_sessionHandler - Variable in class org.eclipse.jetty.servlet.ServletContextHandler
 
_sessionIdListeners - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionIdManager - Variable in class org.eclipse.jetty.server.session.HouseKeeper
 
_sessionIdManager - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionIdPathParameterName - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionIdPathParameterNamePrefix - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionInactivityTimer - Variable in class org.eclipse.jetty.server.session.Session
 
_sessionListeners - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionPath - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionsCreatedStats - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionStoreFactory - Variable in class org.eclipse.jetty.server.session.CachingSessionDataStoreFactory
The SessionDataStore that will store session data.
_sessionTableSchema - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore
 
_sessionTimeStats - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_sessionTrackingModes - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_setter - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
_setters - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor
 
_size - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_size - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_start - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.TimeStatistic
 
_startupClasses - Variable in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
_startupClassNames - Variable in class org.eclipse.jetty.servlet.ServletContainerInitializerHolder
 
_stat - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration.ParserTask
 
_state - Variable in class org.eclipse.jetty.server.session.Session
 
_state - Variable in class org.eclipse.jetty.util.Utf8Appendable
 
_stateChangeCompleted - Variable in class org.eclipse.jetty.server.session.Session
 
_statsPropFile - Variable in class org.eclipse.jetty.runner.Runner
Deprecated.
 
_store - Variable in class org.eclipse.jetty.server.session.CachingSessionDataStore
The actual store for the session data
_storeDir - Variable in class org.eclipse.jetty.server.session.FileSessionDataStore
 
_stringType - Variable in class org.eclipse.jetty.server.session.DatabaseAdaptor
 
_tableName - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_target - Variable in class org.eclipse.jetty.plus.annotation.ContainerInitializer
Deprecated.
 
_task - Variable in class org.eclipse.jetty.server.session.HouseKeeper
 
_temporary - Variable in class org.eclipse.jetty.server.MultiPartFormInputStream.MultiPart
 
_temporary - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser.MultiPart
Deprecated.
 
_terminating - Variable in class org.eclipse.jetty.rewrite.handler.Rule
 
_timer - Variable in class org.eclipse.jetty.server.session.Session.SessionInactivityTimer
 
_tmpDir - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_type - Variable in class org.eclipse.jetty.util.ajax.JSONPojoConvertor.Setter
 
_url - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_url - Variable in class org.eclipse.jetty.util.resource.URLResource
 
_urlString - Variable in class org.eclipse.jetty.util.resource.URLResource
 
_userIdentity - Variable in class org.eclipse.jetty.security.AbstractUserAuthentication
 
_userName - Variable in class org.eclipse.jetty.jaas.callback.AbstractCallbackHandler
 
_userName - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_userPrincipal - Variable in class org.eclipse.jetty.security.UserStore.User
 
_users - Variable in class org.eclipse.jetty.security.UserStore
 
_userSql - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_userTableKey - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_userTablePasswordField - Variable in class org.eclipse.jetty.security.JDBCLoginService
 
_usingCookies - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_usingURLs - Variable in class org.eclipse.jetty.server.session.SessionHandler
 
_validateXml - Variable in class org.eclipse.jetty.webapp.MetaData
 
_values - Variable in class org.eclipse.jetty.http.QuotedCSV
 
_vhost - Variable in class org.eclipse.jetty.gcloud.session.GCloudSessionDataStore.EntityDataModel
 
_vhost - Variable in class org.eclipse.jetty.server.session.SessionData
 
_virtualHostColumn - Variable in class org.eclipse.jetty.server.session.JDBCSessionDataStore.SessionTableSchema
 
_visitors - Variable in class org.eclipse.jetty.webapp.IterativeDescriptorProcessor
 
_weakRandom - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_webDefaultsRoot - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webFragmentNameMap - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webFragmentResourceMap - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webFragmentRoots - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webInfClasses - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webInfClassesStats - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_webInfJars - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webInfLibStats - Variable in class org.eclipse.jetty.annotations.AnnotationConfiguration
 
_webOverrideRoots - Variable in class org.eclipse.jetty.webapp.MetaData
 
_webXmlRoot - Variable in class org.eclipse.jetty.webapp.MetaData
 
_weights - Variable in class org.eclipse.jetty.memcached.session.MemcachedSessionDataMapFactory
 
_workerAttr - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_workerName - Variable in class org.eclipse.jetty.server.session.DefaultSessionIdManager
 
_writeFilesWithFilenames - Variable in class org.eclipse.jetty.server.MultiPartInputStreamParser
Deprecated.
 
_writer - Variable in class org.eclipse.jetty.io.WriterOutputStream
 
_xml - Variable in class org.eclipse.jetty.webapp.Descriptor
 
A B C D E F G H I J K L M N O P Q R S T U V W X _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form