|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
sender
.
msgs
, removing them also from retransmission.
ThreadDecorator.threadReleased(Thread)
on the current thread.
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.
ChannelListener
#compareTo(org.jgroups.Address)
instead
o
.
#compareTo(org.jgroups.Address)
instead
groupname
.
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.
- createChannel(String) -
Method in class org.jgroups.JChannelFactory
-
- createDaemons -
Variable in class org.jgroups.util.DefaultThreadFactory
-
- createDatagramSocket(InetAddress, int) -
Static method in class org.jgroups.util.Util
- Creates a DatagramSocket bound to addr.
- createDatagramSocketWithBindPort() -
Method in class org.jgroups.protocols.UDP
- Creates a DatagramSocket when bind_port > 0.
- createEphemeralDatagramSocket() -
Method in class org.jgroups.protocols.UDP
- Creates a DatagramSocket with a random port.
- createLocalAddress() -
Method in class org.jgroups.protocols.UDP
-
- 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.
- createMonitor() -
Method in class org.jgroups.protocols.FD_ICMP
-
- createMonitor() -
Method in class org.jgroups.protocols.FD_PING
-
- createMulticastSocket(int) -
Static method in class org.jgroups.util.Util
-
- createMulticastSocket(InetAddress, int, Log) -
Static method in class org.jgroups.util.Util
-
- createMultiplexerChannel(String, String, boolean, String) -
Method in interface org.jgroups.ChannelFactory
- Creates an implementation of the Channel using a given stack name and
registering it under a given identity.
- createMultiplexerChannel(String, String) -
Method in interface org.jgroups.ChannelFactory
- Creates an implementation of the Channel using a given stack name and
registering it under a given identity.
- createMultiplexerChannel(String, String) -
Method in class org.jgroups.JChannelFactory
-
- createMultiplexerChannel(String, String, boolean, String) -
Method in class org.jgroups.JChannelFactory
-
- createMultiplexerChannel(String, String) -
Method in class org.jgroups.jmx.JChannelFactory
-
- createMultiplexerChannel(String, String, boolean, String) -
Method in class org.jgroups.jmx.JChannelFactory
-
- createMultiplexerChannel(String, String) -
Method in interface org.jgroups.jmx.JChannelFactoryMBean
-
- createMultiplexerChannel(String, String, boolean, String) -
Method in interface org.jgroups.jmx.JChannelFactoryMBean
-
- createMuxChannel(String, String) -
Method in class org.jgroups.mux.Multiplexer
-
- createProtocol(String, ProtocolStack) -
Static 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.
- createThreadPool() -
Method in class org.jgroups.mux.Multiplexer
-
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) -
Static method in class org.jgroups.protocols.TP
-
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) -
Method in class org.jgroups.stack.GossipRouter
-
- CREDIT_REQUEST -
Static variable in class org.jgroups.protocols.FC.FcHeader
-
- CREDIT_REQUEST -
Static variable in class org.jgroups.protocols.SFC.Header
-
- cvs -
Static variable in class org.jgroups.Version
-
Channel.close()
.
ReplicatedHashMap
insteadmin_size
.
TP.getTimer()
instead to fetch the timer from the
transport and then invoke the method on it
RspList.entrySet()
or RspList.values()
instead
obj
.
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.
ExtendedMessageListener
has additional callbacks for:
partial state transfer - http://jira.jboss.com/jira/browse/JGRP-118
streaming state transfer - http://jira.jboss.com/jira/browse/JGRP-89
DistributedHashtableDemo
to work.
data
map.
JChannel.getState(org.jgroups.Address, long)
instead
TP.isReceiveOnAllInterfaces()
instead
Channel.getClusterName()
instead
JChannel.getClusterName()
instead
remove()
).
data
map.
Protocol.getThreadFactory()
instead
TP.getTimer()
to fetch the timer and call getCorePoolSize() directly
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.JChannelFactory
instance that contains no
protocol stack configuration.
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.lockId
on behalf of the specified
owner
.
obj
for specified owner
.
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.MembershipListener
instances.MessageListener
instances.setName()
has been called.
RspFilter.isAcceptable(Object, org.jgroups.Address)
, this method is called to see whether
we are done with the request and can unblock the caller
javax.jms.MessageListener
interface.
Receiver
instead, this method will not be available in JGroups 3.0
fqn
.
MethodCall
object from the message's buffer and prints it.
Receiver
instead, this class will be removed in JGroups 3.0Receiver
instead
Receiver
instead
FilePersistenceManager
or DBPersistenceManager
.
key
from the node's hashmap
obj
from all receiver sets and wake up
retransmission thread.
next_to_remove
, increments the latter.
addr
from connection table.
ConcurrentHashMap
with replication of the contents across a cluster.ReplicatedHashMap
insteadmembership
variable to the value of
members
.
count
field of this byte array output
stream to zero, so that all currently accumulated output in the
output stream is discarded.
RspList.clear()
instead
first_seqno
and last_seqno
.
getState()
object when calling receive()
.
getState()
object when
calling receive()
.
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.UDP
-
- run() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- 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.util.ReusableThread
- Delicate piece of code (means very important :-)).
- run() -
Method in class org.jgroups.util.Scheduler
-
- 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
-
- runRequest(Address, ByteBuffer) -
Method in class org.jgroups.blocks.ConnectionTableNIO
-
Scheduler
.RequestCorrelator.sendRequest(long,List,Message,RspCollector)
.
Clear
method.
Clear
method.
PullPushAdapter.addMembershipListener(org.jgroups.MembershipListener)
Channel.receive()
, as requested by
Channel.getState(s)
previously.listener
for state notification events.
Protocol.getThreadFactory()
instead
TP.setTimerThreadFactory(org.jgroups.util.ThreadFactory)
instead
messagesHandler<\code>
- start() -
Method in class org.jgroups.protocols.TCP
-
- start() -
Method in class org.jgroups.protocols.TCP_NIO
-
- start() -
Method in class org.jgroups.protocols.TCPGOSSIP
-
- 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
- Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- start() -
Method in class org.jgroups.protocols.UNICAST
-
- start() -
Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- start() -
Method in class org.jgroups.protocols.VIEW_SYNC
-
- start() -
Method in class org.jgroups.stack.GossipRouter
- JBoss MBean lifecycle operation.
- start() -
Method in class org.jgroups.stack.Protocol
- This method is called on a
Channel.connect(String)
.
- 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
- START_FLUSH -
Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- START_PARTITION -
Static variable in class org.jgroups.Event
-
- start_port -
Variable in class org.jgroups.protocols.BasicTCP
-
- started -
Variable in class org.jgroups.blocks.RequestCorrelator
-
- started(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
- startFlush(List<Address>, boolean) -
Method in class org.jgroups.Channel
-
- startFlush(boolean) -
Method in class org.jgroups.Channel
-
- startFlush(long, boolean) -
Method in class org.jgroups.Channel
-
- startFlush(boolean) -
Method in class org.jgroups.JChannel
- Will perform a flush of the system, ie.
- startFlush(List<Address>, boolean) -
Method in class org.jgroups.JChannel
- Performs a partial flush in a cluster for flush participants.
- startFlush(long, boolean) -
Method in class org.jgroups.JChannel
- Will perform a flush of the system, ie.
- startFlush() -
Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
-
- startFlush() -
Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
-
- startFlush() -
Method in class org.jgroups.protocols.pbcast.FLUSH
-
- startFlush(Channel, List<Address>, int, long, long) -
Static method in class org.jgroups.util.Util
-
- startFlush(Channel, List<Address>) -
Static method in class org.jgroups.util.Util
-
- startFlush(Channel, int, long, long) -
Static method in class org.jgroups.util.Util
-
- startFlush(Channel) -
Static method in class org.jgroups.util.Util
-
- startPartition() -
Method in class org.jgroups.jmx.protocols.PARTITION
-
- startPartition() -
Method in interface org.jgroups.jmx.protocols.PARTITIONMBean
-
- startPartition() -
Method in class org.jgroups.protocols.PARTITION
-
- startProtocolStack(List<Protocol>, String, Map<String, Tuple<TP, Short>>) -
Static method in class org.jgroups.stack.Configurator
-
- startStack(String) -
Method in class org.jgroups.stack.ProtocolStack
- Start all layers.
- state -
Variable in class org.jgroups.stack.StateTransferInfo
-
- state_id -
Variable in class org.jgroups.stack.StateTransferInfo
-
- STATE_PART -
Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- state_promise -
Variable in class org.jgroups.blocks.DistributedHashtable
- Deprecated.
- state_promise -
Variable in class org.jgroups.blocks.ReplicatedHashMap
-
- STATE_RECEIVED -
Static variable in class org.jgroups.Event
-
- STATE_REQ -
Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_REQ -
Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STATE_RSP -
Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_RSP -
Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER - Class in org.jgroups.jmx.protocols.pbcast
-
- STATE_TRANSFER() -
Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
-
- STATE_TRANSFER(Protocol) -
Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
-
- STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
- New STATE_TRANSFER protocol based on PBCAST.
- STATE_TRANSFER() -
Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
- Wraps data for a state request/response.
- STATE_TRANSFER.StateHeader() -
Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER.StateHeader(byte, Address, long, Digest) -
Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER.StateHeader(byte, Address, long, Digest, String) -
Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_TRANSFER_INPUTSTREAM -
Static variable in class org.jgroups.Event
-
- STATE_TRANSFER_INPUTSTREAM_CLOSED -
Static variable in class org.jgroups.Event
-
- STATE_TRANSFER_OUTPUTSTREAM -
Static variable in class org.jgroups.Event
-
- STATE_TRANSFER_OUTPUTSTREAM_CLOSED -
Static variable in class org.jgroups.Event
-
- STATE_TRANSFERMBean - Interface in org.jgroups.jmx.protocols.pbcast
-
- stateListener -
Variable in class org.jgroups.blocks.MessageListenerAdapter
-
- stateTransferCompleted(boolean) -
Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
- Deprecated.
- StateTransferException - Exception in org.jgroups
StateTransferException
is thrown to indicate failure of
state transfer between cluster members.- StateTransferException() -
Constructor for exception org.jgroups.StateTransferException
-
- StateTransferException(String) -
Constructor for exception org.jgroups.StateTransferException
-
- StateTransferException(String, Throwable) -
Constructor for exception org.jgroups.StateTransferException
-
- StateTransferInfo - Class in org.jgroups.stack
- Contains parameters for state transfer.
- StateTransferInfo() -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address, long) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address, String, long) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address, String, long, byte[]) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address, InputStream, String) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferInfo(Address, OutputStream, String) -
Constructor for class org.jgroups.stack.StateTransferInfo
-
- stateTransferRunning() -
Method in class org.jgroups.blocks.ReplicatedHashtable
- Deprecated.
- stateTransferStarted() -
Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
- Deprecated.
- StaticInterval - Class in org.jgroups.stack
- Manages retransmission timeouts.
- StaticInterval(long...) -
Constructor for class org.jgroups.stack.StaticInterval
-
- stats -
Variable in class org.jgroups.JChannel
- Collect statistics
- STATS - Class in org.jgroups.jmx.protocols
-
- STATS() -
Constructor for class org.jgroups.jmx.protocols.STATS
-
- STATS(Protocol) -
Constructor for class org.jgroups.jmx.protocols.STATS
-
- STATS - Class in org.jgroups.protocols
- Provides various stats
- STATS() -
Constructor for class org.jgroups.protocols.STATS
-
- stats -
Variable in class org.jgroups.stack.Protocol
-
- statsEnabled() -
Method in class org.jgroups.JChannel
-
- statsEnabled() -
Method in class org.jgroups.stack.Protocol
-
- STATSMBean - Interface in org.jgroups.jmx.protocols
-
- STATUS_CONNECTED -
Static variable in class org.jgroups.stack.RouterStub
-
- STATUS_DISCONNECTED -
Static variable in class org.jgroups.stack.RouterStub
-
- stop() -
Method in class org.jgroups.blocks.BasicConnectionTable
-
- 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
- Deprecated.
- stop() -
Method in class org.jgroups.blocks.DistributedQueue
-
- stop() -
Method in class org.jgroups.blocks.DistributedTree
-
- stop() -
Method in class org.jgroups.blocks.MessageDispatcher
-
- stop() -
Method in class org.jgroups.blocks.NotificationBus
-
- stop() -
Method in class org.jgroups.blocks.PullPushAdapter
- Deprecated.
- stop() -
Method in class org.jgroups.blocks.ReplicatedHashMap
-
- stop() -
Method in class org.jgroups.blocks.ReplicatedTree
-
- stop() -
Method in class org.jgroups.blocks.RequestCorrelator
-
- 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.ChatCore
-
- stop() -
Method in class org.jgroups.demos.Draw
-
- stop() -
Method in class org.jgroups.demos.wb.GraphPanel
-
- stop() -
Method in class org.jgroups.JChannelFactory
-
- stop() -
Method in class org.jgroups.jmx.JChannel
-
- stop() -
Method in class org.jgroups.jmx.JChannelFactory
-
- stop() -
Method in interface org.jgroups.jmx.JChannelFactoryMBean
-
- 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.BARRIER
-
- stop() -
Method in class org.jgroups.protocols.BSH
-
- stop() -
Method in class org.jgroups.protocols.DISCARD
-
- stop() -
Method in class org.jgroups.protocols.Discovery
-
- stop() -
Method in class org.jgroups.protocols.FC
-
- stop() -
Method in class org.jgroups.protocols.FD.BroadcastTask
-
- stop() -
Method in class org.jgroups.protocols.FD
-
- stop() -
Method in class org.jgroups.protocols.FD_ALL
-
- 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.MERGE2
-
- stop() -
Method in class org.jgroups.protocols.MPING
-
- stop() -
Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- stop() -
Method in class org.jgroups.protocols.pbcast.FLUSH
-
- 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.STABLE
-
- stop() -
Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- stop() -
Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
-
- stop() -
Method in class org.jgroups.protocols.PING
-
- stop() -
Method in class org.jgroups.protocols.SFC
-
- stop() -
Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- 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.TCP
-
- stop() -
Method in class org.jgroups.protocols.TCP_NIO
-
- stop() -
Method in class org.jgroups.protocols.TCPGOSSIP
-
- stop() -
Method in class org.jgroups.protocols.TP
-
- stop() -
Method in class org.jgroups.protocols.TUNNEL
-
- stop() -
Method in class org.jgroups.protocols.UDP
-
- stop() -
Method in class org.jgroups.protocols.UDP.UcastReceiver
-
- 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.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.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.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.
- STOP_FLUSH -
Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- STOP_PARTITION -
Static variable in class org.jgroups.Event
-
- stopFlush() -
Method in class org.jgroups.Channel
-
- stopFlush(List<Address>) -
Method in class org.jgroups.Channel
-
- stopFlush() -
Method in class org.jgroups.JChannel
-
- stopFlush(List<Address>) -
Method in class org.jgroups.JChannel
-
- stopFlush() -
Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
-
- stopFlush() -
Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
-
- stopFlush() -
Method in class org.jgroups.protocols.pbcast.FLUSH
-
- stopPartition() -
Method in class org.jgroups.jmx.protocols.PARTITION
-
- stopPartition() -
Method in interface org.jgroups.jmx.protocols.PARTITIONMBean
-
- stopPartition() -
Method in class org.jgroups.protocols.PARTITION
-
- stopped -
Variable in class org.jgroups.blocks.DistributedQueue
-
- stopped(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
- stopProtocolStack(List<Protocol>, String, Map<String, Tuple<TP, Short>>) -
Static method in class org.jgroups.stack.Configurator
-
- stopStack(boolean, boolean) -
Method in class org.jgroups.JChannel
-
- stopStack(String) -
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
- Streamable - Interface in org.jgroups.util
- Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly
serialization
- streamableFromByteBuffer(Class, byte[]) -
Static method in class org.jgroups.util.Util
-
- streamableFromByteBuffer(Class, byte[], int, int) -
Static method in class org.jgroups.util.Util
-
- streamableToByteBuffer(Streamable) -
Static method in class org.jgroups.util.Util
-
- STREAMING_STATE_TRANSFER - Class in org.jgroups.jmx.protocols.pbcast
-
- STREAMING_STATE_TRANSFER() -
Constructor for class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
-
- STREAMING_STATE_TRANSFER(Protocol) -
Constructor for class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
-
- STREAMING_STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
STREAMING_STATE_TRANSFER
, as its name implies, allows a
streaming state transfer between two channel instances.- STREAMING_STATE_TRANSFER() -
Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
-
- STREAMING_STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
-
- STREAMING_STATE_TRANSFER.StateHeader() -
Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STREAMING_STATE_TRANSFER.StateHeader(byte, Address, String) -
Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STREAMING_STATE_TRANSFER.StateHeader(byte, Address, long, Digest) -
Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STREAMING_STATE_TRANSFER.StateHeader(byte, Address, IpAddress, Digest, String) -
Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
-
- STREAMING_STATE_TRANSFERMBean - Interface in org.jgroups.jmx.protocols.pbcast
-
- StreamingGetStateEvent - Class in org.jgroups
- Represents an event returned by
channel.receive()
, as a result
of another channel instance requesting a state from this channel. - StreamingGetStateEvent(OutputStream, String) -
Constructor for class org.jgroups.StreamingGetStateEvent
-
- StreamingSetStateEvent - Class in org.jgroups
- Represents an event returned by
channel.receive()
, as requested by
channel.getState()
previously. - StreamingSetStateEvent(InputStream, String) -
Constructor for class org.jgroups.StreamingSetStateEvent
-
- string_version -
Static variable in class org.jgroups.Version
-
- subgroups -
Variable in class org.jgroups.MergeView
-
- subList(int, int) -
Method in class org.jgroups.util.UnmodifiableVector
-
- substituteVariable(String) -
Static method in class org.jgroups.util.Util
- Replaces variables of ${var:default} with System.getProperty(var, default).
- substituteVariables(ProtocolStackConfigurator) -
Static method in class org.jgroups.conf.ConfiguratorFactory
- Replace variables of the form ${var:default} with the getProperty(var, default)
- supportedKeys() -
Method in interface org.jgroups.protocols.TP.ProbeHandler
- Returns a list of supported keys
- suspect(Address) -
Method in class org.jgroups.blocks.DistributedHashtable
- Deprecated. Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.DistributedLockManager
-
- 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.ReplicatedHashMap
- Called when a member is suspected
- suspect(Address) -
Method in class org.jgroups.blocks.ReplicatedHashtable
- Deprecated. 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 -
Static variable in class org.jgroups.Channel
-
- suspect(Address) -
Method in class org.jgroups.demos.ChatCore
-
- 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 -
Static variable in class org.jgroups.Event
-
- suspect(Address) -
Method in class org.jgroups.ExtendedReceiverAdapter
-
- suspect(Address) -
Method in interface org.jgroups.MembershipListener
- Called whenever a member is suspected of having crashed,
but has not yet been excluded.
- SUSPECT -
Static variable in class org.jgroups.protocols.FD.FdHeader
-
- SUSPECT -
Static variable in class org.jgroups.protocols.FD_ALL.Header
-
- SUSPECT -
Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- 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(Address) -
Method in class org.jgroups.ReceiverAdapter
-
- 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(Address) -
Method in class org.jgroups.util.AckCollector
-
- SuspectedException - Exception in org.jgroups
- Thrown if a message is sent to a suspected member.
- SuspectedException() -
Constructor for exception org.jgroups.SuspectedException
-
- SuspectedException(Object) -
Constructor for exception org.jgroups.SuspectedException
-
- SuspectEvent - Class in org.jgroups
- Represents a suspect event.
- SuspectEvent(Object) -
Constructor for class org.jgroups.SuspectEvent
-
- SUSPEND -
Static variable in class org.jgroups.Event
-
- suspend() -
Method in class org.jgroups.util.ReusableThread
- Suspends the thread.
- SUSPEND_STABLE -
Static variable in class org.jgroups.Event
-
- suspended(Runnable) -
Method in interface org.jgroups.util.SchedulerListener
-
- 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
-
- synchronizedMap(ReplicatedMap<K, V>) -
Static method in class org.jgroups.blocks.ReplicatedHashMap
- Creates a synchronized facade for a ReplicatedMap.
thread
has just been created.
ThreadManager
notifying
it that the thread has been created or released from use.ThreadDecorator
to allow it to alter their state.thread
has just been released from use
(e.g.
charsetName
.
toString(String enc)
method, which takes an encoding-name
argument, or the toString()
method, which uses the
platform's default character encoding.
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.STATS
-
- up(Event) -
Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- 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.UNICAST
-
- up(Event) -
Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- up(Event) -
Method in class org.jgroups.protocols.VIEW_SYNC
-
- up(Event) -
Method in class org.jgroups.stack.Protocol
- An event was received from the layer below.
- up(Event) -
Method in class org.jgroups.stack.ProtocolStack
-
- up(Event) -
Method in interface org.jgroups.UpHandler
- Invoked for all channel events except connection management and state transfer.
- up_handler -
Variable in class org.jgroups.Channel
-
- up_prot -
Variable in class org.jgroups.stack.Protocol
-
- update(Graphics) -
Method in class org.jgroups.demos.wb.GraphPanel
-
- update_mode -
Variable in class org.jgroups.blocks.ReplicatedHashMap
- Whether updates across the cluster should be asynchronous (default) or synchronous)
- UpdateException - Exception in org.jgroups.blocks
-
- UpdateException(String) -
Constructor for exception org.jgroups.blocks.UpdateException
-
- updatePort(int) -
Method in class org.jgroups.util.PortsManager
- Updates the timestamp for the given port
- UpHandler - Interface in org.jgroups
- Provides a way of taking over a channel's tasks.
- upThreadEnabled() -
Method in class org.jgroups.stack.Protocol
- Deprecated. up_thread was removed
- URGENT_CREDIT_REQUEST -
Static variable in class org.jgroups.protocols.SFC.Header
-
- use_gui -
Variable in class org.jgroups.protocols.DISCARD
-
- use_numbering -
Variable in class org.jgroups.util.DefaultThreadFactory
-
- USER_DEFINED -
Static variable in class org.jgroups.Event
-
- UserInfoDialog - Class in org.jgroups.demos.wb
-
- UserInfoDialog(Frame) -
Constructor for class org.jgroups.demos.wb.UserInfoDialog
-
- Util - Class in org.jgroups.util
- Collection of various utility routines that can not be assigned to other classes.
- Util() -
Constructor for class org.jgroups.util.Util
-
true
or false
messages.
len
bytes from the specified byte array
starting at offset off
to this byte array output stream.
b
) to the underlying output stream.
len
bytes from the specified byte array
starting at offset off
to the underlying output stream.
out.write(buf, 0, count)
.
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |