Overview
Package
Class
Use
Tree
Deprecated
Index
Help
PREV NEXT
FRAMES
NO FRAMES
All Classes
Hierarchy For All Packages
Package Hierarchies:
org.jgroups
,
org.jgroups.annotations
,
org.jgroups.auth
,
org.jgroups.blocks
,
org.jgroups.blocks.atomic
,
org.jgroups.blocks.executor
,
org.jgroups.blocks.locking
,
org.jgroups.blocks.mux
,
org.jgroups.client
,
org.jgroups.conf
,
org.jgroups.demos
,
org.jgroups.demos.applets
,
org.jgroups.demos.wb
,
org.jgroups.jmx
,
org.jgroups.logging
,
org.jgroups.protocols
,
org.jgroups.protocols.pbcast
,
org.jgroups.protocols.relay
,
org.jgroups.protocols.relay.config
,
org.jgroups.protocols.rules
,
org.jgroups.protocols.tom
,
org.jgroups.stack
,
org.jgroups.util
Class Hierarchy
java.lang.Object
java.util.AbstractCollection<E> (implements java.util.Collection<E>)
java.util.AbstractQueue<E> (implements java.util.Queue<E>)
java.util.concurrent.ConcurrentLinkedQueue<E> (implements java.util.Queue<E>, java.io.Serializable)
org.jgroups.util.
BoundedList
<T>
org.jgroups.util.
ConcurrentLinkedBlockingQueue
<T> (implements java.util.concurrent.BlockingQueue<E>)
org.jgroups.blocks.
AbstractConnectionMap
<V> (implements org.jgroups.blocks.
ConnectionMap
<V>)
org.jgroups.blocks.
TCPConnectionMap.Mapper
java.util.concurrent.AbstractExecutorService (implements java.util.concurrent.ExecutorService)
org.jgroups.blocks.executor.
ExecutionService
java.util.concurrent.ThreadPoolExecutor
java.util.concurrent.ScheduledThreadPoolExecutor (implements java.util.concurrent.ScheduledExecutorService)
org.jgroups.util.
DefaultTimeScheduler
(implements org.jgroups.util.
TimeScheduler
)
java.util.AbstractMap<K,V> (implements java.util.Map<K,V>)
org.jgroups.blocks.
ReplicatedHashMap
<K,V> (implements java.util.concurrent.ConcurrentMap<K,V>, org.jgroups.
Receiver
, org.jgroups.blocks.
ReplicatedMap
<K,V>)
java.util.concurrent.locks.AbstractOwnableSynchronizer (implements java.io.Serializable)
java.util.concurrent.locks.AbstractQueuedSynchronizer (implements java.io.Serializable)
org.jgroups.blocks.executor.
ExecutionService.DistributedFuture.Sync
<V>
org.jgroups.util.
AckCollector
org.jgroups.util.
AgeOutCache
<K>
org.jgroups.
AnycastAddress
(implements org.jgroups.
Address
)
org.jgroups.auth.
AuthToken
(implements org.jgroups.util.
Streamable
)
org.jgroups.auth.
DemoToken
(implements org.jgroups.protocols.
AUTH.UpHandler
)
org.jgroups.auth.
FixedMembershipToken
org.jgroups.auth.
MD5Token
org.jgroups.auth.
RegexMembership
org.jgroups.auth.
SimpleToken
org.jgroups.auth.
X509Token
org.jgroups.blocks.locking.
AwaitInfo
org.jgroups.blocks.
BasicConnectionTable
org.jgroups.blocks.
ConnectionTableNIO
(implements java.lang.Runnable)
org.jgroups.util.
Buffer
org.jgroups.blocks.
Cache
<K,V>
org.jgroups.blocks.
Cache.Value
<V> (implements java.io.Externalizable)
org.jgroups.
Channel
org.jgroups.
JChannel
org.jgroups.conf.
ClassConfigurator
java.awt.Component (implements java.awt.image.ImageObserver, java.awt.MenuContainer, java.io.Serializable)
java.awt.Container
javax.swing.JComponent (implements java.io.Serializable)
javax.swing.JPanel (implements javax.accessibility.Accessible)
org.jgroups.demos.
ReplCacheDemo
(implements java.awt.event.ActionListener)
java.awt.Panel (implements javax.accessibility.Accessible)
java.applet.Applet
org.jgroups.demos.applets.
DrawApplet
(implements java.awt.event.ActionListener, java.awt.event.MouseMotionListener)
org.jgroups.demos.wb.
Whiteboard
(implements java.awt.event.ActionListener, java.awt.event.ComponentListener, java.awt.event.FocusListener, org.jgroups.
MembershipListener
, org.jgroups.
MessageListener
)
org.jgroups.demos.wb.
GraphPanel
(implements java.awt.event.MouseListener, java.awt.event.MouseMotionListener)
java.awt.Window (implements javax.accessibility.Accessible)
java.awt.Dialog
org.jgroups.demos.wb.
MessageDialog
(implements java.awt.event.ActionListener)
org.jgroups.demos.wb.
SendDialog
(implements java.awt.event.ActionListener)
org.jgroups.demos.wb.
UserInfoDialog
(implements java.awt.event.ActionListener)
java.awt.Frame (implements java.awt.MenuContainer)
org.jgroups.demos.
QuoteClient
(implements java.awt.event.ActionListener, org.jgroups.
MembershipListener
, java.awt.event.WindowListener)
org.jgroups.demos.
ReplicatedHashMapDemo
(implements java.awt.event.ActionListener, org.jgroups.blocks.
ReplicatedHashMap.Notification
<K,V>, java.awt.event.WindowListener)
org.jgroups.demos.
Topology
(implements java.awt.event.WindowListener)
org.jgroups.demos.
TotalOrder
org.jgroups.stack.
Configurator
org.jgroups.stack.
Configurator.InetAddressInfo
org.jgroups.conf.
ConfiguratorFactory
org.jgroups.blocks.
ConnectionTableNIO.SelectorWriteHandler
org.jgroups.blocks.
ConnectionTableNIO.WriteRequest
org.jgroups.protocols.
COUNTER.CounterImpl
(implements org.jgroups.blocks.atomic.
Counter
)
org.jgroups.protocols.
COUNTER.ReconciliationTask
(implements java.lang.Runnable)
org.jgroups.protocols.
COUNTER.Request
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
COUNTER.ReconcileRequest
org.jgroups.protocols.
COUNTER.ResendPendingRequests
org.jgroups.protocols.
COUNTER.SimpleRequest
org.jgroups.protocols.
COUNTER.CompareAndSetRequest
org.jgroups.protocols.
COUNTER.DeleteRequest
org.jgroups.protocols.
COUNTER.GetOrCreateRequest
org.jgroups.protocols.
COUNTER.SetRequest
org.jgroups.protocols.
COUNTER.AddAndGetRequest
org.jgroups.protocols.
COUNTER.UpdateRequest
org.jgroups.protocols.
COUNTER.Response
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
COUNTER.ReconcileResponse
org.jgroups.protocols.
COUNTER.SimpleResponse
org.jgroups.protocols.
COUNTER.BooleanResponse
org.jgroups.protocols.
COUNTER.ExceptionResponse
org.jgroups.protocols.
COUNTER.ValueResponse
org.jgroups.protocols.
COUNTER.GetOrCreateResponse
org.jgroups.protocols.
COUNTER.VersionedValue
org.jgroups.blocks.atomic.
CounterService
org.jgroups.demos.
CounterServiceDemo
org.jgroups.util.
CreditMap
org.jgroups.util.
DefaultSocketFactory
(implements org.jgroups.util.
SocketFactory
)
org.jgroups.util.
DefaultThreadFactory
(implements org.jgroups.util.
ThreadFactory
)
org.jgroups.util.
LazyThreadFactory
org.jgroups.util.
DefaultTimeScheduler.RobustRunnable
(implements java.lang.Runnable)
org.jgroups.util.
DefaultTimeScheduler.TaskWrapper
<V> (implements java.util.concurrent.Future<V>, java.lang.Runnable)
org.jgroups.protocols.tom.
DeliveryManagerImpl
(implements org.jgroups.protocols.tom.
DeliveryManager
)
org.jgroups.auth.
DemoToken.Entry
org.jgroups.stack.
DiagnosticsHandler
(implements java.lang.Runnable)
org.jgroups.util.
Digest
(implements java.lang.Iterable<T>, org.jgroups.util.
Streamable
)
org.jgroups.util.
MutableDigest
org.jgroups.util.
Digest.DigestEntry
org.jgroups.util.
Digest.MyIterator
(implements java.util.Iterator<E>)
org.jgroups.util.
DirectExecutor
(implements java.util.concurrent.Executor)
org.jgroups.protocols.
Discovery.Responses
org.jgroups.demos.
DrawCommand
(implements org.jgroups.util.
Streamable
)
org.jgroups.
Event
org.jgroups.blocks.executor.
ExecutorEvent
java.util.EventObject (implements java.io.Serializable)
javax.management.Notification
org.jgroups.demos.
JmxDemo.MyNotification
org.jgroups.protocols.
Executing.Owner
org.jgroups.protocols.
Executing.Request
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
Executing.RequestWithThread
org.jgroups.blocks.executor.
ExecutionCompletionService
<V> (implements java.util.concurrent.CompletionService<V>)
org.jgroups.blocks.executor.
ExecutionCompletionService.QueueingListener
(implements org.jgroups.util.
FutureListener
<T>)
org.jgroups.blocks.executor.
ExecutionRunner
(implements java.lang.Runnable)
org.jgroups.blocks.executor.
ExecutionRunner.Holder
<T>
org.jgroups.blocks.executor.
Executions
org.jgroups.blocks.executor.
Executions.StreamableCallable
(implements java.util.concurrent.Callable<V>, org.jgroups.util.
Streamable
)
org.jgroups.blocks.executor.
ExecutionService.DistributedFuture
<V> (implements org.jgroups.blocks.executor.
ExecutorNotification
, org.jgroups.util.
NotifyingFuture
<T>, java.util.concurrent.RunnableFuture<V>)
org.jgroups.blocks.executor.
ExecutionService.RunnableAdapter
<T> (implements java.util.concurrent.Callable<V>, org.jgroups.util.
Streamable
)
org.jgroups.demos.
ExecutionServiceDemo
org.jgroups.demos.
ExecutionServiceDemo.ByteBufferStreamable
(implements org.jgroups.util.
Streamable
)
org.jgroups.demos.
ExecutionServiceDemo.SortingByteCallable
(implements java.util.concurrent.Callable<V>, org.jgroups.util.
Streamable
)
org.jgroups.demos.
ExecutionServiceDemo.SortingTwoByteCallable
(implements java.util.concurrent.Callable<V>, org.jgroups.util.
Streamable
)
org.jgroups.util.
ExpiryCache
<K>
org.jgroups.stack.
ExponentialInterval
(implements org.jgroups.stack.
Interval
)
org.jgroups.protocols.
FD_PING.Pinger
org.jgroups.protocols.
FD.Broadcaster
org.jgroups.protocols.
FD.BroadcastTask
(implements java.lang.Runnable)
org.jgroups.protocols.
FD.Monitor
(implements java.lang.Runnable)
org.jgroups.protocols.
FD_ICMP.PingMonitor
org.jgroups.protocols.
FD_PING.PingMonitor
java.io.File (implements java.lang.Comparable<T>, java.io.Serializable)
org.jgroups.blocks.
GridFile
org.jgroups.protocols.
FILE_PING.WriterTask
(implements java.lang.Runnable)
org.jgroups.util.
FixedSizeBitSet
org.jgroups.protocols.
FlowControl.Credit
org.jgroups.util.
ForwardQueue
java.util.concurrent.FutureTask<V> (implements java.util.concurrent.RunnableFuture<V>)
org.jgroups.blocks.
ConnectionTableNIO.MyFuture
org.jgroups.util.
GetNetworkInterfaces
org.jgroups.
Global
org.jgroups.protocols.pbcast.
GmsImpl
org.jgroups.protocols.pbcast.
ClientGmsImpl
org.jgroups.protocols.pbcast.
ServerGmsImpl
org.jgroups.protocols.pbcast.
CoordGmsImpl
org.jgroups.protocols.pbcast.
ParticipantGmsImpl
org.jgroups.protocols.pbcast.
GmsImpl.Request
org.jgroups.stack.
GossipData
(implements org.jgroups.util.
SizeStreamable
)
org.jgroups.stack.
GossipRouter
org.jgroups.blocks.
GridFile.Metadata
(implements org.jgroups.util.
Streamable
)
org.jgroups.blocks.
GridFilesystem
org.jgroups.util.
HashedTimingWheel
(implements java.lang.Runnable, org.jgroups.util.
TimeScheduler
)
org.jgroups.util.
HashedTimingWheel.MyTask
(implements java.util.concurrent.Future<V>, java.lang.Runnable)
org.jgroups.
Header
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
AuthHeader
org.jgroups.protocols.
COMPRESS.CompressHeader
org.jgroups.protocols.
COUNTER.CounterHeader
org.jgroups.protocols.
DAISYCHAIN.DaisyHeader
org.jgroups.auth.
DemoToken.DemoHeader
org.jgroups.protocols.
DISCARD.DiscardHeader
org.jgroups.protocols.
ENCRYPT.EncryptHeader
org.jgroups.protocols.
EXAMPLE.ExampleHeader
org.jgroups.protocols.
Executing.ExecutorHeader
org.jgroups.protocols.
FcHeader
org.jgroups.protocols.
FD_ALL.HeartbeatHeader
org.jgroups.protocols.
FD_SIMPLE.FdHeader
org.jgroups.protocols.
FD_SOCK.FdHeader
org.jgroups.protocols.
FD.FdHeader
org.jgroups.protocols.pbcast.
FLUSH.FlushHeader
org.jgroups.protocols.
FORWARD_TO_COORD.ForwardHeader
org.jgroups.protocols.
FragHeader
org.jgroups.protocols.pbcast.
GMS.GmsHeader
org.jgroups.protocols.
HTOTAL.HTotalHeader
org.jgroups.protocols.
Locking.LockingHeader
org.jgroups.protocols.
MERGE3.MergeHeader
org.jgroups.blocks.mux.
MuxHeader
org.jgroups.protocols.pbcast.
NakAckHeader
org.jgroups.protocols.pbcast.
NakAckHeader2
org.jgroups.protocols.
PingHeader
org.jgroups.protocols.
PrioHeader
org.jgroups.protocols.
RELAY.RelayHeader
org.jgroups.protocols.relay.
RELAY2.Relay2Header
org.jgroups.blocks.
RequestCorrelator.Header
org.jgroups.blocks.
RequestCorrelator.MultiDestinationHeader
org.jgroups.protocols.
RSVP.RsvpHeader
org.jgroups.protocols.
SCOPE.ScopeHeader
org.jgroups.protocols.
SEQUENCER.SequencerHeader
org.jgroups.protocols.pbcast.
STABLE.StableHeader
org.jgroups.protocols.pbcast.
STATE_TRANSFER.StateHeader
org.jgroups.protocols.
STOMP.StompHeader
org.jgroups.protocols.pbcast.
StreamingStateTransfer.StateHeader
org.jgroups.protocols.tom.
ToaHeader
org.jgroups.protocols.
TpHeader
org.jgroups.protocols.
UNICAST.UnicastHeader
org.jgroups.protocols.
UNICAST2.Unicast2Header
org.jgroups.protocols.
VERIFY_SUSPECT.VerifyHeader
org.jgroups.util.
Headers
org.jgroups.util.
ImmutableReference
<T>
java.io.InputStream (implements java.io.Closeable)
org.jgroups.util.
BlockingInputStream
java.io.ByteArrayInputStream
org.jgroups.util.
ExposedByteArrayInputStream
org.jgroups.blocks.
GridInputStream
org.jgroups.stack.
IpAddress
(implements org.jgroups.
PhysicalAddress
)
org.jgroups.logging.
JDKLogImpl
(implements org.jgroups.logging.
Log
)
org.jgroups.jmx.
JmxConfigurator
org.jgroups.protocols.pbcast.
JoinRsp
(implements org.jgroups.util.
Streamable
)
org.jgroups.demos.
KeyStoreGenerator
org.jgroups.blocks.
LazyRemovalCache
<K,V>
org.jgroups.blocks.locking.
LockInfo
org.jgroups.protocols.
Locking.ClientCondition
(implements java.util.concurrent.locks.Condition)
org.jgroups.protocols.
Locking.ClientLock
(implements java.util.concurrent.locks.Lock)
org.jgroups.protocols.
PEER_LOCK.PeerLock
org.jgroups.protocols.
Locking.Request
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
Locking.ServerCondition
org.jgroups.protocols.
Locking.ServerLock
org.jgroups.blocks.locking.
LockService
org.jgroups.blocks.locking.
LockService.LockImpl
(implements java.util.concurrent.locks.Lock)
org.jgroups.demos.
LockServiceDemo
(implements org.jgroups.blocks.locking.
LockNotification
)
org.jgroups.logging.
Log4JLogImpl
(implements org.jgroups.logging.
Log
)
org.jgroups.logging.
LogFactory
org.jgroups.
Membership
org.jgroups.blocks.
MemcachedConnector
(implements java.lang.Runnable)
org.jgroups.blocks.
MemcachedConnector.Request
org.jgroups.demos.
MemcachedServer
org.jgroups.protocols.
MERGE2.FindSubgroupsTask
org.jgroups.protocols.
MERGE3.InfoSender
(implements org.jgroups.util.
TimeScheduler.Task
)
org.jgroups.protocols.
MERGE3.ViewConsistencyChecker
(implements org.jgroups.util.
TimeScheduler.Task
)
org.jgroups.protocols.pbcast.
MergeData
org.jgroups.util.
MergeId
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.pbcast.
Merger
org.jgroups.
Message
(implements org.jgroups.util.
Streamable
)
org.jgroups.blocks.
MessageDispatcher
(implements org.jgroups.
ChannelListener
, org.jgroups.blocks.
RequestHandler
)
org.jgroups.blocks.mux.
MuxMessageDispatcher
org.jgroups.blocks.
RpcDispatcher
org.jgroups.blocks.mux.
MuxRpcDispatcher
org.jgroups.protocols.tom.
MessageID
(implements java.lang.Cloneable, java.lang.Comparable<T>, java.io.Externalizable, org.jgroups.util.
Streamable
)
org.jgroups.blocks.
MethodCall
(implements java.io.Externalizable)
org.jgroups.util.
MockTimeScheduler
(implements org.jgroups.util.
TimeScheduler
)
org.jgroups.blocks.mux.
MuxUpHandler
(implements org.jgroups.blocks.mux.
Muxer
<T>, org.jgroups.
UpHandler
)
org.jgroups.protocols.pbcast.
NAKACK2.Counter
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.protocols.pbcast.
NAKACK2.RetransmitTask
(implements java.lang.Runnable)
org.jgroups.stack.
NakReceiverWindow
org.jgroups.demos.wb.
Node
(implements java.io.Serializable)
org.jgroups.blocks.mux.
NoMuxHandler
(implements java.io.Serializable)
org.jgroups.blocks.mux.
NoMuxHandlerRspFilter
(implements org.jgroups.blocks.
RspFilter
)
javax.management.NotificationBroadcasterSupport (implements javax.management.NotificationEmitter)
org.jgroups.demos.
JmxDemo
org.jgroups.util.
NullFuture
<T> (implements org.jgroups.util.
NotifyingFuture
<T>)
java.io.OutputStream (implements java.io.Closeable, java.io.Flushable)
java.io.ByteArrayOutputStream
org.jgroups.util.
ExposedByteArrayOutputStream
java.io.FilterOutputStream
java.io.DataOutputStream (implements java.io.DataOutput)
org.jgroups.util.
ExposedDataOutputStream
org.jgroups.blocks.
GridOutputStream
org.jgroups.protocols.pbcast.
STATE.StateOutputStream
org.jgroups.util.
Owner
(implements org.jgroups.util.
Streamable
)
org.jgroups.blocks.
PartitionedHashMap
<K,V> (implements org.jgroups.
MembershipListener
)
org.jgroups.blocks.
PartitionedHashMap.ConsistentHashFunction
<K> (implements org.jgroups.
MembershipListener
, org.jgroups.blocks.
PartitionedHashMap.HashFunction
<K>)
org.jgroups.demos.
PartitionedHashMapDemo
org.jgroups.protocols.
PDC.Mapping
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.
PingData
(implements org.jgroups.util.
SizeStreamable
)
org.jgroups.conf.
PlainConfigurator
(implements org.jgroups.conf.
ProtocolStackConfigurator
)
org.jgroups.demos.
ProgrammaticChat
org.jgroups.util.
Promise
<T>
org.jgroups.util.
PropertiesToXML
org.jgroups.conf.
PropertyConverters
org.jgroups.conf.
PropertyConverters.BindInterface
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.Default
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.FlushInvoker
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.InitialHosts
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.InitialHosts2
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.IntegerArray
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.LongArray
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyConverters.NetworkInterfaceList
(implements org.jgroups.conf.
PropertyConverter
)
org.jgroups.conf.
PropertyHelper
org.jgroups.stack.
Protocol
org.jgroups.protocols.
AUTH
org.jgroups.protocols.
BARRIER
org.jgroups.protocols.
BSH
(implements java.lang.Runnable)
org.jgroups.protocols.
COMPRESS
org.jgroups.protocols.
COUNTER
org.jgroups.protocols.
DAISYCHAIN
org.jgroups.protocols.
DELAY
org.jgroups.protocols.
DELAY_JOIN_REQ
org.jgroups.protocols.
DISCARD
org.jgroups.protocols.
DISCARD_PAYLOAD
org.jgroups.protocols.
Discovery
org.jgroups.protocols.
FILE_PING
org.jgroups.protocols.
JDBC_PING
org.jgroups.protocols.
RACKSPACE_PING
org.jgroups.protocols.
S3_PING
org.jgroups.protocols.
SWIFT_PING
org.jgroups.protocols.
PING
org.jgroups.protocols.
BPING
(implements java.lang.Runnable)
org.jgroups.protocols.
MPING
(implements java.lang.Runnable)
org.jgroups.protocols.
TCPGOSSIP
org.jgroups.protocols.
TCPPING
org.jgroups.protocols.
DUPL
org.jgroups.protocols.
ENCRYPT
org.jgroups.protocols.
EXAMPLE
org.jgroups.protocols.
Executing
org.jgroups.protocols.
CENTRAL_EXECUTOR
org.jgroups.protocols.
FC
org.jgroups.protocols.
FD
org.jgroups.protocols.
FD_ICMP
org.jgroups.protocols.
FD_PING
org.jgroups.protocols.
FD_ALL
org.jgroups.protocols.
FD_SIMPLE
org.jgroups.protocols.
FD_SOCK
(implements java.lang.Runnable)
org.jgroups.protocols.
FlowControl
org.jgroups.protocols.
MFC
org.jgroups.protocols.
UFC
org.jgroups.protocols.pbcast.
FLUSH
org.jgroups.protocols.
FORWARD_TO_COORD
org.jgroups.protocols.
FRAG
org.jgroups.protocols.
FRAG2
org.jgroups.protocols.pbcast.
GMS
(implements org.jgroups.stack.
DiagnosticsHandler.ProbeHandler
)
org.jgroups.protocols.
HDRS
org.jgroups.protocols.
HTOTAL
org.jgroups.protocols.
Locking
org.jgroups.protocols.
CENTRAL_LOCK
(implements org.jgroups.blocks.locking.
LockNotification
)
org.jgroups.protocols.
PEER_LOCK
org.jgroups.protocols.
MERGE2
org.jgroups.protocols.
MERGE3
org.jgroups.protocols.pbcast.
NAKACK
(implements org.jgroups.stack.
DiagnosticsHandler.ProbeHandler
, org.jgroups.stack.
Retransmitter.RetransmitCommand
)
org.jgroups.protocols.pbcast.
NAKACK2
(implements org.jgroups.stack.
DiagnosticsHandler.ProbeHandler
)
org.jgroups.protocols.
PDC
org.jgroups.protocols.
PRIO
org.jgroups.stack.
ProtocolStack
org.jgroups.protocols.
RATE_LIMITER
org.jgroups.protocols.
RELAY
org.jgroups.protocols.relay.
RELAY2
org.jgroups.protocols.
RSVP
org.jgroups.protocols.
SCOPE
org.jgroups.protocols.
SEQUENCER
org.jgroups.protocols.
SHUFFLE
org.jgroups.protocols.
SIZE
org.jgroups.protocols.pbcast.
STABLE
org.jgroups.protocols.pbcast.
STATE_TRANSFER
org.jgroups.protocols.
STATS
org.jgroups.protocols.
STOMP
(implements java.lang.Runnable)
org.jgroups.protocols.pbcast.
StreamingStateTransfer
org.jgroups.protocols.pbcast.
STATE
org.jgroups.protocols.pbcast.
STATE_SOCK
org.jgroups.protocols.rules.
SUPERVISOR
org.jgroups.protocols.tom.
TOA
(implements org.jgroups.protocols.tom.
DeliveryProtocol
)
org.jgroups.protocols.
TP
org.jgroups.protocols.
BasicTCP
org.jgroups.protocols.
TCP
(implements org.jgroups.blocks.
TCPConnectionMap.Receiver
)
org.jgroups.protocols.
TCP_NIO
(implements org.jgroups.blocks.
BasicConnectionTable.Receiver
)
org.jgroups.protocols.
SHARED_LOOPBACK
org.jgroups.protocols.
TUNNEL
org.jgroups.protocols.
UDP
org.jgroups.protocols.
TP.ProtocolAdapter
(implements org.jgroups.stack.
DiagnosticsHandler.ProbeHandler
)
org.jgroups.protocols.
TRACE
org.jgroups.protocols.
UNICAST
(implements org.jgroups.util.
AgeOutCache.Handler
<K>)
org.jgroups.protocols.
UNICAST2
(implements org.jgroups.util.
AgeOutCache.Handler
<K>)
org.jgroups.protocols.
VERIFY_SUSPECT
(implements java.lang.Runnable)
org.jgroups.conf.
ProtocolConfiguration
org.jgroups.stack.
ProtocolStack.RefCounter
org.jgroups.demos.
PubSub
org.jgroups.util.
Queue
org.jgroups.util.
Range
(implements java.lang.Comparable<T>, org.jgroups.util.
Streamable
)
org.jgroups.
ReceiverAdapter
(implements org.jgroups.
Receiver
)
org.jgroups.demos.
Chat
org.jgroups.demos.
Draw
(implements java.awt.event.ActionListener, org.jgroups.
ChannelListener
)
org.jgroups.demos.
QuoteServer
org.jgroups.protocols.
RELAY.Receiver
org.jgroups.demos.
RelayDemoRpc
org.jgroups.protocols.relay.
Relayer.Bridge
org.jgroups.blocks.
ReplicatedTree
org.jgroups.demos.
ViewDemo
org.jgroups.protocols.
RELAY.RemoteViewFetcher
(implements java.lang.Runnable)
org.jgroups.protocols.
RELAY.ViewData
(implements org.jgroups.util.
Streamable
)
org.jgroups.protocols.relay.config.
RelayConfig
org.jgroups.protocols.relay.config.
RelayConfig.BridgeConfig
org.jgroups.protocols.relay.config.
RelayConfig.ProgrammaticBridgeConfig
org.jgroups.protocols.relay.config.
RelayConfig.PropertiesBridgeConfig
org.jgroups.protocols.relay.config.
RelayConfig.ForwardConfig
org.jgroups.protocols.relay.config.
RelayConfig.SiteConfig
org.jgroups.demos.
RelayDemo
org.jgroups.protocols.relay.
Relayer
org.jgroups.protocols.relay.
Relayer.Route
org.jgroups.blocks.
ReplCache
<K,V> (implements org.jgroups.blocks.
Cache.ChangeListener
, org.jgroups.
MembershipListener
)
org.jgroups.blocks.
ReplCache.ConsistentHashFunction
<K> (implements org.jgroups.blocks.
ReplCache.HashFunction
<K>)
org.jgroups.blocks.
ReplCache.Value
<V> (implements java.io.Serializable)
org.jgroups.blocks.
ReplicatedTree.Node
(implements java.io.Serializable)
org.jgroups.blocks.
Request
(implements org.jgroups.util.
NotifyingFuture
<T>, org.jgroups.blocks.
RspCollector
)
org.jgroups.blocks.
GroupRequest
<T>
org.jgroups.blocks.
UnicastRequest
<T>
org.jgroups.blocks.
RequestCorrelator
org.jgroups.blocks.mux.
MuxRequestCorrelator
org.jgroups.blocks.
RequestOptions
org.jgroups.jmx.
ResourceDMBean
(implements javax.management.DynamicMBean)
org.jgroups.util.
ResourceManager
org.jgroups.util.
ResponseCollector
<T>
org.jgroups.util.
RetransmitTable
org.jgroups.stack.
Retransmitter
org.jgroups.stack.
DefaultRetransmitter
org.jgroups.stack.
RangeBasedRetransmitter
org.jgroups.stack.
Retransmitter.Task
(implements org.jgroups.util.
TimeScheduler.Task
)
org.jgroups.stack.
DefaultRetransmitter.SeqnoTask
org.jgroups.stack.
RangeBasedRetransmitter.RangeTask
org.jgroups.util.
RingBuffer
<T> (implements java.lang.Iterable<T>)
org.jgroups.util.
RingBuffer.RingBufferIterator
<T> (implements java.util.Iterator<E>)
org.jgroups.util.
RingBufferLockless
<T> (implements java.lang.Iterable<T>)
org.jgroups.util.
RingBufferLockless.RingBufferIterator
<T> (implements java.util.Iterator<E>)
org.jgroups.stack.
RouterStub
org.jgroups.stack.
RouterStubManager
(implements org.jgroups.stack.
RouterStub.ConnectionListener
)
org.jgroups.util.
Rsp
<T>
org.jgroups.util.
RspList
<T> (implements java.lang.Iterable<T>, java.util.Map<K,V>)
org.jgroups.protocols.
RSVP.Entry
org.jgroups.protocols.rules.
Rule
(implements java.lang.Runnable)
org.jgroups.protocols.rules.
CheckFDMonitor
org.jgroups.protocols.rules.
SampleRule
org.jgroups.protocols.
SCOPE.ExpiryTask
(implements java.lang.Runnable)
org.jgroups.protocols.
SCOPE.MessageQueue
org.jgroups.protocols.
SCOPE.QueueThread
(implements java.lang.Runnable)
org.jgroups.protocols.tom.
SenderManager
org.jgroups.util.
Seqno
org.jgroups.util.
SeqnoRange
org.jgroups.util.
SeqnoComparator
(implements java.util.Comparator<T>)
org.jgroups.util.
SeqnoList
(implements java.lang.Iterable<T>, org.jgroups.util.
Streamable
)
org.jgroups.util.
SeqnoList.Seqno
org.jgroups.util.
SeqnoList.SeqnoRange
org.jgroups.util.
SeqnoList.SeqnoListIterator
(implements java.util.Iterator<E>)
org.jgroups.protocols.tom.
SequenceNumberManager
org.jgroups.util.
ShutdownRejectedExecutionHandler
(implements java.util.concurrent.RejectedExecutionHandler)
org.jgroups.util.
SingletonAddress
(implements org.jgroups.
Address
)
org.jgroups.protocols.pbcast.
STABLE.ResumeTask
(implements java.lang.Runnable)
org.jgroups.protocols.pbcast.
STATE_SOCK.StateProviderAcceptor
(implements java.lang.Runnable)
org.jgroups.stack.
StateTransferInfo
org.jgroups.util.
StateTransferResult
org.jgroups.stack.
StaticInterval
(implements org.jgroups.stack.
Interval
)
org.jgroups.protocols.tom.
StatsCollector
org.jgroups.protocols.
STOMP.Connection
(implements java.lang.Runnable)
org.jgroups.protocols.
STOMP.Frame
org.jgroups.demos.
StompChat
(implements org.jgroups.client.
StompConnection.Listener
)
org.jgroups.client.
StompConnection
(implements java.lang.Runnable)
org.jgroups.demos.
StompDraw
(implements java.awt.event.ActionListener, org.jgroups.client.
StompConnection.Listener
)
org.jgroups.protocols.pbcast.
StreamingStateTransfer.StateGetter
(implements java.lang.Runnable)
org.jgroups.util.
SuppressCache
<T>
org.jgroups.util.
SuppressCache.Value
org.jgroups.util.
SuppressLog
<T>
org.jgroups.protocols.
SWIFT_PING.SwiftClient
org.jgroups.util.
Table
<T>
org.jgroups.util.
Table.Counter
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.util.
Table.Dump
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.util.
Table.Getter
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.util.
Table.Missing
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.util.
Table.Remover
(implements org.jgroups.util.
Table.Visitor
<T>)
org.jgroups.blocks.
TCPConnectionMap
org.jgroups.blocks.
TCPConnectionMap.ConnectionAcceptor
(implements java.lang.Runnable)
org.jgroups.blocks.
TCPConnectionMap.TCPConnection
(implements org.jgroups.blocks.
Connection
)
org.jgroups.blocks.
TCPConnectionMap.TCPConnection.ConnectionPeerReceiver
(implements java.lang.Runnable)
org.jgroups.blocks.
TCPConnectionMap.TCPConnection.Sender
(implements java.lang.Runnable)
java.lang.Thread (implements java.lang.Runnable)
org.jgroups.protocols.tom.
DeliveryThread
org.jgroups.util.
ForwardQueue.Flusher
org.jgroups.protocols.
SEQUENCER.Flusher
java.lang.Throwable (implements java.io.Serializable)
java.lang.Exception
org.jgroups.util.
QueueClosedException
java.lang.RuntimeException
org.jgroups.
TimeoutException
org.jgroups.
UnreachableException
org.jgroups.
StateTransferException
org.jgroups.
SuspectedException
org.jgroups.util.
TimeScheduler2
(implements java.lang.Runnable, org.jgroups.util.
TimeScheduler
)
org.jgroups.util.
TimeScheduler2.MyTask
(implements java.util.concurrent.Future<V>, java.lang.Runnable)
org.jgroups.util.
TimeScheduler3
(implements java.lang.Runnable, org.jgroups.util.
TimeScheduler
)
org.jgroups.util.
TimeScheduler3.Task
(implements java.util.concurrent.Delayed, java.util.concurrent.Future<V>, java.lang.Runnable)
org.jgroups.util.
TimeScheduler3.RecurringTask
org.jgroups.protocols.
TP.DefaultBundler
(implements org.jgroups.protocols.
TP.Bundler
)
org.jgroups.protocols.
TP.DefaultBundler2
(implements org.jgroups.protocols.
TP.Bundler
)
org.jgroups.protocols.
TP.TransferQueueBundler
(implements java.lang.Runnable, org.jgroups.protocols.
TP.Bundler
)
org.jgroups.protocols.
TP.TransferQueueBundler2
(implements java.lang.Runnable, org.jgroups.protocols.
TP.Bundler
)
org.jgroups.util.
Triple
<V1,V2,V3>
org.jgroups.protocols.
TUNNEL.StubReceiver
(implements java.lang.Runnable)
org.jgroups.util.
Tuple
<V1,V2>
org.jgroups.protocols.
UDP.PacketReceiver
(implements java.lang.Runnable)
org.jgroups.protocols.
UNICAST.ConnectionReaper
(implements java.lang.Runnable)
org.jgroups.protocols.
UNICAST.ReceiverEntry
org.jgroups.protocols.
UNICAST.RetransmitTask
(implements java.lang.Runnable)
org.jgroups.protocols.
UNICAST.SenderEntry
org.jgroups.protocols.
UNICAST2.ConnectionReaper
(implements java.lang.Runnable)
org.jgroups.protocols.
UNICAST2.ReceiverEntry
org.jgroups.protocols.
UNICAST2.RetransmitTask
(implements java.lang.Runnable)
org.jgroups.protocols.
UNICAST2.SenderEntry
org.jgroups.util.
Util
org.jgroups.util.
UUID
(implements org.jgroups.
Address
)
org.jgroups.util.
AdditionalDataUUID
org.jgroups.protocols.relay.
CanBeSiteMaster
org.jgroups.util.
PayloadUUID
org.jgroups.protocols.relay.
SiteUUID
(implements org.jgroups.protocols.relay.
SiteAddress
)
org.jgroups.protocols.relay.
SiteMaster
org.jgroups.util.
TopologyUUID
org.jgroups.protocols.relay.
CanBeSiteMasterTopology
org.jgroups.protocols.
VERIFY_SUSPECT.Entry
(implements java.util.concurrent.Delayed)
org.jgroups.
Version
org.jgroups.
View
(implements java.lang.Comparable<T>, java.lang.Iterable<T>, org.jgroups.util.
Streamable
)
org.jgroups.
MergeView
org.jgroups.
ViewId
(implements java.lang.Comparable<T>, org.jgroups.util.
Streamable
)
org.jgroups.conf.
XmlConfigurator
(implements org.jgroups.conf.
ProtocolStackConfigurator
)
org.jgroups.util.
XMLSchemaGenerator
Interface Hierarchy
org.jgroups.blocks.
AbstractConnectionMap.ConnectionMapListener
<V>
org.jgroups.stack.
AddressGenerator
org.jgroups.util.
AgeOutCache.Handler
<K>
org.jgroups.protocols.
AUTH.UpHandler
org.jgroups.blocks.
BasicConnectionTable.ConnectionListener
org.jgroups.blocks.
BasicConnectionTable.Receiver
org.jgroups.blocks.
Cache.ChangeListener
org.jgroups.
ChannelListener
java.lang.Comparable<T>
org.jgroups.
Address
(also extends java.io.Externalizable, org.jgroups.util.
Streamable
)
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.blocks.
Connection
org.jgroups.blocks.
ConnectionMap
<V>
org.jgroups.blocks.atomic.
Counter
org.jgroups.logging.
CustomLogFactory
org.jgroups.protocols.tom.
DeliveryManager
org.jgroups.protocols.tom.
DeliveryProtocol
org.jgroups.stack.
DiagnosticsHandler.ProbeHandler
org.jgroups.protocols.rules.
EventHandler
org.jgroups.blocks.executor.
ExecutorNotification
java.util.concurrent.Future<V>
org.jgroups.util.
NotifyingFuture
<T>
org.jgroups.util.
FutureListener
<T>
org.jgroups.stack.
GossipRouter.ConnectionTearListener
org.jgroups.stack.
Interval
org.jgroups.blocks.
LazyRemovalCache.Printable
<K,V>
org.jgroups.blocks.locking.
LockNotification
org.jgroups.logging.
Log
java.util.Map<K,V>
java.util.concurrent.ConcurrentMap<K,V>
org.jgroups.blocks.
ReplicatedMap
<K,V>
org.jgroups.blocks.
ReplicatedMap
<K,V>
org.jgroups.
MembershipListener
org.jgroups.
Receiver
(also extends org.jgroups.
MessageListener
)
org.jgroups.
MessageListener
org.jgroups.
Receiver
(also extends org.jgroups.
MembershipListener
)
org.jgroups.blocks.
MethodLookup
org.jgroups.blocks.mux.
Muxer
<T>
org.jgroups.stack.
NakReceiverWindow.Listener
org.jgroups.blocks.
PartitionedHashMap.HashFunction
<K>
org.jgroups.conf.
PropertyConverter
org.jgroups.conf.
ProtocolStackConfigurator
org.jgroups.blocks.
ReplCache.ChangeListener
org.jgroups.blocks.
ReplCache.HashFunction
<K>
org.jgroups.blocks.
ReplCache.HashFunctionFactory
<K>
org.jgroups.blocks.
ReplicatedHashMap.Notification
<K,V>
org.jgroups.blocks.
ReplicatedTree.ReplicatedTreeListener
org.jgroups.blocks.
RequestHandler
org.jgroups.util.
ResourceManager.IpAddressRep
org.jgroups.stack.
Retransmitter.RetransmitCommand
org.jgroups.stack.
RouterStub.ConnectionListener
org.jgroups.blocks.
RpcDispatcher.Marshaller
org.jgroups.blocks.
RspCollector
org.jgroups.blocks.
RspFilter
java.lang.Runnable
org.jgroups.util.
TimeScheduler.Task
java.io.Serializable
org.jgroups.
Address
(also extends java.lang.Comparable<T>, java.io.Externalizable, org.jgroups.util.
Streamable
)
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
java.io.Externalizable
org.jgroups.
Address
(also extends java.lang.Comparable<T>, org.jgroups.util.
Streamable
)
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.util.
SocketFactory
org.jgroups.client.
StompConnection.Listener
org.jgroups.util.
Streamable
org.jgroups.
Address
(also extends java.lang.Comparable<T>, java.io.Externalizable)
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.
PhysicalAddress
org.jgroups.protocols.relay.
SiteAddress
org.jgroups.util.
SizeStreamable
org.jgroups.util.
Table.Visitor
<T>
org.jgroups.blocks.
TCPConnectionMap.Receiver
java.util.concurrent.ThreadFactory
org.jgroups.util.
ThreadFactory
org.jgroups.util.
TimeScheduler
org.jgroups.protocols.
TP.Bundler
org.jgroups.protocols.
TUNNEL.TUNNELPolicy
org.jgroups.
UpHandler
Annotation Type Hierarchy
org.jgroups.annotations.
Immutable
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
Property
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
ManagedAttribute
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
LocalAddress
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
GuardedBy
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
Experimental
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
Unsupported
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
ManagedOperation
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
DeprecatedProperty
(implements java.lang.annotation.Annotation)
org.jgroups.annotations.
MBean
(implements java.lang.annotation.Annotation)
Enum Hierarchy
java.lang.Object
java.lang.Enum<E> (implements java.lang.Comparable<T>, java.io.Serializable)
org.jgroups.
Message.Flag
org.jgroups.
Message.TransientFlag
org.jgroups.
Channel.State
org.jgroups.blocks.
ResponseMode
org.jgroups.blocks.
MemcachedConnector.Request.Type
org.jgroups.protocols.
Locking.Type
org.jgroups.protocols.
MERGE3.MergeHeader.Type
org.jgroups.protocols.
RELAY.RelayHeader.Type
org.jgroups.protocols.
Executing.Type
org.jgroups.protocols.
STOMP.ClientVerb
org.jgroups.protocols.
STOMP.ServerVerb
org.jgroups.protocols.
STOMP.StompHeader.Type
org.jgroups.protocols.
COUNTER.RequestType
org.jgroups.protocols.
COUNTER.ResponseType
org.jgroups.protocols.relay.
RELAY2.RouteStatus
org.jgroups.stack.
RouterStub.ConnectionStatus
org.jgroups.util.
Util.AddressScope
org.jgroups.util.
TimeScheduler3.TaskType
org.jgroups.util.
StackType
org.jgroups.util.
SuppressLog.Level
Overview
Package
Class
Use
Tree
Deprecated
Index
Help
PREV NEXT
FRAMES
NO FRAMES
All Classes
Copyright © 1998-2012 Bela Ban / Red Hat. All Rights Reserved.