Package | Description |
---|---|
org.eclipse.jetty.client |
Jetty Client : Implementation and Core Classes
This package provides APIs, utility classes and an implementation of an asynchronous HTTP client.
|
org.eclipse.jetty.client.api |
Jetty Client : API Classes
|
org.eclipse.jetty.client.http | |
org.eclipse.jetty.client.util |
Jetty Client : Utility Classes
|
org.eclipse.jetty.fcgi.client.http | |
org.eclipse.jetty.fcgi.generator | |
org.eclipse.jetty.fcgi.server | |
org.eclipse.jetty.http2 | |
org.eclipse.jetty.http2.api | |
org.eclipse.jetty.http2.client | |
org.eclipse.jetty.http2.client.http | |
org.eclipse.jetty.http2.server | |
org.eclipse.jetty.io |
Jetty IO : Core classes for Jetty IO subsystem
|
org.eclipse.jetty.io.ssl |
Jetty IO : Core SSL Support
|
org.eclipse.jetty.proxy |
Jetty Proxy : Async Proxy Support
|
org.eclipse.jetty.server |
Jetty Server : Core Server API
|
org.eclipse.jetty.server.handler |
Jetty Server : Core Handler API
|
org.eclipse.jetty.server.handler.gzip |
Jetty GZIP Handler
|
org.eclipse.jetty.util |
Jetty Util : Common Utility Classes
|
org.eclipse.jetty.websocket.common |
Jetty WebSocket Common : Implementation [Internal Use Only]
|
org.eclipse.jetty.websocket.common.extensions |
Jetty WebSocket Common : Extension Implementations
|
org.eclipse.jetty.websocket.common.extensions.compress |
Jetty WebSocket Common : Message Compression Extension Implementations
|
org.eclipse.jetty.websocket.common.extensions.fragment |
Jetty WebSocket Common : Auto Fragment Extension Implementation
|
org.eclipse.jetty.websocket.common.io |
Jetty WebSocket Common : I/O Implementation
|
Modifier and Type | Class and Description |
---|---|
class |
HttpContent
HttpContent is a stateful, linear representation of the request content provided
by a ContentProvider that can be traversed one-way to obtain content buffers to
send to a HTTP server. |
class |
HttpDestination |
private class |
HttpReceiver.Decoder |
private class |
HttpSender.CommitCallback |
private class |
HttpSender.ContentCallback |
private class |
HttpSender.LastCallback |
private class |
HttpSender.TrailersCallback |
class |
MultiplexHttpDestination |
class |
PoolingHttpDestination |
private static class |
Socks4Proxy.Socks4ProxyConnection |
Modifier and Type | Field and Description |
---|---|
private Callback |
HttpSender.commitCallback |
private Callback |
HttpSender.lastCallback |
private Callback |
AbstractConnectionPool.requester |
private Callback |
HttpSender.trailersCallback |
Modifier and Type | Method and Description |
---|---|
void |
ResponseNotifier.notifyContent(java.util.List<Response.ResponseListener> listeners,
Response response,
java.nio.ByteBuffer buffer,
Callback callback) |
private void |
ResponseNotifier.notifyContent(Response.AsyncContentListener listener,
Response response,
java.nio.ByteBuffer buffer,
Callback callback) |
void |
ResponseNotifier.notifyContent(Response response,
java.nio.ByteBuffer buffer,
Callback callback,
java.util.List<Response.AsyncContentListener> contentListeners) |
protected boolean |
HttpReceiver.responseContent(HttpExchange exchange,
java.nio.ByteBuffer buffer,
Callback callback)
Method to be invoked when response HTTP content is available.
|
protected abstract void |
HttpSender.sendContent(HttpExchange exchange,
HttpContent content,
Callback callback)
Implementations should send the content at the
HttpContent cursor position over the wire. |
protected abstract void |
HttpSender.sendHeaders(HttpExchange exchange,
HttpContent content,
Callback callback)
Implementations should send the HTTP headers over the wire, possibly with some content,
in a single write, and notify the given
callback of the result of this operation. |
protected abstract void |
HttpSender.sendTrailers(HttpExchange exchange,
Callback callback)
Implementations should send the HTTP trailers and notify the given
callback of the
result of this operation. |
Constructor and Description |
---|
AbstractConnectionPool(Destination destination,
int maxConnections,
Callback requester) |
Decoder(ResponseNotifier notifier,
HttpResponse response,
ContentDecoder decoder,
java.nio.ByteBuffer buffer,
Callback callback) |
DuplexConnectionPool(Destination destination,
int maxConnections,
Callback requester) |
LeakTrackingConnectionPool(Destination destination,
int maxConnections,
Callback requester) |
MultiplexConnectionPool(HttpDestination destination,
int maxConnections,
Callback requester,
int maxMultiplex) |
RoundRobinConnectionPool(Destination destination,
int maxConnections,
Callback requester) |
RoundRobinConnectionPool(Destination destination,
int maxConnections,
Callback requester,
int maxMultiplex) |
ValidatingConnectionPool(Destination destination,
int maxConnections,
Callback requester,
Scheduler scheduler,
long timeout) |
Modifier and Type | Method and Description |
---|---|
void |
Response.AsyncContentListener.onContent(Response response,
java.nio.ByteBuffer content,
Callback callback)
Callback method invoked asynchronously when the response content has been received.
|
void |
Response.Listener.Adapter.onContent(Response response,
java.nio.ByteBuffer content,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
class |
HttpDestinationOverHTTP |
private class |
HttpSenderOverHTTP.ByteBufferRecyclerCallback |
private class |
HttpSenderOverHTTP.HeadersCallback |
private class |
HttpSenderOverHTTP.TrailersCallback |
Modifier and Type | Field and Description |
---|---|
private Callback |
HttpSenderOverHTTP.HeadersCallback.callback |
private Callback |
HttpSenderOverHTTP.TrailersCallback.callback |
Modifier and Type | Method and Description |
---|---|
protected void |
HttpSenderOverHTTP.sendContent(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverHTTP.sendHeaders(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverHTTP.sendTrailers(HttpExchange exchange,
Callback callback) |
Constructor and Description |
---|
ByteBufferRecyclerCallback(Callback callback,
ByteBufferPool pool,
java.nio.ByteBuffer... buffers) |
HeadersCallback(HttpExchange exchange,
HttpContent content,
Callback callback,
HttpConnectionOverHTTP httpConnectionOverHTTP) |
TrailersCallback(Callback callback) |
Modifier and Type | Class and Description |
---|---|
class |
DeferredContentProvider
A
ContentProvider that allows to add content after Request.send(Response.CompleteListener)
has been called, therefore providing the request content at a later time. |
private class |
DeferredContentProvider.DeferredContentProviderIterator |
class |
InputStreamContentProvider
A
ContentProvider for an InputStream . |
private class |
MultiPartContentProvider.MultiPartIterator |
class |
OutputStreamContentProvider
A
ContentProvider that provides content asynchronously through an OutputStream
similar to DeferredContentProvider . |
Modifier and Type | Field and Description |
---|---|
Callback |
DeferredContentProvider.Chunk.callback |
Modifier and Type | Method and Description |
---|---|
private java.util.List<Callback> |
InputStreamResponseListener.drain() |
Modifier and Type | Method and Description |
---|---|
boolean |
DeferredContentProvider.offer(java.nio.ByteBuffer buffer,
Callback callback) |
void |
InputStreamResponseListener.onContent(Response response,
java.nio.ByteBuffer content,
Callback callback) |
Constructor and Description |
---|
Chunk(java.nio.ByteBuffer buffer,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
class |
HttpDestinationOverFCGI |
class |
MultiplexHttpDestinationOverFCGI |
Modifier and Type | Method and Description |
---|---|
protected boolean |
HttpChannelOverFCGI.content(java.nio.ByteBuffer buffer,
Callback callback) |
protected boolean |
HttpReceiverOverFCGI.responseContent(HttpExchange exchange,
java.nio.ByteBuffer buffer,
Callback callback) |
protected void |
HttpSenderOverFCGI.sendContent(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverFCGI.sendHeaders(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverFCGI.sendTrailers(HttpExchange exchange,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
private class |
Flusher.FlushCallback |
private class |
Flusher.ShutdownResult |
static class |
Generator.Result |
Modifier and Type | Field and Description |
---|---|
private java.util.List<Callback> |
Generator.Result.callbacks |
Modifier and Type | Method and Description |
---|---|
protected Generator.Result |
Generator.generateContent(int id,
java.nio.ByteBuffer content,
boolean recycle,
boolean lastContent,
Callback callback,
FCGI.FrameType frameType) |
Generator.Result |
ClientGenerator.generateRequestContent(int request,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback) |
Generator.Result |
ClientGenerator.generateRequestHeaders(int request,
HttpFields fields,
Callback callback) |
Generator.Result |
ServerGenerator.generateResponseContent(int request,
java.nio.ByteBuffer content,
boolean lastContent,
boolean aborted,
Callback callback) |
Generator.Result |
ServerGenerator.generateResponseHeaders(int request,
int code,
java.lang.String reason,
HttpFields fields,
Callback callback) |
Constructor and Description |
---|
Result(ByteBufferPool byteBufferPool,
Callback callback) |
Modifier and Type | Method and Description |
---|---|
private void |
HttpTransportOverFCGI.commit(MetaData.Response info,
boolean head,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback) |
protected Generator.Result |
HttpTransportOverFCGI.generateResponseContent(java.nio.ByteBuffer buffer,
boolean lastContent,
Callback callback) |
protected Generator.Result |
HttpTransportOverFCGI.generateResponseHeaders(MetaData.Response info,
Callback callback) |
void |
HttpTransportOverFCGI.send(MetaData.Response info,
boolean head,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
private class |
HTTP2Connection.FillableCallback |
private class |
HTTP2Connection.NetworkBuffer |
class |
HTTP2Flusher |
static class |
HTTP2Flusher.Entry |
private class |
HTTP2Session.CloseCallback |
private class |
HTTP2Session.ControlEntry |
private class |
HTTP2Session.DataCallback |
private class |
HTTP2Session.DataEntry |
private class |
HTTP2Session.DisconnectCallback |
private class |
HTTP2Session.OnResetCallback |
private class |
HTTP2Session.ResetCallback |
private static class |
HTTP2Session.StreamPromiseCallback |
private class |
HTTP2Session.TerminateCallback |
class |
HTTP2Stream |
Modifier and Type | Field and Description |
---|---|
private Callback |
HTTP2Connection.HTTP2Producer.fillableCallback |
Modifier and Type | Field and Description |
---|---|
private java.util.concurrent.atomic.AtomicReference<Callback> |
HTTP2Stream.writing |
Modifier and Type | Method and Description |
---|---|
private Callback |
HTTP2Stream.endWrite() |
Modifier and Type | Method and Description |
---|---|
boolean |
HTTP2Session.close(int error,
java.lang.String reason,
Callback callback)
Invoked internally and by applications to send a GO_AWAY frame to the
other peer.
|
private void |
HTTP2Session.control(IStream stream,
Callback callback,
Frame frame) |
void |
HTTP2Stream.data(DataFrame frame,
Callback callback) |
void |
ISession.data(IStream stream,
Callback callback,
DataFrame frame)
Enqueues the given DATA frame to be written to the connection.
|
void |
HTTP2Session.data(IStream stream,
Callback callback,
DataFrame frame) |
void |
ISession.frames(IStream stream,
Callback callback,
Frame frame,
Frame... frames)
Enqueues the given frames to be written to the connection.
|
void |
HTTP2Session.frames(IStream stream,
Callback callback,
Frame frame,
Frame... frames) |
void |
HTTP2Stream.headers(HeadersFrame frame,
Callback callback) |
protected void |
HTTP2Session.notifyClose(Session session,
GoAwayFrame frame,
Callback callback) |
private void |
HTTP2Stream.notifyData(Stream stream,
DataFrame frame,
Callback callback) |
protected void |
HTTP2Session.notifyFailure(Session session,
java.lang.Throwable failure,
Callback callback) |
private void |
HTTP2Stream.notifyFailure(Stream stream,
FailureFrame frame,
Callback callback) |
private void |
HTTP2Stream.notifyReset(Stream stream,
ResetFrame frame,
Callback callback) |
protected void |
HTTP2Session.onConnectionFailure(int error,
java.lang.String reason,
Callback callback) |
void |
ISession.onData(DataFrame frame,
Callback callback)
Callback method invoked when a DATA frame is received.
|
private void |
HTTP2Stream.onData(DataFrame frame,
Callback callback) |
void |
HTTP2Session.onData(DataFrame frame,
Callback callback) |
private void |
HTTP2Stream.onFailure(FailureFrame frame,
Callback callback) |
private void |
HTTP2Stream.onHeaders(HeadersFrame frame,
Callback callback) |
private void |
HTTP2Stream.onPush(PushPromiseFrame frame,
Callback callback) |
private void |
HTTP2Stream.onReset(ResetFrame frame,
Callback callback) |
private void |
HTTP2Stream.onWindowUpdate(WindowUpdateFrame frame,
Callback callback) |
void |
HTTP2Session.ping(PingFrame frame,
Callback callback) |
int |
HTTP2Session.priority(PriorityFrame frame,
Callback callback) |
void |
IStream.process(Frame frame,
Callback callback)
Processes the given
frame , belonging to this stream. |
void |
HTTP2Stream.process(Frame frame,
Callback callback) |
void |
HTTP2Stream.reset(ResetFrame frame,
Callback callback) |
protected void |
HTTP2Session.reset(ResetFrame frame,
Callback callback) |
void |
HTTP2Session.settings(SettingsFrame frame,
Callback callback) |
private boolean |
HTTP2Stream.startWrite(Callback callback) |
Constructor and Description |
---|
CloseCallback(int error,
java.lang.String reason,
Callback callback) |
ControlEntry(Frame frame,
IStream stream,
Callback callback) |
DataCallback(Callback callback,
IStream stream,
int flowControlLength) |
DataEntry(DataFrame frame,
IStream stream,
Callback callback) |
Entry(Frame frame,
IStream stream,
Callback callback) |
ResetCallback(int streamId,
int error,
Callback callback) |
Modifier and Type | Method and Description |
---|---|
boolean |
Session.close(int error,
java.lang.String payload,
Callback callback)
Closes the session by sending a GOAWAY frame with the given error code
and payload.
|
void |
Stream.data(DataFrame frame,
Callback callback)
Sends the given DATA
frame . |
void |
Stream.headers(HeadersFrame frame,
Callback callback)
Sends the given HEADERS
frame representing a HTTP response. |
default void |
Session.Listener.onClose(Session session,
GoAwayFrame frame,
Callback callback)
Callback method invoked when a GOAWAY frame has been received.
|
void |
Stream.Listener.onData(Stream stream,
DataFrame frame,
Callback callback)
Callback method invoked when a DATA frame has been received.
|
void |
Stream.Listener.Adapter.onData(Stream stream,
DataFrame frame,
Callback callback) |
default void |
Session.Listener.onFailure(Session session,
java.lang.Throwable failure,
Callback callback)
Callback method invoked when a failure has been detected for this session.
|
default void |
Stream.Listener.onFailure(Stream stream,
int error,
java.lang.String reason,
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 |
Session.ping(PingFrame frame,
Callback callback)
Sends the given PING
frame . |
int |
Session.priority(PriorityFrame frame,
Callback callback)
Sends the given PRIORITY
frame . |
void |
Stream.reset(ResetFrame frame,
Callback callback)
Sends the given RST_STREAM
frame . |
void |
Session.settings(SettingsFrame frame,
Callback callback)
Sends the given SETTINGS
frame to configure the session. |
Modifier and Type | Class and Description |
---|---|
private class |
HTTP2ClientConnectionFactory.HTTP2ClientConnection |
Modifier and Type | Class and Description |
---|---|
private class |
HttpChannelOverHTTP2.ReleaseCallback |
class |
HttpDestinationOverHTTP2 |
private class |
HttpReceiverOverHTTP2.ContentNotifier |
Modifier and Type | Field and Description |
---|---|
private Callback |
HttpReceiverOverHTTP2.DataInfo.callback |
Modifier and Type | Method and Description |
---|---|
private void |
HttpReceiverOverHTTP2.notifyContent(HttpExchange exchange,
DataFrame frame,
Callback callback) |
void |
HttpReceiverOverHTTP2.onData(Stream stream,
DataFrame frame,
Callback callback) |
void |
HttpReceiverOverHTTP2.onFailure(Stream stream,
int error,
java.lang.String reason,
Callback callback) |
protected void |
HttpSenderOverHTTP2.sendContent(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverHTTP2.sendHeaders(HttpExchange exchange,
HttpContent content,
Callback callback) |
protected void |
HttpSenderOverHTTP2.sendTrailers(HttpExchange exchange,
Callback callback) |
Constructor and Description |
---|
DataInfo(HttpExchange exchange,
DataFrame frame,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
private class |
HttpTransportOverHTTP2.SendTrailers |
private class |
HttpTransportOverHTTP2.TransportCallback |
Modifier and Type | Field and Description |
---|---|
private Callback |
HttpTransportOverHTTP2.TransportCallback.callback |
private Callback |
HttpChannelOverHTTP2.FailureTask.callback |
Modifier and Type | Method and Description |
---|---|
void |
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onClose(Session session,
GoAwayFrame frame,
Callback callback) |
void |
HTTP2ServerConnection.onData(IStream stream,
DataFrame frame,
Callback callback) |
void |
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onData(Stream stream,
DataFrame frame,
Callback callback) |
void |
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onFailure(Session session,
java.lang.Throwable failure,
Callback callback) |
void |
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onFailure(Stream stream,
int error,
java.lang.String reason,
Callback callback) |
java.lang.Runnable |
HttpChannelOverHTTP2.onFailure(java.lang.Throwable failure,
Callback callback) |
java.lang.Runnable |
HttpChannelOverHTTP2.onRequestContent(DataFrame frame,
Callback callback) |
void |
HTTP2ServerConnectionFactory.HTTPServerSessionListener.onReset(Stream stream,
ResetFrame frame,
Callback callback) |
void |
HTTP2ServerConnection.onSessionFailure(java.lang.Throwable failure,
Callback callback) |
void |
HTTP2ServerConnection.onStreamFailure(IStream stream,
java.lang.Throwable failure,
Callback callback) |
void |
HttpTransportOverHTTP2.send(MetaData.Response info,
boolean isHeadRequest,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback) |
private void |
HttpTransportOverHTTP2.sendDataFrame(java.nio.ByteBuffer content,
boolean lastContent,
boolean endStream,
Callback callback) |
private void |
HttpTransportOverHTTP2.sendHeadersFrame(MetaData.Response info,
boolean endStream,
Callback callback) |
private void |
HttpTransportOverHTTP2.sendTrailersFrame(MetaData metaData,
Callback callback) |
boolean |
HttpTransportOverHTTP2.TransportCallback.start(Callback callback,
boolean commit) |
Constructor and Description |
---|
FailureTask(java.lang.Throwable failure,
Callback callback,
boolean handle) |
SendTrailers(Callback callback,
java.util.function.Supplier<HttpFields> trailers) |
Modifier and Type | Class and Description |
---|---|
private class |
AbstractConnection.ReadCallback |
Modifier and Type | Field and Description |
---|---|
private Callback |
WriteFlusher.PendingState._callback |
private Callback |
AbstractConnection._readCallback |
Modifier and Type | Field and Description |
---|---|
private java.util.concurrent.atomic.AtomicReference<Callback> |
FillInterest._interested |
Modifier and Type | Method and Description |
---|---|
private void |
WriteFlusher.fail(Callback callback,
java.lang.Throwable... suppressed) |
protected void |
AbstractConnection.failedCallback(Callback callback,
java.lang.Throwable x) |
void |
EndPoint.fillInterested(Callback callback)
Requests callback methods to be invoked when a call to
EndPoint.fill(ByteBuffer) would return data or EOF. |
void |
AbstractEndPoint.fillInterested(Callback callback) |
void |
FillInterest.register(Callback callback)
Call to register interest in a callback when a read is possible.
|
boolean |
EndPoint.tryFillInterested(Callback callback)
Requests callback methods to be invoked when a call to
EndPoint.fill(ByteBuffer) would return data or EOF. |
boolean |
AbstractEndPoint.tryFillInterested(Callback callback) |
void |
AbstractConnection.tryFillInterested(Callback callback) |
boolean |
FillInterest.tryRegister(Callback callback)
Call to register interest in a callback when a read is possible.
|
void |
WriteFlusher.write(Callback callback,
java.nio.ByteBuffer... buffers)
Tries to switch state to WRITING.
|
void |
EndPoint.write(Callback callback,
java.nio.ByteBuffer... buffers)
Writes the given buffers via
EndPoint.flush(ByteBuffer...) and invokes callback methods when either
all the data has been flushed or an error occurs. |
void |
AbstractEndPoint.write(Callback callback,
java.nio.ByteBuffer... buffers) |
Constructor and Description |
---|
PendingState(java.nio.ByteBuffer[] buffers,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
private class |
SslConnection.DecryptedEndPoint.IncompleteWriteCallback |
Modifier and Type | Field and Description |
---|---|
private Callback |
SslConnection.DecryptedEndPoint._incompleteWriteCallback |
private Callback |
SslConnection._sslReadCallback |
Modifier and Type | Class and Description |
---|---|
private class |
AsyncMiddleManServlet.ProxyDeferredContentProvider |
protected class |
AsyncMiddleManServlet.ProxyReader |
protected class |
AsyncMiddleManServlet.ProxyResponseListener |
protected class |
AsyncProxyServlet.StreamReader |
private class |
ProxyConnection.ProxyIteratingCallback |
private class |
ProxyServlet.DelegatingContentProvider |
protected class |
ProxyServlet.ProxyInputStreamContentProvider |
Modifier and Type | Field and Description |
---|---|
private Callback |
AsyncProxyServlet.StreamWriter.callback |
private Callback |
AsyncMiddleManServlet.ProxyResponseListener.complete |
Modifier and Type | Method and Description |
---|---|
protected void |
AsyncProxyServlet.StreamWriter.data(byte[] bytes,
int offset,
int length,
Callback callback) |
boolean |
AsyncMiddleManServlet.ProxyWriter.offer(java.nio.ByteBuffer content,
Callback callback) |
boolean |
AsyncMiddleManServlet.ProxyDeferredContentProvider.offer(java.nio.ByteBuffer buffer,
Callback callback) |
void |
ProxyServlet.ProxyResponseListener.onContent(Response proxyResponse,
java.nio.ByteBuffer content,
Callback callback) |
void |
AsyncMiddleManServlet.ProxyResponseListener.onContent(Response serverResponse,
java.nio.ByteBuffer content,
Callback callback) |
protected void |
AsyncProxyServlet.StreamReader.onRequestContent(javax.servlet.http.HttpServletRequest request,
Request proxyRequest,
DeferredContentProvider provider,
byte[] buffer,
int offset,
int length,
Callback callback) |
protected void |
ProxyServlet.onResponseContent(javax.servlet.http.HttpServletRequest request,
javax.servlet.http.HttpServletResponse response,
Response proxyResponse,
byte[] buffer,
int offset,
int length,
Callback callback) |
protected void |
AsyncProxyServlet.onResponseContent(javax.servlet.http.HttpServletRequest request,
javax.servlet.http.HttpServletResponse response,
Response proxyResponse,
byte[] buffer,
int offset,
int length,
Callback callback) |
private void |
AsyncMiddleManServlet.ProxyReader.process(java.nio.ByteBuffer content,
Callback callback,
boolean finished) |
private boolean |
AsyncMiddleManServlet.ProxyWriter.succeed(Callback callback) |
protected abstract void |
ProxyConnection.write(EndPoint endPoint,
java.nio.ByteBuffer buffer,
Callback callback) |
protected void |
ConnectHandler.UpstreamConnection.write(EndPoint endPoint,
java.nio.ByteBuffer buffer,
Callback callback) |
protected void |
ConnectHandler.DownstreamConnection.write(EndPoint endPoint,
java.nio.ByteBuffer buffer,
Callback callback) |
protected void |
ConnectHandler.write(EndPoint endPoint,
java.nio.ByteBuffer buffer,
Callback callback,
java.util.concurrent.ConcurrentMap<java.lang.String,java.lang.Object> context)
Writes (with non-blocking semantic) the given buffer of data onto the given endPoint.
|
Modifier and Type | Class and Description |
---|---|
private class |
HttpChannel.Send100Callback |
private class |
HttpChannel.SendCallback |
private class |
HttpConnection.AsyncReadCallback |
private class |
HttpConnection.BlockingReadCallback |
private class |
HttpConnection.Content |
private class |
HttpConnection.SendCallback |
static class |
HttpInput.Content |
static class |
HttpInput.EofContent |
static class |
HttpInput.SentinelContent
A Sentinel Content, which has zero length content but
indicates some other event in the input stream (eg EOF)
|
private class |
HttpOutput.AsyncFlush |
private class |
HttpOutput.AsyncICB |
private class |
HttpOutput.AsyncWrite |
private class |
HttpOutput.InputStreamWritingCB
An iterating callback that will take content from an
InputStream and write it to the associated
HttpChannel . |
private class |
HttpOutput.ReadableByteChannelWritingCB
An iterating callback that will take content from a
ReadableByteChannel and write it to the
HttpChannel . |
Modifier and Type | Field and Description |
---|---|
private Callback |
HttpConnection.SendCallback._callback |
Modifier and Type | Method and Description |
---|---|
void |
ProxyConnectionFactory.ProxyEndPoint.fillInterested(Callback callback) |
private boolean |
HttpConnection.SendCallback.reset(MetaData.Response info,
boolean head,
java.nio.ByteBuffer content,
boolean last,
Callback callback) |
void |
HttpTransport.send(MetaData.Response info,
boolean head,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback)
Asynchronous call to send a response (or part) over the transport
|
void |
HttpConnection.send(MetaData.Response info,
boolean head,
java.nio.ByteBuffer content,
boolean lastContent,
Callback callback) |
void |
HttpOutput.sendContent(java.nio.ByteBuffer content,
Callback callback)
Asynchronous send of whole content.
|
void |
HttpOutput.sendContent(HttpContent httpContent,
Callback callback)
Asynchronous send of HTTP content.
|
void |
HttpOutput.sendContent(java.io.InputStream in,
Callback callback)
Asynchronous send of stream content.
|
void |
HttpOutput.sendContent(java.nio.channels.ReadableByteChannel in,
Callback callback)
Asynchronous send of channel content.
|
protected boolean |
HttpChannel.sendResponse(MetaData.Response info,
java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
boolean |
ProxyConnectionFactory.ProxyEndPoint.tryFillInterested(Callback callback) |
protected void |
HttpOutput.write(java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
void |
HttpOutput.Interceptor.write(java.nio.ByteBuffer content,
boolean last,
Callback callback)
Write content.
|
void |
HttpChannel.write(java.nio.ByteBuffer content,
boolean complete,
Callback callback)
Non-Blocking write, committing the response if needed.
|
void |
ProxyConnectionFactory.ProxyEndPoint.write(Callback callback,
java.nio.ByteBuffer... buffers) |
Constructor and Description |
---|
InputStreamWritingCB(java.io.InputStream in,
Callback callback) |
ReadableByteChannelWritingCB(java.nio.channels.ReadableByteChannel in,
Callback callback) |
Send100Callback(Callback callback) |
SendCallback(Callback callback,
java.nio.ByteBuffer content,
boolean commit,
boolean complete) |
Modifier and Type | Method and Description |
---|---|
protected void |
BufferedResponseHandler.BufferedInterceptor.commit(java.util.Queue<java.nio.ByteBuffer> buffers,
Callback callback) |
void |
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.
|
void |
BufferedResponseHandler.BufferedInterceptor.write(java.nio.ByteBuffer content,
boolean last,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
private class |
GzipHttpOutputInterceptor.GzipBufferCB |
Modifier and Type | Method and Description |
---|---|
protected void |
GzipHttpOutputInterceptor.commit(java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
private void |
GzipHttpOutputInterceptor.gzip(java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
void |
GzipHttpOutputInterceptor.write(java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
Constructor and Description |
---|
GzipBufferCB(java.nio.ByteBuffer content,
boolean complete,
Callback callback) |
Modifier and Type | Class and Description |
---|---|
static class |
Callback.Completable
A CompletableFuture that is also a Callback.
|
static class |
Callback.Completing |
static class |
Callback.Nested
Nested Completing Callback that completes after
completing the nested callback
|
class |
CompletableCallback
A callback to be used by driver code that needs to know whether the callback has been
succeeded or failed (that is, completed) just after the asynchronous operation or not,
typically because further processing depends on the callback being completed.
|
class |
CountingCallback
A callback wrapper that succeeds the wrapped callback when the count is
reached, or on first failure.
|
class |
FutureCallback |
class |
IteratingCallback
This specialized callback implements a pattern that allows
a large job to be broken into smaller tasks using iteration
rather than recursion.
|
class |
IteratingNestedCallback
Iterating Nested Callback.
|
class |
SharedBlockingCallback.Blocker
A Closeable Callback.
|
Modifier and Type | Field and Description |
---|---|
(package private) Callback |
IteratingNestedCallback._callback |
private Callback |
Callback.Nested.callback |
static 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 Type | Method and Description |
---|---|
static Callback |
Callback.from(Callback callback,
java.lang.Runnable completed)
Create a nested callback that runs completed after
completing the nested callback.
|
static Callback |
Callback.from(java.util.concurrent.CompletableFuture<?> completable)
Creates a non-blocking callback from the given incomplete CompletableFuture.
|
static Callback |
Callback.from(java.util.concurrent.CompletableFuture<?> completable,
Invocable.InvocationType invocation)
Creates a callback from the given incomplete CompletableFuture,
with the given
blocking characteristic. |
static Callback |
Callback.from(java.lang.Runnable completed)
Creaste a callback that runs completed when it succeeds or fails
|
static Callback |
Callback.from(java.lang.Runnable completed,
Callback callback)
Create a nested callback that runs completed before
completing the nested callback.
|
static Callback |
Callback.from(java.lang.Runnable success,
java.util.function.Consumer<java.lang.Throwable> failure)
Create a callback from the passed success and failure
|
Callback |
Callback.Nested.getCallback() |
Modifier and Type | Method and Description |
---|---|
static Callback |
Callback.from(Callback callback,
java.lang.Runnable completed)
Create a nested callback that runs completed after
completing the nested callback.
|
static Callback |
Callback.from(java.lang.Runnable completed,
Callback callback)
Create a nested callback that runs completed before
completing the nested callback.
|
Constructor and Description |
---|
CountingCallback(Callback callback,
int count) |
IteratingNestedCallback(Callback callback) |
Nested(Callback callback) |
Modifier and Type | Class and Description |
---|---|
static class |
BlockingWriteCallback.WriteBlocker |
Modifier and Type | Method and Description |
---|---|
private void |
WebSocketSession.close(CloseInfo closeInfo,
Callback callback)
Close Primary Entry Point.
|
void |
LogicalConnection.close(CloseInfo closeInfo,
Callback callback)
Request a local close.
|
Modifier and Type | Class and Description |
---|---|
private class |
ExtensionStack.Flusher |
Modifier and Type | Class and Description |
---|---|
private class |
CompressExtension.Flusher |
Modifier and Type | Class and Description |
---|---|
private class |
FragmentExtension.Flusher |
Modifier and Type | Class and Description |
---|---|
private class |
AbstractWebSocketConnection.Flusher |
class |
DisconnectCallback |
class |
FrameFlusher |
class |
FutureWriteCallback
Allows events to a
WriteCallback to drive a Future for the user. |
Modifier and Type | Field and Description |
---|---|
private Callback |
AbstractWebSocketConnection.CallbackBridge.callback |
Modifier and Type | Method and Description |
---|---|
void |
AbstractWebSocketConnection.close(CloseInfo close,
Callback callback) |
Constructor and Description |
---|
CallbackBridge(Callback callback) |