Index

A B C D E F G H I J 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

AbortException() - Constructor for exception class org.eclipse.jetty.server.Request.Handler.AbortException
 
AbortException(String) - Constructor for exception class org.eclipse.jetty.server.Request.Handler.AbortException
 
AbortException(String, Throwable) - Constructor for exception class org.eclipse.jetty.server.Request.Handler.AbortException
 
AbortException(Throwable) - Constructor for exception class org.eclipse.jetty.server.Request.Handler.AbortException
 
Abstract() - Constructor for class org.eclipse.jetty.server.Handler.Abstract
Creates a Handler with invocation type Invocable.InvocationType.BLOCKING.
Abstract() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Abstract
 
Abstract(boolean, Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Abstract
 
Abstract(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Abstract
 
Abstract(Invocable.InvocationType) - Constructor for class org.eclipse.jetty.server.Handler.Abstract
Creates a Handler with the given invocation type.
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
 
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
 
AbstractConnectorMBean - Class in org.eclipse.jetty.server.jmx
 
AbstractConnectorMBean(Object) - Constructor for class org.eclipse.jetty.server.jmx.AbstractConnectorMBean
 
AbstractContainer() - Constructor for class org.eclipse.jetty.server.Handler.AbstractContainer
Creates an instance that is dynamic.
AbstractContainer(boolean) - Constructor for class org.eclipse.jetty.server.Handler.AbstractContainer
Creates an instance with the given dynamic argument.
AbstractHandler - Class in org.eclipse.jetty.server.handler
Deprecated.
AbstractHandler() - Constructor for class org.eclipse.jetty.server.handler.AbstractHandler
Deprecated.
 
AbstractHandlerContainer - Class in org.eclipse.jetty.server.handler
Deprecated. 
AbstractHandlerContainer() - Constructor for class org.eclipse.jetty.server.handler.AbstractHandlerContainer
Deprecated.
 
AbstractMBean(Object) - Constructor for class org.eclipse.jetty.server.jmx.Handler.AbstractMBean
 
AbstractMetaDataConnection - Class in org.eclipse.jetty.server
An AbstractConnection that also implements ConnectionMetaData with fixed local and remote addresses.
AbstractMetaDataConnection(Connector, HttpConfiguration, EndPoint) - Constructor for class org.eclipse.jetty.server.AbstractMetaDataConnection
 
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
 
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.MemoryConnector
 
accept(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
accept(Consumer<Throwable>, Throwable, Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
accepted(SelectableChannel) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
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
 
add(Predicate<Request>) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 
addAliasCheck(AliasCheck) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Add an AliasCheck instance to possibly permit aliased resources
addBeanToAllConnectors(Object) - Method in class org.eclipse.jetty.server.Server
Add a bean to all connectors on the server.
addCompletionListener(Request, Consumer<Throwable>) - Static method in interface org.eclipse.jetty.server.Request
Adds a completion listener that is an optimized equivalent to overriding the Callback.succeeded() and Callback.failed(Throwable) methods of a HttpStream.Wrapper created by a call to Request.addHttpStreamWrapper(Function).
addComplianceViolationListener(ComplianceViolation.Listener) - Method in class org.eclipse.jetty.server.HttpConfiguration
Add a ComplianceViolation.Listener to the configuration
addConnectionFactory(ConnectionFactory) - Method in class org.eclipse.jetty.server.AbstractConnector
 
addConnector(Connector) - Method in class org.eclipse.jetty.server.Server
 
addCookie(String, String, int, String, String, String) - Method in class org.eclipse.jetty.server.CookieCache
 
addCookie(Response, HttpCookie) - Static method in interface org.eclipse.jetty.server.Response
Adds an HTTP HttpHeader.SET_COOKIE header to the response.
addCustomizer(HttpConfiguration.Customizer) - Method in class org.eclipse.jetty.server.HttpConfiguration
Adds a HttpConfiguration.Customizer that is invoked for every request received.
addEventListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Add a context event listeners.
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.
addFailureListener(Consumer<Throwable>) - Method in class org.eclipse.jetty.server.handler.ContextRequest
 
addFailureListener(Consumer<Throwable>) - Method in interface org.eclipse.jetty.server.Request
Adds a listener for asynchronous fatal failures.
addFailureListener(Consumer<Throwable>) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
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
addHandler(Supplier<Handler>) - Method in interface org.eclipse.jetty.server.Handler.Collection
Adds the Handler supplied by the given Supplier to this collection of Handlers.
addHandler(Handler) - Method in interface org.eclipse.jetty.server.Handler.Collection
Adds the given Handler to this collection of Handlers.
addHttpStreamWrapper(Function<HttpStream, HttpStream>) - Method in interface org.eclipse.jetty.server.Request
Add a HttpStream.Wrapper to the current HttpStream.
addHttpStreamWrapper(Function<HttpStream, HttpStream>) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
addIdleTimeoutListener(Predicate<TimeoutException>) - Method in class org.eclipse.jetty.server.handler.ContextRequest
 
addIdleTimeoutListener(Predicate<TimeoutException>) - Method in interface org.eclipse.jetty.server.Request
Adds a listener for idle timeouts.
addIdleTimeoutListener(Predicate<TimeoutException>) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
addIfAbsentConnectionFactory(ConnectionFactory) - Method in class org.eclipse.jetty.server.AbstractConnector
 
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.
addLowResourceCheck(LowResourceMonitor.LowResourceCheck) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
addMapping(PathSpec, Handler) - Method in class org.eclipse.jetty.server.handler.PathMappingsHandler
 
addVirtualHosts(String...) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Either set virtual hosts or add to an existing set of virtual hosts.
age(long, TimeUnit) - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
AliasCheck - Interface in org.eclipse.jetty.server
Interface to check aliases.
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 the ContextHandler protected targets 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
 
as(Request, Class<T>) - Static method in interface org.eclipse.jetty.server.Request
 
as(Response, Class<T>) - Static method in interface org.eclipse.jetty.server.Response
Unwraps the given response, recursively, until the wrapped instance is an instance of the given type, otherwise returns null.
asAttributeMap() - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
asAttributeMap() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
asBufferedOutputStream(Request, Response) - Static method in interface org.eclipse.jetty.server.Response
Wraps a Response as a OutputStream that performs buffering.
asBufferedSink(Request, Response) - Static method in interface org.eclipse.jetty.server.Response
Wraps a Response as a Content.Sink that performs buffering.
asInputStream(Request) - Static method in interface org.eclipse.jetty.server.Request
 
asReadOnly(Request) - Static method in interface org.eclipse.jetty.server.Request
Returns a copy of the request that throws UnsupportedOperationException from all mutative methods.
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
 
ATTRIBUTE_PREFIX - Static variable in interface org.eclipse.jetty.server.Deployable
 
AttributesWrapper(Request, Attributes) - Constructor for class org.eclipse.jetty.server.Request.AttributesWrapper
 
AVAILABLE - Enum constant in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
 
await() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 

B

badMessageError(int, String, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Deprecated, for removal: This API element is subject to removal in a future version.
Do not override. No longer invoked by Jetty.
BREAK_EVEN_GZIP_SIZE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
BUFFER_SIZE_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.handler.BufferedResponseHandler
The name of the request attribute used to control the buffer size of a particular request.
BufferedResponseHandler - Class in org.eclipse.jetty.server.handler
A Handler that can apply a mechanism to buffer the entire response content until the output is closed.
BufferedResponseHandler() - Constructor for class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
BufferedResponseHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
ByHttpStatus(Handler) - Constructor for class org.eclipse.jetty.server.handler.ReHandlingErrorHandler.ByHttpStatus
 

C

call(Invocable.Callable, Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
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
 
checkAlias(String, Resource) - Method in interface org.eclipse.jetty.server.AliasCheck
Check if an alias is allowed to be served.
checkAlias(String, Resource) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
checkAlias(String, Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
checkAlias(String, Resource) - Method in class org.eclipse.jetty.server.TrailingSlashAliasChecker
 
checkHandler(Handler.Singleton, Handler) - Static method in interface org.eclipse.jetty.server.Handler.Singleton
Utility method to perform sanity checks on a {Handler to be added to the given Singleton.
checkSameSite(HttpCookie, Attributes) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
Check that samesite is set on the cookie.
checkSni(Request, SSLSession) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
checkVirtualHost(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
cleanupAfterStop() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
clear() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Clear all inclusions and exclusions.
clearAliasChecks() - Method in class org.eclipse.jetty.server.handler.ContextHandler
clear the list of AliasChecks
clearAttributes() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
clearAttributes() - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
clearAttributes() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
clearAttributes() - Method in class org.eclipse.jetty.server.Server
 
clearConnectionFactories() - Method in class org.eclipse.jetty.server.AbstractConnector
 
clearLowResources() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
close() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
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.ServerConnector
 
close(Throwable) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
close(Throwable) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
close(Throwable) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
Collection(RequestLog...) - Constructor for class org.eclipse.jetty.server.RequestLog.Collection
 
commit(boolean, Callback, ByteBuffer) - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
Components - Interface in org.eclipse.jetty.server
Common components made available via a Request.
computeBufferSize(Request) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
ConditionalHandler - Class in org.eclipse.jetty.server.handler
A Handler.Wrapper that conditionally handles a Request.
ConditionalHandler.Abstract - Class in org.eclipse.jetty.server.handler
An Abstract ConditionalHandler.
ConditionalHandler.ConnectorPredicate - Class in org.eclipse.jetty.server.handler
A Predicate over Request that tests the name of the connector obtained from Request.getConnectionMetaData()
ConditionalHandler.DontHandle - Class in org.eclipse.jetty.server.handler
An implementation of ConditionalHandler that, if conditions are met, will not do any further handling by returning false from ConditionalHandler.DontHandle.onConditionsMet(Request, Response, Callback).
ConditionalHandler.ElseNext - Class in org.eclipse.jetty.server.handler
ConditionalHandler.InetAddressPatternPredicate - Class in org.eclipse.jetty.server.handler
A Predicate over Request that tests an InetAddressPattern against the getRemoteSocketAddress() of Request.getConnectionMetaData().
ConditionalHandler.MethodPredicate - Class in org.eclipse.jetty.server.handler
A Predicate over Request that tests method name.
ConditionalHandler.PathSpecPredicate - Class in org.eclipse.jetty.server.handler
A Predicate over Request that tests a PathSpec against the pathInContext.
ConditionalHandler.PredicateSet - Class in org.eclipse.jetty.server.handler
A Set of Predicate over Request optimized for use by IncludeExclude.
ConditionalHandler.Reject - Class in org.eclipse.jetty.server.handler
An implementation of ConditionalHandler that, if conditions are met, will reject the request by sending a response (by default a HttpStatus.FORBIDDEN_403).
ConditionalHandler.SkipNext - Class in org.eclipse.jetty.server.handler
An implementation of ConditionalHandler that, if conditions are met, will skip the next Handler by invoking its next Handler.
CONFIGURATION_CLASSES - Static variable in interface org.eclipse.jetty.server.Deployable
 
configure(Socket) - Method in class org.eclipse.jetty.server.ServerConnector
 
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(T, Connector, EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
configure(T, Connector, EndPoint) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
Configuring Connection Factories - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
connect() - Method in class org.eclipse.jetty.server.LocalConnector
 
connect() - Method in class org.eclipse.jetty.server.MemoryConnector
Client-side applications use this method to connect to the server and obtain a EndPoint.Pipe.
connect(int) - Method in class org.eclipse.jetty.server.LocalConnector
 
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.server.MemoryTransport
 
ConnectContext(Request, Response, Callback, EndPoint) - Constructor for class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
ConnectHandler - Class in org.eclipse.jetty.server.handler
Implementation of a Handler that supports HTTP CONNECT.
ConnectHandler() - Constructor for class org.eclipse.jetty.server.handler.ConnectHandler
 
ConnectHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConnectHandler
 
ConnectHandler.ConnectContext - Class in org.eclipse.jetty.server.handler
 
ConnectHandler.ConnectManager - Class in org.eclipse.jetty.server.handler
 
ConnectHandler.DownstreamConnection - Class in org.eclipse.jetty.server.handler
 
ConnectHandler.UpstreamConnection - Class in org.eclipse.jetty.server.handler
 
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 Class 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.server.handler.ConnectHandler.ConnectManager
 
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
 
ConnectionMetaData - Interface in org.eclipse.jetty.server
 
ConnectionMetaData.Wrapper - Class in org.eclipse.jetty.server
 
ConnectManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.server.handler.ConnectHandler.ConnectManager
 
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.
ConnectorPredicate(String) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.ConnectorPredicate
 
Connector Services - Search tag in class org.eclipse.jetty.server.AbstractConnector
Section
ConnectorsThreadPoolLowResourceCheck() - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.ConnectorsThreadPoolLowResourceCheck
 
connectToServer(Request, String, int, Promise<SocketChannel>) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
consumeAvailable() - Method in interface org.eclipse.jetty.server.HttpStream
 
consumeAvailable() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
consumeAvailable() - Method in interface org.eclipse.jetty.server.Request
Consume any available content.
consumeAvailable() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
consumeAvailable(HttpStream, HttpConfiguration) - Static method in interface org.eclipse.jetty.server.HttpStream
 
CONTAINER_SCAN_JARS - Static variable in interface org.eclipse.jetty.server.Deployable
 
CONTENT_NOT_CONSUMED - Static variable in interface org.eclipse.jetty.server.HttpStream
 
Context - Interface in org.eclipse.jetty.server
A context for handling an Request.
CONTEXT_HANDLER_CLASS - Static variable in interface org.eclipse.jetty.server.Deployable
 
CONTEXT_PATH - Static variable in interface org.eclipse.jetty.server.Deployable
 
ContextHandler - Class in org.eclipse.jetty.server.handler
A Handler that scopes a request to a specific Context.
ContextHandler() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(String) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler(Handler, String) - Constructor for class org.eclipse.jetty.server.handler.ContextHandler
 
ContextHandler.Availability - Enum Class in org.eclipse.jetty.server.handler
 
ContextHandler.ContextScopeListener - Interface in org.eclipse.jetty.server.handler
Listener for all threads entering context scope, including async IO callbacks
ContextHandler.ScopedContext - Class in org.eclipse.jetty.server.handler
 
ContextHandlerCollection - Class in org.eclipse.jetty.server.handler
Creates a Map of contexts to it's contained handlers based on the context path and virtual hosts of any contained ContextHandlers.
ContextHandlerCollection(boolean, ContextHandler...) - 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
 
ContextRequest - Class in org.eclipse.jetty.server.handler
 
ContextRequest(ContextHandler.ScopedContext, Request) - Constructor for class org.eclipse.jetty.server.handler.ContextRequest
 
ContextResponse - Class in org.eclipse.jetty.server.handler
 
ContextResponse(ContextHandler.ScopedContext, Request, Response) - Constructor for class org.eclipse.jetty.server.handler.ContextResponse
 
COOKIE_ATTRIBUTE - Static variable in interface org.eclipse.jetty.server.Request
 
CookieCache - Class in org.eclipse.jetty.server
Cookie parser
CookieCache() - Constructor for class org.eclipse.jetty.server.CookieCache
 
CookieCache(CookieCompliance) - Constructor for class org.eclipse.jetty.server.CookieCache
 
createTempDirectory() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Create the temporary directory.
CROSS_CONTEXT_ATTRIBUTE - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
The attribute name that is set as a Request attribute to indicate the request is a cross context dispatch.
CrossOriginHandler - Class in org.eclipse.jetty.server.handler
Implementation of the CORS protocol defined by the fetch standard.
CrossOriginHandler() - Constructor for class org.eclipse.jetty.server.handler.CrossOriginHandler
 
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(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
customize(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.HostHeaderCustomizer
 
customize(Request, HttpFields.Mutable) - Method in interface org.eclipse.jetty.server.HttpConfiguration.Customizer
 
customize(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.ProxyCustomizer
 
customize(Request, HttpFields.Mutable) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
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
 
CustomRequestLog.LogDetail - Record Class in org.eclipse.jetty.server
Record holding extra detail for logging

D

DebugHandler - Class in org.eclipse.jetty.server.handler
Debug Handler.
DebugHandler() - Constructor for class org.eclipse.jetty.server.handler.DebugHandler
 
DebugHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.DebugHandler
 
decorate(T) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
DEFAULT_DATE_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
DEFAULT_LOCALES - Static variable in interface org.eclipse.jetty.server.Request
 
DEFAULT_MIN_GZIP_SIZE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
DefaultFactory() - Constructor for class org.eclipse.jetty.server.HttpChannel.DefaultFactory
 
DefaultHandler - Class in org.eclipse.jetty.server.handler
Default Handler.
DefaultHandler() - Constructor for class org.eclipse.jetty.server.handler.DefaultHandler
 
DefaultHandler(boolean, boolean) - Constructor for class org.eclipse.jetty.server.handler.DefaultHandler
 
DEFAULTS_DESCRIPTOR - Static variable in interface org.eclipse.jetty.server.Deployable
 
DEFLATE - Static variable in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
delay() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
delay() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.UntilContentDelayedProcess
 
delay() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.UntilFormDelayedProcess
 
delay() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.UntilMultipartDelayedProcess
 
DelayedHandler - Class in org.eclipse.jetty.server.handler
 
DelayedHandler() - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler
 
DelayedHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler
 
DelayedHandler.DelayedProcess - Class in org.eclipse.jetty.server.handler
 
DelayedHandler.UntilContentDelayedProcess - Class in org.eclipse.jetty.server.handler
 
DelayedHandler.UntilFormDelayedProcess - Class in org.eclipse.jetty.server.handler
 
DelayedHandler.UntilMultipartDelayedProcess - Class in org.eclipse.jetty.server.handler
 
DelayedProcess(Handler, Request, Response, Callback) - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
DelayedRejectHandler() - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.DelayedRejectHandler
 
DelayedRejectHandler(long, int, Request.Handler) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.DelayedRejectHandler
 
demand() - Method in interface org.eclipse.jetty.server.HttpStream
Demands more content chunks to the underlying implementation.
demand() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
demand(Runnable) - Method in class org.eclipse.jetty.server.handler.ContextRequest
 
demand(Runnable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler.ErrorRequest
 
demand(Runnable) - Method in class org.eclipse.jetty.server.handler.gzip.GzipRequest
 
demand(Runnable) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler.MinimumDataRateRequest
 
demand(Runnable) - Method in interface org.eclipse.jetty.server.Request
demand(Runnable) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
Deployable - Interface in org.eclipse.jetty.server
Interface that can be implemented by ContextHandlers within Environments to allow configuration to be passed from the DeploymentManager without dependencies on the Deployment module itself.
deployHandler(Handler, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Thread safe deploy of a Handler.
deregister(LifeCycle) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
destroy() - Method in class org.eclipse.jetty.server.Handler.Abstract
 
destroy() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
destroy() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
destroy(Object) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
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).
doGet(Request, Response, Callback, HttpContent) - Method in class org.eclipse.jetty.server.ResourceService
 
DontHandle() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.DontHandle
 
DontHandle(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.DontHandle
 
DoSHandler - Class in org.eclipse.jetty.server.handler
A Denial of Service Handler that protects from attacks by limiting the request rate from remote clients.
DoSHandler(Function<Request, String>, DoSHandler.Tracker.Factory, Request.Handler, int) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler
 
DoSHandler(DoSHandler.Tracker.Factory) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler
 
DoSHandler(Handler, Function<Request, String>, DoSHandler.Tracker.Factory, Request.Handler, int) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler
 
DoSHandler(Handler, Function<Request, String>, DoSHandler.Tracker.Factory, Request.Handler, int, boolean) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler
 
DoSHandler.DelayedRejectHandler - Class in org.eclipse.jetty.server.handler
A Handler to reject DoS requests after first delaying them.
DoSHandler.LeakingBucketTrackerFactory - Class in org.eclipse.jetty.server.handler
The Tracker implements the classic Leaky Bucket Algorithm.
DoSHandler.StatusRejectHandler - Class in org.eclipse.jetty.server.handler
A Handler to reject DoS requests with a status code or failure.
DoSHandler.Tracker - Interface in org.eclipse.jetty.server.handler
A RateTracker is associated with an id, and stores request rate data.
DoSHandler.Tracker.Factory - Interface in org.eclipse.jetty.server.handler
 
doShutdownOutput() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
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.Abstract
 
doStart() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.DoSHandler.DelayedRejectHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.DoSHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
doStart() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
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.MemoryConnector
 
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.Slf4jRequestLogWriter
 
doStart() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
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.Abstract
 
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.DoSHandler.DelayedRejectHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.DoSHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
doStop() - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
doStop() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
doStop() - Method in class org.eclipse.jetty.server.MemoryConnector
 
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
 
DownstreamConnection(EndPoint, Executor, ByteBufferPool, ConcurrentMap<String, Object>) - Constructor for class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
dump() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.PathMappingsHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
dump(Appendable, String) - Method in class org.eclipse.jetty.server.Server
 

E

EE_ENVIRONMENT_NAME_PATTERN - Static variable in interface org.eclipse.jetty.server.Deployable
 
ElseNext() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.ElseNext
 
ElseNext(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.ElseNext
 
enableLowOnResources(boolean, boolean) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
encodeURI(Request, String, boolean) - Method in interface org.eclipse.jetty.server.Session
 
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
ensureConsumeAvailableOrNotPersistent(Request, Response) - Static method in class org.eclipse.jetty.server.ResponseUtils
 
ensureNotPersistent(Request, Response) - Static method in class org.eclipse.jetty.server.ResponseUtils
 
enterScope(Context, Request) - Method in interface org.eclipse.jetty.server.handler.ContextHandler.ContextScopeListener
 
enterScope(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
ENVIRONMENT - Static variable in interface org.eclipse.jetty.server.Deployable
 
ENVIRONMENT_COMPARATOR - Static variable in interface org.eclipse.jetty.server.Deployable
A comparator that ranks names matching EE_ENVIRONMENT_NAME_PATTERN higher than other names, EE names are compared by EE number, otherwise simple name comparison is used.
ENVIRONMENT_XML - Static variable in interface org.eclipse.jetty.server.Deployable
 
equals(Object) - Method in record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.ConnectorPredicate
 
equals(Object) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
equals(Object) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.MethodPredicate
 
equals(Object) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PathSpecPredicate
 
equals(Object) - Method in class org.eclipse.jetty.server.MemoryTransport
 
equals(Object) - Method in record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Indicates whether some other object is "equal to" this one.
ERROR_CACHE_CONTROL - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_CONTEXT - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_EXCEPTION - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_MESSAGE - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_METHODS - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_ORIGIN - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ERROR_STATUS - Static variable in class org.eclipse.jetty.server.handler.ErrorHandler
 
ErrorHandler - Class in org.eclipse.jetty.server.handler
Handler for Error pages An ErrorHandler is registered with Server.setErrorHandler(Request.Handler).
ErrorHandler() - Constructor for class org.eclipse.jetty.server.handler.ErrorHandler
 
ErrorHandler.ErrorRequest - Class in org.eclipse.jetty.server.handler
 
errorPageForMethod(String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
ErrorRequest(Request, int, String, Throwable) - Constructor for class org.eclipse.jetty.server.handler.ErrorHandler.ErrorRequest
 
EventsHandler - Class in org.eclipse.jetty.server.handler
A Handler.Wrapper that fires events during the processing of the requests.
EventsHandler() - Constructor for class org.eclipse.jetty.server.handler.EventsHandler
 
EventsHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.EventsHandler
 
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.server.handler.InetAccessHandler
Excludes InetAccess patterns
exclude(String, String, PathSpec) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Excludes an InetAccess entry.
exclude(Predicate<Request>...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude arbitrary Predicates in the conditions.
exclude(PathSpec...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude PathSpecs in the conditions to be met
exclude(InetAddressPattern...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude InetAddressPatterns in the conditions to be met
excludeInetAddressPattern(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude InetAddressPattern in the conditions to be met
excludeMethod(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude methods in the conditions to be met
excludeMimeType(String...) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
excludePath(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Exclude PathSpec in the conditions to be met
execute(Runnable) - Method in interface org.eclipse.jetty.server.Context
Executes the given task in a thread scoped to this Context.
execute(Runnable) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
execute(Runnable) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
execute(Runnable, Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
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.
exitScope(Context, Request) - Method in interface org.eclipse.jetty.server.handler.ContextHandler.ContextScopeListener
 
exitScope(Request, Context, ClassLoader) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
EXTENDED_NCSA_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
EXTRACT_WARS - Static variable in interface org.eclipse.jetty.server.Deployable
 
extractQueryParameters(Request) - Static method in interface org.eclipse.jetty.server.Request
 
extractQueryParameters(Request, Charset) - Static method in interface org.eclipse.jetty.server.Request
 

F

fail(Throwable) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
failed(Throwable) - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
failed(Throwable) - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
failSuspended(Request, Response, Callback, int, Throwable) - Method in class org.eclipse.jetty.server.handler.QoSHandler
Fails the given suspended request/response with the given error code and failure.
fill(ByteBuffer) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
fillInterested(Callback) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
findContainerOf(Handler.Container, Class<T>, Handler) - Static method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
findNextProtocol(Connector) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
findNextProtocol(Connector, String) - Static method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
findRequestName(Request) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
FOLLOW_LINKS - Static variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
FORCED - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
FormFields - Class in org.eclipse.jetty.server
A CompletableFuture that is completed once a application/x-www-form-urlencoded content has been parsed asynchronously from the Content.Source.
FORWARDED - Enum constant in enum class 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 Class in org.eclipse.jetty.server
Ordered Source Enum.
from(String, String, String, String) - Static method in class org.eclipse.jetty.server.handler.ConditionalHandler
from(String, InetAddressPattern, String, PathSpec) - Static method in class org.eclipse.jetty.server.handler.ConditionalHandler
from(Request) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.
from(Request) - Static method in interface org.eclipse.jetty.server.HttpChannel
 
from(Request, int, int) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.
from(Request, Charset) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.
from(Request, Charset, int, int) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.

G

generateAcceptableResponse(Request, Response, Callback, String, List<Charset>, int, String, Throwable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
generateCacheControl(Response) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
generateResponse(Request, Response, int, String, Throwable, Callback) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
generateResponse(Request, Response, int, String, Throwable, Callback) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler
 
get(int) - Method in class org.eclipse.jetty.server.CookieCache
 
get(int) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler.ByHttpStatus
 
get(Request) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.
get(Request, Class<T>, Function<T, R>) - Static method in interface org.eclipse.jetty.server.Request
 
getAcceptedReceiveBufferSize() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptedSendBufferSize() - Method in class org.eclipse.jetty.server.ServerConnector
 
getAcceptedTcpNoDelay() - Method in class org.eclipse.jetty.server.ServerConnector
 
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
 
getAcceptRateLimit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getAliasChecks() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAllowedHeaders() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getAllowedMethods() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getAllowedOriginPatterns() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getAllowedTimingOriginPatterns() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getAllowNullPathInContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getApi() - Method in interface org.eclipse.jetty.server.Session
 
getApiCookies(Class<C>, Function<HttpCookie, C>) - Method in class org.eclipse.jetty.server.CookieCache
 
getApiCookies(Request, Class<C>, Function<HttpCookie, C>) - Static method in class org.eclipse.jetty.server.CookieCache
Get the API specific cookies for a request.
getAsXHTML(Resource, String, boolean, String) - Static method in class org.eclipse.jetty.server.ResourceListing
Convert the Resource directory into an XHTML directory listing.
getAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttribute(String) - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
getAttribute(String) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getAttribute(String) - Method in class org.eclipse.jetty.server.Server
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getAttributeNameSet() - Method in class org.eclipse.jetty.server.Server
 
getAuthenticationState(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getBaseName(Resource) - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
getBaseResource() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
getBaseResource() - Method in interface org.eclipse.jetty.server.Context
 
getBaseResource() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getBaseResource() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getBaseResource() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getBeginNanoTime() - Method in interface org.eclipse.jetty.server.Request
Get the nanoTime at which the request arrived to a connector, obtained via System.nanoTime().
getBeginNanoTime() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getBlackListHosts() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getBufferSize() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getBufferSize() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getByteBufferPool() - Method in interface org.eclipse.jetty.server.Components
 
getByteBufferPool() - Method in interface org.eclipse.jetty.server.Connector
Get the ByteBufferPool to acquire buffers from and release buffers to.
getByteBufferPool() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
getByteBufferPool() - Method in class org.eclipse.jetty.server.Server
 
getBytesRead() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getBytesWritten() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getCache() - Method in interface org.eclipse.jetty.server.Components
A map-like object that can be used as a cache (for example, as a cookie cache).
getCacheControl() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Get the cacheControl.
getCacheControl() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Get the Cache-Control header value or null.
getCacheControl() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
Get the cacheControl header to set on all static content..
getCacheControl() - Method in class org.eclipse.jetty.server.ResourceService
Get the cacheControl header to set on all static content..
getCallback() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
getCallback() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
getCanonicalNameForTmpDir() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Create a canonical name for a context temp directory.
getCharset(Request) - Static method in interface org.eclipse.jetty.server.Request
Get a Charset from the request HttpHeader.CONTENT_TYPE, if any.
getClassLoader() - Method in interface org.eclipse.jetty.server.Context
 
getClassLoader() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getClassLoader() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getClassPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Make best effort to extract a file classpath from the context classloader
getComplianceViolationListener() - Method in interface org.eclipse.jetty.server.HttpChannel
 
getComplianceViolationListeners() - Method in class org.eclipse.jetty.server.HttpConfiguration
Get the list of configured ComplianceViolation.Listener to use.
getComponents() - Method in interface org.eclipse.jetty.server.Request
 
getComponents() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getConnectedEndPoints() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getConnectedEndPoints() - Method in interface org.eclipse.jetty.server.Connector
 
getConnection() - Method in class org.eclipse.jetty.server.AbstractMetaDataConnection
 
getConnection() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getConnection() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getConnection() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
getConnection() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
getConnection() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
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
 
getConnectionMetaData() - Method in interface org.eclipse.jetty.server.HttpChannel
 
getConnectionMetaData() - Method in interface org.eclipse.jetty.server.Request
 
getConnectionMetaData() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getConnections() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getConnector() - Method in class org.eclipse.jetty.server.AbstractMetaDataConnection
 
getConnector() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getConnector() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getConnector() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getConnectors() - Method in class org.eclipse.jetty.server.Server
 
getConnectTimeout() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Get the timeout, in milliseconds, to connect to the remote server.
getContainer(Handler, Class<T>) - Method in interface org.eclipse.jetty.server.Handler.Container
 
getContent(String, Request) - Method in class org.eclipse.jetty.server.ResourceService
 
getContentBytesRead(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getContentBytesWritten(Response) - Static method in interface org.eclipse.jetty.server.Response
 
getContext() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
getContext() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
getContext() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
getContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContext() - Method in class org.eclipse.jetty.server.handler.ContextRequest
 
getContext() - Method in interface org.eclipse.jetty.server.Request
Get the Context associated with this Request.
getContext() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getContext() - Method in class org.eclipse.jetty.server.Server
Get the Context associated with all Requests prior to being handled by a ContextHandler.
getContextAttributes() - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
getContextHandler() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
getContextHandler() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getContextHandler(Request) - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContextName(ContextHandler) - Method in class org.eclipse.jetty.server.jmx.Handler.AbstractMBean
 
getContextPath() - Method in interface org.eclipse.jetty.server.Context
 
getContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getContextPath() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getContextPath(Request) - Static method in interface org.eclipse.jetty.server.Request
Get the context path of this Request.
getContextPaths() - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
getContexts() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getCookies(Request) - Static method in class org.eclipse.jetty.server.CookieCache
Get the core HttpCookies for a request.
getCookies(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getCrossContextDispatchType(Request) - Method in interface org.eclipse.jetty.server.Context
Get any cross context dispatch type
getCrossContextDispatchType(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getCrossContextHandler(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
If cross context dispatch is supported by this context then find a context by contextPath that also supports cross context dispatch.
getCurrentContext() - Static method in class org.eclipse.jetty.server.handler.ContextHandler
Get the current Context if any.
getCurrentContext(Server) - Static method in class org.eclipse.jetty.server.handler.ContextHandler
Get the current Context if any, or else server context if any.
getCurrentContextHandler() - Static method in class org.eclipse.jetty.server.handler.ContextHandler
 
getCurrentRequestCount() - Method in class org.eclipse.jetty.server.handler.GracefulHandler
 
getCustomizer(Class<T>) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getCustomizers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
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.
getDateField() - Method in class org.eclipse.jetty.server.Server
 
getDecoratedObjectFactory() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getDefaultConnectionFactory() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getDefaultConnectionFactory() - Method in interface org.eclipse.jetty.server.Connector
Get the default ConnectionFactory associated with the default protocol name.
getDefaultFavicon() - Method in class org.eclipse.jetty.server.Server
Get the default Favicon
getDefaultHandler() - Method in class org.eclipse.jetty.server.Server
 
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
 
getDefaultResponseMimeType() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
getDefaultStyleSheet() - Method in class org.eclipse.jetty.server.Server
Get the Default CSS
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.
getDemandCallbackTimeout() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
getDescendant(Class<T>) - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
getDescendant(Class<T>) - Method in interface org.eclipse.jetty.server.Handler.Container
 
getDescendants() - Method in interface org.eclipse.jetty.server.Handler.Container
 
getDescendants(Class<T>) - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
getDescendants(Class<T>) - Method in interface org.eclipse.jetty.server.Handler.Container
 
getDisplayName() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getEncodingCacheSize() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getEncodingCacheSize() - Method in class org.eclipse.jetty.server.ResourceService
 
getEndPoint() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
getEndPoint() - Method in interface org.eclipse.jetty.server.TunnelSupport
Returns the EndPoint that should be used to carry the tunneled protocol.
getErrorHandler() - Method in interface org.eclipse.jetty.server.Context
 
getErrorHandler() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getErrorHandler() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getErrorHandler() - Method in class org.eclipse.jetty.server.Server
 
getErrorHandler(Server, ContextHandler) - Static method in class org.eclipse.jetty.server.handler.ErrorHandler
 
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
getExecutor() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getExecutor() - Method in interface org.eclipse.jetty.server.Components
 
getExecutor() - Method in interface org.eclipse.jetty.server.Connector
Get the Executor used to submit tasks.
getExecutor() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getExposedHeaders() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getExtendedId() - Method in interface org.eclipse.jetty.server.Session
 
getFactories(SslContextFactory.Server, ConnectionFactory...) - Static method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getFailures() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getFields(Content.Source, Attributes, Charset, int, int) - Static method in class org.eclipse.jetty.server.FormFields
Get the Fields from a request.
getFields(Request) - Static method in class org.eclipse.jetty.server.FormFields
Get the Fields from a request.
getFields(Request, int, int) - Static method in class org.eclipse.jetty.server.FormFields
Get the Fields from a request.
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.
getForcedHost() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getFormatString() - Method in class org.eclipse.jetty.server.CustomRequestLog
Retrieve the format string.
getFormEncodedCharset(Request) - Static method in class org.eclipse.jetty.server.FormFields
 
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
Get the forwarded for header.
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
Get the header name for forwarded server..
getForwardedSslSessionIdHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getGzipEquivalentFileExtensions() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getGzipEquivalentFileExtensions() - Method in class org.eclipse.jetty.server.ResourceService
 
getHandleActive() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandleActiveMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandler() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
getHandler() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
getHandler() - Method in interface org.eclipse.jetty.server.Handler.Singleton
 
getHandler() - Method in class org.eclipse.jetty.server.Handler.Wrapper
 
getHandlerCallbackTimeout() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
getHandlers() - Method in interface org.eclipse.jetty.server.Handler.Container
 
getHandlers() - Method in class org.eclipse.jetty.server.handler.PathMappingsHandler
 
getHandlers() - Method in class org.eclipse.jetty.server.Handler.Sequence
 
getHandlers() - Method in interface org.eclipse.jetty.server.Handler.Singleton
 
getHandleTimeMax() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandleTimeMean() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandleTimeStdDev() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandleTimeTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandleTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHandlingFailures() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getHeaderCacheSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getHeaders() - Method in class org.eclipse.jetty.server.handler.gzip.GzipRequest
 
getHeaders() - Method in class org.eclipse.jetty.server.handler.gzip.HeaderWrappingRequest
 
getHeaders() - Method in interface org.eclipse.jetty.server.Request
 
getHeaders() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getHeaders() - Method in interface org.eclipse.jetty.server.Response
 
getHeaders() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
getHeadersNanoTime() - Method in interface org.eclipse.jetty.server.Request
Get the nanoTime at which the request headers were parsed, obtained via System.nanoTime().
getHeadersNanoTime() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getHost() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
getHost() - Method in interface org.eclipse.jetty.server.NetworkConnector
 
getHostHeader() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getHostName(InetSocketAddress) - Static method in interface org.eclipse.jetty.server.Request
 
getHttpCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.AbstractMetaDataConnection
 
getHttpConfiguration() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getHttpConfiguration() - Method in interface org.eclipse.jetty.server.HttpConfiguration.ConnectionFactory
 
getHttpConfiguration() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
getHttpContentFactory() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getHttpContentFactory() - Method in class org.eclipse.jetty.server.ResourceService
 
getHttpCookie() - Method in class org.eclipse.jetty.server.HttpCookieUtils.SetCookieHttpField
 
getHttpURI() - Method in interface org.eclipse.jetty.server.Request
 
getHttpURI() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getHttpVersion() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getHttpVersion() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getId() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getId() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getId() - Method in interface org.eclipse.jetty.server.HttpStream
 
getId() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
getId() - Method in interface org.eclipse.jetty.server.Request
an ID unique within the lifetime scope of the ConnectionMetaData.getId()).
getId() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getId() - Method in interface org.eclipse.jetty.server.Session
 
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.handler.ConnectHandler
Get the idle timeout, in milliseconds.
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 interface org.eclipse.jetty.server.HttpStream
 
getIdleTimeout() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
getIdleTimeout() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getIdleTimeoutMs() - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
getIgnorePaths() - Method in class org.eclipse.jetty.server.CustomRequestLog
Retrieve the request paths that will not be logged.
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
getInetAddress(SocketAddress) - Static method in class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
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.
getInflaterPool() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Get the InflaterPool being used.
getInfo() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler.ThreadInfo
 
getInputBufferSize() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getInputBufferSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getInputBufferSize() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
getInstance() - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
getInvocationType() - Method in class org.eclipse.jetty.server.Handler.Abstract
 
getInvocationType() - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
getInvocationType() - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
getInvocationType() - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
getInvocationType() - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler
 
getInvocationType() - Method in class org.eclipse.jetty.server.Handler.Sequence
 
getInvocationType() - Method in class org.eclipse.jetty.server.Handler.Wrapper
 
getInvocationType() - Method in interface org.eclipse.jetty.server.HttpStream
 
getInvocationType() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
getInvocationType() - Method in interface org.eclipse.jetty.server.Request.Handler
 
getInvocationType() - Method in class org.eclipse.jetty.server.Server
 
getKey() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
getLastAccessedTime() - Method in interface org.eclipse.jetty.server.Session
 
getLeftMost(String) - Static method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getLength() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getLocalAddr(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getLocalAddress() - Method in class org.eclipse.jetty.server.HttpConfiguration
Get the SocketAddress override to be reported as the local address of all connections
getLocales(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getLocalPort() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
getLocalPort() - Method in interface org.eclipse.jetty.server.NetworkConnector
 
getLocalPort() - Method in class org.eclipse.jetty.server.ServerConnector
 
getLocalPort(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.server.AbstractMetaDataConnection
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.server.MemoryConnector
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getLoggerName() - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
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
 
getManagedObject() - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
getManagedObject() - Method in class org.eclipse.jetty.server.handler.jmx.QoSHandlerMBean
 
getManagedObject() - Method in class org.eclipse.jetty.server.jmx.Handler.AbstractMBean
 
getManagedObject() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getMaxConnections() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getMaxErrorDispatches() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMaxInactiveInterval() - Method in interface org.eclipse.jetty.server.Session
 
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
 
getMaxProxyHeader() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory
 
getMaxRate() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getMaxRequestCount() - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
getMaxSuspend() - Method in class org.eclipse.jetty.server.handler.QoSHandler
Get the max duration of time a request may stay suspended.
getMaxSuspendedRequestCount() - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
getMaxSuspendMillis() - Method in class org.eclipse.jetty.server.handler.jmx.QoSHandlerMBean
 
getMaxUnconsumedRequestContentReads() - Method in class org.eclipse.jetty.server.HttpConfiguration
Gets the maximum amount of HttpStream.read()s that can be done by the HttpStream if the content is not fully consumed by the application.
getMethod() - Method in interface org.eclipse.jetty.server.Request
 
getMethod() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getMimeTypes() - Method in interface org.eclipse.jetty.server.Context
 
getMimeTypes() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getMimeTypes() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getMimeTypes() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getMimeTypes() - Method in class org.eclipse.jetty.server.Server
 
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.
getMinRequestDataRate() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMinResponseDataRate() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMonitoredConnectors() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMonitoredOrServerConnectors() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMonitorThreads() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getMultiPartCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getMultiPartConfig(Request, Path) - Static method in interface org.eclipse.jetty.server.Request
Get a MultiPartConfig.Builder given a Request and a location.
getName() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getName() - Method in interface org.eclipse.jetty.server.Connector
Get the connector name if set.
getNegotiatedProtocols() - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
getNetworkTrafficListener() - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
Get the listener.
getNextProtocol() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
getObjectContextBasis() - Method in class org.eclipse.jetty.server.jmx.AbstractConnectorMBean
 
getObjectContextBasis() - Method in class org.eclipse.jetty.server.jmx.Handler.AbstractMBean
 
getOriginalPathAttribute() - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
Get the attribute name of the original request path.
getOriginalQueryAttribute() - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
Get the attribute name of the original request query.
getOriginalResponse(Response) - Static method in interface org.eclipse.jetty.server.Response
Unwraps the given response until the innermost wrapped response instance.
getOutputAggregationSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getOutputBufferSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getOutputStream() - Method in class org.eclipse.jetty.server.handler.DebugHandler
Get the out.
getParameters(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getParametersAsync(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getPath(Resource) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
Deprecated.
getPathInContext(String) - Method in interface org.eclipse.jetty.server.Context
Returns the URI path scoped to this Context.
getPathInContext(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getPathInContext(String, String) - Static method in interface org.eclipse.jetty.server.Context
Returns the URI path scoped to the passed context path.
getPathInContext(Request) - Static method in interface org.eclipse.jetty.server.Request
Returns the canonically encoded path of the URI, scoped to the current context.
getPaths() - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
 
getPendingConnections() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
getPeriod() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getPeriod() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
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
 
getPrecompressedFormats() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getPrecompressedFormats() - Method in class org.eclipse.jetty.server.ResourceService
 
getPreflightMaxAge() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
getPriority(Request) - Method in class org.eclipse.jetty.server.handler.QoSHandler
Returns the priority of the given suspended request, a value greater than or equal to 0.
getProtectedTargets() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getProtocol() - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
getProtocol() - Method in interface org.eclipse.jetty.server.ConnectionFactory
 
getProtocol() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getProtocol() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getProtocol() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getProtocol() - Method in interface org.eclipse.jetty.server.TunnelSupport
Returns the protocol of the CONNECT tunnel, or null if the tunnel transports HTTP or opaque bytes.
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
 
getProxyAsAuthority() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getRate() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
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
 
getReasons() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
getRedirectURI() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Get the URI to redirect to.
getRedirectUriCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getReHandlePathInContext(Request, int, Throwable) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler.ByHttpStatus
 
getReHandlePathInContext(Request, int, Throwable) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler
 
getRemoteAddr(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getRemoteIP(Request) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getRemotePort(Request) - Static method in interface org.eclipse.jetty.server.Request
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.server.AbstractMetaDataConnection
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getRequest() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
getRequest() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
getRequest() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler.MinimumDataRateResponse
 
getRequest() - Method in interface org.eclipse.jetty.server.HttpChannel
Returns the Request object, if available.
getRequest() - Method in interface org.eclipse.jetty.server.Response
 
getRequest() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
getRequestCookieCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getRequestHeaderSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getRequestLog() - Method in class org.eclipse.jetty.server.Server
 
getRequests() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
Deprecated.
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
 
getRequestTotal() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getResourceForTempDirName() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getResourceService() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getResponse() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectContext
 
getResponse() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
getResponse() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
Wait for a response using a parser to detect the end of message
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.
getResponseCookieCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getResponseData() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
getResponseHeaderSize() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
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
 
getRetainDays() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve the number of days before rotated log files are deleted.
getReuseAddress() - Method in class org.eclipse.jetty.server.ServerConnector
 
getRFC2965SetCookie(HttpCookie) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
 
getRFC6265SetCookie(HttpCookie) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
 
getSameSiteDefault(Attributes) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
Get the default value for SameSite cookie attribute, if one has been set for the given context.
getScheduler() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getScheduler() - Method in interface org.eclipse.jetty.server.Components
 
getScheduler() - Method in interface org.eclipse.jetty.server.Connector
Get the Scheduler used to schedule tasks.
getScheduler() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getScheduler() - Method in class org.eclipse.jetty.server.Server
 
getSecurePort() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSecurePort(HttpConfiguration) - Static method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
getSecureScheme() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getSelectorManager() - Method in class org.eclipse.jetty.server.ServerConnector
 
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
 
getSendXPoweredBy() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getServer() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getServer() - Method in interface org.eclipse.jetty.server.Connector
Get the Server instance associated with this Connector.
getServer() - Method in class org.eclipse.jetty.server.Handler.Abstract
 
getServer() - Method in interface org.eclipse.jetty.server.Handler
 
getServer() - Method in class org.eclipse.jetty.server.Server
 
getServerAuthority() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
getServerAuthority() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
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.
getServerInfo() - Method in class org.eclipse.jetty.server.Server
 
getServerName(Request) - Static method in interface org.eclipse.jetty.server.Request
Get the logical name the request was sent to, which may be from the authority of the request; the configured server authority; the actual network name of the server;
getServerPort(Request) - Static method in interface org.eclipse.jetty.server.Request
Get the logical port a request was received on, which may be from the authority of the request; the configured server authority; the default port for the scheme; or the actual network port.
getSession() - Method in interface org.eclipse.jetty.server.Session.API
 
getSession(boolean) - Method in interface org.eclipse.jetty.server.Request
Get a Session associated with the request.
getSession(boolean) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getSession(Object) - Static method in interface org.eclipse.jetty.server.Session
Get the session associated with an API session wrapper.
getSetCookie(HttpCookie, CookieCompliance) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
 
getShutdownIdleTimeout() - Method in class org.eclipse.jetty.server.AbstractConnector
 
getSocketAddress() - Method in class org.eclipse.jetty.server.MemoryTransport
 
getSslContextFactory() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
getSSLEngine() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
getSslSessionData() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getStackFrames() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler.ThreadInfo
 
getStartupTime() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getStatisticsDuration() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
getStatus() - Method in interface org.eclipse.jetty.server.Response
 
getStatus() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
getStatusCode() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Get the redirect status code, by default 303.
getStopAtShutdown() - Method in class org.eclipse.jetty.server.Server
 
getStopTimeout() - Method in class org.eclipse.jetty.server.Server
 
getStsMaxAge() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
getStyleSheet() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getSuspendedRequestCount() - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
getTail() - Method in interface org.eclipse.jetty.server.Handler.Singleton
 
getTempDirectory() - Method in interface org.eclipse.jetty.server.Context
 
getTempDirectory() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
getTempDirectory() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getTempDirectory() - Method in class org.eclipse.jetty.server.Server
 
getThreadLimit() - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getThreadLimit(String) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
getThreadPool() - Method in interface org.eclipse.jetty.server.Components
Deprecated, for removal: This API element is subject to removal in a future version.
getThreadPool() - Method in class org.eclipse.jetty.server.Server
 
getTimeStamp(Request) - Static method in interface org.eclipse.jetty.server.Request
Get the millisecond timestamp at which the request was created, obtained with System.currentTimeMillis().
getTimeZone() - Method in class org.eclipse.jetty.server.RequestLogWriter
 
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.
getTrailers() - Method in interface org.eclipse.jetty.server.Request
 
getTrailers() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getTrailersSupplier() - Method in interface org.eclipse.jetty.server.Response
 
getTrailersSupplier() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
getTransport() - Method in interface org.eclipse.jetty.server.Connector
Get the underlying socket, channel, buffer etc.
getTransport() - Method in class org.eclipse.jetty.server.LocalConnector
 
getTransport() - Method in class org.eclipse.jetty.server.MemoryConnector
 
getTransport() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
getTransport() - Method in class org.eclipse.jetty.server.ServerConnector
 
getTunnelSupport() - Method in interface org.eclipse.jetty.server.HttpStream
 
getTunnelSupport() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
getTunnelSupport() - Method in interface org.eclipse.jetty.server.Request
 
getTunnelSupport() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getUnits() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
getUpTime() - Method in class org.eclipse.jetty.server.jmx.ServerMBean
 
getURI() - Method in class org.eclipse.jetty.server.Server
 
getUriCompliance() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
getUserPrincipal() - Method in interface org.eclipse.jetty.server.Request.AuthenticationState
 
getValue() - Method in class org.eclipse.jetty.server.HttpCookieUtils.SetCookieHttpField
 
getVary() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
getVersion() - Static method in class org.eclipse.jetty.server.Server
 
getVirtualHosts() - Method in interface org.eclipse.jetty.server.Context
 
getVirtualHosts() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get the virtual hosts for the context.
getVirtualHosts() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
getWelcomeFactory() - Method in class org.eclipse.jetty.server.ResourceService
 
getWelcomeFiles() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getWelcomeMode() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
getWelcomeMode() - Method in class org.eclipse.jetty.server.ResourceService
 
getWelcomeTarget(HttpContent, Request) - Method in interface org.eclipse.jetty.server.ResourceService.WelcomeFactory
Finds a matching welcome target for the request.
getWhiteListHosts() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
getWrapped() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
getWriteCallbackTimeout() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
getWriter() - Method in class org.eclipse.jetty.server.CustomRequestLog
 
getWriteTimeout() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
GracefulHandler - Class in org.eclipse.jetty.server.handler
Handler to track active requests and allow them to gracefully complete.
GracefulHandler() - Constructor for class org.eclipse.jetty.server.handler.GracefulHandler
 
GracefulHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.GracefulHandler
 
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
 
GzipFactory - Interface in org.eclipse.jetty.server.handler.gzip
 
GzipHandler - Class in org.eclipse.jetty.server.handler.gzip
 
GzipHandler() - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHandler
Instantiates a new GzipHandler.
GzipHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipHandler
Instantiates a new GzipHandler.
GzipRequest - Class in org.eclipse.jetty.server.handler.gzip
 
GzipRequest(Request, int) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipRequest
 
GzipResponseAndCallback - Class in org.eclipse.jetty.server.handler.gzip
 
GzipResponseAndCallback(GzipHandler, Request, Response, Callback) - Constructor for class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 

H

handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DelayedHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DoSHandler.DelayedRejectHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DoSHandler.StatusRejectHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.EventsHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.GracefulHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.PathMappingsHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.SecuredRedirectHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.Handler.Sequence
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.Handler.Wrapper
 
handle(Request, Response, Callback) - Method in interface org.eclipse.jetty.server.Request.Handler
Invoked to handle the passed HTTP request and response.
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.Server
 
handle(Request, Response, Callback) - Method in class org.eclipse.jetty.server.SizeLimitHandler
 
handleAcceptFailure(Throwable) - Method in class org.eclipse.jetty.server.AbstractConnector
 
handleAcceptFailure(Throwable) - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
handleAuthentication(Request, Response, String) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Handles the authentication before setting up the tunnel to the remote server.
handleByContextHandler(String, ContextRequest, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
handleConnect(Request, Response, Callback, String) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Handles a CONNECT request.
handleMovedPermanently(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
Handler - Class in org.eclipse.jetty.server.jmx
 
Handler - Interface in org.eclipse.jetty.server
A Jetty component that handles HTTP requests, of any version (HTTP/1.1, HTTP/2 or HTTP/3).
Handler() - Constructor for class org.eclipse.jetty.server.jmx.Handler
 
Handler.Abstract - Class in org.eclipse.jetty.server
An abstract implementation of Handler that is a ContainerLifeCycle.
Handler.Abstract.NonBlocking - Class in org.eclipse.jetty.server
An abstract Handler with a Invocable.InvocationType.NON_BLOCKING invocation type.
Handler.AbstractContainer - Class in org.eclipse.jetty.server
Handler.AbstractMBean - Class in org.eclipse.jetty.server.jmx
 
Handler.Collection - Interface in org.eclipse.jetty.server
A Handler.Container that can contain multiple other Handlers.
Handler.Container - Interface in org.eclipse.jetty.server
A Handler that contains one or more other Handlers.
Handler.Sequence - Class in org.eclipse.jetty.server
A Handler.Container that contains an ordered list of children Handlers whose Request.Handler.handle(Request, Response, Callback) method is invoked in sequence on each child until a child returns true.
Handler.Singleton - Interface in org.eclipse.jetty.server
A Handler.Container that can contain one single other Handler.
Handler.Wrapper - Class in org.eclipse.jetty.server
An implementation of Handler.Singleton, which is a Handler.Container that wraps one single other Handler.
HandlerContainer - Interface in org.eclipse.jetty.server
Deprecated.
handlerName() - Method in record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Returns the value of the handlerName record component.
handleUnavailable(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
handleWelcomeAction(Request, Response, Callback, ResourceService.WelcomeAction) - Method in class org.eclipse.jetty.server.ResourceService
 
hashCode() - Method in record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Returns a hash code value for this object.
hashCode() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.ConnectorPredicate
 
hashCode() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
hashCode() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.MethodPredicate
 
hashCode() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PathSpecPredicate
 
hashCode() - Method in class org.eclipse.jetty.server.MemoryTransport
 
hashCode() - Method in record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Returns a hash code value for this object.
hasLastWrite() - Method in interface org.eclipse.jetty.server.Response
Returns whether the last write has been initiated on the response.
hasLastWrite() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
HeaderWrappingRequest - Class in org.eclipse.jetty.server.handler.gzip
 
HeaderWrappingRequest(Request, HttpFields) - Constructor for class org.eclipse.jetty.server.handler.gzip.HeaderWrappingRequest
 
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
 
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
 
HostHeaderCustomizer(String) - Constructor for class org.eclipse.jetty.server.HostHeaderCustomizer
 
HostHeaderCustomizer(String, int) - Constructor for class org.eclipse.jetty.server.HostHeaderCustomizer
 
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
 
htmlRow(Writer, String, Object) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
HttpChannel - Interface in org.eclipse.jetty.server
Represents the state of an HTTP request/response cycle.
HttpChannel.DefaultFactory - Class in org.eclipse.jetty.server
The factory that creates default implementations of HttpChannel.
HttpChannel.Factory - Interface in org.eclipse.jetty.server
A factory for HttpChannel instances.
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.
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
 
HttpCookieUtils - Class in org.eclipse.jetty.server
Utility methods for server-side HTTP cookie handling.
HttpCookieUtils.SetCookieHttpField - Class in org.eclipse.jetty.server
A HttpField that holds an HttpHeader.SET_COOKIE as a HttpCookie instance, delaying any value generation until HttpCookieUtils.SetCookieHttpField.getValue() is called.
HttpStream - Interface in org.eclipse.jetty.server
A HttpStream is an abstraction that together with MetaData.Request, represents the flow of data from and to a single request and response cycle.
HttpStream.Wrapper - Class in org.eclipse.jetty.server
 

I

ID_FROM_CONNECTION - Static variable in class org.eclipse.jetty.server.handler.DoSHandler
A Function to create a remote client identifier from ConnectionMetaData.getId() of a Request.
ID_FROM_REMOTE_ADDRESS - Static variable in class org.eclipse.jetty.server.handler.DoSHandler
A Function to create a remote client identifier from the remote address of a Request.
ID_FROM_REMOTE_ADDRESS_PORT - Static variable in class org.eclipse.jetty.server.handler.DoSHandler
A Function to create a remote client identifier from the remote address and remote port of a Request.
ID_FROM_REMOTE_PORT - Static variable in class org.eclipse.jetty.server.handler.DoSHandler
A Function to create a remote client identifier from the remote port of a Request.
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
 
IdleTimeoutHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
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.server.handler.InetAccessHandler
Includes InetAccess patterns
include(String, String, PathSpec) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
Includes an InetAccess entry.
include(Predicate<Request>...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include arbitrary Predicates in the conditions.
include(PathSpec...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include PathSpecs in the conditions to be met
include(InetAddressPattern...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include InetAddressPatterns in the conditions to be met
includeInetAddressPattern(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include InetAddressPatterns in the conditions to be met
includeMethod(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include methods in the conditions to be met
includeMimeType(String...) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
includePath(String...) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Include PathSpecs in the conditions to be met
InetAccessHandler - Class in org.eclipse.jetty.server.handler
InetAddress Access Handler
InetAccessHandler() - Constructor for class org.eclipse.jetty.server.handler.InetAccessHandler
 
InetAccessHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.InetAccessHandler
 
InetAddressPatternPredicate(InetAddressPattern) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
initialize() - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
initialize() - Method in interface org.eclipse.jetty.server.HttpChannel
Initialize the HttpChannel when a new cycle of request handling begins.
initializeDefaults(Map<String, String>) - Method in interface org.eclipse.jetty.server.Deployable
 
insertHandler(Handler.Singleton) - Method in interface org.eclipse.jetty.server.Handler.Singleton
Inserts the given Handler (and possible chain of Handlers) between this Handler and its current child.
interruptAcceptors() - Method in class org.eclipse.jetty.server.AbstractConnector
 
invalidate() - Method in interface org.eclipse.jetty.server.Session
Invalidate this session in the current context and all sessions of the same identity with associated contexts.
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
 
isAlive() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
isAllowCredentials() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
isAllowed(Path) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
isAppend() - Method in class org.eclipse.jetty.server.RequestLogWriter
Retrieve append to log flag.
isApplyToAsync() - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
isAvailable() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isCommitted() - Method in interface org.eclipse.jetty.server.HttpStream
 
isCommitted() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
isCommitted() - Method in interface org.eclipse.jetty.server.Response
Returns whether this response has already been committed.
isCommitted() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
isCompletedSuccessfully() - Method in interface org.eclipse.jetty.server.Response
Returns whether the response completed successfully.
isCompletedSuccessfully() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
isCompleteHandlerCallbackAtTimeout() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
isCrossContextDispatch(Request) - Method in interface org.eclipse.jetty.server.Context
Check cross context dispatch status
isCrossContextDispatch(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
isCrossContextDispatchSupported() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Get if this context support cross context dispatch, either as originator or target.
isDelayDispatchUntilContent() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isDeliverNonAllowedOriginRequests() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
isDeliverNonAllowedOriginWebSocketUpgradeRequests() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
isDeliverPreflightRequests() - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
isDirAllowed() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isDirAllowed() - Method in class org.eclipse.jetty.server.ResourceService
 
isDirectBuffersForDecryption() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isDirectBuffersForEncryption() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isDiscardPathInContext() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
isDiscardQuery() - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
isDryRun() - Method in class org.eclipse.jetty.server.Server
 
isDumpAfterStart() - Method in class org.eclipse.jetty.server.Server
 
isDumpBeforeStop() - Method in class org.eclipse.jetty.server.Server
 
isDynamic() - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
isEnabled() - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
isEnabled() - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
isEnsureSecureRequestCustomizer() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
isEtags() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isEtags() - Method in class org.eclipse.jetty.server.ResourceService
 
isExitJvm() - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
isExitVm() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
isFillInterested() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isFormEncodedMethod(String) - Method in class org.eclipse.jetty.server.HttpConfiguration
Tests whether the HTTP method supports x-www-form-urlencoded content
isGenerateRedirectBody() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isHeaderCacheCaseSensitive() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isInheritChannel() - Method in class org.eclipse.jetty.server.ServerConnector
 
isInputShutdown() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
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
 
isMimeTypeBufferable(String) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
isMimeTypeDeflatable(String) - Method in interface org.eclipse.jetty.server.handler.gzip.GzipFactory
 
isMimeTypeDeflatable(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.
isMimeTypeDeflatable(MimeTypes, String) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
isNew() - Method in interface org.eclipse.jetty.server.Session
 
isNotifyRemoteAsyncErrors() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
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
 
isOpenEarly() - Method in class org.eclipse.jetty.server.Server
 
isOutputShutdown() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
isPathDeflatable(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.
isPersistent() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
isPersistent() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
isPersistentConnectionsEnabled() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isProtectedTarget(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Check the target when a target within a context is determined.
isPushSupported() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
isPushSupported() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
isRecordHttpComplianceViolations() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
Deprecated, for removal: This API element is subject to removal in a future version.
use HttpConfiguration.getComplianceViolationListeners() instead to know if there are any ComplianceViolation.Listener to notify. this method will be removed in Jetty 12.1.0
isRegistered(LifeCycle) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
isRelativeRedirectAllowed() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isRequestHandled() - Method in interface org.eclipse.jetty.server.HttpChannel
 
isReusePort() - Method in class org.eclipse.jetty.server.ServerConnector
 
isSameFile(Path, Path) - Method in class org.eclipse.jetty.server.AllowedResourceAliasChecker
Deprecated.
isSecure() - Method in interface org.eclipse.jetty.server.ConnectionMetaData
 
isSecure() - Method in class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
isSecure() - Method in interface org.eclipse.jetty.server.Request
 
isSecure() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
isSecure() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer.SecureRequest
 
isSecure() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer.SecureRequestWithSslSessionData
 
isServeFavIcon() - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
isShowCauses() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
isShowContexts() - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
isShowHeaders() - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
isShowMessageInTitle() - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
isShowOrigin() - 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.server.AbstractConnector
 
isShutdown() - Method in class org.eclipse.jetty.server.handler.GracefulHandler
Flag indicating that Graceful shutdown has been initiated.
isSniHostCheck() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSniRequired() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSslIsSecure() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
isStsIncludeSubDomains() - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
isSyncFlush() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Is the Deflater running Deflater.SYNC_FLUSH or not.
isTempDirectoryPersistent() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
isUseFileMapping() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isUseInputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
isUseOutputDirectByteBuffers() - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
isValid() - Method in interface org.eclipse.jetty.server.Session
 
iterator() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 

J

join() - Method in class org.eclipse.jetty.server.AbstractConnector
 
join() - Method in class org.eclipse.jetty.server.Server
 
join(long) - Method in class org.eclipse.jetty.server.AbstractConnector
 

L

LatencyRecordingHandler - Class in org.eclipse.jetty.server.handler
A Handler that helps recording the total latency of the requests executed by the wrapped handler.
LatencyRecordingHandler() - Constructor for class org.eclipse.jetty.server.handler.LatencyRecordingHandler
 
LatencyRecordingHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.LatencyRecordingHandler
 
LeakingBucketTrackerFactory(int) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.LeakingBucketTrackerFactory
 
LeakingBucketTrackerFactory(int, int, Duration) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.LeakingBucketTrackerFactory
 
lifeCycleFailure(LifeCycle, Throwable) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStarted(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStarting(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStopped(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
lifeCycleStopping(LifeCycle) - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
limit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
limit() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
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
LocalEndPoint() - Constructor for class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
LocalEndPoint(int) - Constructor for class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
log(String, Object...) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
log(Request, Response) - Method in class org.eclipse.jetty.server.CustomRequestLog
 
log(Request, Response) - Method in class org.eclipse.jetty.server.RequestLog.Collection
 
log(Request, Response) - Method in interface org.eclipse.jetty.server.RequestLog
 
LOG - Static variable in class org.eclipse.jetty.server.AbstractConnector
 
LOG - Static variable in class org.eclipse.jetty.server.CookieCache
 
LOG - Static variable in interface org.eclipse.jetty.server.Request
 
LOG - Static variable in class org.eclipse.jetty.server.ResourceListing
 
LOG_DETAIL - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
LogDetail(String, String) - Constructor for record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Creates an instance of a LogDetail record class.
low(String, String) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
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

main(String...) - Static method in class org.eclipse.jetty.server.Server
 
MainThreadPoolLowResourceCheck() - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MainThreadPoolLowResourceCheck
 
makeTempDirectory() - Method in class org.eclipse.jetty.server.handler.ContextHandler
Generate a reasonable name for the temp directory because one has not been explicitly configured by the user with ContextHandler.setTempDirectory(File).
MANAGED_ATTRIBUTES - Static variable in class org.eclipse.jetty.server.handler.ContextHandler
 
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
 
mapContexts() - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Remap the contexts.
match(String, String, String, String) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
Check if the Set-Cookie header represented as a string is for the name, domain and path given.
match(HttpCookie, String, String, String) - Static method in class org.eclipse.jetty.server.HttpCookieUtils
Check if the HttpCookie is for the given name, domain and path.
MAX_AGGREGATION_SIZE_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.handler.BufferedResponseHandler
The name of the request attribute used to control the max aggregation size of a particular request.
MAX_FIELDS_ATTRIBUTE - Static variable in class org.eclipse.jetty.server.FormFields
 
MAX_FIELDS_DEFAULT - Static variable in class org.eclipse.jetty.server.FormFields
 
MAX_LENGTH_ATTRIBUTE - Static variable in class org.eclipse.jetty.server.FormFields
 
MAX_LENGTH_DEFAULT - Static variable in class org.eclipse.jetty.server.FormFields
 
MaxConnectionsLowResourceCheck(int) - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MaxConnectionsLowResourceCheck
 
MemoryConnector - Class in org.eclipse.jetty.server
A server Connector that allows clients to communicate via memory.
MemoryConnector(Server, Executor, Scheduler, ByteBufferPool, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.MemoryConnector
 
MemoryConnector(Server, ConnectionFactory...) - Constructor for class org.eclipse.jetty.server.MemoryConnector
 
MemoryLowResourceCheck(long) - Constructor for class org.eclipse.jetty.server.LowResourceMonitor.MemoryLowResourceCheck
 
MemoryTransport - Class in org.eclipse.jetty.server
A Transport suitable to be used when using a MemoryConnector.
MemoryTransport(MemoryConnector) - Constructor for class org.eclipse.jetty.server.MemoryTransport
 
MethodPredicate(String) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.MethodPredicate
 
MinimumDataRateHandler(long, long) - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler
Creates a MinimumDataRateHandler with the specified read and write rates.
MinimumDataRateHandler(Handler, long, long) - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler
Creates a MinimumDataRateHandler with the specified read and write rates.
MinimumDataRateResponse(StatisticsHandler.MinimumDataRateHandler.MinimumDataRateRequest, Response) - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler.MinimumDataRateResponse
 
mode() - Method in record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Returns the value of the mode record component.
monitor() - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
MovedContextHandler - Class in org.eclipse.jetty.server.handler
A ContextHandler with a child Handler that redirects to a configurable URI.
MovedContextHandler() - Constructor for class org.eclipse.jetty.server.handler.MovedContextHandler
 

N

NCSA_FORMAT - Static variable in class org.eclipse.jetty.server.CustomRequestLog
 
NEED_MORE_BYTES - Enum constant in enum class org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting requires more bytes to make a decision.
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
 
NetworkConnector - Interface in org.eclipse.jetty.server
A Connector for TCP/IP network connectors
NetworkConnector.Listener - Interface in org.eclipse.jetty.server
Receives notifications of the NetworkConnector.open() and NetworkConnector.close() events.
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
 
newConnectAddress(String, int) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Creates the server address to connect to.
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectManager
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
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
 
newContext() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
newDelayedProcess(boolean, String, MimeTypes.Type, Handler, Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DelayedHandler
 
newDownstreamConnection(EndPoint, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.ConnectManager
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
newEndPoint(SocketChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
 
newEndPoint(SocketChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.server.ServerConnector
 
newHandlers(List<Handler>) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
 
newHandlers(List<Handler>) - Method in class org.eclipse.jetty.server.Handler.Sequence
 
newHttpChannel(ConnectionMetaData) - Method in class org.eclipse.jetty.server.HttpChannel.DefaultFactory
 
newHttpChannel(ConnectionMetaData) - Method in interface org.eclipse.jetty.server.HttpChannel.Factory
 
newHttpContentFactory(ByteBufferPool.Sized) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
newHttpURIFrom(Request, String) - Static method in interface org.eclipse.jetty.server.Request
Creates a new HttpURI from the given Request's HttpURI and the given path in context.
newResourceService() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
newSecureRequest(Request, EndPoint.SslSessionData) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
newSelectorManager() - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
newSelectorManager(Executor, Scheduler, int) - Method in class org.eclipse.jetty.server.ServerConnector
 
newServerConnection(Connector, EndPoint, SSLEngine, List<String>, String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
newSslConnection(Connector, EndPoint, SSLEngine) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
newTracker(String) - Method in class org.eclipse.jetty.server.handler.DoSHandler.LeakingBucketTrackerFactory
 
newTracker(String) - Method in interface org.eclipse.jetty.server.handler.DoSHandler.Tracker.Factory
 
newTrailersChunkProcessor(Response) - Static method in interface org.eclipse.jetty.server.Response
Returns a chunk processor suitable to be passed to the Content.copy(Content.Source, Content.Sink, Content.Chunk.Processor, Callback) method, that will handle Trailers chunks by adding their fields to the HttpFields supplied by Response.getTrailersSupplier().
newUpstreamConnection(EndPoint, ConnectHandler.ConnectContext) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
nextHandler(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Handle a request by invoking the ConditionalHandler.handle(Request, Response, Callback) method of the next Handler.
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.
NO_FOLLOW_LINKS - Static variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
noCompression() - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
NonBlocking() - Constructor for class org.eclipse.jetty.server.Handler.Abstract.NonBlocking
 
NOT_RECOGNIZED - Enum constant in enum class org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting cannot work with the given bytes.
notifyEnterScope(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
notifyExitScope(Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 

O

onAccepted(SelectableChannel) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAcceptFailed(SelectableChannel, Throwable) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
onAfterHandling(Request, boolean, Throwable) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked after application handling (i.e.
onAfterHandling(Request, boolean, Throwable) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
onBeforeHandling(Request) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked just before calling the server handler tree (i.e.
onBeforeHandling(Request) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
onClose() - Method in interface org.eclipse.jetty.server.HttpChannel
Notifies this HttpChannel that an asynchronous close happened.
onClose(Throwable) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
onClose(NetworkConnector) - Method in interface org.eclipse.jetty.server.NetworkConnector.Listener
Invoked when the given NetworkConnector has been closed.
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
 
onComplete(Request, int, HttpFields, Throwable) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked when the request and response processing are complete, just before the request and response will be recycled (i.e.
onComplete(Request, int, HttpFields, Throwable) - Method in class org.eclipse.jetty.server.handler.LatencyRecordingHandler
 
onComplete(Request, int, HttpFields, Throwable) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
onComplete(Request, Throwable) - Method in class org.eclipse.jetty.server.handler.EventsHandler
onComplianceViolation(ComplianceViolation.Event) - Method in class org.eclipse.jetty.server.CookieCache
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.DontHandle
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
Handle a request that has met the conditions.
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.Reject
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.SkipNext
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.DoSHandler
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
onConditionsMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.ElseNext
 
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler
This method is called when the request has not met the conditions and is not to be handled by this handler.
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.InetAccessHandler
 
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.QoSHandler
 
onConditionsNotMet(Request, Response, Callback) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
onConnectFailure(Request, Response, Callback, Throwable) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
onConnectSuccess(ConnectHandler.ConnectContext, ConnectHandler.UpstreamConnection) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
onContent() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.UntilContentDelayedProcess
 
onContentAvailable() - Method in interface org.eclipse.jetty.server.HttpChannel
HttpStream invokes this method when more HTTP request content is available.
onDemandCallbackBlocked(Request, StateTrackingHandler.ThreadInfo, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the request demand callback run() method blocks for longer than the timeout specified with StateTrackingHandler.getDemandCallbackTimeout().
onEndPointClosed(EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnector
 
onEndPointOpened(EndPoint) - Method in class org.eclipse.jetty.server.AbstractConnector
 
onError(HttpField, Throwable) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
onFailure(Throwable) - Method in interface org.eclipse.jetty.server.HttpChannel
Notifies this HttpChannel that an asynchronous failure happened.
onFields(Request, Charset, Promise.Invocable<Fields>) - Static method in class org.eclipse.jetty.server.FormFields
Asynchronously read and parse FormFields from a Request.
onFields(Request, Promise.Invocable<Fields>) - Static method in class org.eclipse.jetty.server.FormFields
Asynchronously read and parse FormFields from a Request.
onFillable() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
onFillable() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
onFillable() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
onHandlerCallbackNotCompleted(Request, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the Handler callback is not completed within the timeout specified with StateTrackingHandler.getHandlerCallbackTimeout().
onHandlerException(Request, Throwable, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the Handler chain throws an exception from the Request.Handler.handle(Request, Response, Callback) method.
onIdleTimeout(TimeoutException) - Method in interface org.eclipse.jetty.server.HttpChannel
Notifies this HttpChannel that an idle timeout happened.
onInvalidHandlerReturnValue(Request, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the Handler chain returns false, but the handler callback has been completed.
onOpen() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
onOpen() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
onOpen() - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
onOpen() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
onOpen(NetworkConnector) - Method in interface org.eclipse.jetty.server.NetworkConnector.Listener
Invoked when the given NetworkConnector has been opened.
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
 
onRemoteFailure(Throwable) - Method in interface org.eclipse.jetty.server.HttpChannel
Notifies this HttpChannel that an asynchronous notification was received indicating a remote failure happened.
onRequest(long) - Method in interface org.eclipse.jetty.server.handler.DoSHandler.Tracker
Add a request to the tracker and check the rate limit
onRequest(MetaData.Request) - Method in interface org.eclipse.jetty.server.HttpChannel
HttpStream invokes this method when the metadata of an HTTP request (method, URI and headers, but not content) has been parsed.
onRequestComplete(String, long) - Method in class org.eclipse.jetty.server.handler.LatencyRecordingHandler
Called back for each completed request with its execution's latency.
onRequestRead(Request, Content.Chunk) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked every time a request content chunk has been parsed, just before making it available to the application (i.e.
onRequestRead(Request, Content.Chunk) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
onResponseBegin(Request, int, HttpFields) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked just before the response is line written to the network (i.e.
onResponseTrailersComplete(Request, HttpFields) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked after the response trailers have been written and the final EventsHandler.onResponseWriteComplete(Request, Throwable) event was fired.
onResponseWrite(Request, boolean, ByteBuffer) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked before each response content chunk has been written (i.e.
onResponseWrite(Request, boolean, ByteBuffer) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
onResponseWriteComplete(Request, Throwable) - Method in class org.eclipse.jetty.server.handler.EventsHandler
Invoked after each response content chunk has been written (i.e.
onSessionActivation(Session) - Method in interface org.eclipse.jetty.server.Session.ValueListener
 
onSessionAttributeUpdate(Session, String, Object, Object) - Method in interface org.eclipse.jetty.server.Session.ValueListener
 
onSessionCreated(Session) - Method in interface org.eclipse.jetty.server.Session.LifeCycleListener
 
onSessionDestroyed(Session) - Method in interface org.eclipse.jetty.server.Session.LifeCycleListener
 
onSessionIdChanged(Session, String) - Method in interface org.eclipse.jetty.server.Session.LifeCycleListener
 
onSessionPassivation(Session) - Method in interface org.eclipse.jetty.server.Session.ValueListener
 
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
onWriteBlocked(Request, StateTrackingHandler.ThreadInfo, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the Response.write(boolean, ByteBuffer, Callback) call blocks for longer than the timeout specified with StateTrackingHandler.getWriteTimeout().
onWriteCallbackBlocked(Request, Throwable, StateTrackingHandler.ThreadInfo, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the write callback passed to Response.write(boolean, ByteBuffer, Callback) blocks for longer than the timeout specified with StateTrackingHandler.getWriteCallbackTimeout().
onWriteCallbackNotCompleted(Request, Throwable, StateTrackingHandler.ThreadInfo) - Method in interface org.eclipse.jetty.server.handler.StateTrackingHandler.Listener
Invoked when the write callback passed to Response.write(boolean, ByteBuffer, Callback) is not completed for longer than the timeout specified with StateTrackingHandler.getWriteTimeout().
open() - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
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(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.
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.
org.eclipse.jetty.server - module org.eclipse.jetty.server
 
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 Core Server : JMX Integration
otherProtocol(ByteBuffer, EndPoint) - Method in class org.eclipse.jetty.server.OptionalSslConnectionFactory

P

PARENT_LOADER_PRIORITY - Static variable in interface org.eclipse.jetty.server.Deployable
 
parse(Content.Chunk) - Method in class org.eclipse.jetty.server.FormFields
 
parseCookies(HttpFields, ComplianceViolation.Listener) - Method in class org.eclipse.jetty.server.CookieCache
 
passConditionalHeaders(Request, Response, HttpContent, Callback) - Method in class org.eclipse.jetty.server.ResourceService
 
PathMappingsHandler - Class in org.eclipse.jetty.server.handler
A Handler that delegates to other handlers through a configured PathMappings.
PathMappingsHandler() - Constructor for class org.eclipse.jetty.server.handler.PathMappingsHandler
 
PathMappingsHandler(boolean) - Constructor for class org.eclipse.jetty.server.handler.PathMappingsHandler
 
PathSpecPredicate(PathSpec) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.PathSpecPredicate
 
PredicateSet() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 
prepareContext(Request, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
prepareResponse(HttpFields.Mutable) - Method in interface org.eclipse.jetty.server.HttpStream
Prepare the response headers with respect to the stream.
prepareResponse(HttpFields.Mutable) - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
process() - Method in class org.eclipse.jetty.server.handler.DelayedHandler.DelayedProcess
 
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 Attributes.setAttribute(String, Object).
ProxyCustomizer() - Constructor for class org.eclipse.jetty.server.ProxyCustomizer
 
ProxyEndPoint(EndPoint, SocketAddress, SocketAddress) - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
ProxyEndPoint(EndPoint, SocketAddress, SocketAddress, Map<Integer, byte[]>, EndPoint.SslSessionData) - Constructor for class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
push(MetaData.Request) - Method in interface org.eclipse.jetty.server.HttpStream
Pushes the given resource to the client.
push(MetaData.Request) - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
push(MetaData.Request) - Method in interface org.eclipse.jetty.server.Request
Pushes the given resource to the client.
push(MetaData.Request) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
put(int, String) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler.ByHttpStatus
 
putCookie(Response, HttpCookie) - Static method in interface org.eclipse.jetty.server.Response
Put a HTTP HttpHeader.SET_COOKIE header to the response.
putHeaders(Response, HttpContent, long) - Method in class org.eclipse.jetty.server.ResourceService
 

Q

QoSHandler - Class in org.eclipse.jetty.server.handler
A quality of service Handler that conditionally limits the number of concurrent requests, to provide more predictable end-user experience in case descendant Handlers have limited capacity.
QoSHandler() - Constructor for class org.eclipse.jetty.server.handler.QoSHandler
 
QoSHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.QoSHandler
 
QoSHandlerMBean - Class in org.eclipse.jetty.server.handler.jmx
 
QoSHandlerMBean(Object) - Constructor for class org.eclipse.jetty.server.handler.jmx.QoSHandlerMBean
 

R

read() - Method in class org.eclipse.jetty.server.handler.ErrorHandler.ErrorRequest
 
read() - Method in class org.eclipse.jetty.server.handler.gzip.GzipRequest
 
read() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler.MinimumDataRateRequest
 
read() - Method in interface org.eclipse.jetty.server.HttpStream
Reads a chunk of content, with the same semantic as Content.Source.read().
read() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
read() - Method in interface org.eclipse.jetty.server.Request
read() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
read(EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
read(EndPoint, ByteBuffer) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
read(EndPoint, ByteBuffer, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Reads (with non-blocking semantic) into the given buffer from the given endPoint.
realPath() - Method in record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Returns the value of the realPath record component.
RECOGNIZED - Enum constant in enum class org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
A ConnectionFactory.Detecting can work with the given bytes.
recycle() - Method in interface org.eclipse.jetty.server.HttpChannel
Recycle the HttpChannel, so that a new cycle of calling HttpChannel.setHttpStream(HttpStream), HttpChannel.onRequest(MetaData.Request) etc.
REDIRECT - Enum constant in enum class org.eclipse.jetty.server.ResourceService.WelcomeMode
The welcome target is used as the location for a redirect response, sent by ResourceService.redirectWelcome(Request, Response, Callback, String).
redirectWelcome(Request, Response, Callback, String) - Method in class org.eclipse.jetty.server.ResourceService
Redirects to the given welcome target.
register(LifeCycle...) - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
REHANDLE - Enum constant in enum class org.eclipse.jetty.server.ResourceService.WelcomeMode
rehandleWelcome(Request, Response, Callback, String) - Method in class org.eclipse.jetty.server.ResourceService
Rehandles the given welcome target.
ReHandlingErrorHandler - Class in org.eclipse.jetty.server.handler
An ErrorHandler that can re-handle a request at an error page location.
ReHandlingErrorHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.ReHandlingErrorHandler
 
ReHandlingErrorHandler.ByHttpStatus - Class in org.eclipse.jetty.server.handler
An ReHandlingErrorHandler that uses a map of error codes to select a page.
Reject() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Reject
 
Reject(int) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Reject
 
Reject(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Reject
 
Reject(Handler, int) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.Reject
 
REMOTE_ADDRESS_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The remote address attribute name.
REMOTE_PORT_ATTRIBUTE_NAME - Static variable in class org.eclipse.jetty.server.ProxyCustomizer
The remote port attribute name.
remove(int) - Method in class org.eclipse.jetty.server.handler.ReHandlingErrorHandler.ByHttpStatus
 
remove(Object) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
removeAttribute(String) - Method in class org.eclipse.jetty.server.Server
 
removeComplianceViolationListener(ComplianceViolation.Listener) - Method in class org.eclipse.jetty.server.HttpConfiguration
Remove a ComplianceViolation.Listener from the configuration
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.
removeContextAttribute(String) - Method in class org.eclipse.jetty.server.handler.jmx.ContextHandlerMBean
 
removeCustomizer(HttpConfiguration.Customizer) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
removeHandler(Handler) - Method in interface org.eclipse.jetty.server.Handler.Collection
Removes the given Handler from this collection of Handlers.
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
renewId(Request, Response) - Method in interface org.eclipse.jetty.server.Session
Renew the identity of the session.
replaceCookie(Response, HttpCookie) - Static method in interface org.eclipse.jetty.server.Response
Request - Interface in org.eclipse.jetty.server
The representation of an HTTP request, for any protocol version (HTTP/1.1, HTTP/2, HTTP/3).
Request.AttributesWrapper - Class in org.eclipse.jetty.server
A Request.Wrapper that separately provides the request Attributes.
Request.AuthenticationState - Interface in org.eclipse.jetty.server
A minimal Authentication interface, primarily used for logging.
Request.Handler - Interface in org.eclipse.jetty.server
A handler for an HTTP request and response.
Request.Handler.AbortException - Exception Class in org.eclipse.jetty.server
A marker Exception that can be passed the Callback.failed(Throwable) of the Callback passed in Request.Handler.handle(Request, Response, Callback), to cause request handling to be aborted.
Request.ServeAs - Interface in org.eclipse.jetty.server
This interface will be detected by the Request.ServeAs.wrap(Request, HttpURI) static method to wrap the request changing its target to a given path.
Request.Wrapper - Class in org.eclipse.jetty.server
A wrapper for Request instances.
RequestLog - Interface in org.eclipse.jetty.server
TODO
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
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
 
reset() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
reset() - Method in class org.eclipse.jetty.server.handler.StatisticsHandler
 
reset() - Method in interface org.eclipse.jetty.server.Response
Resets this response, clearing the HTTP status code, HTTP headers and HTTP trailers.
reset() - Method in class org.eclipse.jetty.server.Response.Wrapper
 
reset() - Static method in class org.eclipse.jetty.server.ShutdownMonitor
 
ResourceContext() - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler.ResourceContext
 
ResourceHandler - Class in org.eclipse.jetty.server.handler
Resource Handler will serve static content and handle If-Modified-Since headers.
ResourceHandler() - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler
 
ResourceHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler
 
ResourceHandler(Handler, ByteBufferPool.Sized) - Constructor for class org.eclipse.jetty.server.handler.ResourceHandler
 
ResourceHandler.ResourceContext - Class in org.eclipse.jetty.server.handler
Utility class to create a ContextHandler containing a ResourceHandler.
ResourceListing - Class in org.eclipse.jetty.server
Utility methods to generate a List of paths.
ResourceListing() - Constructor for class org.eclipse.jetty.server.ResourceListing
 
ResourceService - Class in org.eclipse.jetty.server
Resource service, used by DefaultServlet and ResourceHandler
ResourceService() - Constructor for class org.eclipse.jetty.server.ResourceService
 
ResourceService.WelcomeAction - Record Class in org.eclipse.jetty.server
A welcome target paired with how to process it.
ResourceService.WelcomeFactory - Interface in org.eclipse.jetty.server
 
ResourceService.WelcomeMode - Enum Class in org.eclipse.jetty.server
How welcome targets should be processed.
Response - Interface in org.eclipse.jetty.server
The representation of an HTTP response, for any protocol version (HTTP/1.1, HTTP/2, HTTP/3).
Response.Wrapper - Class in org.eclipse.jetty.server
 
ResponseUtils - Class in org.eclipse.jetty.server
 
run() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
run(Runnable) - Method in interface org.eclipse.jetty.server.Context
Runs the given task in the current thread scoped to this Context.
run(Runnable) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
run(Runnable, Request) - Method in interface org.eclipse.jetty.server.Context
Runs the given task in the current thread scoped to this Context and the given Request.
run(Runnable, Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 

S

SAME_SITE_DEFAULT_ATTRIBUTE - Static variable in class org.eclipse.jetty.server.HttpCookieUtils
Name of context attribute with default SameSite cookie value
SCI_EXCLUSION_PATTERN - Static variable in interface org.eclipse.jetty.server.Deployable
 
SCI_ORDER - Static variable in interface org.eclipse.jetty.server.Deployable
 
ScopedContext() - Constructor for class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
SecuredRedirectHandler - Class in org.eclipse.jetty.server.handler
Forces a redirect to the secure form of the resource before allowed to access the resource.
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.
SecuredRedirectHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.SecuredRedirectHandler
Uses moved temporarily code (302) as the redirect code.
SecuredRedirectHandler(Handler, int) - Constructor for class org.eclipse.jetty.server.handler.SecuredRedirectHandler
Use supplied code as the redirect code.
SecureRequest(Request) - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer.SecureRequest
 
SecureRequestCustomizer - Class in org.eclipse.jetty.server
Customizer that extracts the attribute of an SSLContext and makes them available via Attributes.getAttribute(String) using the names: EndPoint.SslSessionData.ATTRIBUTE for EndPoint.SslSessionData SecureRequestCustomizer.X509_ATTRIBUTE for the local certificate as a X509 instance
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
 
SecureRequestCustomizer.SecureRequest - Class in org.eclipse.jetty.server
 
SecureRequestCustomizer.SecureRequestWithSslSessionData - Class in org.eclipse.jetty.server
 
SecureRequestWithSslSessionData(Request, EndPoint.SslSessionData) - Constructor for class org.eclipse.jetty.server.SecureRequestCustomizer.SecureRequestWithSslSessionData
 
Selectors - Search tag in class org.eclipse.jetty.server.ServerConnector
Section
send(MetaData.Request, MetaData.Response, boolean, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.server.HttpStream
Send response meta-data and/or data.
send(MetaData.Request, MetaData.Response, boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
sendRedirect(Request, Response, Callback, int, String, boolean) - Static method in interface org.eclipse.jetty.server.Response
Sends a 302 HTTP redirect status code to the given location.
sendRedirect(Request, Response, Callback, int, String, boolean, ByteBuffer) - Static method in interface org.eclipse.jetty.server.Response
Sends a 302 HTTP redirect status code to the given location.
sendRedirect(Request, Response, Callback, String) - Method in class org.eclipse.jetty.server.ResourceService
 
sendRedirect(Request, Response, Callback, String) - Static method in interface org.eclipse.jetty.server.Response
Sends a HTTP redirect status code to the given location, without consuming the available request content.
sendRedirect(Request, Response, Callback, String, boolean) - Static method in interface org.eclipse.jetty.server.Response
Sends HTTP redirect status code to the given location, without consuming the available request content.
sendWelcome(HttpContent, String, boolean, Request, Response, Callback) - Method in class org.eclipse.jetty.server.ResourceService
 
Sequence(boolean, List<Handler>) - Constructor for class org.eclipse.jetty.server.Handler.Sequence
Creates a Sequence with the given dynamic parameter and the given Handlers.
Sequence(List<Handler>) - Constructor for class org.eclipse.jetty.server.Handler.Sequence
Creates a Sequence with the given Handlers.
Sequence(Handler...) - Constructor for class org.eclipse.jetty.server.Handler.Sequence
Creates a Sequence with the given Handlers.
SERVE - Enum constant in enum class org.eclipse.jetty.server.ResourceService.WelcomeMode
serveAs(Request, HttpURI) - Static method in interface org.eclipse.jetty.server.Request
Return a request with its HttpURI changed to the supplied target.
Server - Class in org.eclipse.jetty.server
 
Server() - Constructor for class org.eclipse.jetty.server.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(ThreadPool, Scheduler, ByteBufferPool) - Constructor for class org.eclipse.jetty.server.Server
 
SERVER_VERSION - Static variable in class org.eclipse.jetty.server.HttpConfiguration
 
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
 
ServerConnectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.server.ServerConnector.ServerConnectorManager
 
ServerMBean - Class in org.eclipse.jetty.server.jmx
 
ServerMBean(Object) - Constructor for class org.eclipse.jetty.server.jmx.ServerMBean
 
serveWelcome(Request, Response, Callback, String) - Method in class org.eclipse.jetty.server.ResourceService
Serves the given welcome target.
Session - Interface in org.eclipse.jetty.server
The interface to a generic session associated with a request.
Session.API - Interface in org.eclipse.jetty.server
An API wrapper of the core session.
Session.LifeCycleListener - Interface in org.eclipse.jetty.server
Listener interface that if implemented by a value of an attribute of an enclosing Context at start, will be notified of session lifecycle events.
Session.ValueListener - Interface in org.eclipse.jetty.server
Listener interface that if implemented by a session attribute value, will be notified of session value events.
set(Request, CompletableFuture<Fields>) - Static method in class org.eclipse.jetty.server.FormFields
Deprecated, for removal: This API element is subject to removal in a future version.
setAcceptedReceiveBufferSize(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
setAcceptedSendBufferSize(int) - Method in class org.eclipse.jetty.server.ServerConnector
 
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
Set the accept queue size (also known as accept backlog).
setAcceptRanges(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setAcceptRanges(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
setAliasChecks(List<AliasCheck>) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set list of AliasCheck instances.
setAllowCredentials(boolean) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets whether the cross server allows cross-origin requests to include credentials such as cookies or authentication headers.
setAllowedHeaders(Set<String>) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets the set of allowed headers in a cross-origin request.
setAllowedMethods(Set<String>) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets the set of allowed methods in a cross-origin request.
setAllowedOriginPatterns(Set<String>) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets the set of allowed origin regex strings in a cross-origin request.
setAllowedTimingOriginPatterns(Set<String>) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets the set of allowed timing origin regex strings in a cross-origin request.
setAllowNullPathInContext(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set true if /context is not redirected to /context/.
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
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.Request.AttributesWrapper
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.Request.Wrapper
 
setAttribute(String, Object) - Method in class org.eclipse.jetty.server.Server
 
setAuthenticationState(Request, Request.AuthenticationState) - Static method in interface org.eclipse.jetty.server.Request
 
setAvailable(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set Available status.
setBaseResource(Resource) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the base resource to serve content from for this context, which must exist and be readable when the context is started.
setBaseResource(Resource) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setBaseResourceAsPath(Path) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the base resource to serve content from.
setBaseResourceAsString(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the base resource to serve content from.
setBaseResourceAsString(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setBufferSize(int) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
setBufferSize(int) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
setCacheControl(String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Set the cacheControl.
setCacheControl(String) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Set the Cache-Control header value or null.
setCacheControl(String) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
Set the cacheControl header to set on all static content..
setCacheControl(String) - Method in class org.eclipse.jetty.server.ResourceService
Set the cacheControl header to set on all static content..
setClassLoader(ClassLoader) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setCompleteHandlerCallbackAtTimeout(boolean) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
setConnection(Connection) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
setConnection(ConnectHandler.TunnelConnection) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
setConnection(ConnectHandler.TunnelConnection) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
setConnectionFactories(Collection<ConnectionFactory>) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setConnectors(Connector[]) - Method in class org.eclipse.jetty.server.Server
Set the connectors for this server.
setConnectTimeout(long) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Set the timeout, in milliseconds, to connect to the remote server.
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
 
setContextPath(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
SetCookieHttpField(HttpCookie, CookieCompliance) - Constructor for class org.eclipse.jetty.server.HttpCookieUtils.SetCookieHttpField
 
setCrossContextDispatchSupported(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set if this context support cross context dispatch, either as originator or target.
setCustomizers(List<HttpConfiguration.Customizer>) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the HttpConfiguration.Customizers that are invoked for every request received.
setDebug(boolean) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setDefaultHandler(Handler) - Method in class org.eclipse.jetty.server.Server
 
setDefaultProtocol(String) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setDefaultProtocol(String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnectionFactory
 
setDefaultResponseMimeType(String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setDeflaterPool(DeflaterPool) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the DeflaterPool to be used.
setDelayDispatchUntilContent(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set if true, delays the application dispatch until content is available (defaults to true).
setDeliverNonAllowedOriginRequests(boolean) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets whether requests whose origin is not allowed are delivered to the child Handler.
setDeliverNonAllowedOriginWebSocketUpgradeRequests(boolean) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets whether WebSocket upgrade requests whose origin is not allowed are delivered to the child Handler.
setDeliverPreflightRequests(boolean) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets whether preflight requests are delivered to the child Handler.
setDemandCallbackTimeout(long) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
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.server.SslConnectionFactory
 
setDirectBuffersForEncryption(boolean) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
setDiscardPathInContext(boolean) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Whether to discard the original request pathInContext when building the redirect URI.
setDiscardQuery(boolean) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Whether to discard the original request query when building the redirect URI.
setDisplayName(String) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setDryRun(boolean) - Method in class org.eclipse.jetty.server.Server
 
setDumpAfterStart(boolean) - Method in class org.eclipse.jetty.server.Server
Set true if ContainerLifeCycle.dumpStdErr() is called after starting.
setDumpBeforeStop(boolean) - Method in class org.eclipse.jetty.server.Server
Set true if ContainerLifeCycle.dumpStdErr() is called before stopping.
setDynamic(boolean) - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
setEnabled(boolean) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
setEncodingCacheSize(int) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setEncodingCacheSize(int) - Method in class org.eclipse.jetty.server.ResourceService
 
setEnsureSecureRequestCustomizer(boolean) - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
setErrorHandler(Request.Handler) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setErrorHandler(Request.Handler) - Method in class org.eclipse.jetty.server.Server
 
setEtags(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setEtags(boolean) - Method in class org.eclipse.jetty.server.ResourceService
 
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)
setExecutor(Executor) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
setExitJvm(boolean) - Method in class org.eclipse.jetty.server.handler.ShutdownHandler
 
setExitVm(boolean) - Method in class org.eclipse.jetty.server.ShutdownMonitor
Set true to exit the VM on shutdown.
setExposedHeaders(Set<String>) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
Sets the set of headers exposed in a cross-origin response.
setFields(Request, Fields) - Static method in class org.eclipse.jetty.server.FormFields
Set a Fields or related failure for the request
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.
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.
setForcedHost(String) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
Set a forced valued for the host header.
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
Set the header name holding a forwarded Https status indicator(default X-Proxied-Https).
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
 
setGenerateRedirectBody(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setGzipEquivalentFileExtensions(List<String>) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
Set file extensions that signify that a file is gzip compressed.
setGzipEquivalentFileExtensions(List<String>) - Method in class org.eclipse.jetty.server.ResourceService
Set file extensions that signify that a file is gzip compressed.
setHandler(Supplier<Handler>) - Method in interface org.eclipse.jetty.server.Handler.Singleton
Sets the child Handler supplied by the given Supplier.
setHandler(Handler) - Method in class org.eclipse.jetty.server.handler.HotSwapHandler
 
setHandler(Handler) - Method in interface org.eclipse.jetty.server.Handler.Singleton
 
setHandler(Handler) - Method in class org.eclipse.jetty.server.Handler.Wrapper
 
setHandlerCallbackTimeout(long) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
setHandlers(List<Handler>) - Method in interface org.eclipse.jetty.server.Handler.Collection
Sets the given Handlers as children of this collection of Handlers.
setHandlers(List<Handler>) - Method in class org.eclipse.jetty.server.Handler.Sequence
 
setHandlers(Handler...) - Method in interface org.eclipse.jetty.server.Handler.Collection
setHeaderCacheCaseSensitive(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setHeaderCacheSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
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.
setHttpCompliance(HttpCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setHttpContentFactory(HttpContent.Factory) - Method in class org.eclipse.jetty.server.ResourceService
 
setHttpStream(HttpStream) - Method in interface org.eclipse.jetty.server.HttpChannel
Set the HttpStream to associate to this channel..
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
Sets the endpoint idle timeout in ms to apply when the connection limit is reached.
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Set the idle timeout, in milliseconds.
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 interface org.eclipse.jetty.server.HttpStream
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
setIdleTimeout(long) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
setIdleTimeoutMs(long) - Method in class org.eclipse.jetty.server.handler.IdleTimeoutHandler
 
setIgnorePaths(String[]) - Method in class org.eclipse.jetty.server.CustomRequestLog
Set request paths that will not be logged.
setIncludedInflatePaths(String...) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the included filter list of Path specs (replacing any previously set)
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)
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.
setInheritChannel(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
Sets whether this connector uses a channel inherited from the JVM.
setInputBufferSize(int) - Method in class org.eclipse.jetty.server.AbstractConnectionFactory
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set the size of the buffer into which HTTP request are read.
setInputBufferSize(int) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setKey(String) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
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.
setLoggerName(String) - Method in class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
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
 
setMaxConnections(int) - Method in class org.eclipse.jetty.server.ConnectionLimit
 
setMaxErrorDispatches(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setMaxInactiveInterval(int) - Method in interface org.eclipse.jetty.server.Session
 
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
 
setMaxProxyHeader(int) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory
 
setMaxRequestCount(int) - Method in class org.eclipse.jetty.server.handler.QoSHandler
Sets the max number of concurrent requests.
setMaxSuspend(Duration) - Method in class org.eclipse.jetty.server.handler.QoSHandler
Sets the max duration of time a request may stay suspended.
setMaxSuspendedRequestCount(int) - Method in class org.eclipse.jetty.server.handler.QoSHandler
Sets the max number of suspended requests.
setMaxSuspendMillis(long) - Method in class org.eclipse.jetty.server.handler.jmx.QoSHandlerMBean
 
setMaxUnconsumedRequestContentReads(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the maximum amount of HttpStream.read()s that can be done by the HttpStream if the content is not fully consumed by the application.
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.
setMonitoredConnectors(Collection<Connector>) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMonitorThreads(boolean) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setMultiPartCompliance(MultiPartCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setName(String) - Method in class org.eclipse.jetty.server.AbstractConnector
Set a connector name.
setNetworkTrafficListener(NetworkTrafficListener) - Method in class org.eclipse.jetty.server.NetworkTrafficServerConnector
Set the listener to set, or null to unset.
setNotifyRemoteAsyncErrors(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set whether remote errors, when detected, are notified to async applications.
setOpenEarly(boolean) - Method in class org.eclipse.jetty.server.Server
Allows to disable early opening of network sockets.
setOriginalPathAttribute(String) - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
Sets the request attribute name to use to retrieve the original request path.
setOriginalQueryAttribute(String) - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
Sets the request attribute name to use to retrieve the original request query.
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.server.HttpConfiguration
Set the size of the buffer into which response content is aggregated before being sent to the client.
setOutputStream(OutputStream) - Method in class org.eclipse.jetty.server.handler.DebugHandler
Set the out to set.
setPaths(List<String>) - Method in class org.eclipse.jetty.server.handler.TryPathsHandler
Sets a list of rewrite URI paths.
setPeriod(int) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setPersistentConnectionsEnabled(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setPort(int) - Method in class org.eclipse.jetty.server.AbstractNetworkConnector
 
setPort(int) - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
setPrecompressedFormats(List<CompressedContentFormat>) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setPrecompressedFormats(List<CompressedContentFormat>) - Method in class org.eclipse.jetty.server.ResourceService
 
setPrecompressedFormats(CompressedContentFormat...) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setPreflightMaxAge(Duration) - Method in class org.eclipse.jetty.server.handler.CrossOriginHandler
 
setProtectedTargets(String[]) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setProtocol(String) - Method in class org.eclipse.jetty.server.NegotiatingServerConnection
 
setProxyAsAuthority(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setReasons(String) - Method in class org.eclipse.jetty.server.LowResourceMonitor
 
setRecordHttpComplianceViolations(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
Deprecated, for removal: This API element is subject to removal in a future version.
use HttpConfiguration.addComplianceViolationListener(ComplianceViolation.Listener) instead. this method will be removed in Jetty 12.1.0
setRedirectURI(String) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
Sets the URI to redirect to.
setRedirectUriCompliance(UriCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setRelativeRedirectAllowed(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setRequestCookieCompliance(CookieCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setRequestHeaderSize(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Larger headers will allow for more and/or larger cookies plus larger form content encoded in a URL.
setRequestLog(RequestLog) - Method in class org.eclipse.jetty.server.Server
 
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).
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.server.ServerConnector
 
setReusePort(boolean) - Method in class org.eclipse.jetty.server.ServerConnector
Set whether it is allowed to bind multiple server sockets to the same host and port.
setScheduler(Scheduler) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
 
setSecurePort(int) - Method in class org.eclipse.jetty.server.HttpConfiguration
Sets the TCP/IP port used for CONFIDENTIAL and INTEGRAL redirections.
setSecureScheme(String) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set the URI scheme used for CONFIDENTIAL and INTEGRAL redirections.
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
 
setSendXPoweredBy(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setServeFavIcon(boolean) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
Set true if the handle can server the jetty favicon.ico.
setServer(Server) - Method in class org.eclipse.jetty.server.Handler.Abstract
 
setServer(Server) - Method in class org.eclipse.jetty.server.Handler.AbstractContainer
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
setServer(Server) - Method in class org.eclipse.jetty.server.handler.DoSHandler
 
setServer(Server) - Method in interface org.eclipse.jetty.server.Handler
Set the Server to associate to this Handler.
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.
setServerInfo(String) - Method in class org.eclipse.jetty.server.Server
 
setShowCauses(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShowContexts(boolean) - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
setShowHeaders(boolean) - Method in class org.eclipse.jetty.server.handler.DebugHandler
 
setShowMessageInTitle(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
Set if true, the error message appears in page title.
setShowOrigin(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShowStacks(boolean) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
setShutdownIdleTimeout(long) - Method in class org.eclipse.jetty.server.AbstractConnector
 
setSniHostCheck(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setSniRequired(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
 
setSslIsSecure(boolean) - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
setStatus(int) - Method in interface org.eclipse.jetty.server.Response
Set the response HTTP status code.
setStatus(int) - Method in class org.eclipse.jetty.server.Response.Wrapper
 
setStatusCode(int) - Method in class org.eclipse.jetty.server.handler.MovedContextHandler
 
setStopAtShutdown(boolean) - Method in class org.eclipse.jetty.server.Server
Set stop server at shutdown behaviour.
setStopTimeout(long) - Method in class org.eclipse.jetty.server.Server
 
setStsIncludeSubDomains(boolean) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Set whether the includeSubdomains attribute is sent with the Strict-Transport-Security response header.
setStsMaxAge(long) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Sets the Strict-Transport-Security max age in seconds.
setStsMaxAge(long, TimeUnit) - Method in class org.eclipse.jetty.server.SecureRequestCustomizer
Sets the Strict-Transport-Security max age in the given time unit.
setStyleSheet(Resource) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setSyncFlush(boolean) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
Set the Deflater flush mode to use.
setTempDirectory(File) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the temporary directory returned by ContextHandler.ScopedContext.getTempDirectory().
setTempDirectory(File) - Method in class org.eclipse.jetty.server.Server
Set the temporary directory returned by Context.getTempDirectory() for the root Context returned Server.getContext().
setTempDirectory(String) - Method in class org.eclipse.jetty.server.Server
Convenience method to call Server.setTempDirectory(File) from a String representation of the temporary directory.
setTempDirectoryPersistent(boolean) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set if the temp directory for this context will be kept over a stop and start cycle.
setThreadLimit(int) - Method in class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
setTimeZone(String) - Method in class org.eclipse.jetty.server.RequestLogWriter
 
setTrailersSupplier(Supplier<HttpFields>) - Method in interface org.eclipse.jetty.server.Response
Sets the supplier for the HTTP trailers.
setTrailersSupplier(Supplier<HttpFields>) - Method in class org.eclipse.jetty.server.Response.Wrapper
 
setupWelcomeFactory() - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setUriCompliance(UriCompliance) - Method in class org.eclipse.jetty.server.HttpConfiguration
 
setUseFileMapping(boolean) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set whether to use direct ByteBuffers for reading.
setUseInputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConfiguration
Set whether to use direct ByteBuffers for writing.
setUseOutputDirectByteBuffers(boolean) - Method in class org.eclipse.jetty.server.HttpConnectionFactory
 
setVary(HttpField) - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
setVirtualHosts(List<String>) - Method in class org.eclipse.jetty.server.handler.ContextHandler
Set the virtual hosts for the context.
setWelcomeFactory(ResourceService.WelcomeFactory) - Method in class org.eclipse.jetty.server.ResourceService
 
setWelcomeFiles(String...) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setWelcomeFiles(List<String>) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setWelcomeMode(ResourceService.WelcomeMode) - Method in class org.eclipse.jetty.server.handler.ResourceHandler
 
setWelcomeMode(ResourceService.WelcomeMode) - Method in class org.eclipse.jetty.server.ResourceService
 
setWriteCallbackTimeout(long) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
setWriteTimeout(long) - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
shouldBuffer(Response, boolean) - Method in class org.eclipse.jetty.server.handler.BufferedResponseHandler
 
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.GracefulHandler
 
ShutdownHandler - Class in org.eclipse.jetty.server.handler
A Handler that initiates a Shutdown of the Jetty Server it belongs to.
ShutdownHandler(String) - Constructor for class org.eclipse.jetty.server.handler.ShutdownHandler
Creates a Handler that lets the server be shut down remotely (but only from localhost).
ShutdownHandler(String, boolean) - Constructor for class org.eclipse.jetty.server.handler.ShutdownHandler
Creates a Handler that lets the server be shut down remotely (but only from localhost).
ShutdownHandler(Handler, String, String, boolean) - Constructor for class org.eclipse.jetty.server.handler.ShutdownHandler
Creates a Handler that lets the server be shut down remotely (but only from localhost).
ShutdownMonitor - Class in org.eclipse.jetty.server
Shutdown/Stop Monitor thread.
shutdownOutput() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
size() - Method in class org.eclipse.jetty.server.CookieCache
 
size() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 
SizeLimitHandler - Class in org.eclipse.jetty.server
A Handler that can limit the size of message bodies in requests and responses.
SizeLimitHandler(long, long) - Constructor for class org.eclipse.jetty.server.SizeLimitHandler
 
SkipNext() - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.SkipNext
 
SkipNext(Handler) - Constructor for class org.eclipse.jetty.server.handler.ConditionalHandler.SkipNext
 
Slf4jRequestLogWriter - Class in org.eclipse.jetty.server
Request log writer using a Slf4jLog Logger
Slf4jRequestLogWriter() - Constructor for class org.eclipse.jetty.server.Slf4jRequestLogWriter
 
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
 
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
 
start() - Method in class org.eclipse.jetty.server.ShutdownMonitor
 
start(LifeCycle) - Method in class org.eclipse.jetty.server.Server
 
STARTING - Enum constant in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
 
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
 
StateTrackingHandler - Class in org.eclipse.jetty.server.handler
A troubleshooting Handler.Wrapper that tracks whether Handler/Request/Response asynchronous APIs are properly used by applications.
StateTrackingHandler() - Constructor for class org.eclipse.jetty.server.handler.StateTrackingHandler
Creates a new instance with a default StateTrackingHandler.Listener that logs events at warning level.
StateTrackingHandler(StateTrackingHandler.Listener) - Constructor for class org.eclipse.jetty.server.handler.StateTrackingHandler
Creates a new instance with the given StateTrackingHandler.Listener.
StateTrackingHandler.Listener - Interface in org.eclipse.jetty.server.handler
Listener of events emitted by StateTrackingHandler.
StateTrackingHandler.ThreadInfo - Class in org.eclipse.jetty.server.handler
 
StatisticsHandler - Class in org.eclipse.jetty.server.handler
 
StatisticsHandler() - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler
 
StatisticsHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.StatisticsHandler
 
StatisticsHandler.MinimumDataRateHandler - Class in org.eclipse.jetty.server.handler
Checks that the wrapped handler can read/write at a minimal rate of N bytes per second.
StatisticsHandler.MinimumDataRateHandler.MinimumDataRateRequest - Class in org.eclipse.jetty.server.handler
 
StatisticsHandler.MinimumDataRateHandler.MinimumDataRateResponse - Class in org.eclipse.jetty.server.handler
 
StatusRejectHandler() - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.StatusRejectHandler
 
StatusRejectHandler(int) - Constructor for class org.eclipse.jetty.server.handler.DoSHandler.StatusRejectHandler
 
STOPPED - Enum constant in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
 
succeeded() - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
succeeded() - Method in class org.eclipse.jetty.server.HttpStream.Wrapper
 
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
 

T

target() - Method in record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Returns the value of the target record component.
TEMP_DIR - Static variable in interface org.eclipse.jetty.server.Deployable
 
test(Predicate<T>, T, Request) - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
test(Request) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.ConnectorPredicate
 
test(Request) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
test(Request) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.MethodPredicate
 
test(Request) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PathSpecPredicate
 
test(Request) - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PredicateSet
 
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
 
ThreadLimitHandler(Handler, String, boolean) - Constructor for class org.eclipse.jetty.server.handler.ThreadLimitHandler
 
toConnectionString() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
toConnectionString() - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
toRedirectURI(Request, String) - Static method in interface org.eclipse.jetty.server.Request
toRedirectURI(Request, String) - Static method in interface org.eclipse.jetty.server.Response
Common point to generate a proper "Location" header for redirects.
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 record class org.eclipse.jetty.server.CustomRequestLog.LogDetail
Returns a string representation of this record class.
toString() - Method in class org.eclipse.jetty.server.ForwardedRequestCustomizer
 
toString() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.ConnectorPredicate
 
toString() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.InetAddressPatternPredicate
 
toString() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.MethodPredicate
 
toString() - Method in class org.eclipse.jetty.server.handler.ConditionalHandler.PathSpecPredicate
 
toString() - Method in class org.eclipse.jetty.server.handler.ContextHandler.ScopedContext
 
toString() - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
toString() - Method in class org.eclipse.jetty.server.handler.DefaultHandler
 
toString() - Method in class org.eclipse.jetty.server.handler.ErrorHandler.ErrorRequest
 
toString() - Method in class org.eclipse.jetty.server.handler.gzip.GzipHandler
 
toString() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler.ThreadInfo
 
toString() - Method in class org.eclipse.jetty.server.handler.StateTrackingHandler
 
toString() - Method in class org.eclipse.jetty.server.HttpConfiguration
 
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.NegotiatingServerConnectionFactory
 
toString() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
toString() - Method in class org.eclipse.jetty.server.Request.Wrapper
 
toString() - Method in class org.eclipse.jetty.server.ResourceService
 
toString() - Method in record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Returns a string representation of this record class.
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.ShutdownMonitor
 
toString() - Method in class org.eclipse.jetty.server.SslConnectionFactory
 
toString() - Method in class org.eclipse.jetty.server.StateLifeCycleListener
 
TrailingSlashAliasChecker - Class in org.eclipse.jetty.server
This will approve an alias where the only difference is a trailing slash.
TrailingSlashAliasChecker() - Constructor for class org.eclipse.jetty.server.TrailingSlashAliasChecker
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
TryPathsHandler - Class in org.eclipse.jetty.server.handler
Inspired by nginx's try_files functionality.
TryPathsHandler() - Constructor for class org.eclipse.jetty.server.handler.TryPathsHandler
 
TryPathsHandler(Handler) - Constructor for class org.eclipse.jetty.server.handler.TryPathsHandler
 
TunnelSupport - Interface in org.eclipse.jetty.server
Supports the implementation of HTTP CONNECT tunnels.

U

UNAVAILABLE - Enum constant in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
 
undeployHandler(Handler, Callback) - Method in class org.eclipse.jetty.server.handler.ContextHandlerCollection
Thread safe undeploy of a Handler.
unlimit() - Method in class org.eclipse.jetty.server.AcceptRateLimit
 
unlimit() - Method in class org.eclipse.jetty.server.ConnectionLimit
 
UNSET - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
UntilContentDelayedProcess(Handler, Request, Response, Callback) - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler.UntilContentDelayedProcess
 
UntilFormDelayedProcess(Handler, Request, Response, Callback, String) - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler.UntilFormDelayedProcess
 
UntilMultipartDelayedProcess(Handler, Request, Response, Callback, String, MultiPartConfig) - Constructor for class org.eclipse.jetty.server.handler.DelayedHandler.UntilMultipartDelayedProcess
 
unwrap() - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
unWrap(Request) - Static method in interface org.eclipse.jetty.server.Request
 
updateHandler(Handler.Singleton, Handler) - Static method in interface org.eclipse.jetty.server.Handler.Singleton
Utility method to perform sanity checks before updating the given Handler to the given Singleton, typically used in implementations of Handler.Singleton.setHandler(Handler).
upgrade(Connection) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
UPGRADE_CONNECTION_ATTRIBUTE - Static variable in interface org.eclipse.jetty.server.HttpStream
Attribute name to be used as a Request attribute to store/retrieve the Connection created during the HTTP/1.1 upgrade mechanism or the HTTP/2 tunnel mechanism.
upgradeConnection(Connector, EndPoint, MetaData.Request, HttpFields.Mutable) - Method in interface org.eclipse.jetty.server.ConnectionFactory.Upgrading
Create a connection for an upgrade request.
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.server.handler.ConnectHandler.UpstreamConnection
 

V

validateDestination(String, int) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Checks the given host and port against whitelist and blacklist.
valueOf(String) - Static method in enum class org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.eclipse.jetty.server.ResourceService.WelcomeMode
Returns the enum constant of this class with the specified name.
values() - Static method in enum class org.eclipse.jetty.server.ConnectionFactory.Detecting.Detection
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.eclipse.jetty.server.handler.ContextHandler.Availability
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.eclipse.jetty.server.ResourceService.WelcomeMode
Returns an array containing the constants of this enum class, in the order they are declared.

W

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
waitForResponse(boolean, long, TimeUnit, Consumer<Integer>) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
Wait for a response using a parser to detect the end of message
waitUntilClosed() - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
waitUntilClosedOrIdleFor(long, TimeUnit) - Method in class org.eclipse.jetty.server.LocalConnector.LocalEndPoint
 
WAR - Static variable in interface org.eclipse.jetty.server.Deployable
 
WEBINF_SCAN_JARS - Static variable in interface org.eclipse.jetty.server.Deployable
 
WelcomeAction(String, ResourceService.WelcomeMode) - Constructor for record class org.eclipse.jetty.server.ResourceService.WelcomeAction
Creates an instance of a WelcomeAction record class.
wrap(Request, HttpURI) - Method in interface org.eclipse.jetty.server.Request.ServeAs
Wraps a request but changes the uri so that it can be served to a different target.
Wrapper() - Constructor for class org.eclipse.jetty.server.Handler.Wrapper
Creates a wrapper with no wrapped Handler.
Wrapper(boolean) - Constructor for class org.eclipse.jetty.server.Handler.Wrapper
Creates a wrapper with no wrapped Handler with the given dynamic parameter.
Wrapper(boolean, Handler) - Constructor for class org.eclipse.jetty.server.Handler.Wrapper
Creates a wrapper with the given dynamic parameter wrapping the given Handler.
Wrapper(ConnectionMetaData) - Constructor for class org.eclipse.jetty.server.ConnectionMetaData.Wrapper
 
Wrapper(Handler) - Constructor for class org.eclipse.jetty.server.Handler.Wrapper
Creates a non-dynamic wrapper of the given Handler.
Wrapper(HttpStream) - Constructor for class org.eclipse.jetty.server.HttpStream.Wrapper
 
Wrapper(Request) - Constructor for class org.eclipse.jetty.server.Request.Wrapper
 
Wrapper(Request, Response) - Constructor for class org.eclipse.jetty.server.Response.Wrapper
 
wrapRequest(Request, Response) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
wrapResponse(ContextRequest, Response) - Method in class org.eclipse.jetty.server.handler.ContextHandler
 
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.handler.ContextResponse
 
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.handler.gzip.GzipResponseAndCallback
 
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.handler.StatisticsHandler.MinimumDataRateHandler.MinimumDataRateResponse
 
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.Response.Wrapper
 
write(boolean, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.server.Response
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 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.Slf4jRequestLogWriter
 
write(EndPoint, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.DownstreamConnection
 
write(EndPoint, ByteBuffer, Callback) - Method in class org.eclipse.jetty.server.handler.ConnectHandler.UpstreamConnection
 
write(EndPoint, ByteBuffer, Callback, ConcurrentMap<String, Object>) - Method in class org.eclipse.jetty.server.handler.ConnectHandler
Writes (with non-blocking semantic) the given buffer of data onto the given endPoint.
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.server.ProxyConnectionFactory.ProxyEndPoint
 
writeError(Request, Response, Callback, int) - Static method in interface org.eclipse.jetty.server.Response
Writes an error response with the given HTTP status code.
writeError(Request, Response, Callback, int, String) - Static method in interface org.eclipse.jetty.server.Response
Writes an error response with the given HTTP status code, and the given message in the response content.
writeError(Request, Response, Callback, int, String, Throwable) - Static method in interface org.eclipse.jetty.server.Response
Writes an error response with the given HTTP status code, and the given message in the response content.
writeError(Request, Response, Callback, Throwable) - Static method in interface org.eclipse.jetty.server.Response
Writes an error response with HTTP status code 500.
writeErrorHtml(Request, Writer, Charset, int, String, Throwable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorHtmlBody(Request, Writer, int, String, Throwable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorHtmlHead(Request, Writer, int, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorHtmlMessage(Request, Writer, int, String, Throwable, String) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorHtmlMeta(Request, Writer, Charset) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorHtmlStacks(Request, Writer) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorJson(Request, PrintWriter, int, String, Throwable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorOrigin(String, Consumer<String>) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeErrorPlain(Request, PrintWriter, int, String, Throwable) - Method in class org.eclipse.jetty.server.handler.ErrorHandler
 
writeHttpError(Request, Response, Callback, int) - Method in class org.eclipse.jetty.server.ResourceService
 
writeHttpError(Request, Response, Callback, int, String, Throwable) - Method in class org.eclipse.jetty.server.ResourceService
 
writeHttpError(Request, Response, Callback, Throwable) - Method in class org.eclipse.jetty.server.ResourceService
 
writeInterim(int, HttpFields) - Method in class org.eclipse.jetty.server.Response.Wrapper
 
writeInterim(int, HttpFields) - Method in interface org.eclipse.jetty.server.Response
Writes an HTTP interim response, with the given HTTP status code and HTTP headers.
writePoweredBy(Appendable, String, String) - Method in class org.eclipse.jetty.server.HttpConfiguration
 

X

X509_ATTRIBUTE - Static variable in class org.eclipse.jetty.server.SecureRequestCustomizer
 
XFORWARDED_FOR - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_HOST - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_PORT - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_PROTO - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XFORWARDED_SERVER - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 
XPROXIED_HTTPS - Enum constant in enum class org.eclipse.jetty.server.ForwardedRequestCustomizer.Source
 

_

_base - Variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
Deprecated.
_baseResource - Variable in class org.eclipse.jetty.server.AllowedResourceAliasChecker
 
_rawFields - Variable in class org.eclipse.jetty.server.CookieCache
 
_server - Variable in class org.eclipse.jetty.server.LowResourceMonitor
 
A B C D E F G H I J L M N O P Q R S T U V W X _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form