Uses of Interface
org.eclipse.jetty.util.Callback
Package
Description
Jetty Client : Implementation and Core Classes
This package provides APIs, utility classes and an implementation of an asynchronous HTTP client.
Jetty Client : API Classes
Jetty Client : Utility Classes
Jetty IO : Core classes for Jetty IO subsystem
Jetty Proxy : Async Proxy Support
This module contains the main abstractions for the QUIC protocol.
Jetty Server : Core Server API
Jetty Server : Core Handler API
Jetty GZIP Handler
Jetty Util : Common Utility Classes
Jetty WebSocket Common : Implementation [Internal Use Only]
-
Uses of Callback in org.eclipse.jetty.client
Modifier and TypeClassDescriptionclass
A destination for those network transports that are duplex (e.g.class
class
A destination for those transports that are multiplex (e.g.protected 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
ResponseNotifier.notifyContent
(Response response, ObjLongConsumer<Object> demand, ByteBuffer buffer, Callback callback, List<Response.DemandedContentListener> contentListeners) protected boolean
HttpReceiver.responseContent
(HttpExchange exchange, ByteBuffer buffer, Callback callback) Method to be invoked when response HTTP content is available.protected 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.void
HttpUpgrader.upgrade
(HttpResponse response, EndPoint endPoint, Callback callback) Upgrades the givenendPoint
to a different protocol.protected abstract void
ProxyProtocolClientConnectionFactory.ProxyProtocolConnection.writePROXYBytes
(EndPoint endPoint, Callback callback) ModifierConstructorDescriptionprotected
AbstractConnectionPool
(HttpDestination destination, int maxConnections, boolean cache, Callback requester) protected
AbstractConnectionPool
(HttpDestination destination, Pool.StrategyType strategy, int maxConnections, boolean cache, Callback requester) protected
AbstractConnectionPool
(HttpDestination destination, Pool<Connection> pool, Callback requester) DuplexConnectionPool
(HttpDestination destination, int maxConnections, boolean cache, Callback requester) DuplexConnectionPool
(HttpDestination destination, int maxConnections, Callback requester) DuplexConnectionPool
(HttpDestination destination, Pool<Connection> pool, Callback requester) Deprecated.LeakTrackingConnectionPool
(HttpDestination destination, int maxConnections, Callback requester) MultiplexConnectionPool
(HttpDestination destination, int maxConnections, boolean cache, Callback requester, int maxMultiplex) MultiplexConnectionPool
(HttpDestination destination, int maxConnections, Callback requester, int maxMultiplex) MultiplexConnectionPool
(HttpDestination destination, Pool.StrategyType strategy, int maxConnections, boolean cache, Callback requester, int maxMultiplex) MultiplexConnectionPool
(HttpDestination destination, Pool<Connection> pool, Callback requester, int maxMultiplex) Deprecated.RandomConnectionPool
(HttpDestination destination, int maxConnections, Callback requester, int maxMultiplex) RoundRobinConnectionPool
(HttpDestination destination, int maxConnections, Callback requester) RoundRobinConnectionPool
(HttpDestination destination, int maxConnections, Callback requester, int maxMultiplex) ValidatingConnectionPool
(HttpDestination destination, int maxConnections, Callback requester, Scheduler scheduler, long timeout) -
Uses of Callback in org.eclipse.jetty.client.api
Modifier and TypeMethodDescriptionvoid
Request.Content.Consumer.onContent
(ByteBuffer buffer, boolean last, Callback callback) Callback method invoked by the producer when there is content available and there is demand for content.void
Response.AsyncContentListener.onContent
(Response response, ByteBuffer content, Callback callback) Callback method invoked when the response content has been received, parsed and there is demand.default void
Response.AsyncContentListener.onContent
(Response response, LongConsumer demand, ByteBuffer content, Callback callback) default void
Response.ContentListener.onContent
(Response response, ByteBuffer content, Callback callback) void
Response.DemandedContentListener.onContent
(Response response, LongConsumer demand, ByteBuffer content, Callback callback) Callback method invoked when the response content has been received. -
Uses of Callback in org.eclipse.jetty.client.http
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
ProtocolHttpUpgrader.upgrade
(HttpResponse response, EndPoint endPoint, Callback callback) -
Uses of Callback in org.eclipse.jetty.client.internal
Modifier and TypeClassDescriptionclass
Implements the conversion fromContentProvider
toRequest.Content
. -
Uses of Callback in org.eclipse.jetty.client.util
Modifier and TypeClassDescriptionclass
Deprecated.class
Deprecated.useInputStreamRequestContent
insteadclass
Deprecated.useOutputStreamRequestContent
insteadModifier and TypeMethodDescriptionprotected void
AbstractRequestContent.AbstractSubscription.notifyContent
(ByteBuffer buffer, boolean last, Callback callback) boolean
AsyncRequestContent.offer
(ByteBuffer buffer, Callback callback) boolean
DeferredContentProvider.offer
(ByteBuffer buffer, Callback callback) Deprecated.void
InputStreamResponseListener.onContent
(Response response, ByteBuffer content, Callback callback) boolean
AbstractRequestContent.Producer.produce
(ByteBuffer content, boolean lastContent, Callback callback) -
Uses of Callback in org.eclipse.jetty.fcgi.client.http
Modifier and TypeMethodDescriptionprotected boolean
HttpChannelOverFCGI.content
(ByteBuffer buffer, Callback callback) protected boolean
HttpReceiverOverFCGI.responseContent
(HttpExchange exchange, ByteBuffer buffer, 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 TypeMethodDescriptionprotected Generator.Result
Generator.generateContent
(int id, ByteBuffer content, boolean recycle, boolean lastContent, Callback callback, FCGI.FrameType frameType) ClientGenerator.generateRequestContent
(int request, ByteBuffer content, boolean lastContent, Callback callback) ClientGenerator.generateRequestHeaders
(int request, HttpFields fields, Callback callback) ServerGenerator.generateResponseContent
(int request, ByteBuffer content, boolean lastContent, boolean aborted, Callback callback) ServerGenerator.generateResponseHeaders
(int request, int code, String reason, HttpFields fields, Callback callback) -
Uses of Callback in org.eclipse.jetty.fcgi.server
Modifier and TypeMethodDescriptionprotected Generator.Result
HttpTransportOverFCGI.generateResponseContent
(ByteBuffer buffer, boolean lastContent, Callback callback) protected Generator.Result
HttpTransportOverFCGI.generateResponseHeaders
(MetaData.Response info, Callback callback) void
HttpTransportOverFCGI.send
(MetaData.Request request, MetaData.Response response, ByteBuffer content, boolean lastContent, Callback callback) -
Uses of Callback in org.eclipse.jetty.http2
Modifier and TypeClassDescriptionclass
static class
class
Modifier and TypeMethodDescriptionprotected void
boolean
Invoked internally and by applications to send a GO_AWAY frame to the other peer.void
void
void
Enqueues the given DATA frame to be written to the connection.void
HTTP2StreamEndPoint.fillInterested
(Callback callback) void
void
Enqueues the given frames to be written to the connection.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) protected void
void
void
void
Callback method invoked when a DATA frame is received.void
void
int
HTTP2Session.priority
(PriorityFrame frame, Callback callback) void
void
Processes the givenframe
, belonging to this stream.void
HTTP2Stream.reset
(ResetFrame frame, Callback callback) void
HTTP2Stream.send
(IStream.FrameList frameList, Callback callback) void
IStream.send
(IStream.FrameList frameList, Callback callback) Sends the given list of frames.void
HTTP2Session.settings
(SettingsFrame frame, Callback callback) boolean
HTTP2StreamEndPoint.tryFillInterested
(Callback callback) void
HTTP2StreamEndPoint.write
(Callback callback, ByteBuffer... buffers) -
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.void
default void
Callback method invoked when a DATA frame has been received.default void
Stream.Listener.onDataDemanded
(Stream stream, DataFrame frame, Callback callback) Callback method invoked when a DATA frame has been demanded.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.http
Modifier and TypeMethodDescriptionvoid
void
void
void
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.server
Modifier and TypeMethodDescriptionvoid
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onClose
(Session session, GoAwayFrame frame, Callback callback) void
void
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onDataDemanded
(Stream stream, DataFrame 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) void
HTTP2ServerConnection.onSessionFailure
(Throwable failure, Callback callback) void
HTTP2ServerConnection.onStreamFailure
(IStream stream, Throwable failure, Callback callback) void
HttpTransportOverHTTP2.send
(MetaData.Request request, MetaData.Response response, ByteBuffer content, boolean lastContent, Callback callback) void
HttpTransportOverHTTP2.sendContent
(MetaData.Request request, ByteBuffer content, boolean lastContent, Callback callback) void
HttpTransportOverHTTP2.sendHeaders
(MetaData.Request request, MetaData.Response response, ByteBuffer content, boolean lastContent, Callback callback) -
Uses of Callback in org.eclipse.jetty.io
Modifier and TypeMethodDescriptionvoid
ByteBufferCallbackAccumulator.addEntry
(ByteBuffer buffer, Callback callback) 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.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
DatagramChannelEndPoint.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.proxy
Modifier and TypeClassDescriptionprotected class
protected class
protected class
Modifier and TypeMethodDescriptionprotected void
boolean
AsyncMiddleManServlet.ProxyWriter.offer
(ByteBuffer content, Callback callback) void
AsyncMiddleManServlet.ProxyResponseListener.onContent
(Response serverResponse, ByteBuffer content, Callback callback) void
ProxyServlet.ProxyResponseListener.onContent
(Response proxyResponse, 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) 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.protected abstract void
ProxyConnection.write
(EndPoint endPoint, ByteBuffer buffer, Callback callback) -
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.server
Modifier and TypeClassDescriptionstatic class
A content represents the production of aHttpChannel
returned byHttpChannel.produceContent()
.static final class
EOF special content.static final class
Error special content.static class
Abstract class that implements the standard special content behavior.static class
Simple non-special content wrapper allow overriding the EOF flag.Modifier and TypeMethodDescriptionvoid
void
void
void
Response.completeOutput
(Callback callback) void
ProxyConnectionFactory.ProxyEndPoint.fillInterested
(Callback callback) void
HttpConnection.send
(MetaData.Request request, MetaData.Response response, ByteBuffer content, boolean lastContent, Callback callback) void
HttpTransport.send
(MetaData.Request request, MetaData.Response response, ByteBuffer content, boolean lastContent, Callback callback) Asynchronous call to send a response (or part) over the transportvoid
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
HttpOutput.sendContent
(HttpContent httpContent, Callback callback) Asynchronous send of HTTP content.protected boolean
HttpChannel.sendResponse
(MetaData.Response response, ByteBuffer content, boolean complete, Callback callback) boolean
ProxyConnectionFactory.ProxyEndPoint.tryFillInterested
(Callback callback) void
HttpChannel.write
(ByteBuffer content, boolean complete, Callback callback) Non-Blocking write, committing the response if needed.void
HttpOutput.Interceptor.write
(ByteBuffer content, boolean last, Callback callback) Write content.void
ProxyConnectionFactory.ProxyEndPoint.write
(Callback callback, ByteBuffer... buffers) -
Uses of Callback in org.eclipse.jetty.server.handler
Modifier and TypeMethodDescriptionvoid
ContextHandlerCollection.deployHandler
(Handler handler, Callback callback) Thread safe deploy of a Handler.void
ContextHandlerCollection.undeployHandler
(Handler handler, Callback callback) Thread safe undeploy of a Handler. -
Uses of Callback in org.eclipse.jetty.server.handler.gzip
Modifier and TypeMethodDescriptionprotected void
GzipHttpOutputInterceptor.commit
(ByteBuffer content, boolean complete, Callback callback) void
GzipHttpOutputInterceptor.write
(ByteBuffer content, boolean complete, Callback callback) -
Uses of Callback in org.eclipse.jetty.util
Modifier and TypeClassDescriptionstatic class
A CompletableFuture that is also a Callback.static class
A Callback implementation that calls theCallback.Completing.completed()
method when it either succeeds or fails.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
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 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 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.core
Modifier and TypeMethodDescriptionvoid
Initiate close handshake with provide status code and optional reason phrase.void
Initiate close handshake, no payload (no declared status code or reason phrase)void
void
void
void
If using BatchMode.ON or BatchMode.AUTO, trigger a flush of enqueued / batched frames.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) This is the Close Handshake Complete event.void
An error has occurred or been detected in websocket-core and being reported to FrameHandler.void
void
Receiver of all Frames.void
Process the incoming frame.void
FrameHandler.onOpen
(CoreSession coreSession, Callback callback) Async notification that Connection is being opened.void
void
void
A frame, and optional callback, intended for the network layer. -
Uses of Callback in org.eclipse.jetty.websocket.core.client.internal
Modifier and TypeMethodDescriptionvoid
HttpUpgraderOverHTTP.upgrade
(HttpResponse response, EndPoint endPoint, Callback callback) void
HttpUpgraderOverHTTP2.upgrade
(HttpResponse response, EndPoint endPoint, Callback callback) -
Uses of Callback in org.eclipse.jetty.websocket.core.internal
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.class
class
Modifier and TypeMethodDescriptionvoid
Send Close Frame with specified Status Code and optional Reasonvoid
Send Close Frame with no payload.void
This is used within an implementation ofDemandingFlusher.handle(Frame, Callback, boolean)
to forward a frame onto the next layer of processing.boolean
Enqueue a Frame to be written to the endpoint.void
protected abstract boolean
Called when there is demand for a single frame to be produced.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
Used to supply the flusher with a new frame.void
void
protected boolean
void
void
void
void
protected abstract boolean
Called when a frame is ready to be transformed.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
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
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
final 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.protected boolean
protected abstract boolean
Called to transform the frame given inTransformingFlusher.onFrame(Frame, Callback, boolean)
. -
Uses of Callback in org.eclipse.jetty.websocket.core.internal.messages
Modifier and TypeMethodDescriptionvoid
void
void
void
void
void
Consume the frame payload to the message.void
void
void
void
void
MessageOutputStream.setCallback
(Callback callback) void
MessageWriter.setCallback
(Callback callback) -
Uses of Callback in org.eclipse.jetty.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.websocket.jakarta.common.messages
AsyncRequestContent
instead.