|
||||||||||||
PREV NEXT | FRAMES NO FRAMES |
AbstractService
is a superclass for all service implementations.msgs
, removing them also from retransmission.
sender
.
Tracer
.
true
, every call to print
will call
flush
.
MembershipListener
or
BlockEvent
received from call to receive()
).
MembershipListener
or
BlockEvent
received from call to Receive
).
true
if the specified module name is illegal.
dests
and receive responses
via the RspCollector interface.
mode
responses.
mode
responses.
org.javagroups.conf.magicNumberFile
.flush
) but does not
close the output stream (System.err or System.out).
flush
) and closes
the output file, stream, writer, or socket associated with this tracer.
true
, this tracer has been closed and no further output
will be accepted.
send
and releases all locks associated with
this transaction.
o
.
Channel
interface.
Channel.close()
.
flush
) and closes
the output file, stream, writer, or socket associated with this tracer.
flush
) and closes
the output stream associated with this tracer.
flush
) and closes
the output file, stream, writer, or socket associated with this tracer.
flush
) and closes
the output file, stream, writer, or socket associated with this tracer.
execute()
).
message
to the output file,
stream, writer, or socket associated with this tracer.
message
to the output file,
stream, writer, or socket associated with this tracer.
message
to the output file,
stream, writer, or socket associated with this tracer.
message
to the output file,
stream, writer, or socket associated with this tracer.
obj
.
Tracer
to be used for output for the specified
module name.
date
as a formatted string using the ISO 8601 date
format ("yyyy-MM-dd'T'hh:mm:ss,S").
date
as a formatted string.
data
map.
true
if this tracer performs auto-flushing after
every print.
LeaseFactory.DURATION_ANY
.
Tracer
to be used when no other
appropriate one is found.
LeaseFactory
that created this lease.
data
map.
LeaseFactory.DURATION_FOREVER
.
seqno
(excluding
seqno
).
missing_msgs
.
sender
mbr
from the membership.
mbr
from the membership.
true
if inter-service communication
processes should temporarily stop sending messages to service channel.
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).
Address
representing the JMS node ID or JMS topic group.Lease
interface represents a token granted by lease manager
that allows access to some resource for a limited period of time.LeaseFactory
is responsible for granting new leases, renewing
existing leases and canceling leases when it is no longer needed.LeaseFactoryClient
is an implementation of LeaseFactory
interface that delegates lease granting to group containing one or more
LeaseFactoryService
instances.LeaseFactoryService
is service that is able to lease resources
to clients.LEASE_GRANTED
or LEASE_RENEWED
.
LEASE_CANCELED
or LEASE_RENEWED
.
Trace
level value, return a string describing the
level.
obj
for specified owner
.
lockId
on behalf of the specified
owner
.
LockManager
represents generic lock manager that allows
obtaining and releasing locks on objects.Tracer
that matches the specified module
name.
MembershipListener
instances.MessageListener
instances.SetName
has been called
println
.
javax.jms.MessageListener
interface.
Down
(when done).
fqn
.
message
to it.
message
and calls
print
.
MethodCall
object from the message's buffer and prints it.
PrintStream
.ObjectInput
groupname
.
head
.
next_to_remove
, increments the latter.
addr
from connection table.
addr
from connection table.
obj
from all receiver sets and wake up
retransmission thread.
key
from the node's hashmap
obj
from the list, checking for equality using the equals
operator.
Tracer
for the specified module.
membership
variable to the value of
members
.
STDOUT
.
first_seqno
and last_seqno
.
getState()
object when
calling receive()
.getState()
object when calling receive()
.
send
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.javagroups.protocols.MERGE
- If IP multicast: periodically mcast a HELLO message
If gossiping: periodically retrieve the membership.
- run() -
Method in class org.javagroups.protocols.FLOW_CONTROL
- FCInfo request must be submitted in a different thread.
- run() -
Method in class org.javagroups.protocols.FD_SOCK
- Runs as long as there are 2 members and more.
- run() -
Method in class org.javagroups.protocols.FD_PROB
- Loop while more than 1 member available.
- run() -
Method in class org.javagroups.protocols.GMS
-
- run() -
Method in class org.javagroups.protocols.pbcast.PBCAST
- Gossip thread.
- run() -
Method in class org.javagroups.protocols.pbcast.FD
-
- run() -
Method in class org.javagroups.stack.GossipServer
-
- run() -
Method in class org.javagroups.util.ReusableThread
- Delicate piece of code (means very important :-)).
- run() -
Method in interface org.javagroups.util.TimeScheduler.Task
- Execute the task
- run() -
Method in class org.javagroups.util.Scheduler
-
- runThread -
Variable in class org.javagroups.service.AbstractService
-
- RWLock - class org.javagroups.util.RWLock.
- Lock allowing multiple reads or a single write.
- RWLock.BlockException - exception org.javagroups.util.RWLock.BlockException.
- Exception thrown when a lock request would block the caller
- RWLock.BlockException() -
Constructor for class org.javagroups.util.RWLock.BlockException
-
- RWLock.BlockException(String) -
Constructor for class org.javagroups.util.RWLock.BlockException
-
- RWLock.IntException - exception org.javagroups.util.RWLock.IntException.
- Interrupted exception wrapped in a RuntimeException
- RWLock.IntException() -
Constructor for class org.javagroups.util.RWLock.IntException
-
- RWLock.IntException(String) -
Constructor for class org.javagroups.util.RWLock.IntException
-
- RWLock() -
Constructor for class org.javagroups.util.RWLock
-
RequestCorrelator.sendRequest(long,List,Message,RspCollector)
.
ServiceRunner
is utility class that runs services in standalone
mode.Clear
method.
Clear
method.
addr
on
port
.
addr
on
port
at the specified trace level.
PrintStream
and
trace level.
PrintWriter
and
trace level.
host
on
port
with the given trace level.
PrintStream
.
PrintWriter
.
host
on
port
.
PullPushAdapter.addMembershipListener(org.javagroups.MembershipListener)
module
.
addr
on
port
.
PrintStream
.
PrintWriter
.
host
on
port
.
int
Limits the window size to a reasonable value.
Channel.receive()
, as requested by
Channel.getState(s)
previously.listener
for state notification events.
messagesHandler<\code>
- start() -
Method in class org.javagroups.protocols.PIGGYBACK
-
- start() -
Method in class org.javagroups.protocols.PERF
-
- start() -
Method in class org.javagroups.protocols.MERGE
-
- start() -
Method in class org.javagroups.protocols.LOOPBACK
-
- start() -
Method in class org.javagroups.protocols.JMS
- Start the JMS protocol.
- start() -
Method in class org.javagroups.protocols.FLUSH
-
- start() -
Method in class org.javagroups.protocols.FD_PROB
-
- start() -
Method in class org.javagroups.protocols.FD_PID
-
- start() -
Method in class org.javagroups.protocols.DEADLOCK
-
- start() -
Method in class org.javagroups.protocols.GMS
-
- start() -
Method in class org.javagroups.protocols.BSH
-
- start() -
Method in class org.javagroups.protocols.AUTOCONF
-
- start() -
Method in class org.javagroups.protocols.pbcast.STATE_TRANSFER
-
- start() -
Method in class org.javagroups.protocols.pbcast.STABLE
-
- start() -
Method in class org.javagroups.protocols.pbcast.NAKACK
-
- start() -
Method in class org.javagroups.protocols.pbcast.GMS
-
- start() -
Method in class org.javagroups.protocols.pbcast.GmsImpl
-
- start() -
Method in class org.javagroups.service.AbstractService
- Start standalone thread that will run until explicitly stopped.
- start() -
Method in class org.javagroups.stack.Router
-
- start() -
Method in class org.javagroups.stack.AckMcastSenderWindow
- Start the retransmitter.
- start() -
Method in class org.javagroups.stack.MessageProtocol
-
- start() -
Method in class org.javagroups.stack.ProtocolStack
- Start all layers.
- start() -
Method in class org.javagroups.stack.Protocol
- This method is called on a
Channel.connect(String)
.
- start() -
Method in class org.javagroups.util.Proxy1_4
-
- start() -
Method in class org.javagroups.util.ReusableThread
-
- start() -
Method in class org.javagroups.util.TimeScheduler
- Start the scheduler, if it's suspended or stopped
- start() -
Method in class org.javagroups.util.Scheduler
-
- start(ChannelFactory, String, boolean) -
Method in class org.javagroups.demos.DistributedHashtableDemo
-
- start(long) -
Method in class org.javagroups.blocks.DistributedTree
-
- start(long) -
Method in class org.javagroups.blocks.DistributedQueue
-
- start(long) -
Method in class org.javagroups.blocks.DistributedHashtable
-
- start(String) -
Static method in class org.javagroups.debug.Profiler
-
- start(String) -
Method in class org.javagroups.demos.ViewDemo
-
- start(String) -
Method in class org.javagroups.demos.wb.GraphPanel
-
- start(String, ChannelFactory, String) -
Method in class org.javagroups.demos.DistributedQueueDemo
-
- start(String, String) -
Method in class org.javagroups.demos.NotificationBusDemo
-
- startDownHandler() -
Method in class org.javagroups.protocols.MERGE2
- DON'T REMOVE ! This prevents the down-handler thread to be created, which is not needed in the protocol.
- startDownHandler() -
Method in class org.javagroups.protocols.BSH
- We have no down handler thread
- startDownHandler() -
Method in class org.javagroups.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.javagroups.stack.ProtocolStack
-
- startDownHandler() -
Method in class org.javagroups.stack.Protocol
- Used internally.
- started(Runnable) -
Method in interface org.javagroups.util.SchedulerListener
-
- startProtocolStack(Protocol) -
Method in class org.javagroups.stack.Configurator
-
- startService(ResourceBundle) -
Static method in class org.javagroups.service.ServiceRunner
- Method to start service.
- startUpHandler() -
Method in class org.javagroups.protocols.UDP
- DON'T REMOVE ! 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.javagroups.protocols.TCP
- DON'T REMOVE ! 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.javagroups.protocols.MERGE2
- DON'T REMOVE ! This prevents the up-handler thread to be created, which is not needed in the protocol.
- startUpHandler() -
Method in class org.javagroups.protocols.BSH
- We have no up handler thread
- startUpHandler() -
Method in class org.javagroups.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.javagroups.stack.ProtocolStack
-
- startUpHandler() -
Method in class org.javagroups.stack.Protocol
- Used internally.
- startWork() -
Method in class org.javagroups.stack.ProtocolStack
- Override with null functionality: we don't need any threads to be started !
- STATE_RECEIVED -
Static variable in class org.javagroups.Event
-
- state_timeout -
Variable in class org.javagroups.blocks.TransactionalHashtable
-
- STATE_TRANSFER - class org.javagroups.protocols.STATE_TRANSFER.
- State transfer layer.
- STATE_TRANSFER - class org.javagroups.protocols.pbcast.STATE_TRANSFER.
- New STATE_TRANSFER protocol based on PBCAST.
- STATE_TRANSFER.StateHeader - class org.javagroups.protocols.pbcast.STATE_TRANSFER.StateHeader.
- Wraps data for a state request/response.
- STATE_TRANSFER.StateHeader() -
Constructor for class org.javagroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER.StateHeader(int, Address, long, Digest) -
Constructor for class org.javagroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER() -
Constructor for class org.javagroups.protocols.STATE_TRANSFER
-
- STATE_TRANSFER() -
Constructor for class org.javagroups.protocols.pbcast.STATE_TRANSFER
-
- stateListener -
Variable in class org.javagroups.blocks.MessageListenerAdapter
-
- stateTransferCompleted(boolean) -
Method in interface org.javagroups.blocks.ReplicatedHashtable.StateTransferListener
-
- StateTransferInfo - class org.javagroups.stack.StateTransferInfo.
- Contains parameters for state transfer.
- StateTransferInfo(Address, int, Address) -
Constructor for class org.javagroups.stack.StateTransferInfo
-
- StateTransferInfo(int, Address) -
Constructor for class org.javagroups.stack.StateTransferInfo
-
- StateTransferInfo(int, Vector) -
Constructor for class org.javagroups.stack.StateTransferInfo
-
- stateTransferRunning() -
Method in class org.javagroups.blocks.ReplicatedHashtable
-
- stateTransferStarted() -
Method in interface org.javagroups.blocks.ReplicatedHashtable.StateTransferListener
-
- STDERR_STMT -
Static variable in class org.javagroups.log.Trace
-
- STDERRS -
Static variable in class org.javagroups.log.Trace
- We initially create Tracers for each STDERR level
- STDOUT_STMT -
Static variable in class org.javagroups.log.Trace
-
- STDOUTS -
Static variable in class org.javagroups.log.Trace
- We initially create Tracers for each STDOUT level
- STOP_QUEUEING -
Static variable in class org.javagroups.Event
-
- stop() -
Method in class org.javagroups.blocks.ConnectionTable1_4
- Closes all open sockets, the server socket and all threads waiting for incoming messages
- stop() -
Method in class org.javagroups.blocks.TransactionalHashtable
- Leaves the group.
- stop() -
Method in class org.javagroups.blocks.ReplicationManager
-
- stop() -
Method in class org.javagroups.blocks.ReplicatedTree
-
- stop() -
Method in class org.javagroups.blocks.NotificationBus
-
- stop() -
Method in class org.javagroups.blocks.LogicalLink
- Stop all links
- stop() -
Method in class org.javagroups.blocks.Link
-
- stop() -
Method in class org.javagroups.blocks.DistributedTree
-
- stop() -
Method in class org.javagroups.blocks.DistributedQueue
-
- stop() -
Method in class org.javagroups.blocks.RequestCorrelator
-
- stop() -
Method in class org.javagroups.blocks.PullPushAdapter
-
- stop() -
Method in class org.javagroups.blocks.MessageDispatcher
-
- stop() -
Method in class org.javagroups.blocks.DistributedHashtable
-
- stop() -
Method in class org.javagroups.blocks.ConnectionTable
- Closes all open sockets, the server socket and all threads waiting for incoming messages
- stop() -
Method in class org.javagroups.debug.ProtocolTester
-
- stop() -
Method in class org.javagroups.demos.wb.GraphPanel
-
- stop() -
Method in class org.javagroups.protocols.WANPIPE
-
- stop() -
Method in class org.javagroups.protocols.VERIFY_SUSPECT
-
- stop() -
Method in class org.javagroups.protocols.UNICAST
-
- stop() -
Method in class org.javagroups.protocols.UDP
-
- stop() -
Method in class org.javagroups.protocols.UDP.UcastReceiver
-
- stop() -
Method in class org.javagroups.protocols.TUNNEL
-
- stop() -
Method in class org.javagroups.protocols.TOTAL_TOKEN
- Overrides @org.javagroups.stack.MessageProtocol#stop().
- stop() -
Method in class org.javagroups.protocols.TOTAL_OLD
-
- stop() -
Method in class org.javagroups.protocols.TOTAL
- Handle the stop() method travelling down the stack.
- stop() -
Method in class org.javagroups.protocols.TCP
-
- stop() -
Method in class org.javagroups.protocols.STATE_TRANSFER
-
- stop() -
Method in class org.javagroups.protocols.STABLE
- Stop scheduling the gossip task
- stop() -
Method in class org.javagroups.protocols.SMACK
-
- stop() -
Method in class org.javagroups.protocols.SHUFFLE
- Stops the messagesHandler
- stop() -
Method in class org.javagroups.protocols.PING
-
- stop() -
Method in class org.javagroups.protocols.PIGGYBACK
-
- stop() -
Method in class org.javagroups.protocols.NAKACK
-
- stop() -
Method in class org.javagroups.protocols.MERGE2
-
- stop() -
Method in class org.javagroups.protocols.MERGE
-
- stop() -
Method in class org.javagroups.protocols.JMS
- Stops the work of the JMS protocol.
- stop() -
Method in class org.javagroups.protocols.FD_SOCK
-
- stop() -
Method in class org.javagroups.protocols.FD_SIMPLE
-
- stop() -
Method in class org.javagroups.protocols.FD_PROB
-
- stop() -
Method in class org.javagroups.protocols.FD_PID
-
- stop() -
Method in class org.javagroups.protocols.FD
-
- stop() -
Method in class org.javagroups.protocols.DEADLOCK
-
- stop() -
Method in class org.javagroups.protocols.BSH
-
- stop() -
Method in class org.javagroups.protocols.pbcast.STABLE
-
- stop() -
Method in class org.javagroups.protocols.pbcast.PBCAST
-
- stop() -
Method in class org.javagroups.protocols.pbcast.NAKACK
-
- stop() -
Method in class org.javagroups.protocols.pbcast.FD
-
- stop() -
Method in class org.javagroups.protocols.pbcast.CoordGmsImpl
-
- stop() -
Method in class org.javagroups.protocols.pbcast.GMS
-
- stop() -
Method in class org.javagroups.protocols.pbcast.GmsImpl
-
- stop() -
Method in class org.javagroups.service.AbstractService
- Stop standalone thread started with
AbstractService.start()
method.
- stop() -
Method in class org.javagroups.stack.Router
-
- stop() -
Method in class org.javagroups.stack.GossipClient
-
- stop() -
Method in class org.javagroups.stack.AckMcastSenderWindow
- Stop the rentransmition and clear all pending msgs.
- stop() -
Method in class org.javagroups.stack.Retransmitter
- Stop the rentransmition and clear all pending msgs.
- stop() -
Method in class org.javagroups.stack.MessageProtocol
-
- stop() -
Method in class org.javagroups.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
- stop() -
Method in class org.javagroups.stack.Protocol
- This method is called on a
Channel.disconnect()
.
- stop() -
Method in class org.javagroups.util.ReusableThread
- Stops the thread by setting thread=null and interrupting it.
- stop() -
Method in class org.javagroups.util.TimeScheduler
- Stop the scheduler if it's running.
- stop() -
Method in class org.javagroups.util.Scheduler
- Stop the scheduler thread.
- stop(String) -
Static method in class org.javagroups.debug.Profiler
-
- stopEnsThread() -
Method in class org.javagroups.ensemble.Hot_Ensemble
-
- stopInternal() -
Method in class org.javagroups.stack.ProtocolStack
-
- stopInternal() -
Method in class org.javagroups.stack.Protocol
- Used internally.
- stopped(Runnable) -
Method in interface org.javagroups.util.SchedulerListener
-
- stopProtocolStack(Protocol) -
Method in class org.javagroups.stack.Configurator
-
- stopWork() -
Method in class org.javagroups.stack.ProtocolStack
- Override with null functionality: we don't need any threads to be started !
- string2Level(String) -
Static method in class org.javagroups.log.Trace
-
- subgroups -
Variable in class org.javagroups.MergeView
-
- SUBVIEW_MERGE -
Static variable in class org.javagroups.Event
-
- SUBVIEWSET_MERGE -
Static variable in class org.javagroups.Event
-
- SUSPECT -
Static variable in class org.javagroups.Event
-
- SUSPECT -
Static variable in class org.javagroups.Channel
-
- suspect(Address) -
Method in interface org.javagroups.MembershipListener
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.blocks.ReplicatedTree
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.blocks.ReplicatedHashtable
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.blocks.NotificationBus
-
- suspect(Address) -
Method in class org.javagroups.blocks.MembershipListenerAdapter
- Notify membership listener that some node was suspected.
- suspect(Address) -
Method in class org.javagroups.blocks.GroupRequest
- Callback (called by RequestCorrelator or Transport).
- suspect(Address) -
Method in class org.javagroups.blocks.DistributedTree
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.blocks.DistributedQueue
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.blocks.VotingAdapter
- Callback for notification that one node is suspected
- suspect(Address) -
Method in interface org.javagroups.blocks.RspCollector
-
- suspect(Address) -
Method in class org.javagroups.blocks.DistributedHashtable
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.demos.ViewDemo
- Called when a member is suspected
- suspect(Address) -
Method in class org.javagroups.demos.Topology
-
- suspect(Address) -
Method in class org.javagroups.demos.QuoteServer
-
- suspect(Address) -
Method in class org.javagroups.demos.QuoteClient
-
- suspect(Address) -
Method in class org.javagroups.demos.Chat
-
- suspect(Address) -
Method in class org.javagroups.demos.wb.Whiteboard
-
- suspect(Address) -
Method in class org.javagroups.protocols.ParticipantGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.CoordGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.GMS
-
- suspect(Address) -
Method in class org.javagroups.protocols.GmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.ClientGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.pbcast.ParticipantGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.pbcast.CoordGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.pbcast.GmsImpl
-
- suspect(Address) -
Method in class org.javagroups.protocols.pbcast.ClientGmsImpl
-
- suspect(Address) -
Method in class org.javagroups.service.AbstractService
- This method is called when a member of service group is suspected to
be failed.
- suspect(Address) -
Method in class org.javagroups.stack.AckMcastSenderWindow
- Process with address
suspected
is suspected: remove it
from all receiver sets.
- suspect(Hot_GroupContext, Hot_Endpoint[]) -
Method in class org.javagroups.ensemble.Hot_Ensemble
- NOT SUPPORTED CURRENTLY IN THE ML
- suspect(Object) -
Method in class org.javagroups.stack.AckMcastReceiverWindow
-
- SuspectedException - exception org.javagroups.SuspectedException.
-
- SuspectedException() -
Constructor for class org.javagroups.SuspectedException
-
- SuspectedException(Object) -
Constructor for class org.javagroups.SuspectedException
-
- SuspectEvent - class org.javagroups.SuspectEvent.
-
- SuspectEvent(Object) -
Constructor for class org.javagroups.SuspectEvent
-
- suspend() -
Method in class org.javagroups.util.ReusableThread
- Suspends the thread.
- suspended(Runnable) -
Method in interface org.javagroups.util.SchedulerListener
-
- SWITCH_NAK -
Static variable in class org.javagroups.Event
-
- SWITCH_NAK_ACK -
Static variable in class org.javagroups.Event
-
- SWITCH_OUT_OF_BAND -
Static variable in class org.javagroups.Event
-
- SystemErrTracer - class org.javagroups.log.SystemErrTracer.
- Provides output to
System.err
. - SystemOutTracer - class org.javagroups.log.SystemOutTracer.
- Provides output to
System.out
. - SystemTracer - class org.javagroups.log.SystemTracer.
- Abstract superclass of
SystemOutTracer
and
SystemErrTracer
; avoids ever closing output stream.
Trace.setTimestampFormat()
and used in the
timestamp
method.
Tracer
s.
obj
owned by specified owner
.
lockId
on behalf of the specified
owner
.
messages List<\code> where the messagesHandler<\code>
retrieves them.
- up(Event) -
Method in class org.javagroups.protocols.QUEUE
- Queues or passes up events.
- up(Event) -
Method in class org.javagroups.protocols.PRINTOBJS
-
- up(Event) -
Method in class org.javagroups.protocols.PRINTMETHODS
-
- up(Event) -
Method in class org.javagroups.protocols.PING
- An event was received from the layer below.
- up(Event) -
Method in class org.javagroups.protocols.PIGGYBACK
-
- up(Event) -
Method in class org.javagroups.protocols.PERF
-
- up(Event) -
Method in class org.javagroups.protocols.PARTITIONER
- Discards Messages with the wrong partition number and sets local partition number if
it receives a COMMAND Header
- up(Event) -
Method in class org.javagroups.protocols.NAKACK
- Callback.
- up(Event) -
Method in class org.javagroups.protocols.MERGEFAST
-
- up(Event) -
Method in class org.javagroups.protocols.MERGE2
-
- up(Event) -
Method in class org.javagroups.protocols.MERGE
-
- up(Event) -
Method in class org.javagroups.protocols.HDRS
-
- up(Event) -
Method in class org.javagroups.protocols.FRAG
- If event is a message, if it is fragmented, re-assemble fragments into big message and pass up
the stack.
- up(Event) -
Method in class org.javagroups.protocols.FLOWCONTROL
- Checs if up messages are from myaddr and in the case sends down queued messages or
decremnts sentMsgs if there are no queued messages
- up(Event) -
Method in class org.javagroups.protocols.FD_SOCK
-
- up(Event) -
Method in class org.javagroups.protocols.FD_SIMPLE
-
- up(Event) -
Method in class org.javagroups.protocols.FD_PROB
-
- up(Event) -
Method in class org.javagroups.protocols.FD_PID
-
- up(Event) -
Method in class org.javagroups.protocols.FD
-
- up(Event) -
Method in class org.javagroups.protocols.FC
-
- up(Event) -
Method in class org.javagroups.protocols.EXAMPLE
-
- up(Event) -
Method in class org.javagroups.protocols.DUMMY
-
- up(Event) -
Method in class org.javagroups.protocols.DISCARD
-
- up(Event) -
Method in class org.javagroups.protocols.DELAY
-
- up(Event) -
Method in class org.javagroups.protocols.CAUSAL
- Processes Event going up through the stack
- up(Event) -
Method in class org.javagroups.protocols.BSH
-
- up(Event) -
Method in class org.javagroups.protocols.pbcast.STATE_TRANSFER
-
- up(Event) -
Method in class org.javagroups.protocols.pbcast.STABLE
-
- up(Event) -
Method in class org.javagroups.protocols.pbcast.PBCAST
-
- up(Event) -
Method in class org.javagroups.protocols.pbcast.NAKACK
- Callback.
- up(Event) -
Method in class org.javagroups.protocols.pbcast.FD
-
- up(Event) -
Method in class org.javagroups.protocols.pbcast.GMS
-
- up(Event) -
Method in class org.javagroups.stack.MessageProtocol
- Handle an event coming from the layer above
- up(Event) -
Method in class org.javagroups.stack.ProtocolStack
-
- up(Event) -
Method in class org.javagroups.stack.Protocol
- An event was received from the layer below.
- up(Event, int) -
Method in class org.javagroups.debug.ProtocolView
-
- up(Event, int) -
Method in interface org.javagroups.stack.ProtocolObserver
- Called when an event is about to be dispatched to the protocol (before it is dispatched).
- update(Graphics) -
Method in class org.javagroups.demos.wb.GraphPanel
-
- UpdateException - exception org.javagroups.blocks.UpdateException.
-
- UpdateException(String) -
Constructor for class org.javagroups.blocks.UpdateException
-
- updateView(View) -
Method in class org.javagroups.protocols.TOTAL_TOKEN
-
- updateView(View) -
Method in class org.javagroups.stack.MessageProtocol
-
- updateWindow(RingToken) -
Method in class org.javagroups.protocols.ring.RingNodeFlowControl
-
- UpHandler - interface org.javagroups.UpHandler.
-
- use_properties -
Variable in class org.javagroups.ensemble.Hot_JoinOps
-
- useLocks() -
Method in class org.javagroups.blocks.ReplicationData
-
- USER_DEFINED -
Static variable in class org.javagroups.Event
-
- UserInfoDialog - class org.javagroups.demos.wb.UserInfoDialog.
-
- UserInfoDialog(Frame) -
Constructor for class org.javagroups.demos.wb.UserInfoDialog
-
- Util - class org.javagroups.util.Util.
- Collection of various utility routines that can not be assigned to other classes.
- Util() -
Constructor for class org.javagroups.util.Util
-
true
or false
messages.
ObjectOutput
.
Writer
.
|
||||||||||||
PREV NEXT | FRAMES NO FRAMES |