Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y _ 

A

AbstractProtocolCodec - Class in org.fusesource.hawtdispatch.transport
Provides an abstract base class to make implementing the ProtocolCodec interface easier.
AbstractProtocolCodec() - Constructor for class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
AbstractProtocolCodec.Action - Interface in org.fusesource.hawtdispatch.transport
 
acceptSource - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
AggregatingExecutor - Class in org.fusesource.hawtdispatch
Sends runnable tasks to a DispatchQueue via a an EventAggregator so that they first batch up on the sender side before being sent to the DispatchQueue which then executes that tasks.
AggregatingExecutor(DispatchQueue) - Constructor for class org.fusesource.hawtdispatch.AggregatingExecutor
 
AnnotatedMBean - Class in org.fusesource.hawtdispatch.jmx
MBean that looks for method/parameter descriptions in the Info annotation.
AnnotatedMBean(T, Class<T>) - Constructor for class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
Instance where the MBean interface is implemented by another object.
AnnotatedMBean(Class<?>) - Constructor for class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
Instance where the MBean interface is implemented by this object.
ANY_ADDRESS - Static variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
apply() - Method in interface org.fusesource.hawtdispatch.transport.AbstractProtocolCodec.Action
 
assertExecuting() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Asserts that the current dispatch queue is executing.
assertRetained() - Method in class org.fusesource.hawtdispatch.BaseRetained
Subclasses can use this method to validate that the object has not yet been released.

B

backlog - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
BaseRetained - Class in org.fusesource.hawtdispatch
Base class that implements the Retained interface.
BaseRetained() - Constructor for class org.fusesource.hawtdispatch.BaseRetained
 
bind(String) - Static method in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
bindAddress - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
bindScheme - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
blockingExecutor - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
blockingExecutor - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
BufferPool - Class in org.fusesource.hawtdispatch.util
BufferPool(int) - Constructor for class org.fusesource.hawtdispatch.util.BufferPool
 
bufferPools - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
BufferPools - Class in org.fusesource.hawtdispatch.util
BufferPools() - Constructor for class org.fusesource.hawtdispatch.util.BufferPools
 

C

cancel() - Method in interface org.fusesource.hawtdispatch.DispatchSource
Asynchronously cancel the dispatch source, preventing any further invocation of its event handler runnable.
channel - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
channel - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
channel - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
checkin(T) - Method in class org.fusesource.hawtdispatch.util.ThreadLocalPool
 
checkout() - Method in class org.fusesource.hawtdispatch.util.ThreadLocalPool
 
client() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
close() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
close() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
close() - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
codec - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
codec - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
connect(String) - Static method in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
connect() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
connected(SocketChannel) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
connected(SocketChannel) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
connected(DatagramChannel) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
connecting(URI, URI) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
connecting(URI, URI) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
connecting(URI, URI) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
connectionCounter - Variable in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
connectURI - Variable in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
convert(Metrics, TimeUnit) - Static method in class org.fusesource.hawtdispatch.jmx.JmxService
 
create(Class<T>, T, DispatchQueue) - Static method in class org.fusesource.hawtdispatch.DispatchQueueProxy
Create an asynchronous dispatch proxy to the target object via the dispatch queue.
create(ClassLoader, Class<T>, T, DispatchQueue) - Static method in class org.fusesource.hawtdispatch.DispatchQueueProxy
Create an asynchronous dispatch proxy to the target object via the dispatch queue.
create(Object) - Static method in class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
 
create() - Method in class org.fusesource.hawtdispatch.util.BufferPool
 
create() - Method in class org.fusesource.hawtdispatch.util.ThreadLocalPool
 
createClientTransport() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
CREATED - Static variable in class org.fusesource.hawtdispatch.transport.ServiceBase
 
createQueue(String) - Static method in class org.fusesource.hawtdispatch.Dispatch
Creates a new serial dispatch queue to which runnable objects may be submitted.
createQueue() - Static method in class org.fusesource.hawtdispatch.Dispatch
Creates a new serial dispatch queue to which runnable objects may be submitted.
createQueue(String) - Method in interface org.fusesource.hawtdispatch.Dispatcher
Creates a new serial dispatch queue to which runnable objects may be submitted.
createQueue(String) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Creates a new serial dispatch queue with this queue set as it's target queue.
createServerTransport() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
createSource(SelectableChannel, int, DispatchQueue) - Static method in class org.fusesource.hawtdispatch.Dispatch
Creates a new DispatchSource to monitor SelectableChannel objects and automatically submit a handler runnable to a dispatch queue in response to events.
createSource(EventAggregator<Event, MergedEvent>, DispatchQueue) - Static method in class org.fusesource.hawtdispatch.Dispatch
Creates a new CustomDispatchSource to monitor events merged into the dispatch source and automatically submit a handler runnable to a dispatch queue in response to the events.
createSource(SelectableChannel, int, DispatchQueue) - Method in interface org.fusesource.hawtdispatch.Dispatcher
Creates a new DispatchSource to monitor SelectableChannel objects and automatically submit a handler runnable to a dispatch queue in response to events.
createSource(EventAggregator<Event, MergedEvent>, DispatchQueue) - Method in interface org.fusesource.hawtdispatch.Dispatcher
Creates a new CustomDispatchSource to monitor events merged into the dispatch source and automatically submit a handler runnable to a dispatch queue in response to the events.
createTransport(URI) - Static method in class org.fusesource.hawtdispatch.transport.SslTransport
Allows subclasses of TcpTransportFactory to create custom instances of TcpTransport.
createTransport() - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
createTransport() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
createTransport() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
createTransportServer(URI) - Static method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
CustomDispatchSource<Event,MergedEvent> - Interface in org.fusesource.hawtdispatch
A dispatch source that is used to coalesce multiple application generated events for later processing by the dispatch source event handler.

D

DEFAULT - Static variable in class org.fusesource.hawtdispatch.Dispatch
 
DefaultTransportListener - Class in org.fusesource.hawtdispatch.transport
DefaultTransportListener() - Constructor for class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
dequeued - Variable in class org.fusesource.hawtdispatch.Metrics
The number of runnable tasks that have been removed from the queue and executed.
directReadBuffer - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
Dispatch - Class in org.fusesource.hawtdispatch
The Dispatch class is used to get or create dispatch objects such as global queues, thread queues, serial queues, or dispatch sources.
Dispatch() - Constructor for class org.fusesource.hawtdispatch.Dispatch
 
Dispatcher - Interface in org.fusesource.hawtdispatch
The Dispatcher interface is used to get or create dispatch objects such as global queues, thread queues, serial queues, or dispatch sources.
DISPATCHER_OBJECT_NAME - Static variable in class org.fusesource.hawtdispatch.jmx.JmxService
 
DispatchObject - Interface in org.fusesource.hawtdispatch
Implemented by dispatch objects that can be configured with a target queue that it uses for executing the object's asynchronous tasks.
DispatchPriority - Enum in org.fusesource.hawtdispatch
Defines the supported global/concurrent queue priorities.
DispatchQueue - Interface in org.fusesource.hawtdispatch
Dispatch queues are lightweight objects to which runnable objects may be submitted for asynchronous execution and therefore are Executor objects.
dispatchQueue - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
dispatchQueue - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
dispatchQueue - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
DispatchQueue.QueueType - Enum in org.fusesource.hawtdispatch
Defines the types of dispatch queues supported by the system.
DispatchQueueProxy - Class in org.fusesource.hawtdispatch
This class creates proxy objects that allow you to easily service all method calls to an interface via a DispatchQueue.
DispatchQueueProxy() - Constructor for class org.fusesource.hawtdispatch.DispatchQueueProxy
 
DispatchSource - Interface in org.fusesource.hawtdispatch
A dispatch source is used to monitor low-level system objects and automatically submit a handler runnable to a dispatch queue in response to events.
dispose() - Method in class org.fusesource.hawtdispatch.BaseRetained
This method will be called once the release retained reaches zero.
drainInbound() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
drainInbound() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
drainInbound() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
drainInbound() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
drainInbound() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
drainInbound() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
drainOutboundSource - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
drainOutboundSource - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
durationNS - Variable in class org.fusesource.hawtdispatch.Metrics
How long the metrics gathered

E

encode(Object) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
enqueued - Variable in class org.fusesource.hawtdispatch.Metrics
The number of runnable tasks queued.
equals(Object) - Method in class org.fusesource.hawtdispatch.TaskWrapper
 
EventAggregator<Event,MergedEvent> - Interface in org.fusesource.hawtdispatch
The EventAggregator interface is used by the CustomDispatchSource objects to handle coalescing data before passing it to the application.
EventAggregators - Class in org.fusesource.hawtdispatch
 
EventAggregators() - Constructor for class org.fusesource.hawtdispatch.EventAggregators
 
execute(Runnable) - Method in class org.fusesource.hawtdispatch.AggregatingExecutor
 
execute(Runnable) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Submits a runnable for asynchronous execution on a dispatch queue.
execute(Task) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Submits a task for asynchronous execution on a dispatch queue.
executeAfter(long, TimeUnit, Runnable) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Schedule a runnable for execution on a given queue at a specified time.
executeAfter(long, TimeUnit, Task) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Schedule a task for execution on a given queue at a specified time.

F

flush() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
flush() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
flush() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
Attempts to complete the previous write which did not complete.
flush() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
flush() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
flush() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
flush() - Method in interface org.fusesource.hawtdispatch.transport.Transport
Forces a flush of any output buffers.
flush() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
flush() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
flushNextWriteBuffer() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
full() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
full() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
full() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
Is the codec's buffer full?
full() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
full() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
full() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
full() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
full() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 

G

getBacklog() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getBlockingExecutor() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getBlockingExecutor() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getBlockingExecutor() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
getBoundAddress() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
getBoundAddress() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getBoundAddress() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
getBoundAddress() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
getBufferPool(int) - Method in class org.fusesource.hawtdispatch.util.BufferPools
 
getBufferPools() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getBufferSize() - Method in class org.fusesource.hawtdispatch.util.BufferPool
 
getClientAuth() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getClientAuth() - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
getCurrentQueue() - Static method in class org.fusesource.hawtdispatch.Dispatch
Returns the queue on which the currently executing runnable is running.
getCurrentQueue() - Method in interface org.fusesource.hawtdispatch.Dispatcher
Returns the queue on which the currently executing runnable is running.
getCurrentThreadQueue() - Static method in class org.fusesource.hawtdispatch.Dispatch
 
getCurrentThreadQueue() - Method in interface org.fusesource.hawtdispatch.Dispatcher
 
getData() - Method in interface org.fusesource.hawtdispatch.CustomDispatchSource
Returns pending data for the dispatch source.
getDatagramChannel() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getDescription(MBeanAttributeInfo) - Method in class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
getDescription(MBeanOperationInfo) - Method in class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
getDisabledCypherSuites() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getDisabledCypherSuites() - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getDispatchQueue() - Method in interface org.fusesource.hawtdispatch.transport.Transport
Returns the dispatch queue used by the transport
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getDispatchQueue() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
Returns the dispatch queue used by the transport
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getDispatchQueue() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
getDisposer() - Method in class org.fusesource.hawtdispatch.BaseRetained
 
getEnabledCypherSuites() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getGlobalQueue() - Static method in class org.fusesource.hawtdispatch.Dispatch
Returns the global concurrent queue of default priority.
getGlobalQueue(DispatchPriority) - Static method in class org.fusesource.hawtdispatch.Dispatch
Returns a well-known global concurrent queue of a given priority level.
getGlobalQueue() - Method in interface org.fusesource.hawtdispatch.Dispatcher
Returns the global concurrent queue of default priority.
getGlobalQueue(DispatchPriority) - Method in interface org.fusesource.hawtdispatch.Dispatcher
Returns a well-known global concurrent queue of a given priority level.
getInitialReadCheckDelay() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getInitialWriteCheckDelay() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getLabel() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Returns the label of the queue.
getLastReadSize() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getLastReadSize() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getLastReadSize() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getLastWriteSize() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getLastWriteSize() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getLastWriteSize() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getLocalAddress() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getLocalAddress() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getLocalAddress() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getLocalAddress() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getLocalAddress() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getLocalHost() - Static method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getMaxReadRate() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getMaxWriteRate() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getMetrics() - Method in class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
getMetrics() - Method in interface org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcherMBean
 
getName() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
getNext() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getNext() - Method in interface org.fusesource.hawtdispatch.transport.WrappingProtocolCodec
 
getOnDead() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getOnKeepAlive() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getParameterName(MBeanOperationInfo, MBeanParameterInfo, int) - Method in class org.fusesource.hawtdispatch.jmx.AnnotatedMBean
getPeerX509Certificates() - Method in interface org.fusesource.hawtdispatch.transport.SecuredSession
Gets the X509Certificate associated withe the peer.
getPeerX509Certificates() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getPeerX509Certificates() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getProfile() - Method in class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
getProfile() - Method in interface org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcherMBean
 
getProtocolCodec() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getProtocolCodec() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getProtocolCodec() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getProtocolCodec() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getProtocolCodec() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getQueueType() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
 
getReadBufferSize() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getReadBufferSize() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getReadBufferSize() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getReadChannel() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getReadChannel() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getReadChannel() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getReadChannel() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getReadChannel() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getReadChannel() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getReadCounter() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getReadCounter() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getReadCounter() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getReadCounter() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getReadInterval() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getReceiveBufferSize() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getReceiveBufferSize() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getReceiveBufferSize() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getRemoteAddress() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getRemoteAddress() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getRemoteAddress() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getRemoteAddress() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getRemoteAddress() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getSendBufferSize() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getSendBufferSize() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getSendBufferSize() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getServers() - Static method in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
getServiceState() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
getSocketAddress() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
getSocketAddress() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
getSocketAddress() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
getSocketAddress() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
getSocketChannel() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getSSLContext() - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
getSSLSession() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getSSLSession() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getTargetQueue() - Method in interface org.fusesource.hawtdispatch.DispatchObject
Gets the target queue for this object.
getThreadQueues(DispatchPriority) - Static method in class org.fusesource.hawtdispatch.Dispatch
 
getThreadQueues(DispatchPriority) - Method in interface org.fusesource.hawtdispatch.Dispatcher
 
getTimeUnit() - Method in class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
getTimeUnit() - Method in interface org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcherMBean
 
getTrafficClass() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getTrafficClass() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getTransport() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
getTransportListener() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getTransportListener() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getTransportListener() - Method in interface org.fusesource.hawtdispatch.transport.Transport
Returns the current transport listener
getTransportListener() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getTransportListener() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getWriteBufferSize() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getWriteBufferSize() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getWriteBufferSize() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getWriteChannel() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getWriteChannel() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
getWriteChannel() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
getWriteChannel() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
getWriteChannel() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
getWriteChannel() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
getWriteCounter() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
getWriteCounter() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
getWriteCounter() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
getWriteCounter() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
getWriteInterval() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 

H

handleSocket(SocketChannel) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
handshake() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
handshake() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
hashCode() - Method in class org.fusesource.hawtdispatch.TaskWrapper
 
hashSet() - Static method in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces object data obtained via calls to CustomDispatchSource.merge(Object) into a hash set.
HeartBeatMonitor - Class in org.fusesource.hawtdispatch.transport
A HeartBeatMonitor can be used to watch the read and write activity of a transport and raise events when the write side or read side has been idle too long.
HeartBeatMonitor() - Constructor for class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
HIGH - Static variable in class org.fusesource.hawtdispatch.Dispatch
 

I

initialDecodeAction() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
initializeChannel() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
initializeChannel() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
initializeChannel() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
initializeCodec() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
initializeCodec() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
initializeEngine() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
INTEGER_ADD - Static variable in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces integer data obtained via calls to CustomDispatchSource.merge(Object).
INTEGER_OR - Static variable in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces integer data obtained via calls to CustomDispatchSource.merge(Object).
IPTOS_LOWCOST - Static variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
IPTOS_LOWCOST - Static variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
IPTOS_LOWDELAY - Static variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
IPTOS_LOWDELAY - Static variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
IPTOS_RELIABILITY - Static variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
IPTOS_RELIABILITY - Static variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
IPTOS_THROUGHPUT - Static variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
IPTOS_THROUGHPUT - Static variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
isCanceled() - Method in interface org.fusesource.hawtdispatch.DispatchSource
 
isClosed() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
isClosed() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
isClosed() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
isClosed() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
isClosed() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
isCloseOnCancel() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
isConnected() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
isConnected() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
isConnected() - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
isConnected() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
isConnected() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
isEmpty() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
isExecuting() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Returns true if this dispatch queue is executing the caller.
isKeepAlive() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
isMarshal() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
isMarshal() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
isOpen() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
isOpen() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
isOpen() - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
isStarted() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase.State
 
isStarting() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase.STARTING
 
isStarting() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase.State
 
isSuspended() - Method in interface org.fusesource.hawtdispatch.Suspendable
 
isTrace() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
isUseLocalHost() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
isUseLocalHost() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 

J

JmxDispatcher(Dispatcher) - Constructor for class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
JmxService - Class in org.fusesource.hawtdispatch.jmx
 
JmxService() - Constructor for class org.fusesource.hawtdispatch.jmx.JmxService
 
JmxService.JmxDispatcher - Class in org.fusesource.hawtdispatch.jmx
 
JmxService.JmxDispatcherMBean - Interface in org.fusesource.hawtdispatch.jmx
 

K

keyManagers - Variable in class org.fusesource.hawtdispatch.transport.SslTransportServer
 

L

lastReadIoSize - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
lastWriteIoSize - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
linkedList() - Static method in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces object data obtained via calls to CustomDispatchSource.merge(Object) into a linked list.
listener - Variable in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
listener - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
listener - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
listener - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
localLocation - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
localLocation - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
LONG_ADD - Static variable in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces long data obtained via calls to CustomDispatchSource.merge(Object).
LONG_OR - Static variable in class org.fusesource.hawtdispatch.EventAggregators
An EventAggregator that coalesces long data obtained via calls to CustomDispatchSource.merge(Object).
lookup(String) - Static method in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
LOW - Static variable in class org.fusesource.hawtdispatch.Dispatch
 

M

marshal - Variable in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
maxPoolSizePerThread() - Method in class org.fusesource.hawtdispatch.util.ThreadLocalPool
 
maxRunTimeNS - Variable in class org.fusesource.hawtdispatch.Metrics
The long amount of time a runnable task spent executing in nanoseconds.
maxWaitTimeNS - Variable in class org.fusesource.hawtdispatch.Metrics
The longest amount of time at runnable task spent waiting in the queue.
MBeanInfo - Annotation Type in org.fusesource.hawtdispatch.jmx
 
merge(Event) - Method in interface org.fusesource.hawtdispatch.CustomDispatchSource
Merges data into a dispatch source and submits its event handler runnable to its target queue.
mergeEvent(MergedEvent, Event) - Method in interface org.fusesource.hawtdispatch.EventAggregator
Merge the given event with the previous event values.
mergeEvents(MergedEvent, MergedEvent) - Method in interface org.fusesource.hawtdispatch.EventAggregator
Merge the given events with the previous event values.
metrics() - Static method in class org.fusesource.hawtdispatch.Dispatch
Used to get profiling metrics for all the queues currently being profiled.
metrics() - Method in interface org.fusesource.hawtdispatch.Dispatcher
Used to get profiling metrics for all the queues currently being profiled.
metrics() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Returns the usage metrics of this queue.
Metrics - Class in org.fusesource.hawtdispatch
Metrics() - Constructor for class org.fusesource.hawtdispatch.Metrics
 

N

name - Variable in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
nextDecodeAction - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
nextWriteBuffer - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
NOOP - Static variable in class org.fusesource.hawtdispatch.Dispatch
A Runnable task that does nothing.

O

objectName(HawtDispatcher) - Static method in class org.fusesource.hawtdispatch.jmx.JmxService
 
offer(Object) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
offer(Object) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
offer(Object) - Method in interface org.fusesource.hawtdispatch.transport.Transport
A one way asynchronous send of a command.
offer(Object) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
offer(Object) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
onAccept(Transport) - Method in interface org.fusesource.hawtdispatch.transport.TransportServerListener
 
onAcceptError(Exception) - Method in interface org.fusesource.hawtdispatch.transport.TransportServerListener
 
onBufferFlushed(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
Called when a buffer is flushed out.
onConnected() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
onConnected() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
onConnected() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
onRefill() - Method in class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
onRefill() - Method in interface org.fusesource.hawtdispatch.transport.TransportListener
transport can now accept more commands for transmission.
onTransportCommand(Object) - Method in class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
onTransportCommand(Object) - Method in interface org.fusesource.hawtdispatch.transport.TransportListener
called to process a command
onTransportConnected() - Method in class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
onTransportConnected() - Method in interface org.fusesource.hawtdispatch.transport.TransportListener
The transport has been connected.
onTransportDisconnected() - Method in class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
onTransportDisconnected() - Method in interface org.fusesource.hawtdispatch.transport.TransportListener
The transport has been disconnected.
onTransportFailure(IOException) - Method in class org.fusesource.hawtdispatch.transport.DefaultTransportListener
 
onTransportFailure(IOException) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
onTransportFailure(IOException) - Method in interface org.fusesource.hawtdispatch.transport.TransportListener
An unrecoverable exception has occured on the transport
onTransportFailure(IOException) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
OrderedEventAggregator<Event,MergedEvent> - Interface in org.fusesource.hawtdispatch
This class should be implemented by Aggregator classes which depend on FIFO ordering of events from the point of view of the serial queue which merges events into it.
org.fusesource.hawtdispatch - package org.fusesource.hawtdispatch
HawtDispatch HawtDispatch is an abstract model for expressing concurrency via simple but powerful API.
org.fusesource.hawtdispatch.jmx - package org.fusesource.hawtdispatch.jmx
 
org.fusesource.hawtdispatch.transport - package org.fusesource.hawtdispatch.transport
 
org.fusesource.hawtdispatch.util - package org.fusesource.hawtdispatch.util
 

P

peekBytes(int) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
PipeTransport - Class in org.fusesource.hawtdispatch.transport
 
PipeTransport(PipeTransportServer) - Constructor for class org.fusesource.hawtdispatch.transport.PipeTransport
 
PipeTransportRegistry - Class in org.fusesource.hawtdispatch.transport
 
PipeTransportRegistry() - Constructor for class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
PipeTransportServer - Class in org.fusesource.hawtdispatch.transport
 
PipeTransportServer() - Constructor for class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
profile(boolean) - Static method in class org.fusesource.hawtdispatch.Dispatch
If enabled then it enables profiling on the global queues and any newly created queues.
profile(boolean) - Method in interface org.fusesource.hawtdispatch.Dispatcher
If enabled then it enables profiling on the global queues and any newly created queues.
profile() - Method in interface org.fusesource.hawtdispatch.Dispatcher
 
profile(boolean) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Enables or disables profiler metric tracking on the queue.
profile() - Method in interface org.fusesource.hawtdispatch.DispatchQueue
 
protocol(String) - Static method in class org.fusesource.hawtdispatch.transport.SslTransport
Maps uri schemes to a protocol algorithm names.
protocol - Variable in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
protocol(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
ProtocolCodec - Interface in org.fusesource.hawtdispatch.transport
Interface to encode and decode commands in and out of a a non blocking channel.
ProtocolCodec.BufferState - Enum in org.fusesource.hawtdispatch.transport
 

Q

queue - Variable in class org.fusesource.hawtdispatch.Metrics
The dispatch queue associated with the metrics collected.

R

rateLimitingChannel - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
read() - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
read() - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
Non-blocking channel based decoding.
read() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
read(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
read(ByteBuffer[], int, int) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
read(ByteBuffer[]) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
read(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
read(ByteBuffer[], int, int) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
read(ByteBuffer[]) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
readBuffer - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readBufferPool - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readBufferSize - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readBytes(int) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readChannel - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readCounter - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readDirect(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readEnd - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readStart - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readUntil(Byte) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readUntil(Byte, int) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
readUntil(Byte, int, String) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
receiveBufferSize - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
register(HawtDispatcher) - Static method in class org.fusesource.hawtdispatch.jmx.JmxService
 
release() - Method in class org.fusesource.hawtdispatch.BaseRetained
Decrement the reference count of this object.
release(int) - Method in class org.fusesource.hawtdispatch.BaseRetained
Decrements the reference count by n.
release() - Method in interface org.fusesource.hawtdispatch.Retained
Decrement the reference count of this object.
remoteLocation - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
remoteLocation - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
resolveHostName(String) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
resolveHostName(String) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
restart() - Static method in class org.fusesource.hawtdispatch.Dispatch
Restart default dispatcher instance.
restart() - Method in interface org.fusesource.hawtdispatch.Dispatcher
Restart this dispatcher instance.
resume() - Method in class org.fusesource.hawtdispatch.AggregatingExecutor
 
resume() - Method in interface org.fusesource.hawtdispatch.Suspendable
Resumes the invocation of tasks on a dispatch object.
resume() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
resume() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
resume() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
resume accepting new transports
resume() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
resumeRead() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
resumeRead() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
resumeRead() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
resumeRead() - Method in interface org.fusesource.hawtdispatch.transport.Transport
resume delivery of commands.
resumeRead() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
resumeRead() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
resumeWrite() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
resumeWrite() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
retain() - Method in class org.fusesource.hawtdispatch.BaseRetained
Increment the reference count of this object.
retain() - Method in interface org.fusesource.hawtdispatch.Retained
Increment the reference count of this object.
retained() - Method in class org.fusesource.hawtdispatch.BaseRetained
 
Retained - Interface in org.fusesource.hawtdispatch
Implemented by dispatch objects which use a reference counted life cycle.
retained() - Method in interface org.fusesource.hawtdispatch.Retained
 
run() - Method in class org.fusesource.hawtdispatch.Task
 
run() - Method in class org.fusesource.hawtdispatch.TaskWrapper
 

S

SecuredSession - Interface in org.fusesource.hawtdispatch.transport
sendBufferSize - Variable in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
server(SslProtocolCodec.ClientAuth) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
servers - Static variable in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
ServiceBase - Class in org.fusesource.hawtdispatch.transport
The BaseService provides helpers for dealing async service state.
ServiceBase() - Constructor for class org.fusesource.hawtdispatch.transport.ServiceBase
 
ServiceBase.STARTING - Class in org.fusesource.hawtdispatch.transport
 
ServiceBase.State - Class in org.fusesource.hawtdispatch.transport
 
ServiceBase.STOPPING - Class in org.fusesource.hawtdispatch.transport
 
setBacklog(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setBlockingExecutor(Executor) - Method in interface org.fusesource.hawtdispatch.transport.Transport
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
setBlockingExecutor(Executor) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setBlockingExecutor(Executor) - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
setBufferPools(BufferPools) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
setCancelHandler(Runnable) - Method in interface org.fusesource.hawtdispatch.DispatchSource
Sets the cancellation handler runnable for the given dispatch source.
setCancelHandler(Task) - Method in interface org.fusesource.hawtdispatch.DispatchSource
Sets the cancellation handler task for the given dispatch source.
setClientAuth(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
setClientAuth(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
setCloseOnCancel(boolean) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setConnectURI(String) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setDisabledCypherSuites(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
setDisabledCypherSuites(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setDispatchQueue(DispatchQueue) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Sets the dispatch queue used by the transport
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
setDispatchQueue(DispatchQueue) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
Sets the dispatch queue used by the transport
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setDispatchQueue(DispatchQueue) - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
setDisposer(Runnable) - Method in class org.fusesource.hawtdispatch.BaseRetained
Adds a disposer runnable that is executed once the object is disposed.
setDisposer(Task) - Method in class org.fusesource.hawtdispatch.BaseRetained
Adds a disposer runnable that is executed once the object is disposed.
setEnabledCypherSuites(String) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
setEventHandler(Runnable) - Method in interface org.fusesource.hawtdispatch.DispatchSource
Sets the event handler runnable of this dispatch source.
setEventHandler(Task) - Method in interface org.fusesource.hawtdispatch.DispatchSource
Sets the event handler task of this dispatch source.
setInitialReadCheckDelay(long) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setInitialWriteCheckDelay(long) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setKeepAlive(boolean) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setKeyManagers(KeyManager[]) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
setLabel(String) - Method in interface org.fusesource.hawtdispatch.DispatchQueue
Sets the label of the queue.
setMarshal(boolean) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setMarshal(boolean) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setMaxReadRate(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setMaxWriteRate(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setName(String) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setName(String) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setNext(ProtocolCodec) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
setNext(ProtocolCodec) - Method in interface org.fusesource.hawtdispatch.transport.WrappingProtocolCodec
 
setOnDead(Task) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setOnKeepAlive(Task) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setProfile(boolean) - Method in class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
setProfile(boolean) - Method in interface org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcherMBean
 
setProtocolCodec(ProtocolCodec) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setProtocolCodec(ProtocolCodec) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setProtocolCodec(ProtocolCodec) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Sets the protocol codec for the transport
setProtocolCodec(ProtocolCodec) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
setProtocolCodec(ProtocolCodec) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setReadInterval(long) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setReceiveBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setReceiveBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setReceiveBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setRemoteAddress(String) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setSendBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setSendBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setSendBufferSize(int) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setSSLContext(SSLContext) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
setSSLContext(SSLContext) - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
setSSLContext(SSLContext) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
setTargetQueue(DispatchQueue) - Method in interface org.fusesource.hawtdispatch.DispatchObject
Sets the target queue for this object.
setTimeUnit(String) - Method in class org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcher
 
setTimeUnit(String) - Method in interface org.fusesource.hawtdispatch.jmx.JmxService.JmxDispatcherMBean
 
setTrace(boolean) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setTrafficClass(int) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setTrafficClass(int) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setTransport(Transport) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
setTransport(Transport) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
setTransport(Transport) - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
 
setTransport(Transport) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
setTransportListener(TransportListener) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
setTransportListener(TransportListener) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
setTransportListener(TransportListener) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Registers an inbound command listener
setTransportListener(TransportListener) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
setTransportListener(TransportListener) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
setTransportServerListener(TransportServerListener) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
setTransportServerListener(TransportServerListener) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
setTransportServerListener(TransportServerListener) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
Registers an TransportAcceptListener which is notified of accepted channels.
setTransportServerListener(TransportServerListener) - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
setTrustManagers(TrustManager[]) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
setUseLocalHost(boolean) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
Sets whether 'localhost' or the actual local host name should be used to make local connections.
setUseLocalHost(boolean) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
Sets whether 'localhost' or the actual local host name should be used to make local connections.
setWriteInterval(long) - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
shutdown() - Static method in class org.fusesource.hawtdispatch.Dispatch
Shutdown default dispatcher instance.
shutdown() - Method in interface org.fusesource.hawtdispatch.Dispatcher
Shutdown this dispatcher instance.
ShutdownException - Exception in org.fusesource.hawtdispatch
This exception is thrown when you attempt to use a dispatch object after the dispatch system has been shutdown in OSGi.
ShutdownException() - Constructor for exception org.fusesource.hawtdispatch.ShutdownException
 
ShutdownException(Throwable) - Constructor for exception org.fusesource.hawtdispatch.ShutdownException
 
ShutdownException(String, Throwable) - Constructor for exception org.fusesource.hawtdispatch.ShutdownException
 
ShutdownException(String) - Constructor for exception org.fusesource.hawtdispatch.ShutdownException
 
socket() - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
socketState - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
socketState - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 
SSLChannel() - Constructor for class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
sslContext - Variable in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
SslProtocolCodec - Class in org.fusesource.hawtdispatch.transport
Implements the SSL protocol as a WrappingProtocolCodec.
SslProtocolCodec() - Constructor for class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
SslProtocolCodec.ClientAuth - Enum in org.fusesource.hawtdispatch.transport
 
SslProtocolCodec.SSLReadChannel - Class in org.fusesource.hawtdispatch.transport
 
SslProtocolCodec.SSLWriteChannel - Class in org.fusesource.hawtdispatch.transport
 
SSLReadChannel() - Constructor for class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLReadChannel
 
SslTransport - Class in org.fusesource.hawtdispatch.transport
An SSL Transport for secure communications.
SslTransport() - Constructor for class org.fusesource.hawtdispatch.transport.SslTransport
 
SslTransport.SSLChannel - Class in org.fusesource.hawtdispatch.transport
 
SslTransportServer - Class in org.fusesource.hawtdispatch.transport
 
SslTransportServer(URI) - Constructor for class org.fusesource.hawtdispatch.transport.SslTransportServer
 
SSLWriteChannel() - Constructor for class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
start() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
start(Runnable) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
Deprecated.
start(Task) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
start(Runnable) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
Deprecated.
start(Task) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
start(Runnable) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
start(Task) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
start(Task) - Method in class org.fusesource.hawtdispatch.transport.SslTransportServer
 
start(Runnable) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
Deprecated.
start(Task) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
start(Runnable) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Starts the service.
start(Task) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Starts the service.
start(Runnable) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
start(Task) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
start(Task) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
Starts the service.
start(Runnable) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
STARTED - Static variable in class org.fusesource.hawtdispatch.transport.ServiceBase
 
STARTING() - Constructor for class org.fusesource.hawtdispatch.transport.ServiceBase.STARTING
 
State() - Constructor for class org.fusesource.hawtdispatch.transport.ServiceBase.State
 
stop() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
stop(Runnable) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
Deprecated.
stop(Task) - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
stop(Runnable) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
Deprecated.
stop(Task) - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
stop(Runnable) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
stop(Task) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
stop(Runnable) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
Deprecated.
stop(Task) - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
stop(Runnable) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Stops the service.
stop(Task) - Method in interface org.fusesource.hawtdispatch.transport.Transport
Stops the service.
stop(Runnable) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
stop(Task) - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
stop(Task) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
Stops the service.
stop(Runnable) - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
 
STOPPED - Static variable in class org.fusesource.hawtdispatch.transport.ServiceBase
 
STOPPING() - Constructor for class org.fusesource.hawtdispatch.transport.ServiceBase.STOPPING
 
suspend() - Method in class org.fusesource.hawtdispatch.AggregatingExecutor
 
suspend() - Method in interface org.fusesource.hawtdispatch.Suspendable
Suspends the invocation of tasks on a dispatch object.
suspend() - Method in class org.fusesource.hawtdispatch.transport.PipeTransportServer
 
suspend() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
suspend() - Method in interface org.fusesource.hawtdispatch.transport.TransportServer
suspend accepting new transports
suspend() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
Suspendable - Interface in org.fusesource.hawtdispatch
Implemented by dispatch objects which can suspend the execution of dispatch tasks.
suspendRead() - Method in class org.fusesource.hawtdispatch.transport.HeartBeatMonitor
 
suspendRead() - Method in class org.fusesource.hawtdispatch.transport.PipeTransport
 
suspendRead() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
suspendRead() - Method in interface org.fusesource.hawtdispatch.transport.Transport
suspend delivery of commands.
suspendRead() - Method in class org.fusesource.hawtdispatch.transport.TransportFilter
 
suspendRead() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
suspendWrite() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
suspendWrite() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 

T

Task - Class in org.fusesource.hawtdispatch
We prefer the use of Task over Runnable since the JVM can more efficiently invoke methods of an abstract class than a interface.
Task() - Constructor for class org.fusesource.hawtdispatch.Task
 
TaskWrapper - Class in org.fusesource.hawtdispatch
TaskWrapper(Runnable) - Constructor for class org.fusesource.hawtdispatch.TaskWrapper
 
TcpTransport - Class in org.fusesource.hawtdispatch.transport
An implementation of the Transport interface using raw tcp/ip
TcpTransport() - Constructor for class org.fusesource.hawtdispatch.transport.TcpTransport
 
TcpTransportServer - Class in org.fusesource.hawtdispatch.transport
A TCP based implementation of TransportServer
TcpTransportServer(URI) - Constructor for class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
ThreadLocalPool<T> - Class in org.fusesource.hawtdispatch.util
ThreadLocalPool() - Constructor for class org.fusesource.hawtdispatch.util.ThreadLocalPool
 
toString() - Method in class org.fusesource.hawtdispatch.Metrics
 
toString() - Method in class org.fusesource.hawtdispatch.TaskWrapper
 
toString() - Method in class org.fusesource.hawtdispatch.transport.ServiceBase.State
 
toString() - Method in class org.fusesource.hawtdispatch.transport.TcpTransportServer
 
toString() - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
totalRunTimeNS - Variable in class org.fusesource.hawtdispatch.Metrics
The sum of all the time spent executing tasks in nanoseconds.
totalWaitTimeNS - Variable in class org.fusesource.hawtdispatch.Metrics
The sum of all the time that tasks spent waiting in the queue in nanoseconds.
Transport - Interface in org.fusesource.hawtdispatch.transport
Represents an abstract connection.
TransportFilter - Class in org.fusesource.hawtdispatch.transport
 
TransportFilter(Transport) - Constructor for class org.fusesource.hawtdispatch.transport.TransportFilter
 
transportFlush() - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
transportFlush() - Method in class org.fusesource.hawtdispatch.transport.SslTransport
 
transportFlush() - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
transportFlush() - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
TransportListener - Interface in org.fusesource.hawtdispatch.transport
An asynchronous listener of commands
TransportServer - Interface in org.fusesource.hawtdispatch.transport
A TransportServer asynchronously accepts Transport objects and then delivers those objects to a TransportAcceptListener.
TransportServerListener - Interface in org.fusesource.hawtdispatch.transport
Implemented by object that need to get injected by

U

UdpTransport - Class in org.fusesource.hawtdispatch.transport
UdpTransport() - Constructor for class org.fusesource.hawtdispatch.transport.UdpTransport
 
UdpTransportServer - Class in org.fusesource.hawtdispatch.transport
UdpTransportServer(URI) - Constructor for class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
unbind(PipeTransportServer) - Static method in class org.fusesource.hawtdispatch.transport.PipeTransportRegistry
 
unread(byte[]) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
unread(byte[]) - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
Pushes back a buffer as being unread.
unread(byte[]) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
unregister(HawtDispatcher) - Static method in class org.fusesource.hawtdispatch.jmx.JmxService
 
useLocalHost - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
useLocalHost - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 

V

valueOf(String) - Static method in enum org.fusesource.hawtdispatch.DispatchPriority
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.fusesource.hawtdispatch.DispatchQueue.QueueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.fusesource.hawtdispatch.transport.ProtocolCodec.BufferState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.fusesource.hawtdispatch.transport.SslProtocolCodec.ClientAuth
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.fusesource.hawtdispatch.DispatchPriority
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.fusesource.hawtdispatch.DispatchQueue.QueueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.fusesource.hawtdispatch.transport.ProtocolCodec.BufferState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.fusesource.hawtdispatch.transport.SslProtocolCodec.ClientAuth
Returns an array containing the constants of this enum type, in the order they are declared.

W

WrappingProtocolCodec - Interface in org.fusesource.hawtdispatch.transport
Interface of protocol codecs that wrap other protocol codecs.
write(Object) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
write(Object) - Method in interface org.fusesource.hawtdispatch.transport.ProtocolCodec
Non-blocking channel based encoding.
write(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
write(ByteBuffer[], int, int) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
write(ByteBuffer[]) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec.SSLWriteChannel
 
write(Object) - Method in class org.fusesource.hawtdispatch.transport.SslProtocolCodec
 
write(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
write(ByteBuffer[], int, int) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
write(ByteBuffer[]) - Method in class org.fusesource.hawtdispatch.transport.SslTransport.SSLChannel
 
writeBuffer - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
writeBufferPool - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
writeBufferSize - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
writeChannel - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
writeCounter - Variable in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 
writeDirect(ByteBuffer) - Method in class org.fusesource.hawtdispatch.transport.AbstractProtocolCodec
 

Y

yieldSource - Variable in class org.fusesource.hawtdispatch.transport.TcpTransport
 
yieldSource - Variable in class org.fusesource.hawtdispatch.transport.UdpTransport
 

_

_serviceState - Variable in class org.fusesource.hawtdispatch.transport.ServiceBase
 
_start(Task) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
_start(Task) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
_start(Task) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
_start(Task) - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
_stop(Task) - Method in class org.fusesource.hawtdispatch.transport.ServiceBase
 
_stop(Task) - Method in class org.fusesource.hawtdispatch.transport.TcpTransport
 
_stop(Task) - Method in class org.fusesource.hawtdispatch.transport.UdpTransport
 
_stop(Task) - Method in class org.fusesource.hawtdispatch.transport.UdpTransportServer
 
A B C D E F G H I J K L M N O P Q R S T U V W Y _ 
Skip navigation links

Copyright © 2010–2017 FuseSource, Corp.. All rights reserved.