Index

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

A

Abstract() - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
Abstract(Retainable) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
AbstractConnection - Class in org.eclipse.jetty.io
A convenience base implementation of Connection.
AbstractConnection(EndPoint, Executor) - Constructor for class org.eclipse.jetty.io.AbstractConnection
 
AbstractConnection.NonBlocking - Class in org.eclipse.jetty.io
 
AbstractEndPoint - Class in org.eclipse.jetty.io
Partial implementation of EndPoint that uses FillInterest and WriteFlusher.
AbstractEndPoint(Scheduler) - Constructor for class org.eclipse.jetty.io.AbstractEndPoint
 
AbstractRetainableByteBuffer - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version. 
AbstractRetainableByteBuffer(ByteBuffer) - Constructor for class org.eclipse.jetty.io.AbstractRetainableByteBuffer
Deprecated.
 
accept(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
accept(SelectableChannel, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a channel to perform non-blocking read/write operations.
accept(SelectableChannel, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
accepted(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method when a channel is accepted from the ServerSocketChannel passed to SelectorManager.acceptor(SelectableChannel).
acceptEither(CompletionStage<? extends X>, Consumer<? super X>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
acceptFailed(Throwable, SelectableChannel, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
acceptor(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a server channel for accept operations.
Accumulator() - Constructor for class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
acquire() - Method in class org.eclipse.jetty.io.AbstractRetainableByteBuffer
Deprecated.
 
acquire() - Method in class org.eclipse.jetty.io.ByteBufferPool.Sized
 
acquire() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
Updates the reference count from 0 to 1.
acquire(boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.Sized
 
acquire(int) - Method in class org.eclipse.jetty.io.ByteBufferPool.Sized
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
acquire(int, boolean) - Method in interface org.eclipse.jetty.io.ByteBufferPool
Acquires a RetainableByteBuffer from this pool.
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.NonPooling
 
acquire(int, boolean) - Method in class org.eclipse.jetty.io.ByteBufferPool.Wrapper
 
add(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
add(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
add(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
add(ByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Add the passed ByteBuffer to this buffer, growing this buffer if necessary and possible.
add(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
add(Content.Chunk) - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
Add a Content.Chunk to the accumulator.
add(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
add(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
add(RetainableByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Add the passed RetainableByteBuffer to this buffer, growing this buffer if necessary and possible.
add(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
addEntry(ByteBuffer, Callback) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
 
addEventListener(EventListener) - Method in class org.eclipse.jetty.io.AbstractConnection
 
addEventListener(EventListener) - Method in class org.eclipse.jetty.io.ClientConnector
 
addEventListener(EventListener) - Method in interface org.eclipse.jetty.io.Connection
Adds a listener of connection events.
addEventListener(EventListener) - Method in class org.eclipse.jetty.io.SelectorManager
 
addExtraStringInfo(StringBuilder) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
addExtraStringInfo(StringBuilder) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
addExtraStringInfo(StringBuilder) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
addHandshakeListener(SslHandshakeListener) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
addInput(String) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInput(String, Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInput(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInputAndExecute(String) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInputAndExecute(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addInputEOF() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
addStringInfo(StringBuilder) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
addValueMarker(StringBuilder, boolean) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
addValueMarker(StringBuilder, boolean) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
addValueMarker(StringBuilder, boolean) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
addValueString(StringBuilder) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
addValueString(StringBuilder) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
aggregate(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferAggregator
Deprecated.
Aggregates the given ByteBuffer.
ALPNProcessor - Interface in org.eclipse.jetty.io.ssl
 
ALPNProcessor.Client - Interface in org.eclipse.jetty.io.ssl
Client-side interface used by ServiceLoader.
ALPNProcessor.Server - Interface in org.eclipse.jetty.io.ssl
Server-side interface used by ServiceLoader.
append(CharSequence) - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
append(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
append(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
append(ByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Copies the contents of the given byte buffer to the end of this buffer, growing this buffer if necessary and possible.
append(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
append(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
append(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
append(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
append(RetainableByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Retain or copy the contents of the given retainable byte buffer to the end of this buffer, growing this buffer if necessary and possible.
append(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
appendTo(ByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Appends and consumes the contents of this buffer to the passed buffer, limited by the capacity of the target buffer.
appendTo(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
appendTo(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
appendTo(RetainableByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Appends and consumes the contents of this buffer to the passed buffer, limited by the capacity of the target buffer.
appendTo(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
appendTo(RetainableByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
APPLICATION_PROTOCOL_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
APPLICATION_PROTOCOLS_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
appliesTo(SSLEngine) - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Tests if this processor can be applied to the given SSLEngine.
apply(ClientConnectionFactory) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory.Decorator
Wraps the given factory.
applyToEither(CompletionStage<? extends X>, Function<? super X, U>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
ArrayByteBufferPool - Class in org.eclipse.jetty.io
A RetainableByteBuffer pool where RetainableByteBuffers are held in Pools that are held in array elements.
ArrayByteBufferPool() - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with a default configuration.
ArrayByteBufferPool(int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool(int, int, int, int, long, long, IntUnaryOperator, IntUnaryOperator) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool
Creates a new ArrayByteBufferPool with the given configuration.
ArrayByteBufferPool.Quadratic - Class in org.eclipse.jetty.io
A variant of the ArrayByteBufferPool that uses buckets of buffers that increase in size by a power of 2 (e.g. 1k, 2k, 4k, 8k, etc.).
ArrayByteBufferPool.Tracking - Class in org.eclipse.jetty.io
A variant of ArrayByteBufferPool that tracks buffer acquires/releases, useful to identify buffer leaks.
ArrayByteBufferPool.Tracking.TrackedBuffer - Class in org.eclipse.jetty.io
 
ArrayByteBufferPool.WithBucketCapacities - Class in org.eclipse.jetty.io
A variant of the ArrayByteBufferPool that uses a predefined set of buckets of buffers.
asBuffered(Content.Sink, ByteBufferPool, boolean, int, int) - Static method in interface org.eclipse.jetty.io.Content.Sink
Wraps the given content sink with a buffering sink.
asByteArrayAsync(Content.Source, int) - Static method in interface org.eclipse.jetty.io.Content.Source
Deprecated, for removal: This API element is subject to removal in a future version.
no replacement
asByteBuffer(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, blocking if necessary, the whole content source into a ByteBuffer.
asByteBuffer(Content.Source, Promise<ByteBuffer>) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, non-blocking, the whole content source into a ByteBuffer.
asByteBufferAsync(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Deprecated, for removal: This API element is subject to removal in a future version.
asByteBufferAsync(Content.Source, int) - Static method in interface org.eclipse.jetty.io.Content.Source
Deprecated, for removal: This API element is subject to removal in a future version.
no replacement
asChunk(ByteBuffer, boolean, Retainable) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Returns the given ByteBuffer and last arguments as a Chunk, linked to the given Retainable.
asContentSource(Resource, ByteBufferPool.Sized, long, long) - Static method in class org.eclipse.jetty.io.IOResources
Gets a Content.Source with a range of the contents of a resource.
asInputStream(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Wraps the given content source with an InputStream.
asInputStream(Resource) - Static method in class org.eclipse.jetty.io.IOResources
Gets an InputStream with the contents of a resource.
asMutable() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Access this buffer via the RetainableByteBuffer.Mutable API.
asMutable() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
asMutable() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
asMutable() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
asOutputStream(Content.Sink) - Static method in interface org.eclipse.jetty.io.Content.Sink
Wraps the given content sink with an OutputStream.
asPublisher(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Wraps the given content source with a Flow.Publisher.
asReadOnly() - Method in interface org.eclipse.jetty.io.Content.Chunk
Deprecated, for removal: This API element is subject to removal in a future version.
asRetainableByteBuffer(Content.Source, ByteBufferPool, boolean, int) - Static method in interface org.eclipse.jetty.io.Content.Source
Deprecated, for removal: This API element is subject to removal in a future version.
no replacement
asRetainableByteBuffer(Content.Source, ByteBufferPool, boolean, int, Promise<RetainableByteBuffer>) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, non-blocking, the whole content source into a RetainableByteBuffer.
asString(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, blocking if necessary, the whole content source into a String, converting the bytes using UTF-8.
asString(Content.Source, Charset) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, blocking if necessary, the whole content source into a String, converting the bytes using the given Charset.
asString(Content.Source, Charset, Promise<String>) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, non-blocking, the whole content source into a String, converting the bytes using the given Charset.
asStringAsync(Content.Source, Charset) - Static method in interface org.eclipse.jetty.io.Content.Source
Deprecated, for removal: This API element is subject to removal in a future version.
asSubscriber(Content.Sink, Callback) - Static method in interface org.eclipse.jetty.io.Content.Sink
Wraps the given content sink with a Flow.Subscriber.
AsyncContent - Class in org.eclipse.jetty.io.content
A Content.Source that is also a Content.Sink.
AsyncContent() - Constructor for class org.eclipse.jetty.io.content.AsyncContent
 
ATTRIBUTE - Static variable in interface org.eclipse.jetty.io.EndPoint.SslSessionData
The name at which an SslSessionData instance may be found as a request attribute.
available() - Method in class org.eclipse.jetty.io.ByteBufferInputStream
 
available() - Method in class org.eclipse.jetty.io.content.ContentSourceInputStream
 

B

BufferedContentSink - Class in org.eclipse.jetty.io.content
A Content.Sink backed by another Content.Sink.
BufferedContentSink(Content.Sink, ByteBufferPool.Sized, int) - Constructor for class org.eclipse.jetty.io.content.BufferedContentSink
 
BufferedContentSink(Content.Sink, ByteBufferPool, boolean, int, int) - Constructor for class org.eclipse.jetty.io.content.BufferedContentSink
 
ByteArrayEndPoint - Class in org.eclipse.jetty.io
ByteArrayEndPoint.
ByteArrayEndPoint() - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(byte[], int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(byte[], int, boolean) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(String, int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(String, int, boolean) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, byte[], int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, String, int) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteArrayEndPoint(Scheduler, long, ByteBuffer, int, boolean) - Constructor for class org.eclipse.jetty.io.ByteArrayEndPoint
 
ByteBufferAccumulator - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
ByteBufferAccumulator() - Constructor for class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
ByteBufferAccumulator(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
ByteBufferAggregator - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
ByteBufferAggregator(ByteBufferPool, boolean, int, int) - Constructor for class org.eclipse.jetty.io.ByteBufferAggregator
Deprecated.
Creates a ByteBuffer aggregator.
ByteBufferCallbackAccumulator - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
ByteBufferCallbackAccumulator() - Constructor for class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
 
ByteBufferContentSource - Class in org.eclipse.jetty.io.content
A Content.Source backed by one or more ByteBuffers.
ByteBufferContentSource(ByteBuffer...) - Constructor for class org.eclipse.jetty.io.content.ByteBufferContentSource
 
ByteBufferContentSource(Collection<ByteBuffer>) - Constructor for class org.eclipse.jetty.io.content.ByteBufferContentSource
 
ByteBufferInputStream - Class in org.eclipse.jetty.io
Present a ByteBuffer as an InputStream.
ByteBufferInputStream(ByteBuffer) - Constructor for class org.eclipse.jetty.io.ByteBufferInputStream
 
ByteBufferOutputStream - Class in org.eclipse.jetty.io
Simple wrapper of a ByteBuffer as an OutputStream.
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream
 
ByteBufferOutputStream2 - Class in org.eclipse.jetty.io
ByteBufferOutputStream2() - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
ByteBufferOutputStream2(ByteBufferPool, boolean) - Constructor for class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
ByteBufferPool - Interface in org.eclipse.jetty.io
A pool for RetainableByteBuffer instances.
ByteBufferPool.Accumulator - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
ByteBufferPool.NonPooling - Class in org.eclipse.jetty.io
A ByteBufferPool that does not pool its RetainableByteBuffers.
ByteBufferPool.Sized - Class in org.eclipse.jetty.io
A ByteBufferPool with an additional no-args ByteBufferPool.Sized.acquire() method to obtain a buffer of a preconfigured specific size and type.
ByteBufferPool.Wrapper - Class in org.eclipse.jetty.io
A wrapper for ByteBufferPool instances.

C

calcExpireNanoTime(long) - Static method in interface org.eclipse.jetty.io.CyclicTimeouts.Expirable
Calculates the expiration time in nanoseconds.
cancel() - Method in class org.eclipse.jetty.io.CyclicTimeout
Cancels this CyclicTimeout so that it won't expire.
cancelWrite(Throwable) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
cancelWrite(Throwable) - Method in interface org.eclipse.jetty.io.EndPoint
Cancel any current EndPoint.write(Callback, ByteBuffer...) operation in progress.
cancelWrite(Throwable) - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
cancelWrite(Throwable) - Method in class org.eclipse.jetty.io.WriteFlusher
Abort any write the flusher may have in progress or pending, then prevent any further write.
canRetain() - Method in interface org.eclipse.jetty.io.Retainable
Returns whether this resource is referenced counted by calls to Retainable.retain() and Retainable.release().
canRetain() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
canRetain() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
capacity() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
capacity() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
capacity() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
capacity() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
checkIdleTimeout() - Method in class org.eclipse.jetty.io.IdleTimeout
 
chooseSelector() - Method in class org.eclipse.jetty.io.SelectorManager
 
ChunkAccumulator - Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
ChunkAccumulator() - Constructor for class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
 
ChunksContentSource - Class in org.eclipse.jetty.io.content
A Content.Source backed by one or more Content.Chunks.
ChunksContentSource(Collection<Content.Chunk>) - Constructor for class org.eclipse.jetty.io.content.ChunksContentSource
 
cipherSuite() - Method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
clear() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
clear() - Method in interface org.eclipse.jetty.io.ByteBufferPool
Removes all non-retained pooled instances from this pool.
clear() - Method in class org.eclipse.jetty.io.ByteBufferPool.NonPooling
 
clear() - Method in class org.eclipse.jetty.io.ByteBufferPool.Wrapper
 
clear() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
clear() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
ClientConnectionFactory - Interface in org.eclipse.jetty.io
Factory for client-side Connection instances.
ClientConnectionFactory.Decorator - Interface in org.eclipse.jetty.io
Wraps another ClientConnectionFactory.
ClientConnectionFactory.Info - Class in org.eclipse.jetty.io
A holder for a list of protocol strings identifiers (for example ["h2", "h2-17", "h2-16"]) and a ClientConnectionFactory that creates connections that speak an application protocol such as HTTP.
ClientConnectionFactory.Wrapper - Class in org.eclipse.jetty.io
 
ClientConnector - Class in org.eclipse.jetty.io
The client-side component that connects to server sockets.
ClientConnector() - Constructor for class org.eclipse.jetty.io.ClientConnector
 
ClientConnector.ClientSelectorManager - Class in org.eclipse.jetty.io
 
ClientConnector.ConnectListener - Interface in org.eclipse.jetty.io
A listener for events about SocketChannel.connect(SocketAddress).
ClientSelectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
close() - Method in class org.eclipse.jetty.io.AbstractConnection
 
close() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
close() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
close() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
close() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
close() - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
 
close() - Method in interface org.eclipse.jetty.io.Connection
Performs a logical close of this connection.
close() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
close() - Method in class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
close() - Method in class org.eclipse.jetty.io.content.ContentSourceInputStream
 
close() - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
close() - Method in interface org.eclipse.jetty.io.EndPoint
Closes any backing stream associated with the endpoint.
close() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
close() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
close() - Method in class org.eclipse.jetty.io.WriterOutputStream
 
close() - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
close(Throwable) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
close(Throwable) - Method in interface org.eclipse.jetty.io.EndPoint
Closes any backing stream associated with the endpoint, passing a possibly null failure cause.
close(Callback) - Method in class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
closed(Socket) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when a connection to a remote client has been closed.
completed(String) - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
completeWrite() - Method in class org.eclipse.jetty.io.WriteFlusher
Complete a write that has not completed and that called WriteFlusher.onIncompleteFlush() to request a call to this method when a call to EndPoint.flush(ByteBuffer...) is likely to be able to progress.
configure(SelectableChannel) - Method in class org.eclipse.jetty.io.ClientConnector
 
configure(SSLEngine, Connection) - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Configures the given SSLEngine and the given Connection for ALPN.
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
connect(SocketAddress, Map<String, Object>) - Method in interface org.eclipse.jetty.io.Transport
Establishes a connection to the given socket address.
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.io.Transport.Socket
 
connect(SocketAddress, Map<String, Object>) - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
connect(SelectableChannel, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Registers a channel to perform a non-blocking connect.
connectFailed(SelectableChannel, SocketAddress, Throwable, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
Connection - Interface in org.eclipse.jetty.io
A Connection is associated to an EndPoint so that I/O events happening on the EndPoint can be processed by the Connection.
CONNECTION_PROMISE_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
Connection.Listener - Interface in org.eclipse.jetty.io
A Listener for connection events.
Connection.Tunnel - Interface in org.eclipse.jetty.io
Start a tunnel over the current connection without replacing the connection.
Connection.UpgradeFrom - Interface in org.eclipse.jetty.io
Connection implementations implement this interface when they can upgrade from the protocol they speak (for example HTTP/1.1) to a different protocol (e.g.
Connection.UpgradeTo - Interface in org.eclipse.jetty.io
Connection implementations implement this interface when they can be upgraded to the protocol they speak (e.g.
connectionClosed(Connection, Throwable) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a connection is closed.
connectionFailed(SelectableChannel, Throwable, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
connectionFailed(SelectableChannel, Throwable, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a non-blocking connect failed.
connectionOpened(Connection, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
connectionOpened(Connection, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a connection is opened.
ConnectionSet() - Constructor for class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
ConnectionStatistics - Class in org.eclipse.jetty.io
A Connection.Listener that tracks connection statistics.
ConnectionStatistics() - Constructor for class org.eclipse.jetty.io.ConnectionStatistics
 
ConnectionStatistics.Stats - Class in org.eclipse.jetty.io
 
connectionSucceeded(SelectableChannel) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
connectionSucceeded(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when a non-blocking connect was succeeded.
consumeAll(Content.Source) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, blocking if necessary, the given content source, until a failure or EOF, and discards the content.
consumeAll(Content.Source, Callback) - Static method in interface org.eclipse.jetty.io.Content.Source
Reads, non-blocking, the given content source, until a failure or EOF and discards the content.
Content - Class in org.eclipse.jetty.io
Namespace class that contains the definitions of a content source, a content sink and a content chunk.
Content.Chunk - Interface in org.eclipse.jetty.io
A chunk of content indicating whether it is the last chunk.
Content.Chunk.Empty - Class in org.eclipse.jetty.io
An empty chunk implementation.
Content.Chunk.Processor - Interface in org.eclipse.jetty.io
Implementations of this interface may process Content.Chunks being copied by the Content.copy(Source, Sink, Processor, Callback) method, so that Content.Chunks of unknown types can be copied.
Content.Sink - Interface in org.eclipse.jetty.io
A content sink that writes the content to its implementation (a socket, a file, etc.).
Content.Source - Interface in org.eclipse.jetty.io
A source of content that can be read with a read/demand model.
Content.Source.Factory - Interface in org.eclipse.jetty.io
Factory of Content.Source.
ContentSinkOutputStream - Class in org.eclipse.jetty.io.content
An OutputStream backed by a Content.Sink.
ContentSinkOutputStream(Content.Sink) - Constructor for class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
ContentSinkSubscriber - Class in org.eclipse.jetty.io.content
ContentSinkSubscriber(Content.Sink, Callback) - Constructor for class org.eclipse.jetty.io.content.ContentSinkSubscriber
 
ContentSourceCompletableFuture<X> - Class in org.eclipse.jetty.io.content
A utility class to convert content from a Content.Source to an instance available via a CompletableFuture.
ContentSourceCompletableFuture(Content.Source) - Constructor for class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
ContentSourceCompletableFuture(Content.Source, Invocable.InvocationType) - Constructor for class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
ContentSourceInputStream - Class in org.eclipse.jetty.io.content
An InputStream that is backed by a Content.Source.
ContentSourceInputStream(Content.Source) - Constructor for class org.eclipse.jetty.io.content.ContentSourceInputStream
 
ContentSourcePublisher - Class in org.eclipse.jetty.io.content
ContentSourcePublisher(Content.Source) - Constructor for class org.eclipse.jetty.io.content.ContentSourcePublisher
 
ContentSourceTransformer - Class in org.eclipse.jetty.io.content
This abstract Content.Source wraps another Content.Source and implementers need only to implement the ContentSourceTransformer.transform(Content.Chunk) method, which is used to transform Content.Chunk read from the wrapped source.
ContentSourceTransformer(Content.Source) - Constructor for class org.eclipse.jetty.io.content.ContentSourceTransformer
 
CONTEXT_KEY - Static variable in interface org.eclipse.jetty.io.ClientConnectionFactory
 
CONTEXT_KEY - Static variable in interface org.eclipse.jetty.io.ClientConnectionFactory.Decorator
 
CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
CONTEXT_KEY - Static variable in interface org.eclipse.jetty.io.Transport
 
copy() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Creates a deep copy of this RetainableByteBuffer that is entirely independent
copy() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
copy() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
copy() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Pooled
 
copy() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
copy(Content.Source, Content.Sink, Content.Chunk.Processor, Callback) - Static method in class org.eclipse.jetty.io.Content
Copies the given content source to the given content sink, notifying the given callback when the copy is complete.
copy(Content.Source, Content.Sink, Callback) - Static method in class org.eclipse.jetty.io.Content
Copies the given content source to the given content sink, notifying the given callback when the copy is complete (either succeeded or failed).
copy(Resource, Content.Sink, ByteBufferPool.Sized, long, long, Callback) - Static method in class org.eclipse.jetty.io.IOResources
Performs an asynchronous copy of a subset of the contents of a resource to a sink, using the given buffer pool and buffer characteristics.
copyBuffer(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
copyBytes(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
count() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
customize(Connection, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory
 
customize(Connection, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Wrapper
 
customize(Connection, Map<String, Object>) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
CyclicTimeout - Class in org.eclipse.jetty.io
An abstract implementation of a timeout.
CyclicTimeout(Scheduler) - Constructor for class org.eclipse.jetty.io.CyclicTimeout
 
CyclicTimeouts<T> - Class in org.eclipse.jetty.io
An implementation of a timeout that manages many expirable entities whose timeouts are mostly cancelled or re-scheduled.
CyclicTimeouts(Scheduler) - Constructor for class org.eclipse.jetty.io.CyclicTimeouts
 
CyclicTimeouts.Expirable - Interface in org.eclipse.jetty.io
An entity that may expire.

D

DatagramChannelEndPoint - Class in org.eclipse.jetty.io
An EndPoint implementation based on DatagramChannel.
DatagramChannelEndPoint(DatagramChannel, ManagedSelector, SelectionKey, Scheduler) - Constructor for class org.eclipse.jetty.io.DatagramChannelEndPoint
 
decrementCount() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
DEFAULT_CONNECT_TIMEOUT - Static variable in class org.eclipse.jetty.io.SelectorManager
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.AsyncContent
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.ChunksContentSource
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.InputStreamContentSource
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
demand(Runnable) - Method in class org.eclipse.jetty.io.content.PathContentSource
 
demand(Runnable) - Method in interface org.eclipse.jetty.io.Content.Source
Demands to invoke the given demand callback parameter when a chunk of content is available.
destroy() - Method in class org.eclipse.jetty.io.CyclicTimeout
Destroys this CyclicTimeout.
destroy() - Method in class org.eclipse.jetty.io.CyclicTimeouts
 
doAccept(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
doClose() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
doClose() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
doFinishConnect(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
doShutdownInput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
doShutdownOutput() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
doStart() - Method in class org.eclipse.jetty.io.ClientConnector
 
doStart() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
doStart() - Method in class org.eclipse.jetty.io.ManagedSelector
 
doStart() - Method in class org.eclipse.jetty.io.SelectorManager
 
doStop() - Method in class org.eclipse.jetty.io.ClientConnector
 
doStop() - Method in class org.eclipse.jetty.io.ManagedSelector
 
doStop() - Method in class org.eclipse.jetty.io.SelectorManager
 
dump() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
dump(Appendable, String) - Method in class org.eclipse.jetty.io.ManagedSelector
 
dumpLeaks() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
DynamicCapacity() - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
A buffer with no size limit and default aggregation and retention settings.
DynamicCapacity(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool.Sized) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool.Sized, long) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool.Sized, long, int) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool, boolean, long) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool, boolean, long, int) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
DynamicCapacity(ByteBufferPool, boolean, long, int, int) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 

E

Empty() - Constructor for class org.eclipse.jetty.io.Content.Chunk.Empty
 
EMPTY - Static variable in interface org.eclipse.jetty.io.Content.Chunk
An empty, non-last, chunk instance.
EMPTY - Static variable in interface org.eclipse.jetty.io.RetainableByteBuffer
A Zero-capacity, non-retainable RetainableByteBuffer.
EmptyRetainableByteBuffer() - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
EndPoint - Interface in org.eclipse.jetty.io
EndPoint is the abstraction for I/O communication using bytes.
EndPoint.Pipe - Interface in org.eclipse.jetty.io
A communication conduit between two peers.
EndPoint.SslSessionData - Interface in org.eclipse.jetty.io
Interface representing bundle of SSLSession associated data.
EndPoint.Wrapper - Interface in org.eclipse.jetty.io
Marks an EndPoint that wraps another EndPoint.
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.io.ManagedSelector
 
endPointClosed(EndPoint) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when an endpoint is closed.
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.io.ManagedSelector
 
endPointOpened(EndPoint) - Method in class org.eclipse.jetty.io.SelectorManager
Callback method invoked when an endpoint is opened.
ensureBuffer(int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
Get the last buffer of the accumulator, this can be written to directly to avoid copying into the accumulator.
ensureBuffer(int, int) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
Get the last buffer of the accumulator, this can be written to directly to avoid copying into the accumulator.
EOF - Static variable in interface org.eclipse.jetty.io.Content.Chunk
An empty, last, chunk.
EOF - Static variable in interface org.eclipse.jetty.io.EndPoint
Constant returned by EndPoint.receive(ByteBuffer) to indicate the end-of-file.
EofException - Exception Class in org.eclipse.jetty.io
A Jetty specialization of EOFException.
EofException() - Constructor for exception class org.eclipse.jetty.io.EofException
 
EofException(String) - Constructor for exception class org.eclipse.jetty.io.EofException
 
EofException(String, Throwable) - Constructor for exception class org.eclipse.jetty.io.EofException
 
EofException(Throwable) - Constructor for exception class org.eclipse.jetty.io.EofException
 
equals(Object) - Method in interface org.eclipse.jetty.io.Transport
 
equals(Object) - Method in class org.eclipse.jetty.io.Transport.Unix
 
Event(Object) - Constructor for class org.eclipse.jetty.io.ssl.SslHandshakeListener.Event
Deprecated, for removal: This API element is subject to removal in a future version.
instances of this class can only be created by the implementation
Exception() - Constructor for exception class org.eclipse.jetty.io.QuietException.Exception
 
Exception(String) - Constructor for exception class org.eclipse.jetty.io.QuietException.Exception
 
Exception(String, Throwable) - Constructor for exception class org.eclipse.jetty.io.QuietException.Exception
 
Exception(Throwable) - Constructor for exception class org.eclipse.jetty.io.QuietException.Exception
 
exclude(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
exclude(String) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
execute(Runnable) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
execute(Runnable) - Method in class org.eclipse.jetty.io.SelectorManager
Executes the given task in a different thread.

F

fail(Throwable) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.AsyncContent
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.ChunksContentSource
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.InputStreamContentSource
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
fail(Throwable) - Method in class org.eclipse.jetty.io.content.PathContentSource
 
fail(Throwable) - Method in interface org.eclipse.jetty.io.Content.Source
Fails this content source with a last failure chunk, failing and discarding accumulated content chunks that were not yet read.
fail(Throwable, boolean) - Method in class org.eclipse.jetty.io.content.AsyncContent
 
fail(Throwable, boolean) - Method in class org.eclipse.jetty.io.content.PathContentSource
 
fail(Throwable, boolean) - Method in interface org.eclipse.jetty.io.Content.Source
Fails this content source with a failure chunk that may or not may be last.
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
fill(ByteBuffer) - Method in interface org.eclipse.jetty.io.EndPoint
Fills the passed buffer with data from this endpoint.
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
fill(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
fillable() - Method in class org.eclipse.jetty.io.FillInterest
Call to signal that a read is now possible.
fillBufferFromInputStream(InputStream, byte[], int) - Method in class org.eclipse.jetty.io.content.InputStreamContentSource
 
FillInterest - Class in org.eclipse.jetty.io
A Utility class to help implement EndPoint.fillInterested(Callback) by keeping state and calling the context and callback objects.
FillInterest() - Constructor for class org.eclipse.jetty.io.FillInterest
 
fillInterested() - Method in class org.eclipse.jetty.io.AbstractConnection
Registers read interest using the default Callback with Invocable.InvocationType.BLOCKING.
fillInterested() - Method in class org.eclipse.jetty.io.AbstractConnection.NonBlocking
Registers read interest using the default Callback with Invocable.InvocationType.NON_BLOCKING.
fillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractConnection
Registers read interest with the given callback.
fillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
fillInterested(Callback) - Method in interface org.eclipse.jetty.io.EndPoint
Requests callback methods to be invoked when a call to EndPoint.fill(ByteBuffer) would return data or EOF.
FixedCapacity(ByteBuffer) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
FixedCapacity(ByteBuffer, Retainable) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
flush() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
flush() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
flush() - Method in class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
flush() - Method in class org.eclipse.jetty.io.WriterOutputStream
 
flush() - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
flush(SocketAddress, ByteBuffer[]) - Method in class org.eclipse.jetty.io.WriteFlusher
Flushes the buffers iteratively until no progress is made.
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
flush(ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Flushes data from the passed header/buffer to this endpoint.
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
flush(ByteBuffer...) - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
flush(Callback) - Method in class org.eclipse.jetty.io.content.BufferedContentSink
Flush the buffered content.
FLUSH_BUFFER - Static variable in class org.eclipse.jetty.io.content.BufferedContentSink
An empty ByteBuffer, which if written will invoke a BufferedContentSink.flush(Callback) operation.
from(InputStream) - Static method in interface org.eclipse.jetty.io.Content.Source
 
from(OutputStream) - Static method in interface org.eclipse.jetty.io.Content.Sink
Wraps the given OutputStream as a Content.Sink.
from(Throwable) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Creates an failure chunk with the given failure and Content.Chunk.isLast() returning true.
from(Throwable, boolean) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Creates an failure chunk with the given failure and given last state.
from(ByteBuffer...) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from zero or more ByteBuffers
from(ByteBuffer, boolean) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Creates a Chunk with the given ByteBuffer.
from(ByteBuffer, boolean, Runnable) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Creates a Chunk with the given ByteBuffer.
from(ByteBuffer, boolean, Consumer<ByteBuffer>) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Creates a last/non-last Chunk with the given ByteBuffer.
from(AsynchronousByteChannel) - Static method in interface org.eclipse.jetty.io.Content.Sink
from(ByteChannel) - Static method in interface org.eclipse.jetty.io.Content.Sink
Wraps the given ByteChannel as a Content.Sink.
from(Path) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a Path.
from(Path, long, long) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a Path.
from(SSLSession, String, String, X509Certificate[]) - Static method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
from(ByteBufferPool.Sized, InputStream) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from an InputStream.
from(ByteBufferPool.Sized, InputStream, long, long) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from an InputStream.
from(ByteBufferPool.Sized, ByteChannel) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a ByteChannel.
from(ByteBufferPool.Sized, SeekableByteChannel, long, long) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a ByteChannel.
from(ByteBufferPool.Sized, Path) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a Path.
from(ByteBufferPool.Sized, Path, long, long) - Static method in interface org.eclipse.jetty.io.Content.Source
Create a Content.Source from a Path.

G

get() - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
get() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
get() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
get() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Consumes and returns a byte from this RetainableByteBuffer
get(byte[], int, int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
get(byte[], int, int) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Consumes and copies the bytes from this RetainableByteBuffer to the given byte array.
get(byte[], int, int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
get(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
get(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
get(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Returns a byte from this RetainableByteBuffer at a specific index
get(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
get(long, TimeUnit) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
getAcquireInstant() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
getAcquireStack() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
getAggregationSize() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
getAvailableDirectByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getAvailableDirectMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getAvailableHeapByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getAvailableHeapMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getAverageSelectedKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getBindAddress() - Method in class org.eclipse.jetty.io.ClientConnector
 
getByteBuffer() - Method in class org.eclipse.jetty.io.Content.Chunk.Empty
 
getByteBuffer() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
getByteBuffer() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
getByteBuffer() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
getByteBuffer() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Get the wrapped, not null, ByteBuffer.
getByteBuffer() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
getByteBufferPool() - Method in class org.eclipse.jetty.io.ClientConnector
 
getByteBufferPool() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
getByteBuffers() - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
getByteBuffers() - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
getBytesIn() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getBytesIn() - Method in interface org.eclipse.jetty.io.Connection
 
getBytesIn() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getBytesOut() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getBytesOut() - Method in interface org.eclipse.jetty.io.Connection
 
getBytesOut() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getCallbackInvocationType() - Method in class org.eclipse.jetty.io.FillInterest
 
getCallbackInvocationType() - Method in class org.eclipse.jetty.io.WriteFlusher
 
getChannel() - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
getChannel() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getChannel() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
getChunks() - Method in class org.eclipse.jetty.io.content.ChunksContentSource
 
getClientConnectionFactory() - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
getConnection() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getConnection() - Method in interface org.eclipse.jetty.io.EndPoint
 
getConnectionDurationMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionDurationMean() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationMean() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionDurationStdDev() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionDurationStdDev() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnections() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnections() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionsMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionsMax() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectionStatisticsGroups() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionsTotal() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getConnectionsTotal() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getConnectTimeout() - Method in class org.eclipse.jetty.io.ClientConnector
 
getConnectTimeout() - Method in class org.eclipse.jetty.io.SelectorManager
Get the connect timeout
getContentSource() - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
getContext() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getCreatedTimeStamp() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getCreatedTimeStamp() - Method in interface org.eclipse.jetty.io.Connection
 
getCreatedTimeStamp() - Method in interface org.eclipse.jetty.io.EndPoint
 
getDirectBucketsStatistics() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getDirectByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getDirectMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getEndPoint() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getEndPoint() - Method in interface org.eclipse.jetty.io.Connection
 
getEndPoint() - Method in class org.eclipse.jetty.io.ssl.SslHandshakeListener.Event
 
getExecutor() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getExecutor() - Method in class org.eclipse.jetty.io.ClientConnector
 
getExecutor() - Method in class org.eclipse.jetty.io.SelectorManager
 
getExecutor() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
getExpireNanoTime() - Method in interface org.eclipse.jetty.io.CyclicTimeouts.Expirable
Returns the expiration time in nanoseconds.
getFailure() - Method in interface org.eclipse.jetty.io.Content.Chunk
Get a failure (which may be from a failure or a warning), if any, associated with the chunk.
getFillInterest() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getHeapBucketsStatistics() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getHeapByteBufferCount() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getHeapMemory() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getIdleFor() - Method in class org.eclipse.jetty.io.IdleTimeout
Get the period of time, in milliseconds, that this object was idle.
getIdleTimeout() - Method in class org.eclipse.jetty.io.ClientConnector
 
getIdleTimeout() - Method in interface org.eclipse.jetty.io.EndPoint
Returns the idle timeout in ms.
getIdleTimeout() - Method in class org.eclipse.jetty.io.IdleTimeout
 
getIdleTimeout() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getInputBufferSize() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getInvocationType() - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
getLeaks() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
getLength() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
Get the amount of bytes which have been accumulated.
getLength() - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
Get the total length of the content in the accumulator..
getLength() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
getLength() - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
getLength() - Method in class org.eclipse.jetty.io.content.ChunksContentSource
 
getLength() - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
getLength() - Method in class org.eclipse.jetty.io.content.PathContentSource
 
getLength() - Method in interface org.eclipse.jetty.io.Content.Source
 
getLocalEndPoint() - Method in interface org.eclipse.jetty.io.EndPoint.Pipe
 
getLocalEndPoint() - Method in class org.eclipse.jetty.io.MemoryEndPointPipe
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getLocalSocketAddress() - Method in interface org.eclipse.jetty.io.EndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getLocalSocketAddress() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getMaxCapacity() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMaxSelectedKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getMaxSize() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
getMaxWriteSize() - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
getMessagesIn() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getMessagesIn() - Method in interface org.eclipse.jetty.io.Connection
 
getMessagesOut() - Method in class org.eclipse.jetty.io.AbstractConnection
 
getMessagesOut() - Method in interface org.eclipse.jetty.io.Connection
 
getMinCapacity() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getMinRetainSize() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
getName() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getNoBucketDirectAcquires() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getNoBucketHeapAcquires() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getOutputStream() - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
getOutputString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getOutputString(Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getPath() - Method in class org.eclipse.jetty.io.content.PathContentSource
 
getProtocol() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
getProtocols(boolean) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
getReceiveBufferSize() - Method in class org.eclipse.jetty.io.ClientConnector
 
getReceivedBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getReceivedMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getReceivedMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getRemoteEndPoint() - Method in interface org.eclipse.jetty.io.EndPoint.Pipe
 
getRemoteEndPoint() - Method in class org.eclipse.jetty.io.MemoryEndPointPipe
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
getRemoteSocketAddress() - Method in interface org.eclipse.jetty.io.EndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.SocketChannelEndPoint
 
getRemoteSocketAddress() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getRenegotiationLimit() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getReserved() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
getRetained() - Method in interface org.eclipse.jetty.io.Retainable
Get the retained count.
getRetained() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
getRetained() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
getReuseAddress() - Method in class org.eclipse.jetty.io.ClientConnector
 
getScheduler() - Method in class org.eclipse.jetty.io.ClientConnector
 
getScheduler() - Method in class org.eclipse.jetty.io.CyclicTimeout
 
getScheduler() - Method in class org.eclipse.jetty.io.IdleTimeout
 
getScheduler() - Method in class org.eclipse.jetty.io.SelectorManager
 
getSelectCount() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getSelector() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getSelectorCount() - Method in class org.eclipse.jetty.io.SelectorManager
 
getSelectorManager() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSelectors() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSendBufferSize() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSentBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentBytes() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentBytesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentMessages() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSentMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
getSentMessagesRate() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
getSize() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
getSize() - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
getSize() - Method in class org.eclipse.jetty.io.ByteBufferPool.Sized
 
getSocketAddress() - Method in interface org.eclipse.jetty.io.Transport
 
getSocketAddress() - Method in class org.eclipse.jetty.io.Transport.Unix
 
getSocketAddress() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
getSslConnection() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getSslContextFactory() - Method in class org.eclipse.jetty.io.ClientConnector
 
getSslContextFactory() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
getSslEndPoint() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getSSLEngine() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
getSSLEngine() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
getSSLEngine() - Method in class org.eclipse.jetty.io.ssl.SslHandshakeListener.Event
 
getSslSessionData() - Method in interface org.eclipse.jetty.io.EndPoint
Returns the SslSessionData of a secure end point.
getSslSessionData() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getTotalKeys() - Method in class org.eclipse.jetty.io.ManagedSelector
 
getTotalKeys() - Method in class org.eclipse.jetty.io.SelectorManager
Get total number of keys from each selector.
getTotalLength() - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
getTransport() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
getTransport() - Method in interface org.eclipse.jetty.io.EndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
getTransport() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
getWrapped() - Method in class org.eclipse.jetty.io.ByteBufferPool.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
getWrapped() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
getWriteFlusher() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
getWriteFlusher() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 

H

handle(BiFunction<? super X, Throwable, ? extends U>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
handleSelectFailure(Selector, Throwable) - Method in class org.eclipse.jetty.io.ManagedSelector
 
handshakeFailed(SslHandshakeListener.Event, Throwable) - Method in interface org.eclipse.jetty.io.ssl.SslHandshakeListener
Callback method invoked when the TLS handshake fails.
handshakeSucceeded(SslHandshakeListener.Event) - Method in interface org.eclipse.jetty.io.ssl.SslHandshakeListener
Callback method invoked when the TLS handshake succeeds.
hashCode() - Method in interface org.eclipse.jetty.io.Transport
 
hashCode() - Method in class org.eclipse.jetty.io.Transport.Unix
 
hasMore() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
hasRemaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
hasRemaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
hasRemaining() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
hasRemaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
HTTP_CLIENT_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 

I

Idiomatic usage - Search tag in interface org.eclipse.jetty.io.Content.Source
Section
Idiomatic usage - Search tag in interface org.eclipse.jetty.io.Retainable
Section
IdleTimeout - Class in org.eclipse.jetty.io
An Abstract implementation of an Idle Timeout.
IdleTimeout(Scheduler) - Constructor for class org.eclipse.jetty.io.IdleTimeout
 
include(Class<? extends Connection>) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
include(String) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
IncludeExcludeConnectionStatistics - Class in org.eclipse.jetty.io
 
IncludeExcludeConnectionStatistics() - Constructor for class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
IncludeExcludeConnectionStatistics.ConnectionSet - Class in org.eclipse.jetty.io
 
incoming(Socket, ByteBuffer) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when bytes sent by a remote client arrived on the server.
incrementCount() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
Info(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.ClientConnectionFactory.Info
 
init() - Method in interface org.eclipse.jetty.io.ssl.ALPNProcessor
Initializes this ALPNProcessor
InputStreamContentSource - Class in org.eclipse.jetty.io.content
A Content.Source that is backed by an InputStream.
InputStreamContentSource(InputStream) - Constructor for class org.eclipse.jetty.io.content.InputStreamContentSource
Deprecated, for removal: This API element is subject to removal in a future version.
InputStreamContentSource(InputStream, ByteBufferPool.Sized) - Constructor for class org.eclipse.jetty.io.content.InputStreamContentSource
 
InputStreamContentSource(InputStream, ByteBufferPool.Sized, long, long) - Constructor for class org.eclipse.jetty.io.content.InputStreamContentSource
 
insert(int, RetainableByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
IOResources - Class in org.eclipse.jetty.io
Common IO operations for Resource content.
IOResources() - Constructor for class org.eclipse.jetty.io.IOResources
 
IP() - Constructor for class org.eclipse.jetty.io.Transport.IP
 
isClosed() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
isComplete() - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
isConnectBlocking() - Method in class org.eclipse.jetty.io.ClientConnector
 
isConnectionPending(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
isDirect() - Method in class org.eclipse.jetty.io.ByteBufferPool.Sized
 
isDirect() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
isDirect() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
isDirect() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
isDirect() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
isDirectBuffersForDecryption() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isDirectBuffersForEncryption() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isEmpty() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
isEmpty() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
isFailed() - Method in class org.eclipse.jetty.io.WriteFlusher
 
isFailure(Content.Chunk) - Static method in interface org.eclipse.jetty.io.Content.Chunk
 
isFailure(Content.Chunk, boolean) - Static method in interface org.eclipse.jetty.io.Content.Chunk
 
isFillInterested() - Method in class org.eclipse.jetty.io.AbstractConnection
 
isFillInterested() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isFillInterested() - Method in interface org.eclipse.jetty.io.EndPoint
 
isFull() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
isFull() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
isFull() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
isGrowOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
isInputShutdown() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isInputShutdown() - Method in interface org.eclipse.jetty.io.EndPoint
Tests if the input is shutdown.
isInputShutdown() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
isInterested() - Method in class org.eclipse.jetty.io.FillInterest
 
isIntrinsicallySecure() - Method in interface org.eclipse.jetty.io.Transport
 
isIntrinsicallySecure() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
isLast() - Method in interface org.eclipse.jetty.io.Content.Chunk
 
isMutable() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
isMutable() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
isMutable() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Check if the underlying implementation is mutable.
isOpen() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isOpen() - Method in interface org.eclipse.jetty.io.EndPoint
 
isOpen() - Method in class org.eclipse.jetty.io.IdleTimeout
This abstract method should be called to check if idle timeouts should still be checked.
isOpen() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
isOpen() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
isOutputShutdown() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
isOutputShutdown() - Method in interface org.eclipse.jetty.io.EndPoint
Tests if output is shutdown.
isOutputShutdown() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
isPending() - Method in class org.eclipse.jetty.io.WriteFlusher
 
isQuiet(Throwable) - Static method in interface org.eclipse.jetty.io.QuietException
 
isRenegotiationAllowed() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
isRequireCloseMessage() - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
isRequireCloseMessage() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
isRetained() - Method in interface org.eclipse.jetty.io.Retainable
Returns whether Retainable.retain() has been called at least one more time than Retainable.release().
isRetained() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
isRetained() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
isRetained() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
isReusePort() - Method in class org.eclipse.jetty.io.ClientConnector
 
isSecure() - Method in interface org.eclipse.jetty.io.EndPoint
 
isStatisticsEnabled() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
isTCPNoDelay() - Method in class org.eclipse.jetty.io.ClientConnector
 
isWriteInterested() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
iterate() - Method in class org.eclipse.jetty.io.CyclicTimeouts
 
iterator() - Method in class org.eclipse.jetty.io.CyclicTimeouts
 
iterator() - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 

J

join() - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 

K

keySize() - Method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
Calculates the key size based on the cipher suite.

L

length() - Method in class org.eclipse.jetty.io.ByteBufferAggregator
Deprecated.
Get the currently aggregated length.
length() - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
Get the total length of the accumulated Content.Chunks.
limit(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
limit(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
limit(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Limit this buffer's contents to the size.

M

ManagedSelector - Class in org.eclipse.jetty.io
ManagedSelector wraps a Selector simplifying non-blocking operations on channels.
ManagedSelector(SelectorManager, int) - Constructor for class org.eclipse.jetty.io.ManagedSelector
 
ManagedSelector.Selectable - Interface in org.eclipse.jetty.io
A ManagedSelector.Selectable is an EndPoint that wish to be notified of non-blocking events by the ManagedSelector.
ManagedSelector.SelectorUpdate - Interface in org.eclipse.jetty.io
A selector update to be done when the selector has been woken.
matches(List<String>, boolean) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
Tests whether one of the protocol identifiers of this class is also present in the given candidates list.
maxSize() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
maxSize() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
MemoryEndPointPipe - Class in org.eclipse.jetty.io
Memory-based implementation of EndPoint.Pipe.
MemoryEndPointPipe(Scheduler, Consumer<Invocable.Task>, SocketAddress) - Constructor for class org.eclipse.jetty.io.MemoryEndPointPipe
 

N

needsFillInterest() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.FillInterest
Register the read interest Abstract method to be implemented by the Specific ReadInterest to schedule a future call to FillInterest.fillable() or FillInterest.onFail(Throwable)
needsFillInterest() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
needsFillInterest() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
NegotiatingClientConnection - Class in org.eclipse.jetty.io
 
NegotiatingClientConnection(EndPoint, Executor, SSLEngine, ClientConnectionFactory, Map<String, Object>) - Constructor for class org.eclipse.jetty.io.NegotiatingClientConnection
 
NegotiatingClientConnectionFactory - Class in org.eclipse.jetty.io
 
NegotiatingClientConnectionFactory(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.NegotiatingClientConnectionFactory
 
networkFill(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
networkFlush(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
NetworkTrafficListener - Interface in org.eclipse.jetty.io
A listener for raw network traffic within Jetty.
NetworkTrafficSocketChannelEndPoint - Class in org.eclipse.jetty.io
A specialized version of SocketChannelEndPoint that supports NetworkTrafficListeners.
NetworkTrafficSocketChannelEndPoint(SocketChannel, ManagedSelector, SelectionKey, Scheduler, long, NetworkTrafficListener) - Constructor for class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
newClientConnectionFactory(ClientConnector, ClientConnectionFactory) - Method in interface org.eclipse.jetty.io.Transport
 
newClientConnectionFactory(ClientConnector, ClientConnectionFactory) - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
newConnection(SelectableChannel, EndPoint, Object) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method to create Connection.
newConnection(EndPoint, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Wrapper
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnector
 
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
newConnection(EndPoint, Map<String, Object>) - Method in interface org.eclipse.jetty.io.Transport
Creates a new Connection to be associated with the given low-level EndPoint.
newConnection(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
newContentSource(ByteBufferPool.Sized, long, long) - Method in interface org.eclipse.jetty.io.Content.Source.Factory
Creates a new Content.Source.
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.ClientConnector.ClientSelectorManager
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.ClientConnector
 
newEndPoint(SelectableChannel, ManagedSelector, SelectionKey) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method to create EndPoint.
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in interface org.eclipse.jetty.io.Transport
For Transports that are based on sockets, or for Transports that are layered on top of another Transport that is based on sockets, this method is invoked to create a new EndPoint that wraps the SelectableChannel created by Transport.newSelectableChannel().
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in class org.eclipse.jetty.io.Transport.TCPIP
 
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in class org.eclipse.jetty.io.Transport.TCPUnix
 
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in class org.eclipse.jetty.io.Transport.UDPIP
 
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in class org.eclipse.jetty.io.Transport.UDPUnix
 
newEndPoint(Scheduler, ManagedSelector, SelectableChannel, SelectionKey) - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
newSelectableChannel() - Method in interface org.eclipse.jetty.io.Transport
For Transports that are based on sockets, or for Transports that are layered on top of another Transport that is based on sockets, this method is invoked to create a new SelectableChannel used for the socket communication.
newSelectableChannel() - Method in class org.eclipse.jetty.io.Transport.TCPIP
 
newSelectableChannel() - Method in class org.eclipse.jetty.io.Transport.TCPUnix
 
newSelectableChannel() - Method in class org.eclipse.jetty.io.Transport.UDPIP
 
newSelectableChannel() - Method in class org.eclipse.jetty.io.Transport.UDPUnix
 
newSelectableChannel() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
newSelector() - Method in class org.eclipse.jetty.io.SelectorManager
 
newSelector(int) - Method in class org.eclipse.jetty.io.SelectorManager
Factory method for ManagedSelector.
newSelectorManager() - Method in class org.eclipse.jetty.io.ClientConnector
 
newSslClientConnectionFactory(SslContextFactory.Client, ClientConnectionFactory) - Method in class org.eclipse.jetty.io.ClientConnector
 
newSslConnection(EndPoint, SSLEngine) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
newSslContextFactory() - Method in class org.eclipse.jetty.io.ClientConnector
 
newSslEndPoint() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
newSslEngine(String, int, Map<String, Object>) - Method in interface org.eclipse.jetty.io.ssl.SslClientConnectionFactory.SslEngineFactory
Creates a new SSLEngine instance for the given peer host and port, and with the given context to help the creation of the SSLEngine.
newWriter(OutputStream, String) - Static method in class org.eclipse.jetty.io.WriteThroughWriter
Obtain a new Writer that converts characters written to bytes written to an OutputStream.
newWriter(OutputStream, Charset) - Static method in class org.eclipse.jetty.io.WriteThroughWriter
Obtain a new Writer that converts characters written to bytes written to an OutputStream.
next(Content.Chunk) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Returns the chunk that follows the given chunk.
nioSelect(Selector, boolean) - Method in class org.eclipse.jetty.io.ManagedSelector
 
NON_POOLING - Static variable in interface org.eclipse.jetty.io.ByteBufferPool
 
NON_RETAINABLE - Static variable in interface org.eclipse.jetty.io.Retainable
 
NonBlocking(EndPoint, Executor) - Constructor for class org.eclipse.jetty.io.AbstractConnection.NonBlocking
 
NonPooling() - Constructor for class org.eclipse.jetty.io.ByteBufferPool.NonPooling
 
NonRetainableByteBuffer(ByteBuffer) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.NonRetainableByteBuffer
 
notIdle() - Method in class org.eclipse.jetty.io.IdleTimeout
This method should be called when non-idle activity has taken place.
notifyIncoming(ByteBuffer, int) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
notifyOutgoing(ByteBuffer) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 

O

onAccepted(SelectableChannel) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called after the accepted channel has been allocated an EndPoint and associated Connection, and after the onOpen notifications have been called on both endPoint and connection.
onAccepted(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
onAcceptFailed(SelectableChannel, Throwable) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called if the processing of the accepted channel fails prior to calling SelectorManager.AcceptListener.onAccepted(SelectableChannel).
onAcceptFailed(SelectableChannel, Throwable) - Method in class org.eclipse.jetty.io.SelectorManager
 
onAccepting(SelectableChannel) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called immediately after a new SelectableChannel is accepted, but before it has been submitted to the SelectorManager.
onAccepting(SelectableChannel) - Method in class org.eclipse.jetty.io.SelectorManager
 
onClose() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onClose() - Method in class org.eclipse.jetty.io.FillInterest
 
onClose() - Method in class org.eclipse.jetty.io.IdleTimeout
 
onClose() - Method in class org.eclipse.jetty.io.WriteFlusher
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onClose(Throwable) - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked when this connection is closed.
onClose(Throwable) - Method in interface org.eclipse.jetty.io.EndPoint
Callback method invoked when this EndPoint is closed.
onClose(Throwable) - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onClose(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onClosed(SelectableChannel) - Method in interface org.eclipse.jetty.io.SelectorManager.AcceptListener
Called when an accepted SelectableChannel is closed.
onClosed(Connection) - Method in interface org.eclipse.jetty.io.Connection.Listener
 
onClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onClosed(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
onComplete() - Method in class org.eclipse.jetty.io.content.ContentSinkSubscriber
 
onConnectBegin(SocketChannel, SocketAddress) - Method in interface org.eclipse.jetty.io.ClientConnector.ConnectListener
Callback method invoked just before a SocketChannel.connect(SocketAddress) call.
onConnectFailure(SocketChannel, SocketAddress, Throwable) - Method in interface org.eclipse.jetty.io.ClientConnector.ConnectListener
Callback method invoked when a SocketChannel.connect(SocketAddress) call completes with a failure.
onConnectionClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onConnectionOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onConnectSuccess(SocketChannel) - Method in interface org.eclipse.jetty.io.ClientConnector.ConnectListener
Callback method invoked when a SocketChannel.connect(SocketAddress) call completes successfully.
onError(Throwable) - Method in class org.eclipse.jetty.io.content.ContentSinkSubscriber
 
onExpired(T) - Method in class org.eclipse.jetty.io.CyclicTimeouts
Invoked during the iteration when the given entity is expired.
onFail(Throwable) - Method in class org.eclipse.jetty.io.FillInterest
Call to signal a failure to a registered interest
onFail(Throwable) - Method in class org.eclipse.jetty.io.WriteFlusher
Notify the flusher of a failure
onFillable() - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint is ready to be read.
onFillable() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
onFillable() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onFillable() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
onFillableFail(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
onFillInterestedFailed(Throwable) - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint failed to be ready to be read.
onFillInterestedFailed(Throwable) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.AbstractConnection
 
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onIdleExpired(TimeoutException) - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked upon an idle timeout event.
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.IdleTimeout
This abstract method is called when the idle timeout has expired.
onIdleExpired(TimeoutException) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
onIncompleteFlush() - Method in class org.eclipse.jetty.io.WriteFlusher
Abstract call to be implemented by specific WriteFlushers.
onNext(Content.Chunk) - Method in class org.eclipse.jetty.io.content.ContentSinkSubscriber
 
onOpen() - Method in class org.eclipse.jetty.io.AbstractConnection
 
onOpen() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
onOpen() - Method in interface org.eclipse.jetty.io.Connection
Callback method invoked when this connection is opened.
onOpen() - Method in interface org.eclipse.jetty.io.EndPoint
Callback method invoked when this EndPoint is opened.
onOpen() - Method in class org.eclipse.jetty.io.IdleTimeout
 
onOpen() - Method in class org.eclipse.jetty.io.NegotiatingClientConnection
 
onOpen() - Method in class org.eclipse.jetty.io.NetworkTrafficSocketChannelEndPoint
 
onOpen() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
onOpened(Connection) - Method in interface org.eclipse.jetty.io.Connection.Listener
 
onOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onOpened(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics
 
onReadTimeout(TimeoutException) - Method in class org.eclipse.jetty.io.AbstractConnection
Callback method invoked when the endpoint failed to be ready to be read after a timeout
onSelected() - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when a read or write events has been detected by the ManagedSelector for this endpoint.
onSelected() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
onSelectFailed(Throwable) - Method in class org.eclipse.jetty.io.ManagedSelector
 
onSubscribe(Flow.Subscription) - Method in class org.eclipse.jetty.io.content.ContentSinkSubscriber
 
onTimeoutExpired() - Method in class org.eclipse.jetty.io.CyclicTimeout
Invoked when the timeout expires.
onTotalClosed(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onTotalOpened(Connection) - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
onTransientFailure(Throwable) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
Callback method that informs the parsing about how to handle transient failures.
onUpgradeFrom() - Method in interface org.eclipse.jetty.io.Connection.UpgradeFrom
Invoked during an upgrade to produce a buffer containing bytes that have not been consumed by this connection, and that must be consumed by the upgrade-to connection.
onUpgradeTo(ByteBuffer) - Method in interface org.eclipse.jetty.io.Connection.UpgradeTo
Invoked during an upgrade to receive a buffer containing bytes that have not been consumed by the upgrade-from connection, and that must be consumed by this connection.
onUpgradeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
opened(Socket) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when a connection from a remote client has been accepted.
org.eclipse.jetty.io - module org.eclipse.jetty.io
 
org.eclipse.jetty.io - package org.eclipse.jetty.io
Jetty IO : Core classes for Jetty IO subsystem
org.eclipse.jetty.io.content - package org.eclipse.jetty.io.content
 
org.eclipse.jetty.io.ssl - package org.eclipse.jetty.io.ssl
Jetty IO : Core SSL Support
outgoing(Socket, ByteBuffer) - Method in interface org.eclipse.jetty.io.NetworkTrafficListener
Callback method invoked when bytes are sent to a remote client from the server.
OutputStreamContentSource - Class in org.eclipse.jetty.io.content
A Content.Source that provides content asynchronously through an OutputStream.
OutputStreamContentSource() - Constructor for class org.eclipse.jetty.io.content.OutputStreamContentSource
 

P

parse() - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
Initiates the parsing of the Content.Source.
parse(Content.Chunk) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
PathContentSource - Class in org.eclipse.jetty.io.content
A Content.Source that provides the file content of the passed Path.
PathContentSource(Path) - Constructor for class org.eclipse.jetty.io.content.PathContentSource
 
PathContentSource(Path, ByteBufferPool) - Constructor for class org.eclipse.jetty.io.content.PathContentSource
 
PathContentSource(Path, ByteBufferPool.Sized) - Constructor for class org.eclipse.jetty.io.content.PathContentSource
 
peerCertificates() - Method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
Pooled(ByteBufferPool, ByteBuffer) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.Pooled
 
Pooled(ByteBufferPool, ByteBuffer, Retainable) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.Pooled
 
poolFor(int, boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
process(Content.Chunk, Callback) - Method in interface org.eclipse.jetty.io.Content.Chunk.Processor
 
put(byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
put(byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
Put a byte to the buffer, growing this buffer if necessary and possible.
put(byte) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a byte to the buffer, growing this buffer if necessary and possible.
put(byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
put(byte[]) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a byte array to the buffer, growing this buffer if necessary and possible.
put(byte[], int, int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
put(byte[], int, int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
Put a byte array to the buffer, growing this buffer if necessary and possible.
put(byte[], int, int) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a byte array to the buffer, growing this buffer if necessary and possible.
put(byte[], int, int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
put(long, byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
put(long, byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
put(long, byte) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a byte to the buffer at a given index.
put(long, byte) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
putInt(int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
putInt(int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
Put an int to the buffer, growing this buffer if necessary and possible.
putInt(int) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put an int to the buffer, growing this buffer if necessary and possible.
putInt(int) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
putLong(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
putLong(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
Put a long to the buffer, growing this buffer if necessary and possible.
putLong(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a long to the buffer, growing this buffer if necessary and possible.
putLong(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
putShort(short) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
putShort(short) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
Put a short to the buffer, growing this buffer if necessary and possible.
putShort(short) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer.Mutable
Put a short to the buffer, growing this buffer if necessary and possible.
putShort(short) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
putTo(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
putTo(ByteBuffer) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Consumes and puts the contents of this retainable byte buffer at the end of the given byte buffer.
putTo(ByteBuffer) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 

Q

Quadratic() - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Quadratic
Creates a pool with buckets starting at 1 KiB up to 64 KiB.
Quadratic(int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Quadratic
Creates a pool with the specified minCapacity, maxCapacity and maxBucketSize, see Quadratic(int, int, int, long, long).
Quadratic(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Quadratic
Creates a pool with buckets starting at the closest power of 2 larger than minCapacity, up to the closest power of 2 larger than maxCapacity.
QuietException - Interface in org.eclipse.jetty.io
A Quiet Exception.
QuietException.Exception - Exception Class in org.eclipse.jetty.io
 
QuietException.RuntimeException - Exception Class in org.eclipse.jetty.io
 

R

read() - Method in class org.eclipse.jetty.io.ByteBufferInputStream
 
read() - Method in class org.eclipse.jetty.io.content.AsyncContent
 
read() - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
read() - Method in class org.eclipse.jetty.io.content.ChunksContentSource
 
read() - Method in class org.eclipse.jetty.io.content.ContentSourceInputStream
 
read() - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
read() - Method in class org.eclipse.jetty.io.content.InputStreamContentSource
 
read() - Method in class org.eclipse.jetty.io.content.OutputStreamContentSource
 
read() - Method in class org.eclipse.jetty.io.content.PathContentSource
 
read() - Method in interface org.eclipse.jetty.io.Content.Source
Reads a chunk of content.
read(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferInputStream
 
read(byte[], int, int) - Method in class org.eclipse.jetty.io.content.ContentSourceInputStream
 
readAll(Content.Source) - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated, for removal: This API element is subject to removal in a future version.
readAll(Content.Source, int) - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated, for removal: This API element is subject to removal in a future version.
readAll(Content.Source, ByteBufferPool, boolean, int) - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated, for removal: This API element is subject to removal in a future version.
receive(ByteBuffer) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
receive(ByteBuffer) - Method in interface org.eclipse.jetty.io.EndPoint
Receives data into the given buffer from the returned address.
recordBytesIn(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordBytesOut(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordDuration(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordMessagesIn(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
recordMessagesOut(long) - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
ReferenceCounter() - Constructor for class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
ReferenceCounter(int) - Constructor for class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
register(Callback) - Method in class org.eclipse.jetty.io.FillInterest
Call to register interest in a callback when a read is possible.
release() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
release() - Method in class org.eclipse.jetty.io.ByteBufferPool.Accumulator
Deprecated.
 
release() - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
Invoked when the transformation is complete to release any resource.
release() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
release() - Method in interface org.eclipse.jetty.io.Retainable
Releases this resource, potentially decrementing a reference count (if any).
release() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
release() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
release(R) - Static method in interface org.eclipse.jetty.io.Retainable
Convenience method that replaces code like:
releaseAndNext(Content.Chunk) - Static method in interface org.eclipse.jetty.io.Content.Chunk
Convenience method to release a chunk and return Content.Chunk.next(Chunk).
remaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
remaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
remaining() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
remaining() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
REMOTE_SOCKET_ADDRESS_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
remove(Object) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.io.AbstractConnection
 
removeEventListener(EventListener) - Method in class org.eclipse.jetty.io.ClientConnector
 
removeEventListener(EventListener) - Method in interface org.eclipse.jetty.io.Connection
Removes a listener of connection events.
removeEventListener(EventListener) - Method in class org.eclipse.jetty.io.SelectorManager
 
removeHandshakeListener(SslHandshakeListener) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
replaceKey(SelectionKey) - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when the SelectionKey is replaced because the channel has been moved to a new selector.
replaceKey(SelectionKey) - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
requiresDomainNameResolution() - Method in class org.eclipse.jetty.io.Transport.IP
 
requiresDomainNameResolution() - Method in interface org.eclipse.jetty.io.Transport
Returns whether this Transport requires resolution of domain names.
requiresDomainNameResolution() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
reset() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
reset() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
reset() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
reset() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
resetStats() - Method in class org.eclipse.jetty.io.ManagedSelector
 
retain() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
retain() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
retain() - Method in interface org.eclipse.jetty.io.Retainable
Retains this resource, potentially incrementing a reference count if there are resources that will be released.
retain() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
Retainable - Interface in org.eclipse.jetty.io
A reference counted resource, for example one that is borrowed from a pool, that may be retained an additional number of times, and released a correspondent number of times, over its lifecycle.
Retainable.ReferenceCounter - Class in org.eclipse.jetty.io
A reference count implementation for a Retainable resource.
Retainable.Wrapper - Class in org.eclipse.jetty.io
A wrapper of Retainable instances.
RetainableByteBuffer - Interface in org.eclipse.jetty.io
An abstraction over ByteBuffers which provides:
RetainableByteBuffer.Abstract - Class in org.eclipse.jetty.io
An abstract implementation of RetainableByteBuffer that provides the basic Retainable functionality
RetainableByteBuffer.DynamicCapacity - Class in org.eclipse.jetty.io
An RetainableByteBuffer.Mutable RetainableByteBuffer that can grow its capacity, backed by a chain of ByteBuffer, which may grow either by aggregation and/or retention.
RetainableByteBuffer.EmptyRetainableByteBuffer - Class in org.eclipse.jetty.io
A RetainableByteBuffer that is empty and not retainable.
RetainableByteBuffer.FixedCapacity - Class in org.eclipse.jetty.io
A fixed capacity RetainableByteBuffer.Mutable RetainableByteBuffer backed by a single ByteBuffer.
RetainableByteBuffer.Mutable - Interface in org.eclipse.jetty.io
Extended RetainableByteBuffer API with mutator methods.
RetainableByteBuffer.NonRetainableByteBuffer - Class in org.eclipse.jetty.io
A RetainableByteBuffer.FixedCapacity buffer that is neither poolable nor retainable.
RetainableByteBuffer.Pooled - Class in org.eclipse.jetty.io
A pooled buffer that knows the pool from which it was allocated.
RetainableByteBuffer.Wrapper - Class in org.eclipse.jetty.io
A wrapper for RetainableByteBuffer instances
rewind() - Method in class org.eclipse.jetty.io.content.ByteBufferContentSource
 
rewind() - Method in class org.eclipse.jetty.io.content.PathContentSource
 
rewind() - Method in interface org.eclipse.jetty.io.Content.Source
Rewinds this content, if possible, so that subsequent reads return chunks starting from the beginning of this content.
run() - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
RuntimeException() - Constructor for exception class org.eclipse.jetty.io.QuietException.RuntimeException
 
RuntimeException(String) - Constructor for exception class org.eclipse.jetty.io.QuietException.RuntimeException
 
RuntimeException(String, Throwable) - Constructor for exception class org.eclipse.jetty.io.QuietException.RuntimeException
 
RuntimeException(Throwable) - Constructor for exception class org.eclipse.jetty.io.QuietException.RuntimeException
 
RuntimeIOException - Exception Class in org.eclipse.jetty.io
Deprecated, for removal: This API element is subject to removal in a future version.
RuntimeIOException() - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
Deprecated.
 
RuntimeIOException(String) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
Deprecated.
 
RuntimeIOException(String, Throwable) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
Deprecated.
 
RuntimeIOException(Throwable) - Constructor for exception class org.eclipse.jetty.io.RuntimeIOException
Deprecated.
 

S

schedule(long, TimeUnit) - Method in class org.eclipse.jetty.io.CyclicTimeout
Schedules a timeout, even if already set, cancelled or expired.
schedule(T) - Method in class org.eclipse.jetty.io.CyclicTimeouts
Schedules a timeout for a new or modified item.
select(Selector) - Method in class org.eclipse.jetty.io.ManagedSelector
 
SelectableChannelEndPoint - Class in org.eclipse.jetty.io
A partial EndPoint implementation based on SelectableChannel.
SelectableChannelEndPoint(Scheduler, SelectableChannel, ManagedSelector, SelectionKey) - Constructor for class org.eclipse.jetty.io.SelectableChannelEndPoint
 
SelectorManager - Class in org.eclipse.jetty.io
SelectorManager manages a number of ManagedSelectors that simplify the non-blocking primitives provided by the JVM via the java.nio package.
SelectorManager(Executor, Scheduler) - Constructor for class org.eclipse.jetty.io.SelectorManager
 
SelectorManager(Executor, Scheduler, int) - Constructor for class org.eclipse.jetty.io.SelectorManager
 
SelectorManager.AcceptListener - Interface in org.eclipse.jetty.io
A listener for accept events.
SelectorManager.SelectorManagerListener - Interface in org.eclipse.jetty.io
 
send(SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
send(SocketAddress, ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Sends to the given address the data in the given buffers.
setBindAddress(SocketAddress) - Method in class org.eclipse.jetty.io.ClientConnector
Sets the bind address of sockets before the connect operation.
setByteBufferPool(ByteBufferPool) - Method in class org.eclipse.jetty.io.ClientConnector
 
setConnectBlocking(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
 
setConnection(Connection) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
setConnection(Connection) - Method in interface org.eclipse.jetty.io.EndPoint
 
setConnection(Connection) - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
setConnectTimeout(long) - Method in class org.eclipse.jetty.io.SelectorManager
Set the connect timeout (in milliseconds)
setConnectTimeout(Duration) - Method in class org.eclipse.jetty.io.ClientConnector
 
setDirectBuffersForDecryption(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setDirectBuffersForEncryption(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setExecutor(Executor) - Method in class org.eclipse.jetty.io.ClientConnector
 
setGrowOutput(boolean) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
Deprecated.
setIdleTimeout(long) - Method in interface org.eclipse.jetty.io.EndPoint
Sets the idle timeout.
setIdleTimeout(long) - Method in class org.eclipse.jetty.io.IdleTimeout
Sets the idle timeout in milliseconds.
setIdleTimeout(long) - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
setIdleTimeout(Duration) - Method in class org.eclipse.jetty.io.ClientConnector
 
setInputBufferSize(int) - Method in class org.eclipse.jetty.io.AbstractConnection
 
setLocalEndPointMaxCapacity(int) - Method in class org.eclipse.jetty.io.MemoryEndPointPipe
 
setOutput(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
Deprecated.
setReceiveBufferSize(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setRemoteEndPointMaxCapacity(int) - Method in class org.eclipse.jetty.io.MemoryEndPointPipe
 
setRenegotiationAllowed(boolean) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
setRenegotiationLimit(int) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
setRequireCloseMessage(boolean) - Method in class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
setRequireCloseMessage(boolean) - Method in class org.eclipse.jetty.io.ssl.SslConnection
Sets whether it is required that a peer send the TLS close_notify message to indicate the will to close the connection, otherwise it may be interpreted as a truncation attack.
setReuseAddress(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
Sets whether it is allowed to bind a socket to a socket address that may be in use by another socket in tear-down state, for example in TIME_WAIT state.
setReusePort(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
Sets whether it is allowed to bind multiple sockets to the same socket address (same host and same port).
setScheduler(Scheduler) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSelectors(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSendBufferSize(int) - Method in class org.eclipse.jetty.io.ClientConnector
 
setSslContextFactory(SslContextFactory.Client) - Method in class org.eclipse.jetty.io.ClientConnector
 
setStatisticsEnabled(boolean) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
setTCPNoDelay(boolean) - Method in class org.eclipse.jetty.io.ClientConnector
 
shutdownInput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
shutdownOutput() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
shutdownOutput() - Method in interface org.eclipse.jetty.io.EndPoint
Shuts down the output.
size() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
size() - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
size() - Method in class org.eclipse.jetty.io.ManagedSelector
 
size() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
size() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
Sized(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.ByteBufferPool.Sized
Create a sized pool for non direct buffers of a default size from a wrapped pool.
Sized(ByteBufferPool, boolean, int) - Constructor for class org.eclipse.jetty.io.ByteBufferPool.Sized
Create a sized pool for a give directness and size from a wrapped pool.
SIZED_NON_POOLING - Static variable in interface org.eclipse.jetty.io.ByteBufferPool
 
skip(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
skip(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Skips, advancing the ByteBuffer position, the given number of bytes.
skip(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
slice() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
slice() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
slice() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
slice() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Get a slice of the buffer.
slice() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
slice(long) - Method in class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking.TrackedBuffer
 
slice(long) - Method in class org.eclipse.jetty.io.Content.Chunk.Empty
 
slice(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
slice(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
slice(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Pooled
 
slice(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Get a partial slice of the buffer.
slice(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
Socket() - Constructor for class org.eclipse.jetty.io.Transport.Socket
 
SocketChannelEndPoint - Class in org.eclipse.jetty.io
An EndPoint implementation based on SocketChannel.
SocketChannelEndPoint(SocketChannel, ManagedSelector, SelectionKey, Scheduler) - Constructor for class org.eclipse.jetty.io.SocketChannelEndPoint
 
space() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
space() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.FixedCapacity
 
space() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
space() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
SSL_CONTEXT_FACTORY_CONTEXT_KEY - Static variable in class org.eclipse.jetty.io.ClientConnector
 
SslClientConnectionFactory - Class in org.eclipse.jetty.io.ssl
A ClientConnectionFactory that creates client-side SslConnection instances.
SslClientConnectionFactory(SslContextFactory.Client, ByteBufferPool, Executor, ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.ssl.SslClientConnectionFactory
 
SslClientConnectionFactory.SslEngineFactory - Interface in org.eclipse.jetty.io.ssl
A factory for SSLEngine objects.
SslConnection - Class in org.eclipse.jetty.io.ssl
A Connection that acts as an interceptor between an EndPoint providing SSL encrypted data and another consumer of an EndPoint (typically an Connection like HttpConnection) that wants unencrypted data.
SslConnection(ByteBufferPool, Executor, EndPoint, SSLEngine) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
Deprecated.
SslConnection(ByteBufferPool, Executor, EndPoint, SSLEngine, boolean, boolean) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
Deprecated.
SslConnection(ByteBufferPool, Executor, SslContextFactory, EndPoint, SSLEngine) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
 
SslConnection(ByteBufferPool, Executor, SslContextFactory, EndPoint, SSLEngine, boolean, boolean) - Constructor for class org.eclipse.jetty.io.ssl.SslConnection
 
SslConnection.SslEndPoint - Class in org.eclipse.jetty.io.ssl
 
SslEndPoint() - Constructor for class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
SslHandshakeListener - Interface in org.eclipse.jetty.io.ssl
Implementations of this interface are notified of TLS handshake events.
SslHandshakeListener.Event - Class in org.eclipse.jetty.io.ssl
The event object carrying information about TLS handshake events.
sslSession() - Method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
sslSessionId() - Method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
startTunnel() - Method in interface org.eclipse.jetty.io.Connection.Tunnel
 
Stats(String) - Constructor for class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
submit(ManagedSelector.SelectorUpdate) - Method in class org.eclipse.jetty.io.ManagedSelector
Submit an ManagedSelector.SelectorUpdate to be acted on between calls to Selector.select()
subscribe(Flow.Subscriber<? super Content.Chunk>) - Method in class org.eclipse.jetty.io.content.ContentSourcePublisher
 

T

take() - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
 
take() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
take() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Take the contents of this buffer, leaving it clear.
take(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
take(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Take the contents of this buffer, from the head, leaving remaining bytes in this buffer.
take(ByteBufferPool, boolean) - Method in class org.eclipse.jetty.io.ChunkAccumulator
Deprecated.
 
takeByteArray() - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
 
takeByteArray() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
takeByteArray() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
takeByteArray() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Take the contents of this buffer, leaving it clear and independent.
takeByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
takeByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
Take the combined buffer containing all content written to the OutputStream.
takeFrom(long) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
takeFrom(long) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Take the contents of this buffer, from the tail, leaving remaining bytes in this buffer.
takeOutput() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takeOutputString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takeOutputString(Charset) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
takeRetainableByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
Take the combined buffer containing all content written to the accumulator.
takeRetainableByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAggregator
Deprecated.
Takes the buffer out of the aggregator.
TCP_IP - Static variable in interface org.eclipse.jetty.io.Transport
The TCP/IP Transport.
TCPIP() - Constructor for class org.eclipse.jetty.io.Transport.TCPIP
 
TCPUnix(Path) - Constructor for class org.eclipse.jetty.io.Transport.TCPUnix
 
test(Connection) - Method in class org.eclipse.jetty.io.IncludeExcludeConnectionStatistics.ConnectionSet
 
thenAccept(Consumer<? super X>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super X, ? super U>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
thenApply(Function<? super X, ? extends U>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super X, ? super U, ? extends V1>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
thenCompose(Function<? super X, ? extends CompletionStage<U>>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
thenRun(Runnable) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
toByteArray() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
toByteArray() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
toByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
Take the combined buffer containing all content written to the OutputStream.
toConnectionString() - Method in class org.eclipse.jetty.io.AbstractConnection
 
toConnectionString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toConnectionString() - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
toDetailString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
toDetailString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.EmptyRetainableByteBuffer
 
toDetailString() - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
 
toDetailString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
toEndPointString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toEndPointString() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
toRetainableByteBuffer() - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
Take the combined buffer containing all content written to the accumulator.
toRetainableByteBuffer(Resource, ByteBufferPool.Sized) - Static method in class org.eclipse.jetty.io.IOResources
Reads the contents of a Resource into a RetainableByteBuffer.
toStateString() - Method in class org.eclipse.jetty.io.FillInterest
 
toStateString() - Method in class org.eclipse.jetty.io.WriteFlusher
 
toString() - Method in class org.eclipse.jetty.io.AbstractConnection
 
toString() - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
toString() - Method in class org.eclipse.jetty.io.ArrayByteBufferPool
 
toString() - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
 
toString() - Method in class org.eclipse.jetty.io.ByteBufferAggregator
Deprecated.
 
toString() - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
toString() - Method in class org.eclipse.jetty.io.ConnectionStatistics.Stats
 
toString() - Method in class org.eclipse.jetty.io.ConnectionStatistics
 
toString() - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
 
toString() - Method in class org.eclipse.jetty.io.FillInterest
 
toString() - Method in class org.eclipse.jetty.io.ManagedSelector
 
toString() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 
toString() - Method in class org.eclipse.jetty.io.Retainable.Wrapper
 
toString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Abstract
 
toString() - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
toString() - Method in class org.eclipse.jetty.io.SelectorManager
 
toString() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
toString() - Method in class org.eclipse.jetty.io.Transport.Socket
 
toString() - Method in class org.eclipse.jetty.io.Transport.Unix
 
toString() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
toString() - Method in class org.eclipse.jetty.io.WriteFlusher
 
Tracking() - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
Tracking(int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
Tracking(int, int, int, int) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
Tracking(int, int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
Tracking(int, int, int, long, long) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.Tracking
 
transform(Content.Chunk) - Method in class org.eclipse.jetty.io.content.ContentSourceTransformer
Transforms the input chunk parameter into an output chunk.
Transport - Interface in org.eclipse.jetty.io
The low-level transport used by clients.
Transport.IP - Class in org.eclipse.jetty.io
Abstract implementation of Transport based on IP.
Transport.Socket - Class in org.eclipse.jetty.io
Abstract implementation of Transport based on sockets.
Transport.TCPIP - Class in org.eclipse.jetty.io
The TCP/IP Transport.
Transport.TCPUnix - Class in org.eclipse.jetty.io
The stream Unix-Domain socket Transport.
Transport.UDPIP - Class in org.eclipse.jetty.io
The UDP/IP Transport.
Transport.UDPUnix - Class in org.eclipse.jetty.io
The datagram Unix-Domain socket Transport.
Transport.Unix - Class in org.eclipse.jetty.io
Abstract implementation of Transport based on Unix-Domain sockets.
Transport.Wrapper - Class in org.eclipse.jetty.io
A wrapper for Transport instances to allow layering of Transports.
tryFillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractConnection
 
tryFillInterested(Callback) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
tryFillInterested(Callback) - Method in interface org.eclipse.jetty.io.EndPoint
Requests callback methods to be invoked when a call to EndPoint.fill(ByteBuffer) would return data or EOF.
tryRegister(Callback) - Method in class org.eclipse.jetty.io.FillInterest
Call to register interest in a callback when a read is possible.
tryRetain() - Method in class org.eclipse.jetty.io.Retainable.ReferenceCounter
 

U

UDP_IP - Static variable in interface org.eclipse.jetty.io.Transport
The UDP/IP Transport.
UDPIP() - Constructor for class org.eclipse.jetty.io.Transport.UDPIP
 
UDPUnix(Path) - Constructor for class org.eclipse.jetty.io.Transport.UDPUnix
 
Unix(Path) - Constructor for class org.eclipse.jetty.io.Transport.Unix
 
unwrap() - Method in interface org.eclipse.jetty.io.EndPoint.Wrapper
 
unwrap() - Method in class org.eclipse.jetty.io.ssl.SslConnection.SslEndPoint
 
unwrap() - Method in class org.eclipse.jetty.io.Transport.Wrapper
 
unwrap(SSLEngine, ByteBuffer, ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
update(Selector) - Method in interface org.eclipse.jetty.io.ManagedSelector.SelectorUpdate
 
updateKey() - Method in interface org.eclipse.jetty.io.ManagedSelector.Selectable
Callback method invoked when all the keys selected by the ManagedSelector for this endpoint have been processed.
updateKey() - Method in class org.eclipse.jetty.io.SelectableChannelEndPoint
 
upgrade(Connection) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
upgrade(Connection) - Method in interface org.eclipse.jetty.io.EndPoint
Upgrades this EndPoint from the current connection to the given new connection.
upgrade(EndPoint, Map<String, Object>) - Method in class org.eclipse.jetty.io.ClientConnectionFactory.Info
Upgrades the given EndPoint to the protocol represented by this class.

W

waitForOutput(long, TimeUnit) - Method in class org.eclipse.jetty.io.ByteArrayEndPoint
Wait for some output
whenComplete(BiConsumer<? super X, ? super Throwable>) - Method in class org.eclipse.jetty.io.content.ContentSourceCompletableFuture
 
WithBucketCapacities(int...) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.WithBucketCapacities
 
WithBucketCapacities(long, long, int...) - Constructor for class org.eclipse.jetty.io.ArrayByteBufferPool.WithBucketCapacities
 
withCipherSuite(EndPoint.SslSessionData, String) - Static method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
withSslSessionId(EndPoint.SslSessionData, String) - Static method in interface org.eclipse.jetty.io.EndPoint.SslSessionData
 
wrap(ByteBuffer) - Static method in interface org.eclipse.jetty.io.RetainableByteBuffer
Returns a non-retainable RetainableByteBuffer that wraps the given ByteBuffer.
wrap(ByteBuffer, Runnable) - Static method in interface org.eclipse.jetty.io.RetainableByteBuffer
Returns a RetainableByteBuffer that wraps the given ByteBuffer and Runnable releaser.
wrap(ByteBuffer, Retainable) - Static method in interface org.eclipse.jetty.io.RetainableByteBuffer
Returns a RetainableByteBuffer that wraps the given ByteBuffer and Retainable.
wrap(SSLEngine, ByteBuffer[], ByteBuffer) - Method in class org.eclipse.jetty.io.ssl.SslConnection
 
Wrapper(ByteBufferPool) - Constructor for class org.eclipse.jetty.io.ByteBufferPool.Wrapper
 
Wrapper(ClientConnectionFactory) - Constructor for class org.eclipse.jetty.io.ClientConnectionFactory.Wrapper
 
Wrapper(Retainable) - Constructor for class org.eclipse.jetty.io.Retainable.Wrapper
 
Wrapper(RetainableByteBuffer) - Constructor for class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
Wrapper(Transport) - Constructor for class org.eclipse.jetty.io.Transport.Wrapper
 
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.io.content.AsyncContent
Writes the given ByteBuffer, notifying the Callback when the write is complete.
write(boolean, ByteBuffer, Callback) - Method in class org.eclipse.jetty.io.content.BufferedContentSink
 
write(boolean, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.io.Content.Sink
Writes the given ByteBuffer, notifying the Callback when the write is complete.
write(boolean, ByteBuffer, Callback) - Method in interface org.eclipse.jetty.io.EndPoint
 
write(byte[]) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(byte[]) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
write(byte[], int, int) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(char[], int, int) - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
write(int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream
 
write(int) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
write(int) - Method in class org.eclipse.jetty.io.content.ContentSinkOutputStream
 
write(int) - Method in class org.eclipse.jetty.io.WriterOutputStream
 
write(String, int, int) - Method in class org.eclipse.jetty.io.WriteThroughWriter
 
write(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
write(Content.Sink, boolean, String, Callback) - Static method in interface org.eclipse.jetty.io.Content.Sink
Writes the given String, converting it to UTF-8 bytes, notifying the Callback when the write is complete.
write(Content.Sink, boolean, ByteBuffer) - Static method in interface org.eclipse.jetty.io.Content.Sink
write(Callback, SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.DatagramChannelEndPoint
 
write(Callback, SocketAddress, ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Writes to the given address the data contained in the given buffers, and invokes the given callback when either all the data has been sent, or a failure occurs.
write(Callback, SocketAddress, ByteBuffer...) - Method in class org.eclipse.jetty.io.WriteFlusher
 
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.io.AbstractEndPoint
 
write(Callback, ByteBuffer...) - Method in interface org.eclipse.jetty.io.EndPoint
Writes the given buffers via EndPoint.flush(ByteBuffer...) and invokes callback methods when either all the data has been flushed or an error occurs.
write(Callback, ByteBuffer...) - Method in class org.eclipse.jetty.io.WriteFlusher
Tries to switch state to FLUSHING.
WriteFlusher - Class in org.eclipse.jetty.io
A Utility class to help implement EndPoint.write(Callback, ByteBuffer...) by calling EndPoint.flush(ByteBuffer...) until all content is written.
WriteFlusher(EndPoint) - Constructor for class org.eclipse.jetty.io.WriteFlusher
 
WriterOutputStream - Class in org.eclipse.jetty.io
Wrap a Writer as an OutputStream.
WriterOutputStream(Writer) - Constructor for class org.eclipse.jetty.io.WriterOutputStream
 
WriterOutputStream(Writer, String) - Constructor for class org.eclipse.jetty.io.WriterOutputStream
 
WriteThroughWriter - Class in org.eclipse.jetty.io
An alternate to OutputStreamWriter that supports several optimized implementation for well known Charsets, specifically StandardCharsets.UTF_8 and StandardCharsets.ISO_8859_1.
WriteThroughWriter(OutputStream) - Constructor for class org.eclipse.jetty.io.WriteThroughWriter
 
WriteThroughWriter(OutputStream, int) - Constructor for class org.eclipse.jetty.io.WriteThroughWriter
Construct an OutputStreamWriter
writeTo(OutputStream) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
writeTo(OutputStream) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferAccumulator
Deprecated.
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferCallbackAccumulator
Deprecated.
 
writeTo(ByteBuffer) - Method in class org.eclipse.jetty.io.ByteBufferOutputStream2
Deprecated.
 
writeTo(Content.Sink, boolean) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Writes and consumes the contents of this retainable byte buffer into the given sink.
writeTo(Content.Sink, boolean, Callback) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.DynamicCapacity
 
writeTo(Content.Sink, boolean, Callback) - Method in class org.eclipse.jetty.io.RetainableByteBuffer.Wrapper
 
writeTo(Content.Sink, boolean, Callback) - Method in interface org.eclipse.jetty.io.RetainableByteBuffer
Asynchronously writes and consumes the contents of this retainable byte buffer into the given sink.

_

_encoding - Variable in class org.eclipse.jetty.io.WriterOutputStream
 
_writer - Variable in class org.eclipse.jetty.io.WriterOutputStream
 
A B C D E F G H I J K L M N O P Q R S T U W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form