|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
IoAcceptor.AbstractIoAcceptor.
IoBuffer.IoConnector.AbstractIoConnector.
IoServices.AbstractIoService.
IoSession.IoSessionConfig.IoAcceptor for datagram transport (UDP/IP).AbstractPollingIoAcceptor.
AbstractPollingIoAcceptor.
AbstractPollingIoAcceptor.
AbstractPollingIoAcceptor.
AbstractPollingIoConnector.
AbstractPollingIoConnector.
AbstractPollingIoConnector.
AbstractPollingIoConnector.
IoProcessor which helps
transport developers to write an IoProcessor easily.AbstractPollingIoProcessor with the given Executor
for handling I/Os events.
PropertyAccessor for MINA constructs.PropertyEditor.ProtocolDecoderOutput based on queue.ProtocolEncoderOutput based on queue.StateContext which uses a Map to store the
attributes.StateContextLookup implementation.StateContextFactory
to create StateContext objects.
Transition implementation.State
for the specified Event id.
State as next state
and for the specified Event id.
IoSession
associated with the given IoProcessor
IoSession
associated with the given IoProcessor
session to the I/O processor so that
the I/O processor starts to perform any I/O operations related
with the session.
session to the I/O processor so that
the I/O processor starts to perform any I/O operations related
with the session.
baseName in this chain.
baseName in this chain.
IoEventType to profile
MessageHandler that receives the messages of
the specified type.
IoServiceListener that listens any events related with
this service.
IoServiceListener that listens any events related with
this service.
MessageHandler that handles the received messages of
the specified type.
MessageHandler that handles the sent messages of the
specified type.
Transition to this State with weight 0.
Transition to this State with the
specified weight.
Iterator for all the client sockets polled for connection.
Iterator for all the client sockets polled for connection.
Iterator for all the client sockets polled for connection.
Iterator for the list of IoSession polled by this
IoProcessor
MethodTransition if there are several
methods with the specifed name in the target object's class.AprSocketConnectorIoSession serving of base for APR based sessions.IoConnector for ABR based socket transport (TCP/IP).PropertyEditor which converts a String into
a one-dimensional array and vice versa.InputStream that reads the data from this buffer.
OutputStream that appends the data into this buffer.
Map or session attribute to search
fast while being debug-friendly by providing the string representation.TextLineDecoder.
IoFilter which blocks connections from blacklisted remote
address.TrustManagerFactory which creates
X509TrustManager trusting everything.PropertyEditor which converts a String into
a Character and vice versa.IdleStatus.READER_IDLE and IdleStatus.WRITER_IDLE.
Transition and lets the
State with the specified id handle the next Event.
Transition and lets the
State with the specified id handle the next Event.
Transition and lets the
State with the specified id handle the current Event.
Transition and lets the
State with the specified id handle the current Event.
Transition and tries to
find another Transition with higher weight or a Transition
of a parent State which can handle the current Event.
Transition and lets the
State with the specified id handle the next Event.
Transition and lets the
State with the specified id handle the current Event.
Transition and lets the
last recorded State handle the next Event.
Transition and lets the
last recorded State handle the current Event.
StateControl class.message to the specified sessions.
message to the specified sessions.
message to the specified sessions.
message to the specified sessions.
message to all the IoSessions
managed by this service.
message to all the IoSessions
managed by this service.
RuntimeException which is thrown when the data the IoBuffer
contains is corrupt.IoFilter implementation used to buffer outgoing WriteRequest almost
like what BufferedOutputStream does.bufferSize.Uses a default
instance of ConcurrentHashMap.
bufferSize.
PropertyEditor which converts a String into
an Byte and vice versa.IoBufferAllocator that caches the buffers which are likely to
be reused during auto-expansion of the buffers.IoHandler which executes an IoHandlerChain
on a messageReceived event.IoHandlerChain.
IoHandlerChain on a messageReceived event.
PropertyEditor which converts a String into
a Character and vice versa.PropertyEditor which converts a String into
a Character and vice versa.IoFutureListener that closes the IoSession which is
associated with the specified IoFuture.
ExceptionHandler that closes the session immediately.
IoFuture for asynchronous close requests.PropertyEditor which converts a String into
a Collection and vice versa.IoFuture of IoFutures.IoFilter which compresses all data using
JZlib.ConcurrentHashMap-backed Set.SocketAddress.
default remote address.
default
remote address and invokes the ioSessionInitializer when
the IoSession is created but before IoHandler.sessionCreated(IoSession)
is invoked.
ioSessionInitializer when the IoSession is created but before
IoHandler.sessionCreated(IoSession) is invoked.
ioSessionInitializer when the
IoSession is created but before IoHandler.sessionCreated(IoSession)
is invoked.
default remote address.
default
remote address and invokes the ioSessionInitializer when
the IoSession is created but before IoHandler.sessionCreated(IoSession)
is invoked.
ioSessionInitializer when the IoSession is created but before
IoHandler.sessionCreated(IoSession) is invoked.
ioSessionInitializer when the
IoSession is created but before IoHandler.sessionCreated(IoSession)
is invoked.
SocketAddress.
SocketAddress.
IoFuture for asynchronous connect requests.AbstractPollingIoConnector.ConnectionRequest for a given client socket handle
AbstractPollingIoConnector.ConnectionRequest for a given client socket handle
AbstractPollingIoConnector.ConnectionRequest for a given client socket handle
IoFilter which blocks connections from connecting
at a rate faster than the specified interval.DecodingState which consumes all bytes until a CRLF
has been encountered.DecodingState which consumes all bytes until a fixed (ASCII)
character is reached.DecodingState which consumes all received bytes until the session is
closed.DecodingState which consumes all bytes until a space (0x20) or tab
(0x09) character is reached.DecodingState which consumes all bytes until a fixed (ASCII)
character is reached.IoFilter with the
specified name.
IoFilter of the
specified filterType.
Map in which all operations that change the
Map are implemented by making a new copy of the underlying Map.StateContext.
Event from the specified method and method
arguments.
StateMachine from the specified handler object and
using a start state with id start.
StateMachine from the specified handler object and
using the State with the specified id as start state.
StateMachine from the specified handler objects and
using a start state with id start.
StateMachine from the specified handler objects and
using the State with the specified id as start state.
StateMachine.
StateMachine.
Map which stores messageId-Request
pairs whose Responses are not received yet.
Set which stores Request whose
Responses are not received yet.
DecodingState which decodes a single CRLF.ProtocolDecoder that cumulates the content of received
buffers to a cumulative buffer to help users implement decoders.IoAcceptor for datagram transport (UDP/IP).IoConnector for datagram transport (UDP/IP).IoSessionConfig for datagram transport type.PropertyEditor which converts a String into
a Date and vice versa.CumulativeProtocolDecoder.doDecode(IoSession, IoBuffer, ProtocolDecoderOutput).
DecodingStateMachine.ProtocolDecoder which uses a DecodingState to decode data.DecodingState
instance.
IoSession attribute used to store the
StateContext object.
CloseFuture.ConnectFuture.DatagramSessionConfig.EventFactory implementation.ExceptionMonitor implementation that logs uncaught
exceptions using Logger.IoEventSizeEstimator implementation.IoFilterChain that provides
all operations for developers who want to implement their own
transport layer once used with AbstractIoSession.IoFilterChainBuilder which is useful
in most cases.DefaultIoFilterChainBuilder.
IoFuture associated with
an IoSession.IoSession.
IoSessionDataStructureFactory implementation
that creates a new HashMap-based IoSessionAttributeMap
instance and a new synchronized CircularQueue instance per
IoSession.WriteFuture.SocketSessionConfig.StateContext implementation.StateContextFactory which creates DefaultStateContext
objects.TransportMetadata.WriteFuture.WriteRequest.WriteFuture.
WriteFuture.
IoHandler that demuxes messageReceived events
to the appropriate MessageHandler.MessageHandlers.
ProtocolCodecFactory that provides DemuxingProtocolEncoder
and DemuxingProtocolDecoder as a pair.ProtocolDecoder that demultiplexes incoming IoBuffer
decoding requests into an appropriate MessageDecoder.ProtocolEncoder that demultiplexes incoming message
encoding requests into an appropriate MessageEncoder.ReferenceCountingFilter when this filter
is not used by any IoFilterChain anymore, so you can destroy
shared resources.
IoAcceptor
implementation will be disposed.
IoConnector
implementation will be disposed.
IoConnector
implementation will be disposed.
IoAcceptor
implementation will be disposed.
IoConnector
implementation will be disposed.
Map created by
RequestResponseFilter.createRequestStore(IoSession).
Set created by
RequestResponseFilter.createUnrespondedRequestStore(IoSession).
IoProcessor for polling
the client connections
Transition.
PropertyEditor which converts a String into
an Double and vice versa.IoSession for unit-testing or non-network-use of
the classes that depends on IoSession.Set.
PropertyEditor which converts a String into
an Enum and vice versa.IoFilter implementation generating random bytes and PDU modification in
your communication streams.Event with the specified id and no arguments.
Event with the specified id and arguments.
Event arguments before the Event is passed
to the StateMachine and allows for the arguments to be modified.StateMachineProxyBuilder to create Event objects when
methods are invoked on the proxy.KeepAliveRequestTimeoutException.
IoHandler.exceptionCaught(IoSession,Throwable)
event.
IoHandler
implementation or by MINA.
IoHandler.exceptionCaught(IoSession,Throwable)
event.
session.
IoHandler
implementation or by MINA.
SingleSessionIoHandler.exceptionCaught(Throwable) method of the
handler assigned to this session.
DemuxingIoHandler forwards
exceptionCaught events to.IoHandlerCommand in the
IoHandlerChain.
Transition.
Executor to enforce a certain
thread model while allowing the events per session to be processed
simultaneously.OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
OrderedThreadPoolExecutor.
Executor.
Executor.
ConcurrentHashMap for the internal data structure.
ExpiringMap and will remove
elements that have passed the threshold.IoSessionRecycler with sessions that time out on inactivity.PropertyEditor which converts a String into
a File and vice versa.FileRegion to IoBuffer
objects and writes those buffers to the next filter.NUL (0x00).
NUL (0x00).
IoSession.close() method invocation.
IoSession.setTrafficMask(TrafficMask) method invocation.
IoSession.write(Object) method invocation.
IoSession.write(Object) method invocation.
Set of IoSessions that matches the query
from the specified sessions and returns the matches.
AbstractPollingIoConnector.select(int) call.
AbstractPollingIoConnector.select(int) call.
AbstractPollingIoConnector.select(int) call.
IoSession is closed.
CRLF.
IoSession is closed.
IoSession is closed.
IoSession is closed.
IoSession is closed.
CRLF.
IoSession is closed.
IoSession is closed.
IoSession is closed.
IoSession is closed.
int.
IoSession is closed.
short.
IoSession is closed.
byte.
IoSession is closed.
IoFutureListeners
related with event notifications to the specified session
and future.
IoHandler.exceptionCaught(IoSession, Throwable) event.
IoSession.close() event.
IoSession.setTrafficMask(TrafficMask) event.
IoSession.write(Object) event.
IoFilterChain.fireMessageReceived(Object) event.
IoHandler.sessionOpened(IoSession) event.
IoServiceListener.serviceActivated(IoService)
for all registered listeners.
IoServiceListener.serviceDeactivated(IoService)
for all registered listeners.
IoServiceListener.serviceIdle(IoService, IdleStatus)
for all registered listeners.
IoHandler.sessionClosed(IoSession) event.
IoHandler.sessionCreated(IoSession) event.
IoServiceListener.sessionCreated(IoSession) for all registered listeners.
IoServiceListener.sessionDestroyed(IoSession) for all registered listeners.
IoHandler.sessionIdle(IoSession, IdleStatus) event.
IoHandler.sessionOpened(IoSession) event.
DecodingState which consumes all received bytes until a configured
number of read bytes has been reached.PropertyEditor which converts a String into
an Float and vice versa.session.
session.
ProtocolDecoderOutput.write(Object) to
the next filter.
ProtocolEncoderOutput.write(Object) to
the session.
IoBufferAllocator implementations.
IoFilter with the specified name in this chain.
IoFilter with the specified filterType
in this chain.
IoFilterChain.Entrys this chain contains.
IoFilterChain.Entrys this chain contains.
Event.
IoSession.getAttribute(Object) instead.
nullif not found.
IoSessionAttributeMap which is going to be associated
with the specified session.
Set of currently available port numbers
(Integer).
Set of currently avaliable port numbers (Integer)
between the specified port range.
IoEventType
IdleStatus.BOTH_IDLE.
IdleStatus.BOTH_IDLE.
IdleStatus.BOTH_IDLE.
IdleStatus.BOTH_IDLE in seconds.
IdleStatus.BOTH_IDLE in seconds.
IdleStatus.BOTH_IDLE in seconds.
IdleStatus.BOTH_IDLE in milliseconds.
IdleStatus.BOTH_IDLE in milliseconds.
IdleStatus.BOTH_IDLE in milliseconds.
IoHandlerCommand this handler will use to
handle messageReceived events.
CloseFuture of this session.
CloseFuture of this session.
StateContext this Event was triggered for.
State.
IoService.
IoService.
WriteRequest which is being processed by
IoService.
WriteRequest which is being processed by
IoService.
ProtocolDecoder which
decodes binary or protocol-specific data into message objects.
ProtocolEncoderOutput that buffers
messages generated by ProtocolDecoder.
Queue of the buffered decoder output.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
List of the default local addresses to bind when no
argument is specified in IoAcceptor.bind() method.
List of the default local addresses to bind when no
argument is specified in IoAcceptor.bind() method.
IoConnector.connect() method.
IoConnector.connect() method.
IoConnector.connect() method.
IoConnector.connect() method.
IoConnector.connect() method.
SSLEngine
is initialized.
SSLEngine
is initialized.
ProtocolEncoder which
encodes message objects into binary or protocol-specific data.
ProtocolEncoderOutput that buffers
IoBuffers generated by ProtocolEncoder.
Queue of the buffered encoder output.
IoFilterChain.Entry with the specified name in this chain.
IoFilterChain.Entry with the specified filter in this chain.
IoFilterChain.Entry with the specified filterType
in this chain.
EnumSet.
EnumSet.
EnumSet.
EnumSet.
EnumSet.
EnumSet.
EnumSet.
EnumSet.
IoSession that is managed by the service.
Event which couldn't be handled.
Exception.
Exception.
Exception.
LogLevel that is used to log
exception caught events.
Map which contains all messageType-MessageHandler
pairs registered to this handler.
Executor instance this filter uses.
SingleSessionIoHandlerFactory that is used to create a new
SingleSessionIoHandler instance.
IoService.getFilterChainBuilder() ).
IoService.getFilterChainBuilder() ).
IoFilterChainBuilder which will build the
IoFilterChain of all IoSessions which is created
by this service.
IoFilterChainBuilder which will build the
IoFilterChain of all IoSessions which is created
by this service.
WriteFuture that is associated with this write request.
SingleSessionIoHandler for the given session.
Event.
State.
IdleStatus.
IdleStatus.
IdleStatus.
TrafficMask instance from the
specified interestOps.
StateMachineFactory instance which creates
StateMachines by reading the specified Transition
equivalent annotation.
SelectionKey for this mask.
readBytesThroughput.
readMessagesThroughput.
writtenBytesThroughput.
writtenMessagesThroughput.
IdleStatus.BOTH_IDLE.
IdleStatus.BOTH_IDLE.
IdleStatus.BOTH_IDLE.
IdleStatus.
IdleStatus.
IdleStatus.
IdleStatus.READER_IDLE.
IdleStatus.READER_IDLE.
IdleStatus.READER_IDLE.
IdleStatus.WRITER_IDLE.
IdleStatus.WRITER_IDLE.
IdleStatus.WRITER_IDLE.
Set of the local addresses which are bound currently.
Set of the local addresses which are bound currently.
IoEventType has executed
MessageHandler which is registered to process
the specified type.
LogLevel that is used to log
message received events.
LogLevel that is used to log
message sent events.
Method.
IoEventType has executed
IoHandlerCommand.NextCommand of the command.
IoFilter.NextFilter of the filter.
IoFilter.NextFilter of the IoFilter with the
specified name in this chain.
IoFilter.NextFilter of the specified IoFilter
in this chain.
IoFilter.NextFilter of the specified filterType
in this chain.
State which the StateMachine should move to
if this Transition is taken and Transition.execute(Event) returns
true.
ClassLoader
of the current thread.
WriteRequest which was requested originally,
which is not transformed by any IoFilter.
State.
decoder and returns it.
decoder and returns it.
decoder and returns it.
IoEventQueueHandler which is attached to this
filter.
IdleStatus.READER_IDLE.
IdleStatus.READER_IDLE.
IdleStatus.READER_IDLE.
IdleStatus.READER_IDLE in seconds.
IdleStatus.READER_IDLE in seconds.
IdleStatus.READER_IDLE in seconds.
IdleStatus.READER_IDLE in milliseconds.
IdleStatus.READER_IDLE in milliseconds.
IdleStatus.READER_IDLE in milliseconds.
Map which contains all messageType-MessageHandler
pairs registered to this handler for received messages.
WriteRequest.
WriteRequest, in the order of occurrance.
ResponseInspector.
Map which contains all messageType-MessageHandler
pairs registered to this handler for sent messages.
IoService listens to to manage
this session.
IoService listens to to manage
this session.
IoService listens to to manage
this session.
IoSession of this chain.
IoSession which is the result of connect operation.
IoSession which is associated with this future.
IoSession which is associated with this future.
LogLevel that is used to log
session closed events.
IoSessions
created by this service.
IoSessions
created by this service.
IoSessions
created by this service.
IoSessions
created by this service.
IoSessions
created by this service.
IoSessionConfig of the service
LogLevel that is used to log
session created events.
IoSessionDataStructureFactory that provides
related data structures for a new session created by this service.
IoSessionDataStructureFactory that provides
related data structures for a new session created by this service.
LogLevel that is used to log
session idle events.
LogLevel that is used to log
session opened events.
IoSessionRecycler for this service.
SSLSession for the specified session.
State with the specified id.
Collection of all States used by
this StateMachine.
NUL-terminated string from this buffer using the
specified decoder and returns it.
NUL-terminated string from this buffer using the
specified decoder and returns it.
IoEventType
TrafficMask of this session.
TrafficMask of this session.
List of Transitions going out
from this State.
TransportMetadata that this service runs on.
TransportMetadata that this service runs on.
TransportMetadata that this service runs on.
TransportMetadata that this service runs on.
WriteRequest which is going to be associated with
the specified session.
IdleStatus.WRITER_IDLE.
IdleStatus.WRITER_IDLE.
IdleStatus.WRITER_IDLE.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in milliseconds.
IdleStatus.WRITER_IDLE in milliseconds.
IdleStatus.WRITER_IDLE in milliseconds.
Event through this StateMachine.
session.
SingleSessionIoHandler as a session
attribute.
true if the messages exchanged by the service can be
fragmented
or reassembled by its underlying transport.
IdentityHashMap-backed Set.IoSession or
IoSession.PropertyEditor which converts a String into an
InetAddress.PropertyEditor which converts a String into an
InetSocketAddress.ReferenceCountingFilter when this filter
is added to a IoFilterChain at the first time, so you can
initialize shared resources.
InetAddress is within this subnet
DecodingState which decodes int values in big-endian
order (high bytes come first).PropertyEditor which converts a String into
an Integer and vice versa.IoHandlers.IoBuffers and manages them.LazyInitializer implementation that initializes an
IoBuffer only when needed.bufferSize.
IoBuffer that wraps a buffer and proxies any operations to it.IoHandlers.OrderedThreadPoolExecutor and UnorderedThreadPoolExecutor.IoEvent occupies
in the current JVM.Enum that represents the type of I/O events and requests.IoHandler events like Servlet
filters.IoFilter in IoFilterChain.IoFilter.IoFilters that forwards IoHandler events
to the consisting filters and terminal IoHandler sequentially.IoFilterChain contains.IoFilterChain in predefined way
when IoSession is created.IoFilters.IoFilter events for use in IoFilterTransition
annotations.RuntimeException which is thrown when IoFilter.init()
or IoFilter.onPostAdd(IoFilterChain, String, org.apache.mina.core.filterchain.IoFilter.NextFilter)
failed.IoSession.PropertyAccessor for IoFilter.IoFilterEvents event when in a specific state.IoFilterTransitions.IoSession.IoFuture.IoHandler.IoHandlerCommands.IoHandlerCommands.
IoHandlerChain contains.IoHandlerCommand encapsulates a unit of processing work to be
performed, whose purpose is to examine and/or modify the state of a
transaction that is represented by custom attributes provided by
IoSession.IoHandlerCommand of
the IoHandlerChain.IoHandler events for use in IoHandlerTransition
annotations.IoHandlerEvents event when in a specific state.IoHandlerTransitions.IoSessions.IoAcceptors and IoConnectors
that provide I/O service and manage IoSessions.AbstractIoService.IoService.IoServiceListeners and firing
events.IoSession.PropertyAccessor for IoService.AbstractIoService instance.IoSession.IoSession.IoSessions that match a boolean OGNL expression.RuntimeException that is thrown when the initialization of
an IoSession fails.IoSession during
session initialization.IoSession.PropertyAccessor for IoSession.IoSessionRecycler to an IoService.StateContextLookup which uses an IoSession
attribute to store the StateContextLookup.DefaultStateContextFactory to
create StateContext objects for new IoSessions.
DefaultStateContextFactory to
create StateContext objects for new IoSessions.
StateContextFactory to
create StateContext objects for new IoSessions.
StateContextFactory to
create StateContext objects for new IoSessions.
IoSession and IoFuture.true if this service is IdleStatus.BOTH_IDLE.
true if this session is IdleStatus.BOTH_IDLE.
true if this session is IdleStatus.BOTH_IDLE.
true if the connect operation has been canceled by
ConnectFuture.cancel() method.
IoSession associated with this
future has been closed.
true if and only if this session is being closed
(but not disconnected yet) or is closed.
- isClosing() -
Method in interface org.apache.mina.core.session.IoSession
- Returns
true if and only if this session is being closed
(but not disconnected yet) or is closed.
- isCompressInbound() -
Method in class org.apache.mina.filter.compression.CompressionFilter
- Returns true if incoming data is being compressed.
- isCompressOutbound() -
Method in class org.apache.mina.filter.compression.CompressionFilter
- Returns true if the filter is compressing data being written.
- isConnected() -
Method in interface org.apache.mina.core.future.ConnectFuture
- Returns true if the connect operation is finished successfully.
- isConnected() -
Method in class org.apache.mina.core.future.DefaultConnectFuture
-
- isConnected() -
Method in class org.apache.mina.core.session.AbstractIoSession
- Returns
true if this session is connected with remote peer.
- isConnected() -
Method in interface org.apache.mina.core.session.IoSession
- Returns
true if this session is connected with remote peer.
- isConnectionless() -
Method in class org.apache.mina.core.service.DefaultTransportMetadata
-
- isConnectionless() -
Method in interface org.apache.mina.core.service.TransportMetadata
- Returns
true if the session of this transport type is
connectionless.
- isConnectionOk(IoSession) -
Method in class org.apache.mina.filter.firewall.ConnectionThrottleFilter
- Method responsible for deciding if a connection is OK
to continue
- isDerived() -
Method in class org.apache.mina.core.buffer.AbstractIoBuffer
-
- isDerived() -
Method in class org.apache.mina.core.buffer.IoBuffer
- returns true if and only if this buffer is derived from other buffer
via
IoBuffer.duplicate(), IoBuffer.slice() or IoBuffer.asReadOnlyBuffer().
- isDerived() -
Method in class org.apache.mina.core.buffer.IoBufferWrapper
-
- isDirect() -
Method in class org.apache.mina.core.buffer.AbstractIoBuffer
-
- isDirect() -
Method in class org.apache.mina.core.buffer.IoBuffer
-
- isDirect() -
Method in class org.apache.mina.core.buffer.IoBufferWrapper
-
- isDisposed() -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- Returns true if and if only all resources of this processor
have been disposed.
- isDisposed() -
Method in class org.apache.mina.core.service.AbstractIoService
- Returns true if and if only all resources of this processor
have been disposed.
- isDisposed() -
Method in interface org.apache.mina.core.service.IoProcessor
- Returns true if and if only all resources of this processor
have been disposed.
- isDisposed() -
Method in interface org.apache.mina.core.service.IoService
- Returns true if and if only all resources of this processor
have been disposed.
- isDisposed() -
Method in class org.apache.mina.core.service.SimpleIoProcessorPool
-
- isDisposing() -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- Returns true if and if only
IoProcessor.dispose() method has
been called.
- isDisposing() -
Method in class org.apache.mina.core.service.AbstractIoService
- Returns true if and if only
IoService.dispose() method has
been called.
- isDisposing() -
Method in interface org.apache.mina.core.service.IoProcessor
- Returns true if and if only
IoProcessor.dispose() method has
been called.
- isDisposing() -
Method in interface org.apache.mina.core.service.IoService
- Returns true if and if only
IoService.dispose() method has
been called.
- isDisposing() -
Method in class org.apache.mina.core.service.SimpleIoProcessorPool
-
- isDone() -
Method in class org.apache.mina.core.future.DefaultIoFuture
- Returns if the asynchronous operation is completed.
- isDone() -
Method in interface org.apache.mina.core.future.IoFuture
- Returns if the asynchronous operation is completed.
- isDone() -
Method in class org.apache.mina.core.service.AbstractIoService.ServiceOperationFuture
-
- isEmpty(IoSession) -
Method in interface org.apache.mina.core.write.WriteRequestQueue
-
- isEmpty() -
Method in class org.apache.mina.util.CircularQueue
-
- isEmpty() -
Method in class org.apache.mina.util.CopyOnWriteMap
- Returns true if this map is empty, otherwise false.
- isEmpty() -
Method in class org.apache.mina.util.ExpiringMap
-
- isEmpty() -
Method in class org.apache.mina.util.LazyInitializedCacheMap
-
- isEmpty() -
Method in class org.apache.mina.util.SynchronizedQueue
-
- isExpandable(Class<?>, String) -
Method in class org.apache.mina.integration.jmx.ObjectMBean
-
- isForwardEvent() -
Method in class org.apache.mina.filter.keepalive.KeepAliveFilter
- Returns true if and only if this filter forwards
a
IoEventType.SESSION_IDLE event to the next filter.
- isGetTrafficClassAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isGetTrafficClassAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isIdle(IdleStatus) -
Method in class org.apache.mina.core.service.IoServiceIdleState
- Returns
true if this service is idle for the specified
IdleStatus.
- isIdle(IdleStatus) -
Method in class org.apache.mina.core.session.AbstractIoSession
- Returns
true if this session is idle for the specified
IdleStatus.
- isIdle(IdleStatus) -
Method in interface org.apache.mina.core.session.IoSession
- Returns
true if this session is idle for the specified
IdleStatus.
- isInterestedInRead(T) -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- is this session registered for reading
- isInterestedInRead(AprSession) -
Method in class org.apache.mina.transport.socket.apr.AprIoProcessor
-
- isInterestedInRead(NioSession) -
Method in class org.apache.mina.transport.socket.nio.NioProcessor
-
- isInterestedInWrite(T) -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- is this session registered for writing
- isInterestedInWrite(AprSession) -
Method in class org.apache.mina.transport.socket.apr.AprIoProcessor
-
- isInterestedInWrite(NioSession) -
Method in class org.apache.mina.transport.socket.nio.NioProcessor
-
- isKeepAlive() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isKeepAlive() -
Method in interface org.apache.mina.transport.socket.SocketSessionConfig
-
- isKeepAliveChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the keepAlive property
has been changed by its setter method.
- isKeepAliveChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isLowLatency() -
Method in interface org.apache.mina.transport.serial.SerialSessionConfig
- Is the low latency mode is enabled.
- isManipulateReads() -
Method in class org.apache.mina.filter.errorgenerating.ErrorGeneratingFilter
-
- isManipulateWrites() -
Method in class org.apache.mina.filter.errorgenerating.ErrorGeneratingFilter
-
- isNeedClientAuth() -
Method in class org.apache.mina.filter.ssl.SslFilter
- Returns true if the engine will require client authentication.
- isOobInline() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isOobInline() -
Method in interface org.apache.mina.transport.socket.SocketSessionConfig
-
- isOobInlineChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the oobInline property
has been changed by its setter method.
- isOobInlineChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isOperation(String, Class<?>[]) -
Method in class org.apache.mina.integration.jmx.IoFilterMBean
-
- isOperation(String, Class<?>[]) -
Method in class org.apache.mina.integration.jmx.IoServiceMBean
-
- isOperation(String, Class<?>[]) -
Method in class org.apache.mina.integration.jmx.IoSessionMBean
-
- isOperation(String, Class<?>[]) -
Method in class org.apache.mina.integration.jmx.ObjectMBean
-
- isRead() -
Method in class org.apache.mina.core.future.DefaultReadFuture
-
- isRead() -
Method in interface org.apache.mina.core.future.ReadFuture
- Returns true if a message was received successfully.
- isReadable(H) -
Method in class org.apache.mina.core.polling.AbstractPollingConnectionlessIoAcceptor
-
- isReadable(T) -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- Is the session ready for reading
- isReadable() -
Method in class org.apache.mina.core.session.TrafficMask
- Returns true if this mask allows a read operation.
- isReadable(Class<?>, String) -
Method in class org.apache.mina.integration.jmx.ObjectMBean
-
- isReadable(AprSession) -
Method in class org.apache.mina.transport.socket.apr.AprIoProcessor
-
- isReadable(DatagramChannel) -
Method in class org.apache.mina.transport.socket.nio.NioDatagramAcceptor
-
- isReadable(NioSession) -
Method in class org.apache.mina.transport.socket.nio.NioProcessor
-
- isReaderIdle() -
Method in class org.apache.mina.core.service.IoServiceIdleState
- Returns
true if this service is IdleStatus.READER_IDLE.
- isReaderIdle() -
Method in class org.apache.mina.core.session.AbstractIoSession
- Returns
true if this session is IdleStatus.READER_IDLE.
- isReaderIdle() -
Method in interface org.apache.mina.core.session.IoSession
- Returns
true if this session is IdleStatus.READER_IDLE.
- isReadOnly() -
Method in class org.apache.mina.core.buffer.AbstractIoBuffer
-
- isReadOnly() -
Method in class org.apache.mina.core.buffer.IoBuffer
-
- isReadOnly() -
Method in class org.apache.mina.core.buffer.IoBufferWrapper
-
- isReceiveBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.AbstractDatagramSessionConfig
- Returns true if and only if the receiveBufferSize property
has been changed by its setter method.
- isReceiveBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the receiveBufferSize property
has been changed by its setter method.
- isReceiveBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isReceiveBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isRequest(IoSession, Object) -
Method in interface org.apache.mina.filter.keepalive.KeepAliveMessageFactory
- Returns true if and only if the specified message is a
keep-alive request message.
- isResponse(IoSession, Object) -
Method in interface org.apache.mina.filter.keepalive.KeepAliveMessageFactory
- Returns true if and only if the specified message is a
keep-alive response message;
- isReuseAddress() -
Method in class org.apache.mina.transport.socket.apr.AprSocketAcceptor
-
- isReuseAddress() -
Method in interface org.apache.mina.transport.socket.DatagramSessionConfig
-
- isReuseAddress() -
Method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isReuseAddress() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isReuseAddress() -
Method in class org.apache.mina.transport.socket.nio.NioSocketAcceptor
-
- isReuseAddress() -
Method in interface org.apache.mina.transport.socket.SocketAcceptor
-
- isReuseAddress() -
Method in interface org.apache.mina.transport.socket.SocketSessionConfig
-
- isReuseAddressChanged() -
Method in class org.apache.mina.transport.socket.AbstractDatagramSessionConfig
- Returns true if and only if the reuseAddress property
has been changed by its setter method.
- isReuseAddressChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the reuseAddress property
has been changed by its setter method.
- isReuseAddressChanged() -
Method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isReuseAddressChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isRunning() -
Method in class org.apache.mina.util.ExpiringMap.Expirer
- Checks to see if the thread is running
- isScheduledForFlush() -
Method in class org.apache.mina.core.session.AbstractIoSession
- TODO Add method documentation
- isSelectorEmpty() -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- Say if the list of
IoSession polled by this IoProcessor
is empty
- isSelectorEmpty() -
Method in class org.apache.mina.transport.socket.apr.AprIoProcessor
-
- isSelectorEmpty() -
Method in class org.apache.mina.transport.socket.nio.NioProcessor
-
- isSendBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.AbstractDatagramSessionConfig
- Returns true if and only if the sendBufferSize property
has been changed by its setter method.
- isSendBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the sendBufferSize property
has been changed by its setter method.
- isSendBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isSendBufferSizeChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isSetReceiveBufferSizeAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isSetReceiveBufferSizeAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isSetSendBufferSizeAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isSetSendBufferSizeAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isSetTrafficClassAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isSetTrafficClassAvailable() -
Static method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isShutdown() -
Method in class org.apache.mina.filter.executor.OrderedThreadPoolExecutor
-
- isShutdown() -
Method in class org.apache.mina.filter.executor.UnorderedThreadPoolExecutor
-
- isSoLingerChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the soLinger property
has been changed by its setter method.
- isSoLingerChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isSslStarted(IoSession) -
Method in class org.apache.mina.filter.ssl.SslFilter
- Returns true if and only if the specified session is
encrypted/decrypted over SSL/TLS currently.
- isTcpNoDelay() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isTcpNoDelay() -
Method in interface org.apache.mina.transport.socket.SocketSessionConfig
-
- isTcpNoDelayChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the tcpNoDelay property
has been changed by its setter method.
- isTcpNoDelayChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isTerminated() -
Method in class org.apache.mina.filter.executor.OrderedThreadPoolExecutor
-
- isTerminated() -
Method in class org.apache.mina.filter.executor.UnorderedThreadPoolExecutor
-
- isTerminating() -
Method in class org.apache.mina.filter.executor.OrderedThreadPoolExecutor
-
- isTerminating() -
Method in class org.apache.mina.filter.executor.UnorderedThreadPoolExecutor
-
- isTerminator(byte) -
Method in class org.apache.mina.filter.codec.statemachine.ConsumeToDynamicTerminatorDecodingState
- Determines whether the specified
byte is a terminator.
- isTerminator(byte) -
Method in class org.apache.mina.filter.codec.statemachine.ConsumeToLinearWhitespaceDecodingState
-
- isTrafficClassChanged() -
Method in class org.apache.mina.transport.socket.AbstractDatagramSessionConfig
- Returns true if and only if the trafficClass property
has been changed by its setter method.
- isTrafficClassChanged() -
Method in class org.apache.mina.transport.socket.AbstractSocketSessionConfig
- Returns true if and only if the trafficClass property
has been changed by its setter method.
- isTrafficClassChanged() -
Method in class org.apache.mina.transport.socket.DefaultDatagramSessionConfig
-
- isTrafficClassChanged() -
Method in class org.apache.mina.transport.socket.DefaultSocketSessionConfig
-
- isUseClientMode() -
Method in class org.apache.mina.filter.ssl.SslFilter
- Returns true if the engine is set to use client mode
when handshaking.
- isUseDirectBuffer() -
Static method in class org.apache.mina.core.buffer.IoBuffer
- Returns true if and only if a direct buffer is allocated
by default when the type of the new buffer is not specified.
- isUseReadOperation() -
Method in class org.apache.mina.core.session.AbstractIoSessionConfig
- Returns true if and only if
IoSession.read() operation
is enabled.
- isUseReadOperation() -
Method in interface org.apache.mina.core.session.IoSessionConfig
- Returns true if and only if
IoSession.read() operation
is enabled.
- isUseResponseQueue() -
Method in class org.apache.mina.filter.reqres.Request
-
- isWantClientAuth() -
Method in class org.apache.mina.filter.ssl.SslFilter
- Returns true if the engine will request client authentication.
- isWritable(H) -
Method in class org.apache.mina.core.polling.AbstractPollingConnectionlessIoAcceptor
-
- isWritable(T) -
Method in class org.apache.mina.core.polling.AbstractPollingIoProcessor
- Is the session ready for writing
- isWritable() -
Method in class org.apache.mina.core.session.TrafficMask
- Returns true if this mask allows a write operation.
- isWritable(Class<?>, String) -
Method in class org.apache.mina.integration.jmx.ObjectMBean
-
- isWritable(AprSession) -
Method in class org.apache.mina.transport.socket.apr.AprIoProcessor
-
- isWritable(DatagramChannel) -
Method in class org.apache.mina.transport.socket.nio.NioDatagramAcceptor
-
- isWritable(NioSession) -
Method in class org.apache.mina.transport.socket.nio.NioProcessor
-
- isWriterIdle() -
Method in class org.apache.mina.core.service.IoServiceIdleState
- Returns
true if this service is IdleStatus.WRITER_IDLE.
- isWriterIdle() -
Method in class org.apache.mina.core.session.AbstractIoSession
- Returns
true if this session is IdleStatus.WRITER_IDLE.
- isWriterIdle() -
Method in interface org.apache.mina.core.session.IoSession
- Returns
true if this session is IdleStatus.WRITER_IDLE.
- isWritten() -
Method in class org.apache.mina.core.future.DefaultWriteFuture
- Returns true if the write operation is finished successfully.
- isWritten() -
Method in interface org.apache.mina.core.future.WriteFuture
- Returns true if the write operation is finished successfully.
- iterator() -
Method in class org.apache.mina.util.MapBackedSet
-
- iterator() -
Method in class org.apache.mina.util.SynchronizedQueue
-
DefaultIoFuture.awaitUninterruptibly().
DefaultIoFuture.awaitUninterruptibly(long).
IoFuture.awaitUninterruptibly().
IoFuture.awaitUninterruptibly(long).
IoFilter that sends a keep-alive request on
IoEventType.SESSION_IDLE and sends back the response for the
sent keep-alive request.KeepAliveFilter.KeepAliveFilter couldn't receive the response for
the sent keep alive message.
RuntimeException which is thrown when a keep-alive response
message was not received within a certain timeout.KeepAliveFilter what to do when a keep-alive response message
was not received within a certain timeout.Set.
KeyStore instance.IoBuffer for example.ConcurrentHashMap
to stick with each special case the user needs.
LazyInitializer meaning it
will return the same object it received when instantiated.DecodingState which skips space (0x20) and tab (0x09) characters.PropertyEditor which converts a String into
a List and vice versa.Formatter that generates xml in the log4j format.PropertyEditor which converts a String into
a Long and vice versa.StateContext from the specified event argument which
is an instance of a class AbstractStateContextLookup.supports(Class) returns
true for.
Event and returns a
StateContext if any of the arguments holds one.
Map-backed Set.PropertyEditor which converts a String into
a Collection and vice versa.MdcInjectionFilter.setProperty(IoSession, String, String)
ProtocolEncoderOutput.write(Object) into
one IoBuffer and replaces the old fragmented ones with it.
MessageDecoder implementation for those who don't need to
implement MessageDecoder.finishDecode(IoSession, ProtocolDecoderOutput)
method.MessageDecoder.MessageDecoder.MessageEncoder.DemuxingIoHandler forwards
messageReceived or messageSent events to.IoHandler.messageReceived(IoSession,Object)
event.
IoHandlerCommand or IoHandlerChain you specified
in the constructor.
MessageHandler
which is registered by DemuxingIoHandler.addReceivedMessageHandler(Class, MessageHandler).
SingleSessionIoHandler.messageReceived(Object) method of the
handler assigned to this session.
IoHandler.messageSent(IoSession,Object)
event.
IoSession.write(Object) is
sent out.
IoSession.write(Object) is sent out actually.
SingleSessionIoHandler.messageSent(Object) method of the handler
assigned to this session.
MethodTransition if the target method couldn't be invoked
or threw an exception.Method and
Throwable.
Transition which invokes a Method.State as next state
and for the specified Event id.
State
for the specified Event id.
State as next state
and for the specified Event id.
State
for the specified Event id.
State
for the specified Event id.
State as next state
and for the specified Event id.
IoBuffer.compact() and
IoBuffer.shrink() operation.
IoBuffer.compact() and
IoBuffer.shrink() operation.
Runnable wrapper that preserves the name of the thread after the runnable is
complete (for Runnables that change the name of the Thread they use.)MessageDecoder.decodable(IoSession, IoBuffer) and
MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
MessageDecoder.decodable(IoSession, IoBuffer)
and MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
Messages and MessageRecognizers.ProtocolDecoder that decodes buffers into
Netty2 Messages using specified MessageRecognizers.MessageRecognizer.
Messages
into buffers.ConnectFuture which is already marked as 'failed to connect'.
SocketAddress
SocketAddress
SocketAddress
KeyStore.
DefaultWriteFuture which is already marked as 'not written'.
IoSession that is bound to the specified
localAddress and the specified remoteAddress which
reuses the local address that is already bound by this service.
IoSession that is bound to the specified
localAddress and the specified remoteAddress which
reuses the local address that is already bound by this service.
IoSession from a connected socket client handle.
IoSession that is bound to the specified
localAddress and the specified remoteAddress which
reuses the local address that is already bound by this service.
IoSession from a connected socket client handle.
IoSession from a connected socket client handle.
DefaultWriteFuture which is already marked as 'written'.
IoAcceptor for datagram transport (UDP/IP).IoConnector for datagram transport (UDP/IP).IoSession which is managed by the NIO transport.IoAcceptor for socket transport (TCP/IP).NioSocketAcceptor using default parameters (multiple thread model).
NioSocketAcceptor using default parameters, and
given number of NioProcessor for multithreading I/O operations.
NioSocketAcceptor with default configuration but a
specific IoProcessor, useful for sharing the same processor over multiple
IoService of the same type.
NioSocketAcceptor with a given Executor for handling
connection events and a given IoProcessor for handling I/O events, useful for
sharing the same processor and executor over multiple IoService of the same type.
IoConnector for socket transport (TCP/IP).NioSocketConnector with default configuration (multiple thread model).
NioSocketConnector with default configuration, and
given number of NioProcessor for multithreading I/O operations
NioSocketConnector with default configuration but a
specific IoProcessor, useful for sharing the same processor over multiple
IoService of the same type.
NioSocketConnector with a given Executor for handling
connection events and a given IoProcessor for handling I/O events, useful for sharing
the same processor and executor over multiple IoService of the same type.
ExceptionHandler that does nothing.
MessageHandler that does nothing.
Transition implementation which does nothing but change the state.State
for the specified Event id.
State as next state
and for the specified Event id.
RuntimeException equivalent of NoSuchMethodException.StateMachine when a transition in the state
machine references a state which doesn't exist.MessageDecoder.decodable(IoSession, IoBuffer) and
MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
MessageDecoder.decodable(IoSession, IoBuffer)
and MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
IoEventType.SESSION_IDLE event to any applicable
sessions in the specified collection.
IoEventType.SESSION_IDLE event if applicable for the
specified session.
PropertyEditor for null.PropertyEditor which converts a String into
a Number and vice versa.ModelMBean wrapper implementation for a POJO.ProtocolCodecFactory that serializes and deserializes Java objects.ClassLoader of
the current thread.
ClassLoader.
ProtocolDecoder which deserializes Serializable Java
objects using IoBuffer.getObject(ClassLoader).ClassLoader of
the current thread.
ClassLoader.
ProtocolEncoder which serializes Serializable Java objects
using IoBuffer.putObject(Object).ObjectInput and InputStream that can read the objects encoded
by ObjectSerializationEncoder.ObjectOutput and OutputStream that can write the objects as
the serialized form that ObjectSerializationDecoder can decode.MessageDecoder.decodable(IoSession, IoBuffer) and
MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
MessageDecoder.decodable(IoSession, IoBuffer)
and MessageDecoder.decode(IoSession, IoBuffer, ProtocolDecoderOutput).
IoFuture
has been completed even if you add the listener after the completion.
ThreadPoolExecutor that maintains the order of IoEvents.PropertyEditor which converts a String into
a Pattern and vice versa.InetSocketAddress.
ProtocolCodecFactory that performs encoding and decoding
of a Java String object using a fixed-length length prefix.ProtocolDecoder which decodes a String using a fixed-length length prefix.ProtocolEncoder which encodes a string
using a fixed-length length prefix.IoFilterAdapter class to execute.PropertyEditor which converts a String into
a Properties and vice versa.PropertyEditor which is appropriate for
the specified object or class.PropertyEditor-based implementation of OGNL TypeConverter.ProtocolEncoder or
ProtocolDecoder cannot understand or failed to validate
data to process.ProtocolEncoder and ProtocolDecoder which translates
binary or protocol specific data into message object and vice versa.IoFilter which translates binary or protocol specific data into
message object and vice versa using ProtocolCodecFactory,
ProtocolEncoder, or ProtocolDecoder.IoSession that provides ProtocolEncoderOutput
and ProtocolDecoderOutput.ProtocolDecoder implementation for those who don't need
ProtocolDecoder.finishDecode(IoSession, ProtocolDecoderOutput) nor
ProtocolDecoder.dispose(IoSession) method.ProtocolDecoder
cannot understand or failed to validate the specified IoBuffer
content.ProtocolDecoder to generate decoded messages.ProtocolEncoder implementation for those who don't have any
resources to dispose.ProtocolEncoder
cannot understand or failed to validate the specified message object.ProtocolEncoder to generate encoded messages such as
IoBuffers.IoSession.
Set to the buffer as a byte sized bit vector.
Set to the buffer as a byte sized bit vector.
Set to the buffer as an int sized bit vector.
Set to the buffer as an int sized bit vector.
Set to the buffer as a long sized bit vector.
Set to the buffer as a long sized bit vector.
Set to the buffer as a short sized bit vector.
Set to the buffer as a short sized bit vector.
in into this buffer as a
string which has a 16-bit length field before the actual
encoded string, using the specified encoder.
in into this buffer as a
string which has a 16-bit length field before the actual
encoded string, using the specified encoder.
in into this buffer as a
string which has a 16-bit length field before the actual
encoded string, using the specified encoder.
in into this buffer as a
string which has a 16-bit length field before the actual
encoded string, using the specified encoder.
in into this buffer using the
specified encoder.
in into this buffer as a
NUL-terminated string using the specified
encoder.
IoSession into the given IoBuffer.
IoFuture for asynchronous read requests.ProtocolDecoder can keep
decoding even after this exception is thrown.IoSession.
IoFilters wrapper that keeps track of the number of usages of this filter and will call init/destroy
when the filter is not in use.session from the I/O
processor so that the I/O processor closes the connection
associated with the session and releases any other related
resources.
session from the I/O
processor so that the I/O processor closes the connection
associated with the session and releases any other related
resources.
IoSession is explicitly closed.
IoEventType to profile
MessageHandler that receives the messages of
the specified type.
IoServiceListener that listens any events
related with this service.
IoServiceListener that listens any events
related with this service.
MessageHandler that handles the received messages
of the specified type.
MessageHandler that handles the sent messages of
the specified type.
RuntimeIoException which is thrown when a Request is timed out.IoSession.setTrafficMask(TrafficMask) that
resumes read operations for this session.
IoSession.setTrafficMask(TrafficMask) that
resumes read operations for this session.
IoSession.setTrafficMask(TrafficMask) that
resumes write operations for this session.
IoSession.setTrafficMask(TrafficMask) that
resumes write operations for this session.
IOException.Iterator for the set of server sockets found with acceptable incoming connections
during the last AbstractPollingIoAcceptor.select() call.
Iterator for the set of client sockets found connected or
failed to connect during the last #select() call.
Iterator for the set of client sockets found connected or
failed to connect during the last #select() call.
Iterator for the set of server sockets found with acceptable incoming connections
during the last AbstractPollingIoAcceptor.select() call.
Iterator for the set of client sockets found connected or
failed to connect during the last #select() call.
Iterator for the list of IoSession found selected
by the last call of {@link AbstractPollingIoProcessor#select(int)
PropertyEditor which converts a String into a
SerialAddress and vice versa.IoConnector for serial communication transport.IoSession for serial communication transport.IoSessionConfig for serial transport type.IoService.
IoService.
IoFuture related with
the IoSession.
IoHandler.messageReceived(IoSession, Object)
event when the session is secured and its SslFilter.USE_NOTIFICATION
attribute is set.
IoHandler.messageReceived(IoSession, Object)
event when the session is not secure anymore and its SslFilter.USE_NOTIFICATION
attribute is set.
IoFilter that sets initial attributes when a new
IoSession is created.IoHandler.sessionClosed(IoSession) event.
IoHandler.sessionClosed(IoSession) event.
SingleSessionIoHandler.sessionClosed() method of the handler
assigned to this session.
IoHandler.sessionCreated(IoSession) event.
IoService.
IoService.
IoHandler.sessionIdle(IoSession,IdleStatus)
event.
IdleStatus when a connection becomes idle.
SingleSessionIoHandler.sessionIdle(IdleStatus) method of the
handler assigned to this session.
IoHandler.sessionOpened(IoSession) event.
SingleSessionIoHandler.sessionOpened() method of the handler
assigned to this session.
IoSession.setAttribute(Object, Object) instead.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
SSLSessionContext for use in client mode.
SSLSessionContext for use in client mode.
IoSession is closed.
State.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoAcceptor.bind() method.
IoConnector.connect() method.
IoConnector.connect() method.
PropertyEditor which converts a String into
a Set and vice versa.SSLEngine
is initialized.
SSLEngine
is initialized.
EventArgumentsInterceptor to be used.
EventFactory to be used.
LogLevel to be used when exceptions are logged.
IoFilterChainBuilder which will build the
IoFilterChain of all IoSessions which is created
by this service.
IoFilterChainBuilder which will build the
IoFilterChain of all IoSessions which is created
by this service.
IoEventType.SESSION_IDLE event to the next filter.
IoHandler which handles this session.
StateContext corresponding
to a method call on the proxy produced by this builder will raise an
exception or be silently ignored.
KeyManagerFactory to use.
KeyManagerFactory
using KeyManagerFactory.getInstance(java.lang.String) or
KeyManagerFactory.getInstance(java.lang.String, java.lang.String).
true while no KeyManagerFactory
has been set using SslContextFactory.setKeyManagerFactory(KeyManagerFactory) and
no algorithm has been set using
SslContextFactory.setKeyManagerFactoryAlgorithm(String) the default algorithm
return by KeyManagerFactory.getDefaultAlgorithm() will be used.
KeyStore which will be used in the call to
KeyManagerFactory.init(java.security.KeyStore, char[]) when
the SSLContext is created.
KeyManagerFactory.init(java.security.KeyStore, char[]) when
the SSLContext is created.
KeyManagerFactory
using
KeyManagerFactory.getInstance(java.lang.String, java.lang.String).
LogLevel
event.
IoBuffer
IoBuffer
IllegalArgumentException when more bytes
are needed to encode a String value.
IoBuffer.
LogLevel to be used when message received events are logged.
LogLevel to be used when message sent events are logged.
SSLContext.
SSLContext.
IdleStatus.READER_IDLE in seconds.
IdleStatus.READER_IDLE in seconds.
IdleStatus.READER_IDLE in seconds.
SecureRandom to use when initializing the
SSLContext.
SSLSessionContext for use in server mode.
SSLSessionContext for use in server mode.
IoService which provides I/O service to this session.
LogLevel to be used when session closed events are logged.
LogLevel to be used when session created events are logged.
IoSessionDataStructureFactory that provides
related data structures for a new session created by this service.
IoSessionDataStructureFactory that provides
related data structures for a new session created by this service.
LogLevel to be used when session idle events are logged.
LogLevel to be used when session opened events are logged.
IoSessionRecycler for this service.
StateContextLookup to be used.
TimeUnit being used.
TrafficMask of this session which will result
the parent IoService to start to control the traffic
of this session immediately.
TrafficMask of this session which will result
the parent IoService to start to control the traffic
of this session immediately.
TransportMetadata that this session runs on.
TrustManagerFactory to use.
TrustManagerFactory
using TrustManagerFactory.getInstance(java.lang.String) or
TrustManagerFactory.getInstance(java.lang.String, java.lang.String).
true while no TrustManagerFactory
has been set using SslContextFactory.setTrustManagerFactory(TrustManagerFactory) and
no algorithm has been set using
SslContextFactory.setTrustManagerFactoryAlgorithm(String) the default algorithm
return by TrustManagerFactory.getDefaultAlgorithm() will be used.
KeyStore which will be used in the call to
TrustManagerFactory.init(java.security.KeyStore) when
the SSLContext is created.
ManagerFactoryParameters which will be used in the call to
TrustManagerFactory.init(javax.net.ssl.ManagerFactoryParameters) when
the SSLContext is created.
TrustManagerFactory
using
TrustManagerFactory.getInstance(java.lang.String, java.lang.String).
IoSession.read() operation.
IoSession.read() operation.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
IdleStatus.WRITER_IDLE in seconds.
PropertyEditor which converts a String into
a Short and vice versa.DecodingState which decodes short values in big-endian
order (high bytes come first).IoBufferAllocator which simply allocates a new
buffer every time.IoProcessor pool that distributes IoSessions into one or more
IoProcessors.DecodingState which decodes byte values.IoSession parameter for simplicity.SingleSessionIoHandler
interface.IoHandler implementation which delegates all requests to
SingleSessionIoHandlers.SingleSessionIoHandlerFactory to create new
SingleSessionIoHandlers.
SingleSessionIoHandler to be used with one
particular session.StateContextLookup implementation which always returns the same
StateContext instance.DefaultStateContext instance.
StateContextFactory
to create the single instance.
size
bytes.
DecodingState which skips data until SkippingState.canSkip(byte) returns
false.IoAcceptor for socket transport (TCP/IP).IoConnector for socket transport (TCP/IP).IoSessionConfig for socket transport type.SSLSession
for each session.
SSLContext.SSLContext.
SSLContext.
SslFilter when the connection became
secure or is not secure anymore.StateMachine.State with the specified id.
State with the specified id and parent.
StateContext objects are used to store the current State and
any application specific attributes for a specific client of a
StateMachine.StateContext instances.StateContext from a collection of event arguments.States and start
state.
States and start
state.
StateMachineFactory when a StateMachine
could not be constructed for some reason.StateMachines by reading State,
Transition and Transitions (or equivalent) annotations from one or more arbitrary
objects.StateMachine.StateContext in the specified event argument which
is an instance of a class AbstractStateContextLookup.supports(Class) returns
true for.
IoHandler that adapts asynchronous MINA events to stream I/O.InputStream
objects directly using IoSession.write(Object).PropertyEditor for a String.true for any Class that this
StateContextLookup can use to store and lookup
StateContext objects.
IoSession.setTrafficMask(TrafficMask) that
suspends read operations for this session.
IoSession.setTrafficMask(TrafficMask) that
suspends read operations for this session.
IoSession.setTrafficMask(TrafficMask) that
suspends write operations for this session.
IoSession.setTrafficMask(TrafficMask) that
suspends write operations for this session.
ProtocolDecoder implementation which decorates an existing decoder
to be thread-safe.ProtocolEncoder implementation which decorates an existing encoder
to be thread-safe.Queue thread-safe.ProtocolCodecFactory that performs encoding and decoding between
a text line data and a Java string object.Charset.
Charset.
ProtocolDecoder which decodes a text line into a string.Charset
and LineDelimiter.AUTO delimiter.
Charset
and the specified delimiter.
Charset
and the specified delimiter.
LineDelimiter.AUTO delimiter.
ProtocolEncoder which encodes a string into a text line
which ends with the delimiter.Charset
and LineDelimiter.UNIX delimiter.
Charset
and the specified delimiter.
Charset
and the specified delimiter.
LineDelimiter.UNIX delimiter.
IoSession
with IoSession.setTrafficMask(TrafficMask).PropertyEditor which converts a String into a
TrafficMask and vice versa.IoSession, if the underlying API isn't supporting
system calls like sendfile(), you can throw a UnsupportedOperationException so
the file will be send using usual AbstractPollingIoProcessor.write(AbstractIoSession, IoBuffer, int) call.
Transitions.IoService.Event passed to a state machine couldn't be handled.ThreadPoolExecutor that does not maintain the order of IoEvents.session as specified
in IoSession.getTrafficMask().
session as specified
in IoSession.getTrafficMask().
PropertyEditor which converts a String into
a URI and vice versa.PropertyEditor which converts a String into
a URL and vice versa.IoHandler.messageReceived(IoSession, Object) event with a
special message (SslFilter.SESSION_SECURED or SslFilter.SESSION_UNSECURED).
Collection.
IoHandler to the specified
VmPipeAddress.SocketAddress which represents in-VM pipe port number.PropertyEditor which converts a String into
a VmPipeAddress and vice versa.IoHandlers which is bound on the specified
VmPipeAddress.IoSessionConfig for vmpipe transport type.AbstractPollingIoAcceptor.select() method.
#select() method.
#select() method.
AbstractPollingIoAcceptor.select() method.
#select() method.
ByteBuffer into MINA buffer.
ByteBuffer into MINA buffer.
IoSession, means to be called when a session
was found ready for writing.
message to remote peer.
message to remote peer.
ProtocolDecoder to generate decoded messages.
ProtocolEncoder to generate an encoded message such
as an IoBuffer.
IoFuture for asynchronous write requests.IoSession.write(Object).IoEventQueueHandler to an IoSession's
WriteRequest queue to provide accurate write queue status tracking.IoEventQueueThrottle.
IoEventQueueHandler.
IoFilter that simplifies the implementation of
an IoFilter that filters an IoEventType.WRITE event.WriteRequests which are queued to an IoSession.WriteRequest.ProtocolDecoderOutput#write(Object).
IoSessionConfig.getWriteTimeout() seconds.
|
||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||