|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |
sender
.
msgs
, removing them also from retransmission.
MembershipListener
or
BlockEvent
received from call to Receive
).
MembershipListener
or
BlockEvent
received from call to receive()
).
mode
responses.
dests
and receive responses via the RspCollector
interface.
mode
responses.
ReplicationManager.send(org.jgroups.Address, byte[], boolean, long, org.jgroups.blocks.Xid, byte[], long, long, boolean)
and releases all locks associated with
this transaction.
o
.
Channel
interface.
JChannel
's conversion to type-specific
construction, and the subsequent deprecation of its
JChannel(Object)
constructor, necessitate the
deprecation of this factory method as well. Type-specific
protocol stack configuration should be specfied during
construction of an instance of this factory.
JChannel
implementation of the
Channel interface using the protocol stack configuration
information specfied during construction of an instance of this factory.
- createDatagramSocket(InetAddress, int) -
Static method in class org.jgroups.util.Util
- Creates a DatagramSocket bound to addr.
- createManager() -
Method in class org.jgroups.persistence.PersistenceFactory
- Reads the default properties and creates a persistencemanager
The default properties are picked up from the $USER_HOME or
from the classpath.
- createManager(String) -
Method in class org.jgroups.persistence.PersistenceFactory
- Duplicated signature to create PersistenceManager to allow user to
provide property path.
- createProtocol(String, ProtocolStack) -
Method in class org.jgroups.stack.Configurator
- Creates a new protocol given the protocol specification.
- createProtocol(String) -
Method in class org.jgroups.stack.ProtocolStack
- Creates a new protocol given the protocol specification.
- createServerSocket(int, int) -
Method in class org.jgroups.blocks.ConnectionTable
- Finds first available port starting at start_port and returns server socket.
- createServerSocket(int, int) -
Method in class org.jgroups.blocks.ConnectionTableNIO
- Finds first available port starting at start_port and returns server socket.
- createServerSocket(int) -
Static method in class org.jgroups.util.Util
- Finds first available port starting at start_port and returns server socket
- createServerSocket(InetAddress, int) -
Static method in class org.jgroups.util.Util
-
- createSocket(InetAddress, InetAddress, int, long) -
Method in class org.jgroups.util.TimedWriter
- Tries to create a socket to remote_peer:remote_port.
- creator -
Variable in class org.jgroups.blocks.Xid
-
- cummulative -
Variable in class org.jgroups.debug.Debugger
-
- cvs -
Static variable in class org.jgroups.Version
-
Channel.close()
.
min_size
.
BufferedInputStream
and saves its argument, the input stream
in
, for later use.
BufferedInputStream
with the specified buffer size,
and saves its argument, the input stream
in
, for later use.
ByteArrayInputStream
so that it uses buf
as its
buffer array.
ByteArrayInputStream
that uses buf
as its
buffer array.
obj
.
DistributedHashtableDemo
to work.
data
map.
TP.isReceiveOnAllInterfaces()
instead
data
map.
seqno
(excluding
seqno
).
missing_msgs
.
sender
mbr
from the membership.
mbr
from the membership.
ACQUIRE_EXPIRATION
time after creation and if the lock is still valid (in the
future locks will be leased for a predefined period of time).
JChannel
instance with the protocol stack
specified by the DEFAULT_PROTOCOL_STACK
member.
JChannel
instance with the protocol stack
configuration contained by the specified file.
JChannel
instance with the protocol stack
configuration contained by the specified XML element.
JChannel
instance with the protocol stack
configuration indicated by the specified URL.
JChannel
instance with the protocol stack
configuration based upon the specified properties parameter.
JChannel
instance with the protocol stack
configuration contained by the protocol stack configurator parameter.
Channel
interface.getChannel(Object)
method of this
class.
JChannelFactory
instance that utilizes the
specified file for protocl stack configuration.
JChannelFactory
instance that utilizes the
specified file for protocl stack configuration.
JChannelFactory
instance that utilizes the
specified file for protocl stack configuration.
JChannel
instance with the protocol stack
configuration based upon the specified properties parameter.
Address
representing the JMS node ID or JMS topic group.LockManager
represents generic lock manager that allows
obtaining and releasing locks on objects.DistributedLockManager.unlock(Object, Object, boolean)
method if a lock is only locally released, because it is locked
by multiple DistributedLockManagers.lockId
on behalf of the specified
owner
.
obj
for specified owner
.
MembershipListener
instances.MessageListener
instances.setName()
has been called.
javax.jms.MessageListener
interface.
Channel
to be notified when messages have been received
instead of having to actively poll the channel for new messages.Down
(when done).
fqn
.
MethodCall
object from the message's buffer and prints it.
groupname
.
FilePersistenceManager
or DBPersistenceManager
.
addr
from connection table.
key
from the node's hashmap
obj
from all receiver sets and wake up
retransmission thread.
next_to_remove
, increments the latter.
obj
from the list, checking for equality using the equals
operator.
membership
variable to the value of
members
.
first_seqno
and last_seqno
.
getState()
object when calling receive()
.
getState()
object when
calling receive()
.
ReplicationManager.send(org.jgroups.Address, byte[], boolean, long, org.jgroups.blocks.Xid, byte[], long, long, boolean)
and releases all locks associated with
this transaction.
messages List<\code> if there
are less than 10 messages in the List it waits some time to ensure to chose from
a set of messages > 1.
- run() -
Method in class org.jgroups.protocols.TUNNEL
-
- run() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- run() -
Method in class org.jgroups.protocols.UDP
-
- run() -
Method in class org.jgroups.protocols.UDP_NIO.Connector
-
- run() -
Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
-
- run() -
Method in class org.jgroups.protocols.UDP_NIO.MulticastReceiver
-
- run() -
Method in class org.jgroups.protocols.VERIFY_SUSPECT
- Will be started when a suspect is added to the suspects hashtable.
- run() -
Method in class org.jgroups.protocols.pbcast.FD
-
- run() -
Method in class org.jgroups.protocols.pbcast.PBCAST
- Gossip thread.
- run() -
Method in class org.jgroups.stack.GossipServer
- Deprecated.
- run() -
Method in class org.jgroups.util.ReusableThread
- Delicate piece of code (means very important :-)).
- run() -
Method in class org.jgroups.util.Scheduler
-
- run() -
Method in interface org.jgroups.util.TimeScheduler.Task
- Execute the task
- runMessageGarbageCollection() -
Method in class org.jgroups.jmx.protocols.pbcast.STABLE
-
- runMessageGarbageCollection() -
Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
-
- runMessageGarbageCollection() -
Method in class org.jgroups.protocols.pbcast.STABLE
-
Scheduler
.Channel.receive()
, as requested by
Channel.getState(s)
previously.RequestCorrelator.sendRequest(long,List,Message,RspCollector)
.
Clear
method.
Clear
method.
PullPushAdapter.addMembershipListener(org.jgroups.MembershipListener)
int
Limits the window size to a reasonable value.
listener
for state notification events.
messagesHandler<\code>
- start() -
Method in class org.jgroups.protocols.STABLE
- Start the layer:
i.
- start() -
Method in class org.jgroups.protocols.STATE_TRANSFER
-
- start() -
Method in class org.jgroups.protocols.TCP
-
- start() -
Method in class org.jgroups.protocols.TCPGOSSIP
-
- start() -
Method in class org.jgroups.protocols.TOTAL
- Prepare this layer to receive messages from above
- start() -
Method in class org.jgroups.protocols.TOTAL_OLD
-
- start() -
Method in class org.jgroups.protocols.TOTAL_TOKEN
-
- start() -
Method in class org.jgroups.protocols.TP
- Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() -
Method in class org.jgroups.protocols.TUNNEL
-
- start() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- start() -
Method in class org.jgroups.protocols.UDP
- Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() -
Method in class org.jgroups.protocols.UDP_NIO.Connector
-
- start() -
Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
- Get all interfaces, create one Connector per interface and call start() on it
- start() -
Method in class org.jgroups.protocols.UDP_NIO
- Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() -
Method in class org.jgroups.protocols.UNICAST
-
- start() -
Method in class org.jgroups.protocols.VIEW_SYNC
-
- start() -
Method in class org.jgroups.protocols.WANPIPE
-
- start() -
Method in class org.jgroups.protocols.pbcast.GMS
-
- start() -
Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- start() -
Method in class org.jgroups.protocols.pbcast.NAKACK
-
- start() -
Method in class org.jgroups.protocols.pbcast.STABLE
-
- start() -
Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- start() -
Method in class org.jgroups.stack.AckMcastSenderWindow
- Start the retransmitter.
- start() -
Method in class org.jgroups.stack.GossipRouter
- JBoss MBean lifecycle operation.
- start() -
Method in class org.jgroups.stack.MessageProtocol
-
- start() -
Method in class org.jgroups.stack.Protocol
- This method is called on a
Channel.connect(String)
.
- start() -
Method in class org.jgroups.stack.Router
-
- start() -
Method in class org.jgroups.util.Proxy
-
- start() -
Method in class org.jgroups.util.ReusableThread
- Will always be called from synchronized method, no need to do our own synchronization
- start() -
Method in class org.jgroups.util.Scheduler
-
- start() -
Method in class org.jgroups.util.TimeScheduler
- Start the scheduler, if it's suspended or stopped
- startDownHandler() -
Method in class org.jgroups.protocols.AUTOCONF
- Leave empty: no down_thread will be created, but the down_thread of the neighbor above us will be used
- startDownHandler() -
Method in class org.jgroups.protocols.BSH
- We have no down handler thread
- startDownHandler() -
Method in class org.jgroups.protocols.MERGE2
- This prevents the down-handler thread to be created, which is not needed in the protocol.
- startDownHandler() -
Method in class org.jgroups.protocols.MERGE3
- This prevents the down-handler thread to be created, which is not needed in the protocol.
- startDownHandler() -
Method in class org.jgroups.stack.Protocol
- Used internally.
- startDownHandler() -
Method in class org.jgroups.stack.ProtocolStack
-
- startProtocolStack(Protocol) -
Method in class org.jgroups.stack.Configurator
-
- startStack() -
Method in class org.jgroups.stack.ProtocolStack
- Start all layers.
- startUpHandler() -
Method in class org.jgroups.protocols.AUTOCONF
- Leave empty: no up_thread will be created, but the up_thread of the neighbor below us will be used
- startUpHandler() -
Method in class org.jgroups.protocols.BSH
- We have no up handler thread
- startUpHandler() -
Method in class org.jgroups.protocols.MERGE2
- This prevents the up-handler thread to be created, which is not needed in the protocol.
- startUpHandler() -
Method in class org.jgroups.protocols.MERGE3
- This prevents the up-handler thread to be created, which is not needed in the protocol.
- startUpHandler() -
Method in class org.jgroups.protocols.TP
- This prevents the up-handler thread to be created, which essentially is superfluous:
messages are received from the network rather than from a layer below.
- startUpHandler() -
Method in class org.jgroups.protocols.TUNNEL
- This prevents the up-handler thread to be created, which essentially is superfluous:
messages are received from the network rather than from a layer below.
- startUpHandler() -
Method in class org.jgroups.protocols.UDP_NIO
- This prevents the up-handler thread to be created, which essentially is superfluous:
messages are received from the network rather than from a layer below.
- startUpHandler() -
Method in class org.jgroups.stack.Protocol
- Used internally.
- startUpHandler() -
Method in class org.jgroups.stack.ProtocolStack
-
- startWork() -
Method in class org.jgroups.stack.ProtocolStack
- Override with null functionality: we don't need any threads to be started !
- started -
Variable in class org.jgroups.blocks.RequestCorrelator
-
- started(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
- stateListener -
Variable in class org.jgroups.blocks.MessageListenerAdapter
-
- stateTransferCompleted(boolean) -
Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
-
- stateTransferRunning() -
Method in class org.jgroups.blocks.ReplicatedHashtable
-
- stateTransferStarted() -
Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
-
- state_promise -
Variable in class org.jgroups.blocks.DistributedHashtable
-
- stats -
Variable in class org.jgroups.JChannel
- Collect statistics
- stats -
Variable in class org.jgroups.stack.Protocol
-
- statsEnabled() -
Method in class org.jgroups.JChannel
-
- statsEnabled() -
Method in class org.jgroups.stack.Protocol
-
- stop() -
Method in class org.jgroups.blocks.ConnectionTable
- Closes all open sockets, the server socket and all threads waiting for incoming messages
- stop() -
Method in class org.jgroups.blocks.ConnectionTableNIO
- Closes all open sockets, the server socket and all threads waiting for incoming messages
- stop() -
Method in class org.jgroups.blocks.DistributedHashtable
-
- stop() -
Method in class org.jgroups.blocks.DistributedQueue
-
- stop() -
Method in class org.jgroups.blocks.DistributedTree
-
- stop() -
Method in class org.jgroups.blocks.Link
-
- stop() -
Method in class org.jgroups.blocks.LogicalLink
- Stop all links
- stop() -
Method in class org.jgroups.blocks.MessageDispatcher
-
- stop() -
Method in class org.jgroups.blocks.NotificationBus
-
- stop() -
Method in class org.jgroups.blocks.PullPushAdapter
-
- stop() -
Method in class org.jgroups.blocks.ReplicatedTree
-
- stop() -
Method in class org.jgroups.blocks.ReplicationManager
-
- stop() -
Method in class org.jgroups.blocks.RequestCorrelator
-
- stop() -
Method in class org.jgroups.debug.Debugger
-
- stop(String) -
Static method in class org.jgroups.debug.Profiler
-
- stop() -
Method in class org.jgroups.debug.ProtocolTester
-
- stop() -
Method in class org.jgroups.debug.Simulator
-
- stop() -
Method in class org.jgroups.demos.wb.GraphPanel
-
- stop() -
Method in class org.jgroups.jmx.JChannel
-
- stop() -
Method in interface org.jgroups.jmx.JChannelMBean
-
- stop() -
Method in class org.jgroups.jmx.Protocol
-
- stop() -
Method in interface org.jgroups.jmx.ProtocolMBean
-
- stop() -
Method in class org.jgroups.protocols.BSH
-
- stop() -
Method in class org.jgroups.protocols.DEADLOCK
-
- stop() -
Method in class org.jgroups.protocols.Discovery
-
- stop() -
Method in class org.jgroups.protocols.FC
-
- stop() -
Method in class org.jgroups.protocols.FD
-
- stop() -
Method in class org.jgroups.protocols.FD_PID
-
- stop() -
Method in class org.jgroups.protocols.FD_PROB
-
- stop() -
Method in class org.jgroups.protocols.FD_SIMPLE
-
- stop() -
Method in class org.jgroups.protocols.FD_SOCK
-
- stop() -
Method in class org.jgroups.protocols.JMS
- Stops the work of the JMS protocol.
- stop() -
Method in class org.jgroups.protocols.MERGE
-
- stop() -
Method in class org.jgroups.protocols.MERGE2
-
- stop() -
Method in class org.jgroups.protocols.MPING
-
- stop() -
Method in class org.jgroups.protocols.NAKACK
-
- stop() -
Method in class org.jgroups.protocols.PIGGYBACK
-
- stop() -
Method in class org.jgroups.protocols.PING
-
- stop() -
Method in class org.jgroups.protocols.PingSender
-
- stop() -
Method in class org.jgroups.protocols.PingWaiter
-
- stop() -
Method in class org.jgroups.protocols.SHUFFLE
- Stops the messagesHandler
- stop() -
Method in class org.jgroups.protocols.SMACK
-
- stop() -
Method in class org.jgroups.protocols.STABLE
- Stop scheduling the gossip task
- stop() -
Method in class org.jgroups.protocols.STATE_TRANSFER
-
- stop() -
Method in class org.jgroups.protocols.TCP
-
- stop() -
Method in class org.jgroups.protocols.TCPGOSSIP
-
- stop() -
Method in class org.jgroups.protocols.TOTAL
- Handle the stop() method travelling down the stack.
- stop() -
Method in class org.jgroups.protocols.TOTAL_OLD
-
- stop() -
Method in class org.jgroups.protocols.TOTAL_TOKEN
- Overrides @org.jgroups.stack.MessageProtocol#stop().
- stop() -
Method in class org.jgroups.protocols.TP
-
- stop() -
Method in class org.jgroups.protocols.TUNNEL
-
- stop() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- stop() -
Method in class org.jgroups.protocols.UDP
-
- stop() -
Method in class org.jgroups.protocols.UDP_NIO.Connector
- Stops the connector.
- stop() -
Method in class org.jgroups.protocols.UDP_NIO.ConnectorTable
-
- stop() -
Method in class org.jgroups.protocols.UDP_NIO
-
- stop() -
Method in class org.jgroups.protocols.UNICAST
-
- stop() -
Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- stop() -
Method in class org.jgroups.protocols.VIEW_SYNC
-
- stop() -
Method in class org.jgroups.protocols.WANPIPE
-
- stop() -
Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- stop() -
Method in class org.jgroups.protocols.pbcast.FD
-
- stop() -
Method in class org.jgroups.protocols.pbcast.GMS
-
- stop() -
Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- stop() -
Method in class org.jgroups.protocols.pbcast.NAKACK
-
- stop() -
Method in class org.jgroups.protocols.pbcast.PBCAST
-
- stop() -
Method in class org.jgroups.protocols.pbcast.STABLE
-
- stop() -
Method in class org.jgroups.stack.AckMcastSenderWindow
- Stop the rentransmition and clear all pending msgs.
- stop() -
Method in class org.jgroups.stack.GossipClient
-
- stop() -
Method in class org.jgroups.stack.GossipRouter
- JBoss MBean lifecycle operation.
- stop() -
Method in class org.jgroups.stack.MessageProtocol
-
- stop() -
Method in class org.jgroups.stack.Protocol
- This method is called on a
Channel.disconnect()
.
- stop() -
Method in class org.jgroups.stack.Retransmitter
- Stop the rentransmition and clear all pending msgs.
- stop() -
Method in class org.jgroups.stack.Router
-
- stop() -
Method in class org.jgroups.util.ReusableThread
- Stops the thread by setting thread=null and interrupting it.
- stop() -
Method in class org.jgroups.util.Scheduler
- Stop the scheduler thread.
- stop() -
Method in class org.jgroups.util.TimeScheduler
- Stop the scheduler if it's running.
- stopInternal() -
Method in class org.jgroups.stack.Protocol
- Used internally.
- stopInternal() -
Method in class org.jgroups.stack.ProtocolStack
-
- stopProtocolStack(Protocol) -
Method in class org.jgroups.stack.Configurator
-
- stopStack() -
Method in class org.jgroups.stack.ProtocolStack
- Iterates through all the protocols from top to bottom and does the following:
Waits until all messages in the down queue have been flushed (ie., size is 0)
Calls stop() on the protocol
- stopWork() -
Method in class org.jgroups.stack.ProtocolStack
- Override with null functionality: we don't need any threads to be started !
- stopped -
Variable in class org.jgroups.blocks.DistributedQueue
-
- stopped(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
- streamableFromByteBuffer(Class, byte[]) -
Static method in class org.jgroups.util.Util
-
- streamableToByteBuffer(Streamable) -
Static method in class org.jgroups.util.Util
-
- subgroups -
Variable in class org.jgroups.MergeView
-
- suspect(Address) -
Method in interface org.jgroups.MembershipListener
- Called whenever a member is suspected of having crashed,
but has not yet been excluded.
- suspect(Address) -
Method in class org.jgroups.ReceiverAdapter
-
- suspect(Address) -
Method in class org.jgroups.blocks.DistributedHashtable
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.DistributedQueue
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.DistributedTree
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.GroupRequest
- Callback (called by RequestCorrelator or Transport).
- suspect(Address) -
Method in class org.jgroups.blocks.MembershipListenerAdapter
- Notify membership listener that some node was suspected.
- suspect(Address) -
Method in class org.jgroups.blocks.NotificationBus
-
- suspect(Address) -
Method in class org.jgroups.blocks.ReplicatedHashtable
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.ReplicatedTree
- Called when a member is suspected
- suspect(Address) -
Method in interface org.jgroups.blocks.RspCollector
-
- suspect(Address) -
Method in class org.jgroups.blocks.VotingAdapter
- Callback for notification that one node is suspected
- suspect(Address) -
Method in class org.jgroups.demos.Chat
-
- suspect(Address) -
Method in class org.jgroups.demos.QuoteClient
-
- suspect(Address) -
Method in class org.jgroups.demos.QuoteServer
-
- suspect(Address) -
Method in class org.jgroups.demos.Topology
-
- suspect(Address) -
Method in class org.jgroups.demos.ViewDemo
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.demos.wb.Whiteboard
-
- suspect(Address) -
Method in class org.jgroups.protocols.ClientGmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.CoordGmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.GMS
-
- suspect(Address) -
Method in class org.jgroups.protocols.GmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.ParticipantGmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- suspect(Address) -
Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
- suspect(Object) -
Method in class org.jgroups.stack.AckMcastReceiverWindow
-
- suspect(Address) -
Method in class org.jgroups.stack.AckMcastSenderWindow
- Process with address
suspected
is suspected: remove it
from all receiver sets.
- suspect(Object) -
Method in class org.jgroups.util.AckCollector
-
- suspend() -
Method in class org.jgroups.JChannel
- Send() blocks from now on, until resume() is called
- suspend() -
Method in class org.jgroups.jmx.JChannel
-
- suspend() -
Method in interface org.jgroups.jmx.JChannelMBean
-
- suspend() -
Method in class org.jgroups.util.ReusableThread
- Suspends the thread.
- suspendViewHandler() -
Method in class org.jgroups.jmx.protocols.pbcast.GMS
-
- suspendViewHandler() -
Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
-
- suspendViewHandler() -
Method in class org.jgroups.protocols.pbcast.GMS
-
- suspended(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
lockId
on behalf of the specified
owner
.
lockId
on behalf of the specified
owner
.
obj
owned by specified owner
.
obj
owned by specified owner
.
messages List<\code> where the messagesHandler<\code>
retrieves them.
- up(Event) -
Method in class org.jgroups.protocols.SIZE
-
- up(Event) -
Method in class org.jgroups.protocols.SMACK
-
- up(Event) -
Method in class org.jgroups.protocols.STATE_TRANSFER
-
- up(Event) -
Method in class org.jgroups.protocols.STATS
-
- up(Event) -
Method in class org.jgroups.protocols.TOTAL
-
- up(Event) -
Method in class org.jgroups.protocols.TOTAL_OLD
- handles an Event coming up the Protocol Stack
- up(Event) -
Method in class org.jgroups.protocols.TP
- handle the UP event.
- up(Event) -
Method in class org.jgroups.protocols.TRACE
-
- up(Event) -
Method in class org.jgroups.protocols.UDP_NIO
- handle the UP event.
- up(Event) -
Method in class org.jgroups.protocols.UNICAST
-
- up(Event) -
Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- up(Event) -
Method in class org.jgroups.protocols.VIEW_ENFORCER
-
- up(Event) -
Method in class org.jgroups.protocols.VIEW_SYNC
-
- up(Event) -
Method in class org.jgroups.protocols.pbcast.FD
-
- up(Event) -
Method in class org.jgroups.protocols.pbcast.GMS
-
- up(Event) -
Method in class org.jgroups.protocols.pbcast.NAKACK
- Callback.
- up(Event) -
Method in class org.jgroups.protocols.pbcast.PBCAST
-
- up(Event) -
Method in class org.jgroups.protocols.pbcast.STABLE
-
- up(Event) -
Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- up(Event) -
Method in class org.jgroups.stack.MessageProtocol
- Handle an event coming from the layer above
- up(Event) -
Method in class org.jgroups.stack.Protocol
- An event was received from the layer below.
- up(Event, int) -
Method in interface org.jgroups.stack.ProtocolObserver
- Called when an event is about to be dispatched to the protocol (before it is dispatched).
- up(Event) -
Method in class org.jgroups.stack.ProtocolStack
-
- upThreadEnabled() -
Method in class org.jgroups.stack.Protocol
-
- up_handler -
Variable in class org.jgroups.Channel
-
- up_handler -
Variable in class org.jgroups.stack.Protocol
-
- up_prot -
Variable in class org.jgroups.stack.Protocol
-
- up_queue -
Variable in class org.jgroups.stack.Protocol
-
- up_thread -
Variable in class org.jgroups.stack.Protocol
-
- up_thread_prio -
Variable in class org.jgroups.stack.Protocol
-
- update(Graphics) -
Method in class org.jgroups.demos.wb.GraphPanel
-
- updateView(View) -
Method in class org.jgroups.protocols.TOTAL_TOKEN
-
- updateView(View) -
Method in class org.jgroups.stack.MessageProtocol
-
- updateWindow(RingToken) -
Method in class org.jgroups.protocols.ring.RingNodeFlowControl
-
- useLocks() -
Method in class org.jgroups.blocks.ReplicationData
-
true
or false
messages.
|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |