Uses of Interface
org.eclipse.jetty.util.Callback
Package
Description
Jetty Proxy : Async Proxy Support
Jetty Jaspi : Java Authentication SPI
Jetty Server : Modular Servlet Integration
Jetty IO : Core classes for Jetty IO subsystem
This module contains the main abstractions for the QUIC protocol.
Jetty Rewrite : Rewrite Handler and Rules for Jetty
Jetty Security : Modular Support for Security in Jetty
Jetty Security : Authenticators and Callbacks
Jetty Server : Core Server API
Jetty Server : Core Handler API
Jetty GZIP Handler
Jetty Server : Session Management Implementations
Jetty Util : Common Utility Classes
Jetty WebSocket Common : Implementation [Internal Use Only]
-
Uses of Callback in org.eclipse.jetty.client
Modifier and TypeClassDescriptionprotected static class
Modifier and TypeMethodDescriptionvoid
Socks5.Authentication.authenticate
(EndPoint endPoint, Callback callback) Performs the authentication send and receive bytes exchanges specific for thisSocks5.Authentication
.void
Upgrades the givenendPoint
to a different protocol.void
AsyncRequestContent.write
(ByteBuffer buffer, Callback callback) protected abstract void
ProxyProtocolClientConnectionFactory.ProxyProtocolConnection.writePROXYBytes
(EndPoint endPoint, Callback callback) -
Uses of Callback in org.eclipse.jetty.client.transport
Modifier and TypeMethodDescriptionprotected abstract void
HttpSender.sendContent
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) Implementations should send the given HTTP content over the wire.protected abstract void
HttpSender.sendHeaders
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) Implementations should send the HTTP headers over the wire, possibly with some content, in a single write, and notify the givencallback
of the result of this operation. -
Uses of Callback in org.eclipse.jetty.client.transport.internal
Modifier and TypeMethodDescriptionprotected void
HttpSenderOverHTTP.sendContent
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) protected void
HttpSenderOverHTTP.sendHeaders
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) void
-
Uses of Callback in org.eclipse.jetty.ee10.proxy
Modifier and TypeClassDescriptionprotected class
protected class
protected class
Modifier and TypeMethodDescriptionprotected void
boolean
AsyncMiddleManServlet.ProxyWriter.offer
(ByteBuffer content, Callback callback) protected void
AsyncProxyServlet.StreamReader.onRequestContent
(jakarta.servlet.http.HttpServletRequest request, Request proxyRequest, AsyncRequestContent content, byte[] buffer, int offset, int length, Callback callback) protected void
AsyncProxyServlet.onResponseContent
(jakarta.servlet.http.HttpServletRequest request, jakarta.servlet.http.HttpServletResponse response, Response proxyResponse, byte[] buffer, int offset, int length, Callback callback) protected void
ProxyServlet.onResponseContent
(jakarta.servlet.http.HttpServletRequest request, jakarta.servlet.http.HttpServletResponse response, Response proxyResponse, byte[] buffer, int offset, int length, Callback callback) -
Uses of Callback in org.eclipse.jetty.ee10.security.jaspi
Modifier and TypeMethodDescriptionboolean
JaspiAuthenticator.secureResponse
(Request request, Response response, Callback callback, boolean mandatory, AuthenticationState.Succeeded validatedSucceeded) JaspiAuthenticator.validateRequest
(Request request, Response response, Callback callback) ModifierConstructorDescriptionJaspiMessageInfo
(Request request, Response response, Callback callback) -
Uses of Callback in org.eclipse.jetty.ee10.servlet
Modifier and TypeMethodDescriptionvoid
Associate this channel with possibly wrapped values forServletChannel.getRequest()
,ServletChannel.getResponse()
andServletChannel.getCallback()
.void
This method is invoked for the COMPLETE action handling in HttpChannel.handle.void
ServletContextResponse.completeOutput
(Callback callback) boolean
boolean
boolean
boolean
protected boolean
ServletContextHandler.handleByContextHandler
(String pathInContext, ContextRequest request, Response response, Callback callback) protected boolean
EagerFormHandler.handleFormFields
(Request request, Response response, Callback callback) protected boolean
EagerFormHandler.handleMultiPartFormData
(Request request, String contentType, Response response, Callback callback) void
HttpOutput.sendContent
(InputStream in, Callback callback) Asynchronous send of stream content.void
HttpOutput.sendContent
(ByteBuffer content, Callback callback) Asynchronous send of whole content.void
HttpOutput.sendContent
(ReadableByteChannel in, Callback callback) Asynchronous send of channel content.void
ServletContextResponse.write
(boolean last, ByteBuffer content, Callback callback) void
ServletCoreResponse.write
(boolean last, ByteBuffer byteBuffer, Callback callback) -
Uses of Callback in org.eclipse.jetty.ee10.websocket.jakarta.common
Modifier and TypeClassDescriptionclass
Wrapper of user providedSendHandler
to Jetty internalCallback
Modifier and TypeMethodDescriptionvoid
void
void
JakartaWebSocketFrameHandler.onClosed
(CloseStatus closeStatus, Callback callback) void
JakartaWebSocketFrameHandler.onContinuation
(Frame frame, Callback callback) void
void
void
JakartaWebSocketFrameHandler.onOpen
(CoreSession coreSession, Callback callback) void
void
void
void
void
JakartaWebSocketRemoteEndpoint.sendObject
(Object data, Callback callback) -
Uses of Callback in org.eclipse.jetty.ee10.websocket.jakarta.common.messages
-
Uses of Callback in org.eclipse.jetty.ee10.websocket.jakarta.server.internal
Modifier and TypeMethodDescriptionJakartaWebSocketCreator.createWebSocket
(ServerUpgradeRequest request, ServerUpgradeResponse response, Callback callback) -
Uses of Callback in org.eclipse.jetty.fcgi.client.transport.internal
Modifier and TypeMethodDescriptionprotected void
HttpChannelOverFCGI.flush
(ByteBufferPool.Accumulator accumulator, Callback callback) protected void
HttpSenderOverFCGI.sendContent
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) protected void
HttpSenderOverFCGI.sendHeaders
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) -
Uses of Callback in org.eclipse.jetty.fcgi.generator
Modifier and TypeMethodDescriptionvoid
Flusher.flush
(ByteBufferPool.Accumulator accumulator, Callback callback) -
Uses of Callback in org.eclipse.jetty.fcgi.proxy
Modifier and TypeMethodDescriptionprotected void
FastCGIProxyHandler.sendProxyToServerRequest
(Request clientToProxyRequest, Request proxyToServerRequest, Response proxyToClientResponse, Callback proxyToClientCallback) -
Uses of Callback in org.eclipse.jetty.fcgi.server.internal
Modifier and TypeMethodDescriptionvoid
HttpStreamOverFCGI.send
(MetaData.Request request, MetaData.Response response, boolean last, ByteBuffer byteBuffer, Callback callback) -
Uses of Callback in org.eclipse.jetty.http2
Modifier and TypeMethodDescriptionprotected void
boolean
Invoked internally and by applications to send a GO_AWAY frame to the other peer.void
HTTP2Session.data
(HTTP2Stream stream, DataFrame frame, Callback callback) void
void
HTTP2StreamEndPoint.fillInterested
(Callback callback) void
HTTP2Session.frames
(HTTP2Stream stream, List<? extends Frame> frames, Callback callback) boolean
HTTP2Session.goAway
(GoAwayFrame frame, Callback callback) void
HTTP2Stream.headers
(HeadersFrame frame, Callback callback) protected void
HTTP2Session.notifyClose
(Session session, GoAwayFrame frame, Callback callback) protected void
HTTP2Session.notifyFailure
(Session session, Throwable failure, Callback callback) HTTP2Channel.Client.onReset
(ResetFrame frame, Callback callback) void
int
HTTP2Session.priority
(PriorityFrame frame, Callback callback) void
void
HTTP2Stream.reset
(ResetFrame frame, Callback callback) void
HTTP2Stream.send
(HTTP2Stream.FrameList frameList, Callback callback) void
HTTP2Session.settings
(SettingsFrame frame, Callback callback) boolean
HTTP2StreamEndPoint.tryFillInterested
(Callback callback) void
HTTP2StreamEndPoint.write
(Callback callback, ByteBuffer... buffers) ModifierConstructorDescriptionprotected
Entry
(Frame frame, HTTP2Stream stream, Callback callback) -
Uses of Callback in org.eclipse.jetty.http2.api
Modifier and TypeMethodDescriptionboolean
Closes the session by sending a GOAWAY frame with the given error code and payload.void
Sends the given DATAframe
.void
Stream.headers
(HeadersFrame frame, Callback callback) Sends the given HEADERSframe
.default void
Session.Listener.onClose
(Session session, GoAwayFrame frame, Callback callback) Callback method invoked when a GOAWAY frame caused the session to be closed.default void
Callback method invoked when a failure has been detected for this session.default void
Stream.Listener.onFailure
(Stream stream, int error, String reason, Throwable failure, Callback callback) Callback method invoked when the stream failed.default void
Stream.Listener.onReset
(Stream stream, ResetFrame frame, Callback callback) Callback method invoked when a RST_STREAM frame has been received for this stream.void
Sends the given PINGframe
.int
Session.priority
(PriorityFrame frame, Callback callback) Sends the given PRIORITYframe
.void
Stream.reset
(ResetFrame frame, Callback callback) Sends the given RST_STREAMframe
.void
Session.settings
(SettingsFrame frame, Callback callback) Sends the given SETTINGSframe
to configure the session. -
Uses of Callback in org.eclipse.jetty.http2.client.transport.internal
Modifier and TypeMethodDescriptionvoid
HTTPSessionListenerPromise.onClose
(Session session, GoAwayFrame frame, Callback callback) void
ClientHTTP2StreamEndPoint.onReset
(ResetFrame frame, Callback callback) HttpReceiverOverHTTP2.onReset
(ResetFrame frame, Callback callback) protected void
HttpSenderOverHTTP2.sendContent
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) protected void
HttpSenderOverHTTP2.sendHeaders
(HttpExchange exchange, ByteBuffer contentBuffer, boolean lastContent, Callback callback) -
Uses of Callback in org.eclipse.jetty.http2.internal
-
Uses of Callback in org.eclipse.jetty.http2.server
Modifier and TypeMethodDescriptionvoid
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onClose
(Session session, GoAwayFrame frame, Callback callback) void
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onFailure
(Session session, Throwable failure, Callback callback) void
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onFailure
(Stream stream, int error, String reason, Throwable failure, Callback callback) void
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onReset
(Stream stream, ResetFrame frame, Callback callback) -
Uses of Callback in org.eclipse.jetty.http2.server.internal
Modifier and TypeMethodDescriptionvoid
HTTP2ServerConnection.onSessionFailure
(Throwable failure, Callback callback) void
HTTP2ServerConnection.onStreamFailure
(Stream stream, Throwable failure, Callback callback) void
HttpStreamOverHTTP2.send
(MetaData.Request request, MetaData.Response response, boolean last, ByteBuffer byteBuffer, Callback callback) -
Uses of Callback in org.eclipse.jetty.http3
Modifier and TypeClassDescriptionclass
class
class
Modifier and TypeMethodDescriptionboolean
boolean
MessageFlusher.offer
(QuicStreamEndPoint endPoint, Frame frame, Callback callback) abstract void
HTTP3Session.writeControlFrame
(Frame frame, Callback callback) abstract void
HTTP3Session.writeMessageFrame
(long streamId, Frame frame, Callback callback) -
Uses of Callback in org.eclipse.jetty.http3.client
Modifier and TypeMethodDescriptionvoid
HTTP3SessionClient.writeControlFrame
(Frame frame, Callback callback) void
HTTP3SessionClient.writeMessageFrame
(long streamId, Frame frame, Callback callback) -
Uses of Callback in org.eclipse.jetty.io
Modifier and TypeMethodDescriptionvoid
ByteBufferCallbackAccumulator.addEntry
(ByteBuffer buffer, Callback callback) static Flow.Subscriber<Content.Chunk>
Content.Sink.asSubscriber
(Content.Sink sink, Callback callback) Wraps the given content sink with aFlow.Subscriber
.static void
Content.Source.consumeAll
(Content.Source source, Callback callback) Reads, non-blocking, the given content source, until afailure
or EOF and discards the content.static void
Content.copy
(Content.Source source, Content.Sink sink, Content.Chunk.Processor chunkProcessor, Callback callback) Copies the given content source to the given content sink, notifying the given callback when the copy is complete.static void
Content.copy
(Content.Source source, Content.Sink sink, Callback callback) Copies the given content source to the given content sink, notifying the given callback when the copy is complete (either succeeded or failed).static void
IOResources.copy
(Resource resource, Content.Sink sink, ByteBufferPool bufferPool, int bufferSize, boolean direct, long first, long length, Callback callback) Performs an asynchronous copy of a subset of the contents of a resource to a sink, using the given buffer pool and buffer characteristics.static void
IOResources.copy
(Resource resource, Content.Sink sink, ByteBufferPool bufferPool, int bufferSize, boolean direct, Callback callback) Performs an asynchronous copy of the contents of a resource to a sink, using the given buffer pool and buffer characteristics.protected void
AbstractConnection.failedCallback
(Callback callback, Throwable x) void
AbstractEndPoint.fillInterested
(Callback callback) void
EndPoint.fillInterested
(Callback callback) Requests callback methods to be invoked when a call toEndPoint.fill(ByteBuffer)
would return data or EOF.boolean
Content.Chunk.Processor.process
(Content.Chunk chunk, Callback callback) void
Call to register interest in a callback when a read is possible.void
AbstractConnection.tryFillInterested
(Callback callback) boolean
AbstractEndPoint.tryFillInterested
(Callback callback) boolean
EndPoint.tryFillInterested
(Callback callback) Requests callback methods to be invoked when a call toEndPoint.fill(ByteBuffer)
would return data or EOF.boolean
FillInterest.tryRegister
(Callback callback) Call to register interest in a callback when a read is possible.void
AbstractEndPoint.write
(Callback callback, ByteBuffer... buffers) void
Content.Sink.write
(boolean last, ByteBuffer byteBuffer, Callback callback) Writes the givenByteBuffer
, notifying theCallback
when the write is complete.static void
Content.Sink.write
(Content.Sink sink, boolean last, String utf8Content, Callback callback) void
DatagramChannelEndPoint.write
(Callback callback, SocketAddress address, ByteBuffer... buffers) default void
EndPoint.write
(Callback callback, SocketAddress address, ByteBuffer... buffers) Writes to the given address the data contained in the given buffers, and invokes the given callback when either all the data has been sent, or a failure occurs.default void
EndPoint.write
(Callback callback, ByteBuffer... buffers) Writes the given buffers viaEndPoint.flush(ByteBuffer...)
and invokes callback methods when either all the data has been flushed or an error occurs.void
WriteFlusher.write
(Callback callback, SocketAddress address, ByteBuffer... buffers) void
WriteFlusher.write
(Callback callback, ByteBuffer... buffers) Tries to switch state to WRITING. -
Uses of Callback in org.eclipse.jetty.io.content
Modifier and TypeMethodDescriptionvoid
void
Flush the buffered content.void
AsyncContent.write
(boolean last, ByteBuffer byteBuffer, Callback callback) Writes the givenByteBuffer
, notifying theCallback
when the write is complete.void
BufferedContentSink.write
(boolean last, ByteBuffer byteBuffer, Callback callback) -
Uses of Callback in org.eclipse.jetty.io.internal
ModifierConstructorDescriptionContentCopier
(Content.Source source, Content.Sink sink, Content.Chunk.Processor chunkProcessor, Callback callback) ContentSourceConsumer
(Content.Source source, Callback callback) -
Uses of Callback in org.eclipse.jetty.proxy
Modifier and TypeMethodDescriptionboolean
ProxyHandler.handle
(Request clientToProxyRequest, Response proxyToClientResponse, Callback proxyToClientCallback) protected Response.CompleteListener
ProxyHandler.newServerToProxyResponseListener
(Request clientToProxyRequest, Request proxyToServerRequest, Response proxyToClientResponse, Callback proxyToClientCallback) protected void
ProxyHandler.onProxyToClientResponseComplete
(Request clientToProxyRequest, Request proxyToServerRequest, Response serverToProxyResponse, Response proxyToClientResponse, Callback proxyToClientCallback) protected void
ProxyHandler.onProxyToClientResponseFailure
(Request clientToProxyRequest, Request proxyToServerRequest, Response serverToProxyResponse, Response proxyToClientResponse, Callback proxyToClientCallback, Throwable failure) protected void
ProxyHandler.onServerToProxyResponseFailure
(Request clientToProxyRequest, Request proxyToServerRequest, Response serverToProxyResponse, Response proxyToClientResponse, Callback proxyToClientCallback, Throwable failure) protected void
ProxyHandler.sendProxyToServerRequest
(Request clientToProxyRequest, Request proxyToServerRequest, Response proxyToClientResponse, Callback proxyToClientCallback) ModifierConstructorDescriptionProxyResponseListener
(Request clientToProxyRequest, Request proxyToServerRequest, Response proxyToClientResponse, Callback proxyToClientCallback) -
Uses of Callback in org.eclipse.jetty.quic.common
Modifier and TypeMethodDescriptionvoid
QuicStreamEndPoint.fillInterested
(Callback callback) boolean
QuicStreamEndPoint.tryFillInterested
(Callback callback) void
QuicConnection.write
(Callback callback, SocketAddress remoteAddress, ByteBuffer... buffers) void
QuicStreamEndPoint.write
(Callback callback, List<ByteBuffer> buffers, boolean last) -
Uses of Callback in org.eclipse.jetty.rewrite.handler
-
Uses of Callback in org.eclipse.jetty.security
Modifier and TypeMethodDescriptionAuthenticationState.authenticate
(Request request, Response response, Callback callback) Get successful authentication for a request.AuthenticationState.Deferred.authenticate
(Request request, Response response, Callback callback) Authenticate the request using any credentials already associated with the request or challenging if necessary.boolean
protected void
SecurityHandler.redirectToSecure
(Request request, Response response, Callback callback) Authenticator.NoOp.validateRequest
(Request request, Response response, Callback callback) Authenticator.validateRequest
(Request request, Response response, Callback callback) Validate a request -
Uses of Callback in org.eclipse.jetty.security.authentication
Modifier and TypeMethodDescriptionLoginAuthenticator.LoggedOutAuthentication.authenticate
(Request request, Response response, Callback callback) BasicAuthenticator.validateRequest
(Request req, Response res, Callback callback) DigestAuthenticator.validateRequest
(Request req, Response res, Callback callback) FormAuthenticator.validateRequest
(Request request, Response response, Callback callback) SPNEGOAuthenticator.validateRequest
(Request req, Response res, Callback callback) SslClientCertAuthenticator.validateRequest
(Request req, Response res, Callback callback) -
Uses of Callback in org.eclipse.jetty.security.internal
Modifier and TypeMethodDescriptionDeferredAuthenticationState.authenticate
(Request request, Response response, Callback callback) -
Uses of Callback in org.eclipse.jetty.security.openid
Modifier and TypeMethodDescriptionOpenIdAuthenticator.validateRequest
(Request request, Response response, Callback cb) -
Uses of Callback in org.eclipse.jetty.server
Modifier and TypeInterfaceDescriptioninterface
A HttpStream is an abstraction that together withMetaData.Request
, represents the flow of data from and to a single request and response cycle.Modifier and TypeMethodDescriptionvoid
ResourceService.doGet
(Request request, Response response, Callback callback, HttpContent content) void
ProxyConnectionFactory.ProxyEndPoint.fillInterested
(Callback callback) boolean
boolean
boolean
Invoked to handle the passed HTTP request and response.boolean
boolean
protected void
ResourceService.handleWelcomeAction
(Request request, Response response, Callback callback, ResourceService.WelcomeAction welcomeAction) protected boolean
ResourceService.passConditionalHeaders
(Request request, Response response, HttpContent content, Callback callback) protected void
ResourceService.redirectWelcome
(Request request, Response response, Callback callback, String welcomeTarget) Redirects to the given welcome target.protected void
ResourceService.rehandleWelcome
(Request request, Response response, Callback callback, String welcomeTarget) Rehandles the given welcome target.void
HttpStream.send
(MetaData.Request request, MetaData.Response response, boolean last, ByteBuffer content, Callback callback) Send response meta-data and/or data.void
HttpStream.Wrapper.send
(MetaData.Request request, MetaData.Response response, boolean last, ByteBuffer content, Callback callback) protected void
ResourceService.sendRedirect
(Request request, Response response, Callback callback, String target) static void
Response.sendRedirect
(Request request, Response response, Callback callback, int code, String location, boolean consumeAvailable) Sends a302
HTTP redirect status code to the given location.static void
Response.sendRedirect
(Request request, Response response, Callback callback, String location) Sends a HTTP redirect status code to the given location, without consuming the available request content.static void
Response.sendRedirect
(Request request, Response response, Callback callback, String location, boolean consumeAvailable) Sends HTTP redirect status code to the given location, without consuming the available request content.protected void
ResourceService.sendWelcome
(HttpContent content, String pathInContext, boolean endsWithSlash, Request request, Response response, Callback callback) protected void
ResourceService.serveWelcome
(Request request, Response response, Callback callback, String welcomeTarget) Serves the given welcome target.boolean
ProxyConnectionFactory.ProxyEndPoint.tryFillInterested
(Callback callback) void
ProxyConnectionFactory.ProxyEndPoint.write
(Callback callback, ByteBuffer... buffers) void
Response.Wrapper.write
(boolean last, ByteBuffer byteBuffer, Callback callback) void
Response.write
(boolean last, ByteBuffer byteBuffer, Callback callback) Writes the givenByteBuffer
, notifying theCallback
when the write is complete.static void
Response.writeError
(Request request, Response response, Callback callback, int status) Writes an error response with the given HTTP status code.static void
Response.writeError
(Request request, Response response, Callback callback, int status, String message) Writes an error response with the given HTTP status code, and the given message in the response content.static void
Response.writeError
(Request request, Response response, Callback callback, int status, String message, Throwable cause) Writes an error response with the given HTTP status code, and the given message in the response content.static void
Response.writeError
(Request request, Response response, Callback callback, Throwable cause) Writes an error response with HTTP status code500
.protected void
ResourceService.writeHttpContent
(Request request, Response response, Callback callback, HttpContent content) protected void
ResourceService.writeHttpError
(Request request, Response response, Callback callback, int status) protected void
ResourceService.writeHttpError
(Request request, Response response, Callback callback, int status, String msg, Throwable cause) protected void
ResourceService.writeHttpError
(Request request, Response response, Callback callback, Throwable cause) -
Uses of Callback in org.eclipse.jetty.server.handler
Modifier and TypeMethodDescriptionConnectHandler.ConnectContext.getCallback()
protected Callback
DelayedHandler.DelayedProcess.getCallback()
Modifier and TypeMethodDescriptionvoid
ContextHandlerCollection.deployHandler
(Handler handler, Callback callback) Thread safe deploy of a Handler.protected void
QoSHandler.failSuspended
(Request request, Response response, Callback callback, int status, Throwable failure) Fails the given suspended request/response with the given error code and failure.protected boolean
ErrorHandler.generateAcceptableResponse
(Request request, Response response, Callback callback, String contentType, List<Charset> charsets, int code, String message, Throwable cause) protected void
ErrorHandler.generateResponse
(Request request, Response response, int code, String message, Throwable cause, Callback callback) protected void
ReHandlingErrorHandler.generateResponse
(Request request, Response response, int code, String message, Throwable cause, Callback callback) final boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
StateTrackingHandler.handle
(Request originalRequest, Response originalResponse, Callback originalCallback) boolean
StatisticsHandler.MinimumDataRateHandler.handle
(Request request, Response response, Callback callback) boolean
protected boolean
ContextHandler.handleByContextHandler
(String pathInContext, ContextRequest request, Response response, Callback callback) protected void
ConnectHandler.handleConnect
(Request request, Response response, Callback callback, String serverAddress) Handles a CONNECT request.protected void
ContextHandler.handleMovedPermanently
(Request request, Response response, Callback callback) protected void
ContextHandler.handleUnavailable
(Request request, Response response, Callback callback) protected DelayedHandler.DelayedProcess
DelayedHandler.newDelayedProcess
(boolean contentExpected, String contentType, MimeTypes.Type mimeType, Handler handler, Request request, Response response, Callback callback) protected boolean
ConditionalHandler.nextHandler
(Request request, Response response, Callback callback) Handle a request by invoking theConditionalHandler.handle(Request, Response, Callback)
method of thenext Handler
.boolean
BufferedResponseHandler.onConditionsMet
(Request request, Response response, Callback callback) protected boolean
ConditionalHandler.DontHandle.onConditionsMet
(Request request, Response response, Callback callback) protected abstract boolean
ConditionalHandler.onConditionsMet
(Request request, Response response, Callback callback) Handle a request that has met the conditions.protected boolean
ConditionalHandler.Reject.onConditionsMet
(Request request, Response response, Callback callback) protected boolean
ConditionalHandler.SkipNext.onConditionsMet
(Request request, Response response, Callback callback) protected boolean
InetAccessHandler.onConditionsMet
(Request request, Response response, Callback callback) boolean
QoSHandler.onConditionsMet
(Request request, Response response, Callback callback) boolean
ThreadLimitHandler.onConditionsMet
(Request request, Response response, Callback callback) protected boolean
BufferedResponseHandler.onConditionsNotMet
(Request request, Response response, Callback callback) protected boolean
ConditionalHandler.ElseNext.onConditionsNotMet
(Request request, Response response, Callback callback) protected abstract boolean
ConditionalHandler.onConditionsNotMet
(Request request, Response response, Callback callback) This method is called when the request has not met the conditions and is not to be handled by this handler.protected boolean
InetAccessHandler.onConditionsNotMet
(Request request, Response response, Callback callback) protected boolean
QoSHandler.onConditionsNotMet
(Request request, Response response, Callback callback) protected boolean
ThreadLimitHandler.onConditionsNotMet
(Request request, Response response, Callback callback) protected void
ConnectHandler.onConnectFailure
(Request request, Response response, Callback callback, Throwable failure) void
ContextHandlerCollection.undeployHandler
(Handler handler, Callback callback) Thread safe undeploy of a Handler.protected void
ConnectHandler.DownstreamConnection.write
(EndPoint endPoint, ByteBuffer buffer, Callback callback) protected void
ConnectHandler.UpstreamConnection.write
(EndPoint endPoint, ByteBuffer buffer, Callback callback) protected void
ConnectHandler.write
(EndPoint endPoint, ByteBuffer buffer, Callback callback, ConcurrentMap<String, Object> context) Writes (with non-blocking semantic) the given buffer of data onto the given endPoint.void
ContextResponse.write
(boolean last, ByteBuffer content, Callback callback) void
StatisticsHandler.MinimumDataRateHandler.MinimumDataRateResponse.write
(boolean last, ByteBuffer byteBuffer, Callback callback) ModifierConstructorDescriptionConnectContext
(Request request, Response response, Callback callback, EndPoint endPoint) protected
DelayedProcess
(Handler handler, Request request, Response response, Callback callback) UntilContentDelayedProcess
(Handler handler, Request request, Response response, Callback callback) UntilFormDelayedProcess
(Handler handler, Request wrapped, Response response, Callback callback, String contentType) UntilMultipartDelayedProcess
(Handler handler, Request request, Response response, Callback callback, String contentType, MultiPartConfig config) -
Uses of Callback in org.eclipse.jetty.server.handler.gzip
Modifier and TypeMethodDescriptionprotected void
GzipResponseAndCallback.commit
(boolean last, Callback callback, ByteBuffer content) boolean
void
GzipResponseAndCallback.write
(boolean last, ByteBuffer content, Callback callback) ModifierConstructorDescriptionGzipResponseAndCallback
(GzipHandler handler, Request request, Response response, Callback callback) -
Uses of Callback in org.eclipse.jetty.server.internal
Modifier and TypeClassDescriptionclass
A HttpStream wrapper that keeps a list of listeners.static class
The Channel's implementation of theResponse
API.protected class
Modifier and TypeMethodDescriptionvoid
HttpConnection.HttpStreamOverHTTP1.send
(MetaData.Request request, MetaData.Response response, boolean last, ByteBuffer content, Callback callback) void
HttpChannelState.ChannelResponse.write
(boolean last, ByteBuffer content, Callback callback) -
Uses of Callback in org.eclipse.jetty.session
-
Uses of Callback in org.eclipse.jetty.util
Modifier and TypeInterfaceDescriptionstatic interface
static interface
A Callback implementation that calls theCallback.Completing.completed()
method when it either succeeds or fails.Modifier and TypeClassDescriptionstatic class
ACompletableFuture
that is also aCallback
.static class
Nested Completing Callback that completes after completing the nested callbackclass
A callback wrapper that succeeds the wrapped callback when the count is reached, or on first failure.class
class
This specialized callback implements a pattern that allows a large asynchronous task to be broken into smaller asynchronous sub-tasks using iteration rather than recursion.class
Iterating Nested Callback.class
Deprecated.A Closeable Callback.Modifier and TypeFieldDescriptionstatic final Callback
Callback.NOOP
Instance of Adapter that can be used when the callback methods need an empty implementation without incurring in the cost of allocating a new Adapter object.Modifier and TypeMethodDescriptionstatic Callback
static Callback
Creates a callback that runs completed when it succeeds or failsstatic Callback
Creates a callback from the given success and failure lambdas.static Callback
Creates a nested callback that runs completed before completing the nested callback.static Callback
Callback.from
(CompletableFuture<?> completable) Creates a non-blocking callback from the given incomplete CompletableFuture.static Callback
Callback.from
(CompletableFuture<?> completable, Invocable.InvocationType invocation) Creates a callback from the given incomplete CompletableFuture, with the givenblocking
characteristic.static Callback
Creates a nested callback that runs completed after completing the nested callback.static Callback
Creates a nested callback which always fails the nested callback on completion.static Callback
Creates a nested callback that runs completed after completing the nested callback.static Callback
Creates a callback which combines two other callbacks and will succeed or fail them both.static Callback
Callback.from
(Invocable.InvocationType invocationType, Runnable completed) Creates a Callback with the giveninvocationType
, that runs the givenRunnable
when it succeeds or fails.static Callback
Callback.from
(Invocable.InvocationType invocationType, Runnable success, Consumer<Throwable> failure) Creates a callback with the given InvocationType from the given success and failure lambdas.Callback.Nested.getCallback()
Modifier and TypeMethodDescriptionstatic Callback
static Callback.Completable
Creates a completable future given a callback.static Callback
Creates a nested callback that runs completed before completing the nested callback.static Callback
Creates a nested callback that runs completed after completing the nested callback.static Callback
Creates a nested callback which always fails the nested callback on completion.static Callback
Creates a nested callback that runs completed after completing the nested callback.static Callback
Creates a callback which combines two other callbacks and will succeed or fail them both.void
Get the scanner to perform a scan cycle as soon as possible and call the Callback when the scan is finished or failed.ModifierConstructorDescriptionCountingCallback
(Callback callback, int count) IteratingNestedCallback
(Callback callback) -
Uses of Callback in org.eclipse.jetty.websocket.common
Modifier and TypeMethodDescriptionvoid
JettyWebSocketFrameHandler.onClosed
(CloseStatus closeStatus, Callback callback) void
void
void
JettyWebSocketFrameHandler.onOpen
(CoreSession coreSession, Callback callback) -
Uses of Callback in org.eclipse.jetty.websocket.common.internal
Modifier and TypeMethodDescriptionprotected void
ByteBufferMessageSink.invoke
(MethodHandle methodHandle, ByteBuffer byteBuffer, Callback callback) protected void
PartialByteBufferMessageSink.invoke
(MethodHandle methodHandle, ByteBuffer byteBuffer, boolean fin, Callback callback) -
Uses of Callback in org.eclipse.jetty.websocket.core
Modifier and TypeMethodDescriptionvoid
Initiate close handshake with provided status code and optional reason phrase.void
Initiate close handshake, no payload (no declared status code or reason phrase).default void
CoreSession.close
(CloseStatus closeStatus, Callback callback) Initiate close handshake with a providedCloseStatus
.void
void
void
CoreSession.Empty.close
(CloseStatus closeStatus, Callback callback) void
void
void
WebSocketCoreSession.close
(CloseStatus closeStatus, Callback callback) void
WebSocketConnection.enqueueFrame
(Frame frame, Callback callback, boolean batch) Enqueue a Frame to be sent.void
void
void
protected void
AbstractExtension.nextIncomingFrame
(Frame frame, Callback callback) protected void
AbstractExtension.nextOutgoingFrame
(Frame frame, Callback callback, boolean batch) void
FrameHandler.onClosed
(CloseStatus closeStatus, Callback callback) Invoked when a WebSocket close event happened.void
Invoked when an error has occurred or has been detected.void
void
void
void
Invoked when a WebSocket frame is received.void
Process the incoming frame.void
void
FrameHandler.onOpen
(CoreSession coreSession, Callback callback) Invoked when the WebSocket connection is opened.void
WebSocketCoreSession.processConnectionError
(Throwable cause, Callback callback) Process an Error that originated from the connection.void
WebSocketCoreSession.processHandlerError
(Throwable cause, Callback callback) Process an Error that originated from the handler.void
void
void
void
A frame, and optional callback, intended for the network layer.void
-
Uses of Callback in org.eclipse.jetty.websocket.core.client.internal
-
Uses of Callback in org.eclipse.jetty.websocket.core.internal
Modifier and TypeClassDescriptionclass
class
Modifier and TypeMethodDescriptionboolean
Enqueue a Frame to be written to the endpoint.protected boolean
protected void
PerMessageDeflateExtension.nextIncomingFrame
(Frame frame, Callback callback) protected void
PerMessageDeflateExtension.nextOutgoingFrame
(Frame frame, Callback callback, boolean batch) protected void
FrameFlusher.notifyCallbackFailure
(Callback callback, Throwable failure) protected void
FrameFlusher.notifyCallbackSuccess
(Callback callback) protected void
MessageHandler.onBinary
(ByteBuffer message, Callback callback) Method called when a complete binary message is received.protected void
MessageHandler.onBinaryFrame
(Frame frame, Callback callback) void
MessageHandler.onClosed
(CloseStatus closeStatus, Callback callback) protected void
MessageHandler.onCloseFrame
(Frame frame, Callback callback) protected void
MessageHandler.onContinuationFrame
(Frame frame, Callback callback) void
void
void
void
void
void
void
void
MessageHandler.onOpen
(CoreSession coreSession, Callback callback) protected void
MessageHandler.onPingFrame
(Frame frame, Callback callback) protected void
MessageHandler.onPongFrame
(Frame frame, Callback callback) protected void
Method called when a complete text message is received.protected void
MessageHandler.onTextFrame
(Frame frame, Callback callback) void
MessageHandler.sendBinary
(ByteBuffer message, Callback callback, boolean batch) Send a ByteBuffer as a single binary frame.void
MessageHandler.sendBinary
(Callback callback, boolean batch, ByteBuffer... parts) Send a sequence of ByteBuffers as a sequences for fragmented text frame.void
void
void
void
void
void
Send a String as a single text frame.void
Send a sequence of Strings as a sequences for fragmented text frame. -
Uses of Callback in org.eclipse.jetty.websocket.core.messages
Modifier and TypeMethodDescriptionvoid
void
void
void
void
void
Consumes the WebSocket frame, possibly asynchronously when this method has returned.void
void
void
void
protected void
ByteBufferMessageSink.invoke
(MethodHandle methodHandle, ByteBuffer byteBuffer, Callback callback) protected void
PartialByteBufferMessageSink.invoke
(MethodHandle methodHandle, ByteBuffer byteBuffer, boolean fin, Callback callback) void
MessageOutputStream.setCallback
(Callback callback) void
MessageWriter.setCallback
(Callback callback) -
Uses of Callback in org.eclipse.jetty.websocket.core.server
Modifier and TypeMethodDescriptionWebSocketCreator.createWebSocket
(ServerUpgradeRequest request, ServerUpgradeResponse response, Callback callback) Create a websocket from the incoming request.boolean
WebSocketNegotiator.negotiate
(ServerUpgradeRequest request, ServerUpgradeResponse response, Callback callback) Creates aFrameHandler
from the incoming request.boolean
WebSocketMappings.upgrade
(Request request, Response response, Callback callback, Configuration.Customizer defaultCustomizer) Attempts to find a WebSocket mapping and upgrade a request to WebSocket.boolean
WebSocketMappings.upgrade
(WebSocketNegotiator negotiator, Request request, Response response, Callback callback, Configuration.Customizer defaultCustomizer) Attempts to find a WebSocket mapping and upgrade a request to WebSocket.boolean
Handshaker.upgradeRequest
(WebSocketNegotiator negotiator, Request request, Response response, Callback callback, WebSocketComponents components, Configuration.Customizer defaultCustomizer) Attempts to upgrade a request to WebSocket. -
Uses of Callback in org.eclipse.jetty.websocket.core.server.internal
Modifier and TypeMethodDescriptionCreatorNegotiator.negotiate
(ServerUpgradeRequest request, ServerUpgradeResponse response, Callback callback) protected abstract WebSocketNegotiation
AbstractHandshaker.newNegotiation
(Request request, Response response, Callback callback, WebSocketComponents webSocketComponents) protected WebSocketNegotiation
RFC6455Handshaker.newNegotiation
(Request request, Response response, Callback callback, WebSocketComponents webSocketComponents) protected WebSocketNegotiation
RFC8441Handshaker.newNegotiation
(Request request, Response response, Callback callback, WebSocketComponents webSocketComponents) boolean
AbstractHandshaker.upgradeRequest
(WebSocketNegotiator negotiator, Request request, Response response, Callback callback, WebSocketComponents components, Configuration.Customizer defaultCustomizer) boolean
HandshakerSelector.upgradeRequest
(WebSocketNegotiator negotiator, Request request, Response response, Callback callback, WebSocketComponents components, Configuration.Customizer defaultCustomizer) ModifierConstructorDescriptionRFC6455Negotiation
(Request request, Response response, Callback callback, WebSocketComponents components) RFC8441Negotiation
(Request request, Response response, Callback callback, WebSocketComponents components) WebSocketNegotiation
(Request request, Response response, Callback callback, WebSocketComponents webSocketComponents) -
Uses of Callback in org.eclipse.jetty.websocket.core.util
Modifier and TypeClassDescriptionclass
This flusher can be used to mutated and fragmentFrame
s and forwarded them on towards the application using theIncomingFrames
provided in the constructor.Modifier and TypeMethodDescriptionvoid
This is used within an implementation ofDemandingFlusher.handle(Frame, Callback, boolean)
to forward a frame onto the next layer of processing.protected abstract void
FragmentingFlusher.forwardFrame
(Frame frame, Callback callback, boolean batch) protected abstract boolean
Called when there is demand for a single frame to be produced.void
Used to supply the flusher with a new frame.protected boolean
protected abstract boolean
Called when a frame is ready to be transformed.final void
protected boolean
protected abstract boolean
Called to transform the frame given inTransformingFlusher.onFrame(Frame, Callback, boolean)
. -
Uses of Callback in org.eclipse.jetty.websocket.server
Modifier and TypeMethodDescriptionWebSocketCreator.createWebSocket
(ServerUpgradeRequest upgradeRequest, ServerUpgradeResponse upgradeResponse, Callback callback) Creates a WebSocket endpoint instance from the incoming request.boolean
Matches the givenrequest
against existing WebSocket mappings, upgrading to WebSocket if there is a match.boolean
protected boolean
WebSocketUpgradeHandler.handle
(ServerWebSocketContainer container, Request request, Response response, Callback callback) boolean
ServerWebSocketContainer.upgrade
(WebSocketCreator creator, Request request, Response response, Callback callback) Upgrades the givenrequest
without matching against the WebSocket mappings.