- ABNORMAL_TERMINATION - Static variable in class org.jgroups.protocols.FD_SOCK
-
- ABORT_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- ABOVE - Static variable in class org.jgroups.stack.ProtocolStack
-
- ABP - Class in org.jgroups.protocols
-
Alternating Bit Protocol.
- ABP() - Constructor for class org.jgroups.protocols.ABP
-
- ABP.ABPHeader - Class in org.jgroups.protocols
-
- ABP.Entry - Class in org.jgroups.protocols
-
- ABP.Type - Enum in org.jgroups.protocols
-
- ABPHeader() - Constructor for class org.jgroups.protocols.ABP.ABPHeader
-
- ABPHeader(ABP.Type, byte) - Constructor for class org.jgroups.protocols.ABP.ABPHeader
-
- accept() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- accept(Message) - Method in class org.jgroups.stack.Protocol
-
Called by the default implementation of
Protocol.up(org.jgroups.util.MessageBatch)
for each message to determine
if the message should be removed from the message batch (and handled by the current protocol) or not.
- accept(RouterStub) - Method in interface org.jgroups.stack.RouterStubManager.Consumer
-
- accept(T, U) - Method in interface org.jgroups.util.BiConsumer
-
Performs this operation on the given arguments.
- accept(T) - Method in interface org.jgroups.util.Filter
-
- accept(C) - Method in interface org.jgroups.util.ResponseCollectorTask.Consumer
-
- acceptor - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- Acceptor() - Constructor for class org.jgroups.blocks.cs.NioBaseServer.Acceptor
-
- acceptor - Variable in class org.jgroups.blocks.cs.TcpServer
-
- Acceptor() - Constructor for class org.jgroups.blocks.cs.TcpServer.Acceptor
-
- acceptor - Variable in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
- acceptor - Variable in class org.jgroups.protocols.STOMP
-
- acceptorRunning() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- access_key - Variable in class org.jgroups.protocols.S3_PING
-
- accumulated_bytes - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- accumulated_bytes - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- accumulated_credits - Variable in class org.jgroups.util.CreditMap
-
- ACK - Static variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- ack(Address) - Method in class org.jgroups.protocols.RSVP.Entry
-
- ACK - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- ACK - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- ACK - Static variable in class org.jgroups.protocols.UNICAST3.Header
-
- ack(Address) - Method in class org.jgroups.util.AckCollector
-
- ack(long) - Method in class org.jgroups.util.ForwardQueue
-
- ack_batches_immediately - Variable in class org.jgroups.protocols.UNICAST3
-
Deprecated.
- ack_collector - Variable in class org.jgroups.protocols.pbcast.GMS
-
To collect VIEW_ACKs from all members
- ack_collector - Variable in class org.jgroups.protocols.RSVP.Entry
-
- ack_mode - Variable in class org.jgroups.protocols.SEQUENCER
-
When ack_mode is set, we need to wait for an ack for each forwarded message until we can send the next one
- ack_on_delivery - Variable in class org.jgroups.protocols.RSVP
-
- ack_promise - Variable in class org.jgroups.protocols.SEQUENCER
-
Used for each resent message to wait until the message has been received
- ack_promise - Variable in class org.jgroups.util.ForwardQueue
-
Used for each resent message to wait until the message has been received
- ack_received - Variable in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- ack_threshold - Variable in class org.jgroups.protocols.UNICAST3
-
- AckCollector - Class in org.jgroups.util
-
Collects acks from a number of nodes, waits for all acks.
- AckCollector() - Constructor for class org.jgroups.util.AckCollector
-
- AckCollector(Collection<Address>) - Constructor for class org.jgroups.util.AckCollector
-
- AckCollector(Address...) - Constructor for class org.jgroups.util.AckCollector
-
- acquire(boolean) - Method in class org.jgroups.protocols.Locking.ClientLock
-
- acquire() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- acquired - Variable in class org.jgroups.protocols.Locking.ClientLock
-
- acquireTryLock(long, boolean) - Method in class org.jgroups.protocols.Locking.ClientLock
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.applets.DrawApplet
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Draw
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.QuoteClient
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.ReplCacheDemo
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.StompDraw
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.MessageDialog
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.SendDialog
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.UserInfoDialog
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- actionPerformed(ActionEvent) - Method in class org.jgroups.protocols.DISCARD.DiscardDialog
-
- add(Address...) - Method in class org.jgroups.AnycastAddress
-
- add(K, V) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- add(short, T) - Method in interface org.jgroups.blocks.mux.Muxer
-
Registers the specified handler to handle messages containing a mux header with the specified mux identifier.
- add(short, UpHandler) - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
Registers the specified handler to handle messages containing a mux header with the specified mux identifier.
- add(short, Class) - Static method in class org.jgroups.conf.ClassConfigurator
-
Method to register a user-defined header with jg-magic-map at runtime
- add(int, int) - Method in class org.jgroups.demos.JmxDemo
-
- add(Address) - Method in class org.jgroups.Membership
-
Adds a new member to this membership.
- add(Address...) - Method in class org.jgroups.Membership
-
- add(Collection<Address>) - Method in class org.jgroups.Membership
-
Adds a list of members to this membership
- add(ByteBuffer...) - Method in class org.jgroups.nio.Buffers
-
- add(ByteBuffer) - Method in class org.jgroups.nio.Buffers
-
- add(COUNTER.ReconcileResponse, Address) - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- add(Message) - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- add(long, long) - Method in class org.jgroups.stack.DefaultRetransmitter
-
Add the given range [first_seqno, last_seqno] in the list of
entries eligible for retransmission.
- add(long, Message) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Adds a message according to its seqno (sequence number).
- add(long, long) - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
Add the given range [first_seqno, last_seqno] in the list of
entries eligible for retransmission.
- add(long, long) - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
Add messages from first_seqno
to last_seqno
for retransmission
- add(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
-
- add(RouterStubManager.Target) - Method in class org.jgroups.stack.RouterStubManager
-
- add(K) - Method in class org.jgroups.util.AgeOutCache
-
- add(long) - Method in class org.jgroups.util.Average
-
- add(long) - Method in class org.jgroups.util.AverageMinMax
-
- add(K, V) - Method in class org.jgroups.util.BoundedHashMap
-
- add(T) - Method in class org.jgroups.util.BoundedList
-
Adds an element at the tail.
- add(Message) - Method in class org.jgroups.util.MessageBatch
-
- add(T) - Method in class org.jgroups.util.ProcessingQueue
-
- add(Object) - Method in class org.jgroups.util.Queue
-
adds an object to the tail of this queue
If the queue has been closed with close(true) no exception will be
thrown if the queue has not been flushed yet.
- add(T) - Method in class org.jgroups.util.RequestTable
-
Adds a new element and returns the sequence number at which it was inserted.
- add(Address, T) - Method in class org.jgroups.util.ResponseCollector
-
- add(Address, T) - Method in class org.jgroups.util.ResponseCollectorTask
-
- add(PingData) - Method in class org.jgroups.util.Responses
-
- add(long, T) - Method in class org.jgroups.util.RingBufferSeqno
-
- add(long, T, boolean) - Method in class org.jgroups.util.RingBufferSeqno
-
Adds a new element to the buffer
- add(long, T) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- add(long, T, boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Adds a new element to the buffer
- add(RpcStats.Type, Address, boolean, long) - Method in class org.jgroups.util.RpcStats
-
- add(boolean, long) - Method in class org.jgroups.util.RpcStats.Result
-
- add(long) - Method in class org.jgroups.util.SeqnoList
-
Adds a single seqno
- add(long...) - Method in class org.jgroups.util.SeqnoList
-
- add(long, long) - Method in class org.jgroups.util.SeqnoList
-
Adds a seqno range
- add(long, T) - Method in class org.jgroups.util.Table
-
Adds an element if the element at the given index is null.
- add(long, T, Filter<T>) - Method in class org.jgroups.util.Table
-
Adds an element if the element at the given index is null.
- add(List<Tuple<Long, T>>) - Method in class org.jgroups.util.Table
-
Adds elements from list to the table
- add(List<Tuple<Long, T>>, boolean) - Method in class org.jgroups.util.Table
-
Adds elements from list to the table, removes elements from list that were not added to the table
- add(List<Tuple<Long, T>>, boolean, T) - Method in class org.jgroups.util.Table
-
Adds elements from the list to the table
- add(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
-
- add(Address, String) - Static method in class org.jgroups.util.UUID
-
- add(Map<Address, String>) - Static method in class org.jgroups.util.UUID
-
- addAddressGenerator(AddressGenerator) - Method in class org.jgroups.fork.ForkChannel
-
- addAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
-
- addAddressMapping(Address, String, Address, PhysicalAddress, String) - Method in class org.jgroups.stack.GossipRouter
-
- addAll(Collection<Address>) - Method in class org.jgroups.AnycastAddress
-
- addAll(Map<K, V>) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- addAll(Address...) - Method in class org.jgroups.util.AckCollector
-
- addAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
-
- addAll(Collection) - Method in class org.jgroups.util.Queue
-
- addAll(List<Object>) - Method in class org.jgroups.util.Queue
-
- addAndGet(long) - Method in interface org.jgroups.blocks.atomic.Counter
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- addAndGet(long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
-
num == 0 --> GET
- AddAndGetRequest() - Constructor for class org.jgroups.protocols.COUNTER.AddAndGetRequest
-
- AddAndGetRequest(Owner, String, long) - Constructor for class org.jgroups.protocols.COUNTER.AddAndGetRequest
-
- addAnycast(boolean, long, Collection<Address>) - Method in class org.jgroups.util.RpcStats
-
- addAnycastSentDuration(long, int) - Method in class org.jgroups.protocols.tom.StatsCollector
-
- addBridge(RelayConfig.BridgeConfig) - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- addCallback(StompConnection.ConnectionCallback) - Method in class org.jgroups.client.StompConnection
-
- addChangeListener(Cache.ChangeListener) - Method in class org.jgroups.blocks.Cache
-
- addChangeListener(ReplCache.ChangeListener) - Method in class org.jgroups.blocks.ReplCache
-
- addChannelListener(ChannelListener) - Method in class org.jgroups.blocks.MessageDispatcher
-
Adds a new channel listener to be notified on the channel's state change.
- addChannelListener(ChannelListener) - Method in class org.jgroups.Channel
-
Adds a ChannelListener instance that will be notified when a channel event such as connect,
disconnect or close occurs.
- addCondition(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- addConnection(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
-
- addConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- addConnectionListener(ConnectionListener) - Method in class org.jgroups.blocks.cs.BaseServer
-
- addContents(ExtendedUUID) - Method in class org.jgroups.util.ExtendedUUID
-
- addDataMessageDuration(long) - Method in class org.jgroups.protocols.tom.StatsCollector
-
- addDiscoveryResponseToCaches(Address, String, PhysicalAddress) - Method in class org.jgroups.protocols.Discovery
-
- addDiscoveryResponseToCaches(Address, String, PhysicalAddress) - Method in class org.jgroups.protocols.FILE_PING
-
Only add the discovery response if the logical address is not present or the physical addrs are different
- addExecutorListener(Future<?>, ExecutorNotification) - Method in class org.jgroups.protocols.Executing
-
- addFinalSequenceNumberDuration(long) - Method in class org.jgroups.protocols.tom.StatsCollector
-
- addForward(RelayConfig.ForwardConfig) - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- addHeader(Message, byte[]) - Method in class org.jgroups.auth.sasl.SaslClientContext
-
- addIfAbsent(Address) - Method in class org.jgroups.protocols.FD_ALL
-
- addIfAbsent(T) - Method in class org.jgroups.util.BoundedList
-
- addIfAbsentOrExpired(K) - Method in class org.jgroups.util.ExpiryCache
-
- addIgnoreMember(Address) - Method in class org.jgroups.protocols.DISCARD
-
Messages from this sender will get dropped
- addInfo(Address, ViewId, String, PhysicalAddress) - Method in class org.jgroups.protocols.MERGE3
-
Adds received INFO to views hashmap
- addInitialHost(String, int) - Method in class org.jgroups.protocols.TCPGOSSIP
-
- AdditionalDataUUID - Class in org.jgroups.util
-
- AdditionalDataUUID() - Constructor for class org.jgroups.util.AdditionalDataUUID
-
Deprecated.
- AdditionalDataUUID(byte[], byte[]) - Constructor for class org.jgroups.util.AdditionalDataUUID
-
Deprecated.
- addListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
-
- addLocalMessageToDeliver(MessageID, Message, ToaHeader) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- addLockListener(LockNotification) - Method in class org.jgroups.blocks.locking.LockService
-
- addLockListener(LockNotification) - Method in class org.jgroups.protocols.Locking
-
- addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.ReplCache
-
- addMessage(Message, long) - Method in class org.jgroups.protocols.BaseBundler
-
- addMessage(Message, long) - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- addNewMessageToSend(MessageID, Collection<Address>, long, boolean) - Method in class org.jgroups.protocols.tom.SenderManager
-
Add a new message sent
- addNode(Address) - Method in class org.jgroups.demos.Topology
-
- addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.GraphPanel
-
- addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.Whiteboard
-
- addNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- addNotReceived(Address) - Method in class org.jgroups.util.RspList
-
- addPhysicalAddressToCache(Address, PhysicalAddress) - Method in class org.jgroups.protocols.TP
-
- addPingData(PingData) - Method in class org.jgroups.stack.GossipData
-
- addPropose(MessageID, Address, long) - Method in class org.jgroups.protocols.tom.SenderManager
-
Add a propose from a member in destination set
- addProposeSequenceNumberDuration(long, boolean) - Method in class org.jgroups.protocols.tom.StatsCollector
-
- addProtocol(short, Class) - Static method in class org.jgroups.conf.ClassConfigurator
-
- addProtocol(Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
Adds a protocol at the tail of the protocol list
- addProtocols(Protocol...) - Method in class org.jgroups.stack.ProtocolStack
-
Adds a list of protocols
- addProtocols(List<Protocol>) - Method in class org.jgroups.stack.ProtocolStack
-
Adds a list of protocols
- addr - Variable in class org.jgroups.demos.wb.Node
-
- addr - Variable in class org.jgroups.util.SingletonAddress
-
- addRemoteMessageToDeliver(MessageID, Message, long) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- addReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
-
- addResponse(PingData, boolean) - Method in class org.jgroups.protocols.Discovery
-
- addResponse(PingData, boolean) - Method in class org.jgroups.util.Responses
-
- Address - Interface in org.jgroups
-
Address identifies cluster member.
- address - Variable in class org.jgroups.protocols.Executing.Owner
-
- address - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- address - Variable in class org.jgroups.util.DefaultThreadFactory
-
- address - Variable in class org.jgroups.util.Owner
-
- ADDRESS_BITS_PER_WORD - Static variable in class org.jgroups.util.FixedSizeBitSet
-
- address_generators - Variable in class org.jgroups.JChannel
-
- address_mappings - Variable in class org.jgroups.stack.GossipRouter
-
- addressAsString(Address) - Static method in class org.jgroups.protocols.Discovery
-
- addressAsString(Address) - Static method in class org.jgroups.protocols.PDC
-
- AddressGenerator - Interface in org.jgroups.stack
-
Callback to provide custom addresses.
- addressToFilename(Address) - Static method in class org.jgroups.protocols.FILE_PING
-
- addRsp(Address, T) - Method in class org.jgroups.util.RspList
-
- addSite(String, RelayConfig.SiteConfig) - Method in class org.jgroups.protocols.relay.RELAY2
-
- addSubtree(Node) - Method in class org.jgroups.conf.ProtocolConfiguration
-
- addSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
-
Adds a suspected member.
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.BroadcastTask
-
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
Adds a suspected member.
- addToCache(String) - Method in class org.jgroups.protocols.Discovery
-
- addToPendingReleaseRequests(Locking.ClientLock) - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- addToQueue(Buffer) - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- addToQueue(Locking.Request) - Method in class org.jgroups.protocols.Locking.ServerLock
-
- addToRelayedTime(long) - Method in class org.jgroups.protocols.relay.RELAY2
-
- addToResults(Address, boolean, long) - Method in class org.jgroups.util.RpcStats
-
- addVote(int) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Adds mbr to votes and returns true if we have all the votes, otherwise false.
- addWaiter(Owner) - Method in class org.jgroups.protocols.Locking.ServerCondition
-
- adjustCredit(Map<Address, FlowControl.Credit>, Address, int) - Method in class org.jgroups.protocols.FlowControl
-
Check whether sender has enough credits left.
- adjustNodes(List<Address>) - Method in class org.jgroups.demos.wb.GraphPanel
-
- adjustPosition(boolean) - Method in class org.jgroups.nio.Buffers
-
- adjustReceivers(List<Address>) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Removes old members from xmit-table and adds new members to xmit-table (at seqnos hd=0, hr=0).
- adjustSuspectedMembers(List<Address>) - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
Removes all elements from suspected_mbrs that are not in the new membership
- adjustSuspectedMembers(List<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
Removes all elements from suspects that are not in the new membership
- adler() - Method in class org.jgroups.protocols.EncryptBase
-
- adler(boolean) - Method in class org.jgroups.protocols.EncryptBase
-
- advance(int) - Method in class org.jgroups.protocols.RingBufferBundler
-
- advanceLow() - Method in class org.jgroups.util.RequestTable
-
- advanceReadIndex(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- advanceWriteIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- after_creation_hook - Variable in class org.jgroups.stack.Protocol
-
- afterCreation(Protocol) - Method in interface org.jgroups.stack.ProtocolHook
-
Called after all protocols have been created, connected and its attributes set, but
before
Protocol.init()
is called.
- afterCreationHook() - Method in class org.jgroups.stack.Protocol
-
- age() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- age() - Method in class org.jgroups.util.SuppressCache.Value
-
- AgeOutCache<K> - Class in org.jgroups.util
-
Cache which removes its elements after a certain time
- AgeOutCache(TimeScheduler, long) - Constructor for class org.jgroups.util.AgeOutCache
-
- AgeOutCache(TimeScheduler, long, AgeOutCache.Handler) - Constructor for class org.jgroups.util.AgeOutCache
-
- AgeOutCache.Handler<K> - Interface in org.jgroups.util
-
- alias - Variable in class org.jgroups.protocols.SYM_ENCRYPT
-
- alias() - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
- alias(String) - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
- all - Variable in class org.jgroups.blocks.locking.AwaitInfo
-
- all(Collection, Object) - Static method in class org.jgroups.util.Util
-
Returns true if all elements of c match obj
- all_acks_received - Variable in class org.jgroups.util.AckCollector
-
- ALL_TASK_CANCEL - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
-
- allChannelsHaveSameView(JChannel...) - Static method in class org.jgroups.util.Util
-
- allEqual(Collection<T>) - Static method in class org.jgroups.util.Util
-
Returns true if all elements in the collection are the same
- allSet() - Method in class org.jgroups.util.MutableDigest
-
Returns true if all members have a corresponding seqno >= 0, else false
- allVotesReceived(FixedSizeBitSet) - Static method in class org.jgroups.protocols.pbcast.STABLE
-
Votes is already locked and guaranteed to be non-null
- always_send_physical_addr_with_discovery_request - Variable in class org.jgroups.protocols.Discovery
-
Deprecated.
- AnycastAddress - Class in org.jgroups
-
This type of address represents a subset of the cluster members in which the total order properties must be applied,
e.g.
- AnycastAddress() - Constructor for class org.jgroups.AnycastAddress
-
- AnycastAddress(Collection<Address>) - Constructor for class org.jgroups.AnycastAddress
-
- AnycastAddress(Address...) - Constructor for class org.jgroups.AnycastAddress
-
- anycasts(boolean) - Method in class org.jgroups.util.RpcStats
-
- apiKey - Variable in class org.jgroups.protocols.RACKSPACE_PING
-
- apply(RouterStub, RouterStubManager.Consumer) - Method in class org.jgroups.stack.RouterStubManager
-
- arg() - Method in class org.jgroups.Event
-
- args - Variable in class org.jgroups.blocks.MethodCall
-
The arguments of the method.
- array() - Method in class org.jgroups.util.MessageBatch
-
Returns the underlying message array.
- ArrayIterator<T> - Class in org.jgroups.util
-
Iterator over an array of elements of type T.
- ArrayIterator(T[]) - Constructor for class org.jgroups.util.ArrayIterator
-
- AsciiString - Class in org.jgroups.util
-
Simple string implemented as a byte[] array.
- AsciiString() - Constructor for class org.jgroups.util.AsciiString
-
- AsciiString(String) - Constructor for class org.jgroups.util.AsciiString
-
- AsciiString(AsciiString) - Constructor for class org.jgroups.util.AsciiString
-
- AsciiString(byte[]) - Constructor for class org.jgroups.util.AsciiString
-
- AsciiString(int) - Constructor for class org.jgroups.util.AsciiString
-
- assembleMessage() - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
Assembles all the fragments into one buffer.
- assertAllChannelsHaveSameView(JChannel...) - Static method in class org.jgroups.util.Util
-
- assertEquals(String, Object, Object) - Static method in class org.jgroups.util.Util
-
- assertEquals(Object, Object) - Static method in class org.jgroups.util.Util
-
- assertFalse(boolean) - Static method in class org.jgroups.util.Util
-
- assertFalse(String, boolean) - Static method in class org.jgroups.util.Util
-
- assertNotNull(String, Object) - Static method in class org.jgroups.util.Util
-
- assertNotNull(Object) - Static method in class org.jgroups.util.Util
-
- assertNull(String, Object) - Static method in class org.jgroups.util.Util
-
- assertPositive(int, String) - Static method in class org.jgroups.protocols.RingBufferBundler
-
- assertPositive(int, String) - Static method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- assertPositive(int, String) - Static method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- assertPositive(int, String) - Static method in class org.jgroups.protocols.TP
-
- assertPositive(int, String) - Static method in class org.jgroups.protocols.TransferQueueBundler
-
- assertPositiveUnsignedShort(int) - Static method in class org.jgroups.nio.Buffers
-
- assertTrue(boolean) - Static method in class org.jgroups.util.Util
-
- assertTrue(String, boolean) - Static method in class org.jgroups.util.Util
-
- asym_algorithm - Variable in class org.jgroups.protocols.EncryptBase
-
- asym_cipher - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- ASYM_ENCRYPT - Class in org.jgroups.protocols
-
Encrypts and decrypts communication in JGroups by using a secret key distributed to all cluster members by the
key server (coordinator) using asymmetric (public/private key) encryption.
The secret key is identical for all cluster members and is used to encrypt messages when sending and decrypt them
when receiving messages.
- ASYM_ENCRYPT() - Constructor for class org.jgroups.protocols.ASYM_ENCRYPT
-
- asym_keylength - Variable in class org.jgroups.protocols.EncryptBase
-
- asymAlgorithm - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- asymAlgorithm() - Method in class org.jgroups.protocols.EncryptBase
-
- asymAlgorithm(String) - Method in class org.jgroups.protocols.EncryptBase
-
- asymCipher() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- asymKeylength() - Method in class org.jgroups.protocols.EncryptBase
-
- asymKeylength(int) - Method in class org.jgroups.protocols.EncryptBase
-
- ASYNC() - Static method in class org.jgroups.blocks.RequestOptions
-
- async - Variable in class org.jgroups.util.RpcStats.Result
-
- async() - Method in class org.jgroups.util.RpcStats.Result
-
- async_anycasts - Variable in class org.jgroups.util.RpcStats
-
- async_discovery - Variable in class org.jgroups.protocols.Discovery
-
- async_discovery_use_separate_thread_per_request - Variable in class org.jgroups.protocols.Discovery
-
- async_dispatching - Variable in class org.jgroups.blocks.MessageDispatcher
-
- async_dispatching - Variable in class org.jgroups.blocks.RequestCorrelator
-
Whether or not to use async dispatcher
- async_multicasts - Variable in class org.jgroups.util.RpcStats
-
- async_relay_creation - Variable in class org.jgroups.protocols.relay.RELAY2
-
- async_unicasts - Variable in class org.jgroups.util.RpcStats
-
- asyncDispatching() - Method in class org.jgroups.blocks.MessageDispatcher
-
- asyncDispatching(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
- asyncDispatching() - Method in class org.jgroups.blocks.RequestCorrelator
-
- asyncDispatching(boolean) - Method in class org.jgroups.blocks.RequestCorrelator
-
- asyncRelayCreation(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
-
- asyncRelayCreation() - Method in class org.jgroups.protocols.relay.RELAY2
-
- AsyncRequestHandler - Interface in org.jgroups.blocks
-
Provides a way to invoke requests asynchronously
- attemptSchemaInitialization() - Method in class org.jgroups.protocols.JDBC_PING
-
- AttributeEntry(String, MBeanAttributeInfo) - Constructor for class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- AttributeEntry(String, MBeanAttributeInfo, ResourceDMBean.Accessor, ResourceDMBean.Accessor) - Constructor for class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- attributeNameToMethodName(String) - Static method in class org.jgroups.util.Util
-
- attrInfo - Variable in class org.jgroups.jmx.ResourceDMBean
-
- atts - Variable in class org.jgroups.jmx.ResourceDMBean
-
- auth - Variable in class org.jgroups.auth.AuthToken
-
A reference to AUTH
- AUTH - Class in org.jgroups.protocols
-
The AUTH protocol adds a layer of authentication to JGroups.
- AUTH() - Constructor for class org.jgroups.protocols.AUTH
-
- AUTH.UpHandler - Interface in org.jgroups.protocols
-
Interface to provide callbacks for handling up events
- auth_token - Variable in class org.jgroups.protocols.AUTH
-
Used on the coordinator to authentication joining member requests against
- auth_type - Variable in class org.jgroups.protocols.SWIFT_PING
-
- auth_url - Variable in class org.jgroups.protocols.SWIFT_PING
-
- auth_value - Variable in class org.jgroups.auth.X509Token
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.AuthToken
-
This method should be implemented to perform the actual authentication of joining members.
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.DemoToken
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.FixedMembershipToken
-
Check if I'm in memberList, too
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.Krb5Token
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.MD5Token
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.RegexMembership
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.SimpleToken
-
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.X509Token
-
- authenticate() - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Authenticate
- authenticate_coord - Variable in class org.jgroups.protocols.AUTH
-
- AuthHeader - Class in org.jgroups.protocols
-
AuthHeader is a holder object for the token that is passed from the joiner to the coordinator
- AuthHeader() - Constructor for class org.jgroups.protocols.AuthHeader
-
- AuthHeader(AuthToken) - Constructor for class org.jgroups.protocols.AuthHeader
-
- authorizeProbeRequest(DatagramPacket) - Method in class org.jgroups.stack.DiagnosticsHandler
-
Performs authorization on given DatagramPacket.
- AuthToken - Class in org.jgroups.auth
-
Abstract AuthToken class used by implementations of AUTH, e.g.
- AuthToken() - Constructor for class org.jgroups.auth.AuthToken
-
- automatic_purging - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- available() - Method in class org.jgroups.blocks.GridInputStream
-
- available() - Method in class org.jgroups.util.BlockingInputStream
-
- available() - Method in class org.jgroups.util.InputStreamAdapter
-
- Average - Class in org.jgroups.util
-
Maintains an approximation of an average of values.
- Average() - Constructor for class org.jgroups.util.Average
-
- average() - Method in class org.jgroups.util.Average
-
- AverageMinMax - Class in org.jgroups.util
-
Measures min and max in addition to average
- AverageMinMax() - Constructor for class org.jgroups.util.AverageMinMax
-
- avg - Variable in class org.jgroups.protocols.PERF
-
- avg - Variable in class org.jgroups.util.Average
-
- avg - Variable in class org.jgroups.util.RpcStats.Result
-
- avg() - Method in class org.jgroups.util.RpcStats.Result
-
- avg_batch_size - Variable in class org.jgroups.protocols.TP
-
- avg_block_time - Variable in class org.jgroups.protocols.UFC
-
- avg_block_time - Variable in class org.jgroups.util.CreditMap
-
- avg_blockings - Variable in class org.jgroups.protocols.FlowControl.Credit
-
- avg_size - Variable in class org.jgroups.protocols.PERF
-
- avg_state_size - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- avg_state_size - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- await() - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- await(long, TimeUnit) - Method in class org.jgroups.protocols.Locking.ClientCondition
-
Note this wait will only work correctly if the converted value is less
than 292 years.
- await(boolean) - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- await(long) - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- awaitCompletion(long) - Method in class org.jgroups.auth.sasl.SaslServerContext
-
- awaited(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
-
- awaited(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
-
- awaited(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- AwaitInfo - Class in org.jgroups.blocks.locking
-
- AwaitInfo(String, boolean) - Constructor for class org.jgroups.blocks.locking.AwaitInfo
-
- awaiting(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
-
- awaiting(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
-
- awaiting(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- awaitNanos(long) - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- awaitTermination(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- awaitUninterruptibly() - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- awaitUntil(Date) - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- Cache<K,V> - Class in org.jgroups.blocks
-
Simple cache which maintains keys and value.
- Cache() - Constructor for class org.jgroups.blocks.Cache
-
- cache - Variable in class org.jgroups.protocols.FD_SOCK
-
Cache of member addresses and their ServerSocket addresses
- cache - Variable in class org.jgroups.protocols.PDC
-
- cache - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- cache - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- cache - Variable in class org.jgroups.protocols.UNICAST3
-
- cache - Variable in class org.jgroups.util.SuppressLog
-
- cache - Static variable in class org.jgroups.util.UUID
-
Keeps track of associations between logical addresses (UUIDs) and logical names
- Cache.ChangeListener - Interface in org.jgroups.blocks
-
- Cache.Value<V> - Class in org.jgroups.blocks
-
- cache_dir - Variable in class org.jgroups.protocols.PDC
-
- cache_max_age - Variable in class org.jgroups.protocols.FD_SOCK
-
- cache_max_elements - Variable in class org.jgroups.protocols.FD_SOCK
-
- call() - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
-
- call() - Method in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- call() - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
-
- call() - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
-
- call_options - Variable in class org.jgroups.blocks.ReplicatedHashMap
-
- callable - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
The underlying callable
- callAfterCreationHook(Protocol, String) - Static method in class org.jgroups.stack.ProtocolStack
-
- callbacks - Variable in class org.jgroups.client.StompConnection
-
- callRemoteMethod(Address, String, Object[], Class[], RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in a cluster member and - if blocking - returns the result
- callRemoteMethod(Address, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in a cluster member and - if blocking - returns the result
- callRemoteMethods(Collection<Address>, String, Object[], Class[], RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
- callRemoteMethods(Collection<Address>, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
- callRemoteMethodsWithFuture(Collection<Address>, MethodCall, RequestOptions, FutureListener<RspList<T>>) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
- callRemoteMethodsWithFuture(Collection<Address>, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in all members and expects responses from members contained in dests (or all members if dests is null).
- callRemoteMethodWithFuture(Address, MethodCall, RequestOptions, FutureListener<T>) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in a cluster member and - if blocking - returns the result
- callRemoteMethodWithFuture(Address, MethodCall, RequestOptions) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in a cluster member and - if blocking - returns the result
- callRetransmissionCommand() - Method in class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
-
- callRetransmissionCommand() - Method in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
-
- callRetransmissionCommand() - Method in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- callUpHandlers(Event) - Method in class org.jgroups.protocols.AUTH
-
- can_become_site_master - Variable in class org.jgroups.protocols.relay.RELAY2
-
- can_become_site_master - Static variable in class org.jgroups.util.ExtendedUUID
-
- can_bind_to_mcast_addr - Static variable in class org.jgroups.protocols.TP
-
- can_forward_local_cluster - Variable in class org.jgroups.protocols.relay.RELAY2
-
- canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.CanBeSiteMasterTopology
-
Deprecated.
- canBecomeSiteMaster(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
-
- canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY2
-
- canBeProcessedTogether(GmsImpl.Request) - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
-
Specifies whether this request can be processed with other request simultaneously
- CanBeSiteMaster - Class in org.jgroups.protocols.relay
-
- CanBeSiteMaster() - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- CanBeSiteMaster(byte[], boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- CanBeSiteMaster(UUID, boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- CanBeSiteMasterTopology - Class in org.jgroups.protocols.relay
-
- CanBeSiteMasterTopology() - Constructor for class org.jgroups.protocols.relay.CanBeSiteMasterTopology
-
Deprecated.
- CanBeSiteMasterTopology(TopologyUUID, boolean) - Constructor for class org.jgroups.protocols.relay.CanBeSiteMasterTopology
-
Deprecated.
- cancel(boolean) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- cancel(boolean) - Method in class org.jgroups.blocks.Request
-
- cancel() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- cancel() - Method in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- cancel(boolean) - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- cancel(boolean) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- cancel(boolean) - Method in class org.jgroups.util.NullFuture
-
- cancel(boolean) - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- cancel(boolean) - Method in class org.jgroups.util.TimeScheduler3.Task
-
- CANCEL_MERGE - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- cancelBarrierOpener() - Method in class org.jgroups.protocols.BARRIER
-
- CANCELLED - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
State value representing that task was cancelled
- cancelled - Variable in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- cancelled - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
-
- cancelled - Variable in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- cancelled - Variable in class org.jgroups.util.TimeScheduler3.Task
-
- cancelMerge() - Method in class org.jgroups.protocols.pbcast.GMS
-
- cancelMerge(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
- cancelRebroadcasting() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- canDeliver(Address, long) - Method in class org.jgroups.protocols.SEQUENCER
-
Checks if seqno has already been received from sender.
- canDeliver(Address, long) - Method in class org.jgroups.util.ForwardQueue
-
Checks if seqno has already been received from sender.
- canRun() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- canRun() - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- cap - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Deprecated.
- capacity - Variable in class org.jgroups.protocols.RingBufferBundler
-
- capacity() - Method in class org.jgroups.util.BlockingInputStream
-
- capacity() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- capacity - Variable in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- capacity() - Method in class org.jgroups.util.Digest
-
- capacity() - Method in class org.jgroups.util.MessageBatch
-
- capacity() - Method in class org.jgroups.util.RequestTable
-
- capacity() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Returns the total capacity in the matrix
- capacity() - Method in class org.jgroups.util.RingBuffer
-
- capacity() - Method in class org.jgroups.util.RingBufferSeqno
-
- capacity() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- capacity() - Method in class org.jgroups.util.Table
-
Returns the total capacity in the matrix
- cardinality() - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the number of bits set to true in this bit set
- cast(Collection<Address>, Message, RequestOptions, boolean, FutureListener<RspList<T>>) - Method in class org.jgroups.blocks.MessageDispatcher
-
- cast(Collection<Address>, Message, RequestOptions, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
- cast(Collection<Address>, Message, RequestOptions, boolean, FutureListener<RspList<T>>) - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- cast(Collection<Address>, Message, RequestOptions, boolean, FutureListener<RspList<T>>) - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- castMessage(Collection<Address>, Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a message to all members and expects responses from members in dests (if non-null).
- castMessageWithFuture(Collection<Address>, Message, RequestOptions, FutureListener<RspList<T>>) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a message to all members and expects responses from members in dests (if non-null).
- castMessageWithFuture(Collection<Address>, Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a message to all members and expects responses from members in dests (if non-null).
- castViewChange(View, Digest, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Broadcasts the new view and digest as a VIEW message and waits for acks from existing members
- CCHM_CONCURRENCY_LEVEL - Static variable in class org.jgroups.Global
-
- CCHM_CONCURRENCY_LEVEL - Static variable in class org.jgroups.util.Util
-
- CCHM_INITIAL_CAPACITY - Static variable in class org.jgroups.Global
-
- CCHM_INITIAL_CAPACITY - Static variable in class org.jgroups.util.Util
-
- CCHM_LOAD_FACTOR - Static variable in class org.jgroups.Global
-
- CCHM_LOAD_FACTOR - Static variable in class org.jgroups.util.Util
-
- CENTRAL_EXECUTOR - Class in org.jgroups.protocols
-
This is a central executor service where each request is sent to the coordinator
for either a task or a current waiting thread.
- CENTRAL_EXECUTOR() - Constructor for class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- CENTRAL_LOCK - Class in org.jgroups.protocols
-
Implementation of a locking protocol which acquires locks by contacting the coordinator.
- CENTRAL_LOCK() - Constructor for class org.jgroups.protocols.CENTRAL_LOCK
-
- CERT_ALIAS - Static variable in class org.jgroups.auth.X509Token
-
- cert_alias - Variable in class org.jgroups.auth.X509Token
-
- CERT_PASSWORD - Static variable in class org.jgroups.auth.X509Token
-
- CertficateCNMatcher - Class in org.jgroups.protocols
-
- CertficateCNMatcher() - Constructor for class org.jgroups.protocols.CertficateCNMatcher
-
- ch - Variable in class org.jgroups.blocks.atomic.CounterService
-
- ch - Variable in class org.jgroups.blocks.executor.ExecutionRunner
-
- ch - Variable in class org.jgroups.blocks.executor.ExecutionService
-
- ch - Variable in class org.jgroups.blocks.locking.LockService
-
- ch - Variable in class org.jgroups.demos.CounterServiceDemo
-
- ch - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- ch - Variable in class org.jgroups.demos.LockServiceDemo
-
- ch - Variable in class org.jgroups.demos.RelayDemoRpc
-
- CHALLENGE - Static variable in class org.jgroups.auth.DemoToken.DemoHeader
-
- challenge - Variable in class org.jgroups.auth.DemoToken.Entry
-
- change_key_on_leave - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- changed() - Method in interface org.jgroups.blocks.Cache.ChangeListener
-
- changed() - Method in class org.jgroups.blocks.ReplCache
-
- changed() - Method in interface org.jgroups.blocks.ReplCache.ChangeListener
-
- changeName(String) - Method in class org.jgroups.util.LazyThreadFactory
-
Replaces "
" with the local address and with the cluster name
- channel - Variable in class org.jgroups.blocks.cs.NioConnection
-
- channel - Variable in class org.jgroups.blocks.cs.NioServer
-
- channel - Variable in class org.jgroups.blocks.MessageDispatcher
-
- Channel - Class in org.jgroups
-
A channel represents a group communication endpoint (like BSD datagram sockets).
- Channel() - Constructor for class org.jgroups.Channel
-
- channel - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
-
- channel - Variable in class org.jgroups.stack.ProtocolStack
-
- Channel.State - Enum in org.jgroups
-
- channel_listeners - Variable in class org.jgroups.blocks.MessageDispatcher
-
- channel_listeners - Variable in class org.jgroups.Channel
-
- channelClosed(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
-
- channelClosed(Channel) - Method in interface org.jgroups.ChannelListener
-
Channel has been closed notification callback
- channelClosed(Channel) - Method in class org.jgroups.demos.Draw
-
- channelClosed(Channel) - Method in class org.jgroups.fork.ForkChannel
-
- channelConnected(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
-
- channelConnected(Channel) - Method in interface org.jgroups.ChannelListener
-
Channel has been connected notification callback
- channelConnected(Channel) - Method in class org.jgroups.demos.Draw
-
- channelConnected(Channel) - Method in class org.jgroups.fork.ForkChannel
-
- channelDisconnected(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
-
- channelDisconnected(Channel) - Method in interface org.jgroups.ChannelListener
-
Channel has been disconnected notification callback
- channelDisconnected(Channel) - Method in class org.jgroups.demos.Draw
-
- channelDisconnected(Channel) - Method in class org.jgroups.fork.ForkChannel
-
- ChannelListener - Interface in org.jgroups
-
Allows a listener to be notified when an important channel lifecycle event occurs.
- chars() - Method in class org.jgroups.util.AsciiString
-
- Chat - Class in org.jgroups.demos
-
- Chat() - Constructor for class org.jgroups.demos.Chat
-
- check_interval - Variable in class org.jgroups.protocols.MERGE3
-
- check_timeout - Variable in class org.jgroups.protocols.FD_HOST
-
- checkBounds(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- checkBounds(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- checkClosed() - Method in class org.jgroups.JChannel
-
health check
throws a ChannelClosed exception if the channel is closed
- checkClosedOrNotConnected() - Method in class org.jgroups.JChannel
-
- checkCompletion(Future) - Method in class org.jgroups.blocks.Request
-
- CheckFDMonitor - Class in org.jgroups.protocols.rules
-
Rule which checks if the FD monitor is running when we have more than 1 member.
- CheckFDMonitor() - Constructor for class org.jgroups.protocols.rules.CheckFDMonitor
-
- checkForAndroid() - Static method in class org.jgroups.util.Util
-
- checkForHp() - Static method in class org.jgroups.util.Util
-
- checkForLinux() - Static method in class org.jgroups.util.Util
-
- checkForMac() - Static method in class org.jgroups.util.Util
-
- checkforPendingRegistrations() - Method in class org.jgroups.blocks.cs.NioBaseServer.Acceptor
-
- checkForRebroadcasts() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- checkForRebroadcasts() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- checkForSharedTransport(TP) - Method in class org.jgroups.protocols.BaseBundler
-
- checkForSolaris() - Static method in class org.jgroups.util.Util
-
- checkForWindows() - Static method in class org.jgroups.util.Util
-
- checkIfValidAddress(InetAddress, String) - Static method in class org.jgroups.util.Util
-
- checkInconsistencies() - Method in class org.jgroups.protocols.MERGE3
-
- checkParentDirs(String, boolean) - Method in class org.jgroups.blocks.GridFile
-
Checks whether the parent directories are present (and are directories).
- checkPostcondition() - Method in class org.jgroups.util.Digest
-
- cipher - Variable in class org.jgroups.protocols.ENCRYPT.Decrypter
-
Deprecated.
- cipher - Variable in class org.jgroups.protocols.EncryptBase.Decrypter
-
- cipher_index - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- cipher_pool_size - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- cipher_pool_size - Variable in class org.jgroups.protocols.EncryptBase
-
- CIPHER_TYPE - Static variable in class org.jgroups.auth.X509Token
-
- cipher_type - Variable in class org.jgroups.auth.X509Token
-
- CLASS - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- ClassConfigurator - Class in org.jgroups.conf
-
This class will be replaced with the class that read info
from the magic number configurator that reads info from the xml file.
- ClassConfigurator() - Constructor for class org.jgroups.conf.ClassConfigurator
-
- clear(int) - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- clear(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- clear() - Method in class org.jgroups.blocks.ReplCache
-
Removes all keys and values in the L2 and L1 caches
- clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Removes all of the mappings from this map.
- clear() - Method in class org.jgroups.demos.Draw.DrawPanel
-
- clear() - Method in class org.jgroups.Membership
-
Removes all the members from this membership
- clear() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- clear() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
remove all the pending messages
- clear() - Method in class org.jgroups.protocols.tom.SenderManager
-
removes all pending messages
- clear() - Method in class org.jgroups.util.AgeOutCache
-
- clear() - Method in class org.jgroups.util.Average
-
- clear() - Method in class org.jgroups.util.AverageMinMax
-
- clear() - Method in class org.jgroups.util.CreditMap
-
- clear() - Method in class org.jgroups.util.ExpiryCache
-
- clear(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Sets the bit specified by the index to false
.
- clear(int, int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Sets the bits from the specified from
(inclusive) to the
specified to
(inclusive) to false
.
- clear() - Method in class org.jgroups.util.MessageBatch
-
- clear() - Method in class org.jgroups.util.Queue
-
Removes all elements from the queue.
- clear() - Method in class org.jgroups.util.RequestTable
-
Removes all elements, compacts the buffer and sets low=high=0
- clear(long) - Method in class org.jgroups.util.RequestTable
-
- clear() - Method in class org.jgroups.util.Responses
-
- clear() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Removes all elements.
- clear() - Method in class org.jgroups.util.RingBuffer
-
- clear() - Method in class org.jgroups.util.RspList
-
- clear(long) - Method in class org.jgroups.util.Seqno
-
- clear(long) - Method in class org.jgroups.util.SeqnoRange
-
- clear(long...) - Method in class org.jgroups.util.SeqnoRange
-
- clear() - Method in class org.jgroups.util.SuppressCache
-
- clear_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- clear_table_on_view_change - Variable in class org.jgroups.protocols.JDBC_PING
-
- clearAllFragments() - Method in class org.jgroups.protocols.FRAG2
-
- clearChannelListeners() - Method in class org.jgroups.Channel
-
Clears all installed ChannelListener instances
- clearConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
Used only for testing !
- clearConnections() - Method in class org.jgroups.protocols.TCP
-
- clearConnections() - Method in class org.jgroups.protocols.TCP_NIO2
-
- clearDifferentClusterCache() - Method in class org.jgroups.protocols.TP
-
- clearDifferentVersionCache() - Method in class org.jgroups.protocols.TP
-
- clearDroppedMessagesCache() - Method in class org.jgroups.protocols.UDP
-
- clearDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
-
- clearFlag(Message.Flag...) - Method in class org.jgroups.Message
-
Clears a number of flags in a message
- clearFlag(short) - Method in class org.jgroups.util.ExtendedUUID
-
- clearFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
-
- clearFlags(byte, byte) - Static method in class org.jgroups.util.Util
-
- clearFragmentsFor(Address) - Method in class org.jgroups.protocols.FRAG2
-
- clearLogicalAddressCache() - Method in class org.jgroups.protocols.TP
-
Clears the cache.
- clearMessages() - Method in class org.jgroups.protocols.BaseBundler
-
- clearNonMemberCache() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- clearNonMemberCache() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- clearPanel() - Method in class org.jgroups.demos.applets.DrawApplet
-
- clearPanel() - Method in class org.jgroups.demos.Draw
-
- clearPanel() - Method in class org.jgroups.demos.StompDraw
-
- clearQueue(Address) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- clearSelectionKey(int) - Method in class org.jgroups.blocks.cs.NioConnection
-
- clearStats() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- clearTable() - Method in class org.jgroups.protocols.JDBC_PING
-
- clearTransientFlag(Message.TransientFlag...) - Method in class org.jgroups.Message
-
- clearTransientFlags(Message.TransientFlag...) - Method in class org.jgroups.blocks.RequestOptions
-
- clearViews() - Method in class org.jgroups.protocols.MERGE3
-
- Client - Interface in org.jgroups.blocks.cs
-
Defines common operations for clients (TCP or NIO)
- client - Variable in class org.jgroups.demos.PubClient
-
- CLIENT - Static variable in class org.jgroups.demos.StompChat
-
- CLIENT - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- client - Variable in class org.jgroups.stack.RouterStub
-
- client_addr - Variable in class org.jgroups.stack.GossipRouter.Entry
-
- client_bind_addr - Variable in class org.jgroups.blocks.cs.BaseServer
-
- client_bind_addr - Variable in class org.jgroups.protocols.BasicTCP
-
- client_bind_port - Variable in class org.jgroups.blocks.cs.BaseServer
-
- client_bind_port - Variable in class org.jgroups.protocols.BasicTCP
-
- client_bind_port - Variable in class org.jgroups.protocols.FD_SOCK
-
- client_callback_handler - Variable in class org.jgroups.protocols.SASL
-
- CLIENT_JOINED - Static variable in class org.jgroups.demos.StompChat
-
- CLIENT_LEFT - Static variable in class org.jgroups.demos.StompChat
-
- client_lock_table - Variable in class org.jgroups.protocols.Locking
-
- client_name - Variable in class org.jgroups.protocols.SASL
-
- CLIENT_PASSWORD - Static variable in class org.jgroups.auth.Krb5Token
-
- client_password - Variable in class org.jgroups.auth.Krb5Token
-
- client_password - Variable in class org.jgroups.protocols.SASL
-
- CLIENT_PRINCIPAL_NAME - Static variable in class org.jgroups.auth.Krb5Token
-
- client_principal_name - Variable in class org.jgroups.auth.Krb5Token
-
- client_subject - Variable in class org.jgroups.protocols.SASL
-
- clientBindAddress() - Method in class org.jgroups.blocks.cs.BaseServer
-
- clientBindAddress(InetAddress) - Method in class org.jgroups.blocks.cs.BaseServer
-
- clientBindPort() - Method in class org.jgroups.blocks.cs.BaseServer
-
- clientBindPort(int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- ClientCondition(Locking.ClientLock) - Constructor for class org.jgroups.protocols.Locking.ClientCondition
-
- ClientConnectionHandler(Socket, List<FD_SOCK.ClientConnectionHandler>) - Constructor for class org.jgroups.protocols.FD_SOCK.ClientConnectionHandler
-
- ClientGmsImpl - Class in org.jgroups.protocols.pbcast
-
Client part of GMS.
- ClientGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- ClientLock(String) - Constructor for class org.jgroups.protocols.Locking.ClientLock
-
- ClientLock(String, Owner) - Constructor for class org.jgroups.protocols.Locking.ClientLock
-
- ClientLockTable() - Constructor for class org.jgroups.protocols.Locking.ClientLockTable
-
- CLIENTS - Static variable in class org.jgroups.demos.StompChat
-
- clients - Variable in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
List
- clients_dest - Static variable in class org.jgroups.demos.StompDraw
-
- CLIENTS_KW - Static variable in class org.jgroups.demos.StompChat
-
- clone() - Method in class org.jgroups.blocks.ReplicatedTree.Node
-
- clone() - Method in class org.jgroups.protocols.tom.MessageID
-
- close() - Method in class org.jgroups.blocks.cs.BaseServer
-
- close() - Method in class org.jgroups.blocks.cs.BaseServer.Reaper
-
- close() - Method in class org.jgroups.blocks.cs.NioConnection
-
- close() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- close() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- close() - Method in class org.jgroups.blocks.GridInputStream
-
- close() - Method in class org.jgroups.blocks.GridOutputStream
-
- close() - Method in class org.jgroups.blocks.MessageDispatcher
-
- close() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- close() - Method in class org.jgroups.Channel
-
Destroys the channel and its associated resources (e.g., the protocol stack).
- close() - Method in class org.jgroups.fork.ForkChannel
-
Closes the fork-channel, essentially setting its state to CLOSED.
- close() - Method in class org.jgroups.JChannel
-
- close() - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- close(Object) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- close(Object) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- CLOSE - Static variable in class org.jgroups.protocols.UNICAST3.Header
-
- close() - Method in class org.jgroups.util.Base64.OutputStream
-
Flushes and closes (I think, in the superclass) the stream.
- close() - Method in class org.jgroups.util.BlockingInputStream
-
Closes the stream.
- close(Socket) - Method in class org.jgroups.util.DefaultSocketFactory
-
- close(ServerSocket) - Method in class org.jgroups.util.DefaultSocketFactory
-
- close(DatagramSocket) - Method in class org.jgroups.util.DefaultSocketFactory
-
- close() - Method in class org.jgroups.util.InputStreamAdapter
-
- close() - Method in class org.jgroups.util.OutputStreamAdapter
-
- close(boolean) - Method in class org.jgroups.util.Queue
-
Marks the queues as closed.
- close(Socket) - Method in interface org.jgroups.util.SocketFactory
-
- close(ServerSocket) - Method in interface org.jgroups.util.SocketFactory
-
- close(DatagramSocket) - Method in interface org.jgroups.util.SocketFactory
-
- close(Closeable) - Static method in class org.jgroups.util.Util
-
- close(Closeable...) - Static method in class org.jgroups.util.Util
-
- CLOSE_BARRIER - Static variable in class org.jgroups.Event
-
- CLOSE_HOLE - Static variable in class org.jgroups.Event
-
- close_listener - Variable in class org.jgroups.stack.RouterStub
-
- closeBarrier() - Method in class org.jgroups.protocols.BARRIER
-
Close the barrier.
- closeBarrierAndSuspendStable() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- closeBarrierAndSuspendStable() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- closeClientSocket() - Method in class org.jgroups.protocols.FD_SOCK.ClientConnectionHandler
-
- closeConnection(Connection, Throwable) - Method in class org.jgroups.blocks.cs.BaseServer
-
- closeConnection(Connection) - Method in class org.jgroups.protocols.JDBC_PING
-
- closeConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Removes and resets from connection table (which is already locked).
- closeConnections() - Method in class org.jgroups.client.StompConnection
-
- closed - Variable in class org.jgroups.nio.MockSocketChannel
-
- closed - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- closed(RouterStub) - Method in interface org.jgroups.stack.RouterStub.CloseListener
-
- closed(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
-
- closed - Variable in class org.jgroups.util.BlockingInputStream
-
- closed() - Method in class org.jgroups.util.Queue
-
returns true if the Queue has been closed
however, this method will return false if the queue has been closed
using the close(true) method and the last element has yet not been received.
- closeHoleFor(Address) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- closeHoleFor(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- closeIdleConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- closeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- closeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- closeUnicastSocket() - Method in class org.jgroups.protocols.UDP
-
- cluster - Variable in class org.jgroups.protocols.TP.SingleMessageHandlerWithClusterName
-
- cluster_name - Variable in class org.jgroups.demos.Draw
-
- cluster_name - Variable in class org.jgroups.JChannel
-
- cluster_name - Variable in class org.jgroups.protocols.Discovery
-
- cluster_name - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- cluster_name - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- cluster_name - Variable in class org.jgroups.protocols.MERGE3
-
- cluster_name - Variable in class org.jgroups.protocols.PingHeader
-
- cluster_name - Variable in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
-
- cluster_name - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
-
- cluster_name - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- cluster_name - Variable in class org.jgroups.protocols.TP
-
The name of the group to which this member is connected.
- cluster_name - Variable in class org.jgroups.protocols.TpHeader
-
- cluster_name - Variable in class org.jgroups.stack.RouterStubManager
-
- cluster_name - Variable in class org.jgroups.util.MessageBatch
-
The name of the cluster in which the message batch is sent, this is equivalent to TpHeader.cluster_name
- cluster_name - Variable in class org.jgroups.util.SingletonAddress
-
- clusterName(String) - Method in class org.jgroups.protocols.PingHeader
-
- clusterName - Variable in class org.jgroups.util.DefaultThreadFactory
-
- clusterName() - Method in class org.jgroups.util.MessageBatch
-
- clusterName(AsciiString) - Method in class org.jgroups.util.MessageBatch
-
- cmd - Variable in class org.jgroups.protocols.FD_HOST
-
- cmd - Variable in class org.jgroups.protocols.FD_HOST.ExternalPingCommand
-
- cmd - Variable in class org.jgroups.stack.Retransmitter
-
Deprecated.
- cn_name - Variable in class org.jgroups.protocols.CertficateCNMatcher
-
- cnt - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
-
- code(byte[], int, int, boolean) - Method in class org.jgroups.protocols.EncryptBase
-
- CODENAME - Static variable in class org.jgroups.Version
-
- collectionToByteBuffer(Collection<Address>) - Static method in class org.jgroups.util.Util
-
- command - Variable in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- CommandExecutor() - Constructor for class org.jgroups.protocols.FD_HOST.CommandExecutor
-
- CommandExecutor2() - Constructor for class org.jgroups.protocols.FD_HOST.CommandExecutor2
-
- compact() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- compact() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- compact() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- compact() - Method in class org.jgroups.util.BlockingInputStream
-
Moves the bytes between [read_pos and write_pos] read_pos bytes to the left, such that the new read_pos is 0
and the write_pos is write_pos - read_pos.
- compact() - Method in class org.jgroups.util.RequestTable
-
Shrinks the underlying array to half its size _if_ the new array can hold all of the existing elements.
- compact() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Moves the contents of matrix down by the number of purged rows and resizes the matrix accordingly.
- compact() - Method in class org.jgroups.util.Table
-
- compare(long, long) - Static method in class org.jgroups.protocols.UNICAST3
-
Compares 2 timestamps, handles numeric overflow
- compare(RouterStubManager.Target, RouterStubManager.Target) - Method in class org.jgroups.stack.RouterStubManager.Target
-
- compare(Seqno, Seqno) - Method in class org.jgroups.util.SeqnoComparator
-
- compare(byte[], byte[]) - Static method in class org.jgroups.util.Util
-
Compares 2 byte arrays, elements are treated as unigned
- compareAndSet(long, long) - Method in interface org.jgroups.blocks.atomic.Counter
-
Atomically updates the counter using a CAS operation
- compareAndSet(long, long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- compareAndSet(long, long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
-
- CompareAndSetRequest() - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- CompareAndSetRequest(Owner, String, long, long) - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- compareTo(Address) - Method in class org.jgroups.AnycastAddress
-
- compareTo(Locking.ClientLock) - Method in class org.jgroups.protocols.Locking.ClientLock
-
- compareTo(Route) - Method in class org.jgroups.protocols.relay.Route
-
- compareTo(Address) - Method in class org.jgroups.protocols.relay.SiteMaster
-
- compareTo(Address) - Method in class org.jgroups.protocols.relay.SiteUUID
-
- compareTo(MessageID) - Method in class org.jgroups.protocols.tom.MessageID
-
- compareTo(Delayed) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- compareTo(Address) - Method in class org.jgroups.stack.IpAddress
-
implements the java.lang.Comparable interface
- compareTo(RouterStub) - Method in class org.jgroups.stack.RouterStub
-
- compareTo(AsciiString) - Method in class org.jgroups.util.AsciiString
-
- compareTo(Owner) - Method in class org.jgroups.util.Owner
-
- compareTo(Range) - Method in class org.jgroups.util.Range
-
- compareTo(Address) - Method in class org.jgroups.util.SingletonAddress
-
- compareTo(byte[], byte[]) - Static method in class org.jgroups.util.SingletonAddress
-
- compareTo(Delayed) - Method in class org.jgroups.util.TimeScheduler3.Task
-
- compareTo(Address) - Method in class org.jgroups.util.UUID
-
Compares this UUID with the specified UUID.
- compareTo(View) - Method in class org.jgroups.View
-
- compareTo(ViewId) - Method in class org.jgroups.ViewId
-
Establishes an order between 2 ViewIds.
- compareToIDs(ViewId) - Method in class org.jgroups.ViewId
-
Establishes an order between 2 ViewIds.
- completionQueue - Variable in class org.jgroups.blocks.executor.ExecutionCompletionService
-
- componentHidden(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- componentMoved(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- componentResized(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- components(String, String) - Static method in class org.jgroups.util.Util
-
- componentShown(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- COMPRESS - Class in org.jgroups.protocols
-
Compresses the payload of a message.
- COMPRESS() - Constructor for class org.jgroups.protocols.COMPRESS
-
- COMPRESS.CompressHeader - Class in org.jgroups.protocols
-
- CompressHeader() - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
-
- CompressHeader(int) - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
-
- compression_level - Variable in class org.jgroups.protocols.COMPRESS
-
- computeCheckInterval() - Method in class org.jgroups.protocols.MERGE3
-
- computeChecksum(byte[], int, int) - Method in class org.jgroups.protocols.EncryptBase
-
- computeFragOffsets(int, int, int) - Static method in class org.jgroups.util.Util
-
Given a buffer and a fragmentation size, compute a list of fragmentation offset/length pairs, and
return them in a list.
- computeFragOffsets(byte[], int) - Static method in class org.jgroups.util.Util
-
- computeIndex(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Computes and returns the index within a row for seqno
- computeIndex(long) - Method in class org.jgroups.util.Table
-
Computes and returns the index within a row for seqno
- computeInterval() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
Returns a random value within [min_interval - max_interval]
- computeLowestCredit() - Method in class org.jgroups.util.CreditMap
-
Needs to be called with lock held
- computeLowestCreditWithAccumulated() - Method in class org.jgroups.util.CreditMap
-
- computeNewMembership(List<Address>, Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes the regular membership
- computeNewMembership(Collection<Collection<Address>>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes a merge membership
- computePingDest(Address) - Method in class org.jgroups.protocols.FD
-
Computes pingable_mbrs (based on the current membership and the suspected members) and ping_dest
- computeRow(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Computes and returns the row index for seqno
- computeRow(long) - Method in class org.jgroups.util.Table
-
Computes and returns the row index for seqno.
- computeSize() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Iterate from highest_seqno_purged to highest_seqno and add up non-null values
- computeSize() - Method in class org.jgroups.util.Table
-
Iterate from low to hr and add up non-null values.
- ConcurrentLinkedBlockingQueue<T> - Class in org.jgroups.util
-
Attempt at writing a fast transfer queue, which is bounded.
- ConcurrentLinkedBlockingQueue(int) - Constructor for class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- ConcurrentLinkedBlockingQueue2<T> - Class in org.jgroups.util
-
Attempt at writing a fast transfer queue, which is bounded.
- ConcurrentLinkedBlockingQueue2(int) - Constructor for class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- cond - Variable in class org.jgroups.blocks.Request
-
Is set as soon as the request has received all required responses
- cond - Variable in class org.jgroups.util.CondVar
-
- cond - Variable in class org.jgroups.util.Promise
-
- cond - Variable in class org.jgroups.util.Responses
-
- condition - Variable in class org.jgroups.protocols.Locking.ClientLock
-
- condition - Variable in class org.jgroups.protocols.Locking.ServerLock
-
- condition() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- condition() - Method in class org.jgroups.protocols.rules.Rule
-
Returns a description of the condition that led to
Rule.eval()
returning true
- condition() - Method in class org.jgroups.protocols.rules.SampleRule
-
- Condition - Interface in org.jgroups.util
-
- CondVar - Class in org.jgroups.util
-
A condition variable with methods for (timed) waiting and signalling
- CondVar() - Constructor for class org.jgroups.util.CondVar
-
- CondVar(Lock) - Constructor for class org.jgroups.util.CondVar
-
- CONFIG - Static variable in class org.jgroups.Event
-
- config - Variable in class org.jgroups.JChannel
-
- config - Variable in class org.jgroups.protocols.FORK
-
- config - Variable in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
-
- config - Variable in class org.jgroups.protocols.relay.RELAY2
-
- config(String) - Method in class org.jgroups.protocols.relay.RELAY2
-
- config() - Method in class org.jgroups.protocols.relay.RELAY2
-
- config - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- Configurator - Class in org.jgroups.stack
-
The task if this class is to setup and configure the protocol stack.
- Configurator() - Constructor for class org.jgroups.stack.Configurator
-
- Configurator(ProtocolStack) - Constructor for class org.jgroups.stack.Configurator
-
- Configurator.InetAddressInfo - Class in org.jgroups.stack
-
- ConfiguratorFactory - Class in org.jgroups.conf
-
The ConfigurationFactory is a factory that returns a protocol stack configurator.
- ConfiguratorFactory() - Constructor for class org.jgroups.conf.ConfiguratorFactory
-
- configure() - Method in class org.jgroups.protocols.relay.RELAY2
-
- conn - Variable in class org.jgroups.blocks.cs.NioClient
-
- conn - Variable in class org.jgroups.blocks.cs.TcpClient
-
- conn - Variable in class org.jgroups.protocols.S3_PING
-
- conn_close_timeout - Variable in class org.jgroups.protocols.UNICAST3
-
- conn_expire_time - Variable in class org.jgroups.blocks.cs.BaseServer
-
- conn_expire_time - Variable in class org.jgroups.protocols.BasicTCP
-
- conn_expiry_timeout - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- conn_expiry_timeout - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- conn_expiry_timeout - Variable in class org.jgroups.protocols.UNICAST3
-
- conn_id - Variable in class org.jgroups.protocols.UNICAST3.Entry
-
- conn_listeners - Variable in class org.jgroups.blocks.cs.BaseServer
-
- connect(Address) - Method in class org.jgroups.blocks.cs.Connection
-
- connect(Address) - Method in class org.jgroups.blocks.cs.NioConnection
-
- connect(Address, boolean) - Method in class org.jgroups.blocks.cs.NioConnection
-
- connect(Address) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- connect(Address, boolean) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- connect(String) - Method in class org.jgroups.Channel
-
Connects the channel to a group.
- connect(String, Address, long) - Method in class org.jgroups.Channel
-
Connects this channel to a group and gets a state from a specified state provider.
- connect() - Method in class org.jgroups.client.StompConnection
-
- connect() - Method in class org.jgroups.demos.StompChat
-
- CONNECT - Static variable in class org.jgroups.Event
-
- connect(String) - Method in class org.jgroups.fork.ForkChannel
-
Connects the fork-channel, which will be operational after this.
- connect(String, Address, long) - Method in class org.jgroups.fork.ForkChannel
-
- connect(String) - Method in class org.jgroups.JChannel
-
- connect(String, boolean) - Method in class org.jgroups.JChannel
-
Connects the channel to a group.
- connect(String, Address, long) - Method in class org.jgroups.JChannel
-
- connect(String, Address, long, boolean) - Method in class org.jgroups.JChannel
-
Connects this channel to a group and gets a state from a specified state provider.
This method invokes
connect()
and then
getState
.
If the FLUSH protocol is in the channel's stack definition, only one flush round is executed for both connecting and
fetching the state rather than two flushes if we invoke
connect
and
getState
in succession.
- connect(SocketAddress) - Method in class org.jgroups.nio.MockSocketChannel
-
- connect(String, Address, String, PhysicalAddress) - Method in class org.jgroups.stack.RouterStub
-
Registers mbr with the GossipRouter under the given group, with the given logical name and physical address.
- connect() - Method in class org.jgroups.stack.RouterStub
-
- connect(Socket, SocketAddress, int) - Static method in class org.jgroups.util.Util
-
Utility method.
- connect(SocketChannel, SocketAddress) - Static method in class org.jgroups.util.Util
-
- connect_count - Variable in class org.jgroups.protocols.TP
-
Keeps track of connects and disconnects, in order to start and stop threads
- CONNECT_USE_FLUSH - Static variable in class org.jgroups.Event
-
- CONNECT_WITH_STATE_TRANSFER - Static variable in class org.jgroups.Event
-
- CONNECT_WITH_STATE_TRANSFER_USE_FLUSH - Static variable in class org.jgroups.Event
-
- connected - Variable in class org.jgroups.blocks.cs.NioConnection
-
- connected(boolean) - Method in class org.jgroups.blocks.cs.NioConnection
-
- connected - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- Connection - Class in org.jgroups.blocks.cs
-
Represents a connection to a peer
- Connection() - Constructor for class org.jgroups.blocks.cs.Connection
-
- Connection(Socket) - Constructor for class org.jgroups.protocols.STOMP.Connection
-
- connection_driver - Variable in class org.jgroups.protocols.JDBC_PING
-
- connection_password - Variable in class org.jgroups.protocols.JDBC_PING
-
- connection_reaper - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- connection_reaper - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- connection_url - Variable in class org.jgroups.protocols.JDBC_PING
-
- connection_username - Variable in class org.jgroups.protocols.JDBC_PING
-
- connectionClosed(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
-
- connectionClosed(Connection, String) - Method in class org.jgroups.blocks.cs.BaseServer
-
- connectionClosed(Connection, String) - Method in interface org.jgroups.blocks.cs.ConnectionListener
-
- connectionClosed(Connection, String) - Method in class org.jgroups.blocks.cs.TcpClient
-
- connectionClosed(Connection, String) - Method in class org.jgroups.demos.PubClient
-
- connectionClosed(Connection, String) - Method in class org.jgroups.stack.GossipRouter
-
- connectionClosed(Connection, String) - Method in class org.jgroups.stack.RouterStub
-
- connectionEstablished(Connection) - Method in class org.jgroups.blocks.cs.BaseServer
-
- connectionEstablished(Connection) - Method in interface org.jgroups.blocks.cs.ConnectionListener
-
- connectionEstablished(Connection) - Method in class org.jgroups.blocks.cs.TcpClient
-
- connectionEstablished(Connection) - Method in class org.jgroups.demos.PubClient
-
- connectionEstablished(Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Is the send connection to target established
- connectionEstablished(Connection) - Method in class org.jgroups.stack.GossipRouter
-
- connectionEstablished(Connection) - Method in class org.jgroups.stack.RouterStub
-
- connectionEstablishedTo(Address) - Method in class org.jgroups.blocks.cs.BaseServer
-
- ConnectionListener - Interface in org.jgroups.blocks.cs
-
- connectionListener() - Method in class org.jgroups.stack.RouterStub
-
- connectionListener(RouterStub.CloseListener) - Method in class org.jgroups.stack.RouterStub
-
- connectionOpened(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
-
- ConnectionReaper() - Constructor for class org.jgroups.protocols.UNICAST.ConnectionReaper
-
Deprecated.
- ConnectionReaper() - Constructor for class org.jgroups.protocols.UNICAST2.ConnectionReaper
-
Deprecated.
- connections - Variable in class org.jgroups.protocols.STOMP
-
- ConnectionTableNIO - Class in org.jgroups.blocks
-
Manages incoming and outgoing TCP connections.
- ConnectionTableNIO(int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, int, long, long, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
-
- ConnectionTableNIO.MyFuture - Class in org.jgroups.blocks
-
- ConnectionTableNIO.SelectorWriteHandler - Class in org.jgroups.blocks
-
- ConnectionTableNIO.WriteRequest - Class in org.jgroups.blocks
-
- connectLock - Variable in class org.jgroups.protocols.TP
-
- connectProtocols(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Creates a protocol stack by iterating through the protocol list and connecting
adjacent layers.
- connects - Variable in class org.jgroups.fork.ForkProtocolStack
-
- connectStubs() - Method in class org.jgroups.stack.RouterStubManager
-
- connectToDestination(String) - Method in class org.jgroups.client.StompConnection
-
- connEstablished() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- connEstablished(boolean) - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- connExpireTime() - Method in class org.jgroups.blocks.cs.BaseServer
-
- connExpireTimeout(long) - Method in class org.jgroups.blocks.cs.BaseServer
-
- connId() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- conns - Variable in class org.jgroups.blocks.cs.BaseServer
-
- ConsistentHashFunction() - Constructor for class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
-
- ConsistentHashFunction() - Constructor for class org.jgroups.blocks.ReplCache.ConsistentHashFunction
-
- consolidateDigests(View, List<MergeData>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
Merge all digests into one.
- consolidateMergeData(List<MergeData>, List<View>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
Merge all MergeData.
- constant_delay - Variable in class org.jgroups.protocols.DELAY
-
- consumer_lock - Variable in class org.jgroups.util.ProcessingQueue
-
- CONSUMER_READY - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
-
- container - Variable in class org.jgroups.protocols.RACKSPACE_PING
-
- container - Variable in class org.jgroups.protocols.SWIFT_PING
-
- contains(Address) - Method in class org.jgroups.Membership
-
Returns true if the provided member belongs to this membership
- contains(String, Address) - Method in class org.jgroups.protocols.JDBC_PING
-
- contains(List<Route>, Address) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
- contains(K) - Method in class org.jgroups.util.AgeOutCache
-
- contains(Address) - Method in class org.jgroups.util.Digest
-
- contains(K) - Method in class org.jgroups.util.ExpiryCache
-
- contains(long) - Method in class org.jgroups.util.Seqno
-
- contains(long) - Method in class org.jgroups.util.SeqnoRange
-
- contains(T, T[]) - Static method in class org.jgroups.util.Util
-
- contains_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- containsAll(Address...) - Method in class org.jgroups.util.Digest
-
- containsId(short, short[]) - Static method in class org.jgroups.util.Util
-
- containsKey(K) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- containsKey(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- containsKey(Object) - Method in class org.jgroups.util.RspList
-
- containsKeys(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
-
Returns true if all of the keys in keys are present.
- containsMember(Address) - Method in class org.jgroups.View
-
Returns true if this view contains a certain member
- containsMembers(Address...) - Method in class org.jgroups.View
-
Returns true if all mbrs are elements of this view, false otherwise
- containsResponseFrom(Address) - Method in class org.jgroups.util.Responses
-
- containsValue(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- containsValue(Object) - Method in class org.jgroups.util.RspList
-
- containsViewId(Collection<View>, ViewId) - Static method in class org.jgroups.util.Util
-
- contents() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- contents(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- contentsCleared() - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
-
- contentsCleared() - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- contentsSet(Map<K, V>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
-
- contentsSet(Map<Object, Object>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- contiguousSpaceAvailable() - Method in class org.jgroups.util.RequestTable
-
Checks if there is at least buffer.length/2 contiguous space in range [low+1 ..
- convert(String, Class<?>) - Static method in class org.jgroups.blocks.MethodCall
-
- convert(Object, Class<?>, String, String, boolean) - Method in interface org.jgroups.conf.PropertyConverter
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.BindInterface
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.Default
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.FlushInvoker
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.IntegerArray
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.LongArray
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
-
- convert(Object, Class<?>, String, String, boolean) - Method in class org.jgroups.conf.PropertyConverters.StringProperties
-
- convertUnsupportedToAsciidocTable(Properties, List<Class<?>>, String) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
- convertViews() - Method in class org.jgroups.protocols.MERGE3
-
- cookie - Static variable in class org.jgroups.blocks.cs.Connection
-
- coord - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- coord - Variable in class org.jgroups.protocols.CENTRAL_LOCK
-
- coord - Variable in class org.jgroups.protocols.COUNTER
-
The address of the cluster coordinator.
- coord - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
-
the address of the current coordinator, all msgs are forwarded to it
- COORD - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- coord(boolean) - Method in class org.jgroups.protocols.PingData
-
- coord - Variable in class org.jgroups.protocols.RELAY
-
- coord - Variable in class org.jgroups.protocols.SEQUENCER
-
- coord - Variable in class org.jgroups.protocols.SEQUENCER2
-
- CoordGmsImpl - Class in org.jgroups.protocols.pbcast
-
Coordinator role of the Group MemberShip (GMS) protocol.
- CoordGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- coordinator - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- coordinatorChosen() - Method in class org.jgroups.demos.Topology
-
- coords - Variable in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
List of all subpartition coordinators and their members
- copied_fields - Static variable in class org.jgroups.fork.ForkChannel
-
- copy() - Method in class org.jgroups.Membership
-
Returns a copy of this membership
- copy() - Method in class org.jgroups.MergeView
-
- copy() - Method in class org.jgroups.Message
-
- copy(boolean) - Method in class org.jgroups.Message
-
Create a copy of the message.
- copy(boolean, boolean) - Method in class org.jgroups.Message
-
Create a copy of the message.
- copy(boolean, short) - Method in class org.jgroups.Message
-
Doesn't copy any headers except for those with ID >= copy_headers_above
- copy(boolean, short, short...) - Method in class org.jgroups.Message
-
Copies a message.
- copy() - Method in class org.jgroups.nio.Buffers
-
Copies the data that has not yet been written and moves last_copied.
- copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- copy(Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
Copies the message, but only the headers above the current protocol (RELAY) (or RpcDispatcher related headers)
- copy() - Method in class org.jgroups.protocols.relay.SiteMaster
-
- copy() - Method in class org.jgroups.protocols.relay.SiteUUID
-
- copy() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- copy() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- copy() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- copy() - Method in class org.jgroups.stack.ExponentialInterval
-
We don't need to copy as we don't have any state
- copy() - Method in interface org.jgroups.stack.Interval
-
Returns a copy of the state.
- copy() - Method in class org.jgroups.stack.IpAddress
-
- copy() - Method in class org.jgroups.stack.StateTransferInfo
-
- copy() - Method in class org.jgroups.stack.StaticInterval
-
- copy() - Method in class org.jgroups.util.Buffer
-
- copy() - Method in class org.jgroups.util.Digest
-
- copy(Header[]) - Static method in class org.jgroups.util.Headers
-
- copy(Reader, Writer) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
- copy() - Method in class org.jgroups.util.UUID
-
- copy() - Method in class org.jgroups.View
-
- copy() - Method in class org.jgroups.ViewId
-
- copy_multicast_msgs - Variable in class org.jgroups.protocols.DUPL
-
- copy_on_partial_write - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- copy_on_partial_write - Variable in class org.jgroups.blocks.cs.NioConnection
-
- copy_on_partial_write - Variable in class org.jgroups.protocols.TCP_NIO2
-
- copy_unicast_msgs - Variable in class org.jgroups.protocols.DUPL
-
- copyBuffer(ByteBuffer) - Static method in class org.jgroups.nio.Buffers
-
Copies a ByteBuffer by copying and wrapping the underlying array of a heap-based buffer.
- copyFields() - Method in class org.jgroups.fork.ForkChannel
-
Copies state from main-channel to this fork-channel
- copyLocksTo(List<Address>) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- copyOnPartialWrite() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- copyOnPartialWrite(boolean) - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- copyOnPartialWrite(boolean) - Method in class org.jgroups.blocks.cs.NioConnection
-
- copyOnPartialWrite() - Method in class org.jgroups.blocks.cs.NioConnection
-
- copyProtocols(ProtocolStack) - Method in class org.jgroups.stack.ProtocolStack
-
- copyQueueTo(List<Address>) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- corr - Variable in class org.jgroups.blocks.MessageDispatcher
-
- corr - Variable in class org.jgroups.blocks.Request
-
- corr_id - Variable in class org.jgroups.blocks.RequestCorrelator
-
makes the instance unique (together with IDs)
- corrDone() - Method in class org.jgroups.blocks.Request
-
- correlator() - Method in class org.jgroups.blocks.MessageDispatcher
-
- correlator(RequestCorrelator) - Method in class org.jgroups.blocks.MessageDispatcher
-
- correlatorStarted() - Method in class org.jgroups.blocks.MessageDispatcher
-
- correlatorStarted() - Method in class org.jgroups.blocks.RpcDispatcher
-
- corrId - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
The unique ID of the associated RequestCorrelator
- corrId() - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- count - Variable in class org.jgroups.protocols.BaseBundler
-
- count - Variable in class org.jgroups.util.Average
-
- count() - Method in class org.jgroups.util.Average
-
- count - Variable in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- count - Variable in class org.jgroups.util.ProcessingQueue
-
- count - Variable in class org.jgroups.util.RingBuffer
-
- count() - Method in class org.jgroups.util.RingBuffer
-
- count(boolean) - Method in class org.jgroups.util.RingBufferSeqno
-
- count(boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- count - Variable in class org.jgroups.util.SuppressCache.Value
-
- count() - Method in class org.jgroups.util.SuppressCache.Value
-
- count_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2.Counter
-
- Counter - Interface in org.jgroups.blocks.atomic
-
- COUNTER - Class in org.jgroups.protocols
-
Protocol which is used by
CounterService
to provide a distributed atomic counter
- COUNTER() - Constructor for class org.jgroups.protocols.COUNTER
-
- counter - Static variable in class org.jgroups.protocols.Executing
-
This keeps track of all the requests we send.
- Counter(boolean) - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.Counter
-
- counter - Variable in class org.jgroups.util.DefaultThreadFactory
-
- Counter() - Constructor for class org.jgroups.util.Table.Counter
-
- COUNTER.AddAndGetRequest - Class in org.jgroups.protocols
-
- COUNTER.BooleanResponse - Class in org.jgroups.protocols
-
- COUNTER.CompareAndSetRequest - Class in org.jgroups.protocols
-
- COUNTER.CounterHeader - Class in org.jgroups.protocols
-
- COUNTER.CounterImpl - Class in org.jgroups.protocols
-
- COUNTER.DeleteRequest - Class in org.jgroups.protocols
-
- COUNTER.ExceptionResponse - Class in org.jgroups.protocols
-
- COUNTER.GetOrCreateRequest - Class in org.jgroups.protocols
-
- COUNTER.GetOrCreateResponse - Class in org.jgroups.protocols
-
- COUNTER.ReconcileRequest - Class in org.jgroups.protocols
-
- COUNTER.ReconcileResponse - Class in org.jgroups.protocols
-
- COUNTER.ReconciliationTask - Class in org.jgroups.protocols
-
- COUNTER.Request - Class in org.jgroups.protocols
-
- COUNTER.RequestType - Enum in org.jgroups.protocols
-
- COUNTER.ResendPendingRequests - Class in org.jgroups.protocols
-
- COUNTER.Response - Class in org.jgroups.protocols
-
- COUNTER.ResponseType - Enum in org.jgroups.protocols
-
- COUNTER.SetRequest - Class in org.jgroups.protocols
-
- COUNTER.SimpleRequest - Class in org.jgroups.protocols
-
- COUNTER.SimpleResponse - Class in org.jgroups.protocols
-
Response without data
- COUNTER.UpdateRequest - Class in org.jgroups.protocols
-
- COUNTER.ValueResponse - Class in org.jgroups.protocols
-
- COUNTER.VersionedValue - Class in org.jgroups.protocols
-
- counter_prot - Variable in class org.jgroups.blocks.atomic.CounterService
-
- CounterHeader() - Constructor for class org.jgroups.protocols.COUNTER.CounterHeader
-
- CounterImpl(String) - Constructor for class org.jgroups.protocols.COUNTER.CounterImpl
-
- counters - Variable in class org.jgroups.protocols.COUNTER
-
- CounterService - Class in org.jgroups.blocks.atomic
-
Provides a distributed counter (similar to AtomicLong) which can be atomically updated across a cluster.
- CounterService(Channel) - Constructor for class org.jgroups.blocks.atomic.CounterService
-
- CounterServiceDemo - Class in org.jgroups.demos
-
- CounterServiceDemo() - Constructor for class org.jgroups.demos.CounterServiceDemo
-
- countLockLockless() - Method in class org.jgroups.util.RingBuffer
-
- countNonSetMembers() - Method in class org.jgroups.util.MutableDigest
-
- create() - Method in interface org.jgroups.blocks.ReplCache.HashFunctionFactory
-
- create(RELAY.RelayHeader.Type) - Static method in class org.jgroups.protocols.RELAY.RelayHeader
-
- create(View, View) - Static method in class org.jgroups.protocols.RELAY.ViewData
-
- create(Address) - Static method in class org.jgroups.util.MergeId
-
- create() - Method in interface org.jgroups.util.Pool.Creator
-
- create(Address, long, Address...) - Static method in class org.jgroups.View
-
- create(Address, long, Collection<Address>) - Static method in class org.jgroups.View
-
- createAcceptor() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- createAckHeader(long, short) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- createAckHeader(long, short) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- createAckHeader(long, short, long) - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- createAndRegisterStub(IpAddress, IpAddress) - Method in class org.jgroups.stack.RouterStubManager
-
- createArrays(Map<Address, long[]>) - Method in class org.jgroups.util.Digest
-
- createAsciidocTable(List<String[]>, String, String) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
Creates an AsciiDoc table of the elements in rows.
- createAuthenticationDigest(String, long, double) - Static method in class org.jgroups.util.Util
-
- createBridge() - Method in class org.jgroups.protocols.RELAY
-
- createBundler(String) - Method in class org.jgroups.protocols.TP
-
- createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
-
- createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
-
- createChannel() - Method in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
-
- createChannel(Protocol...) - Static method in class org.jgroups.util.Util
-
- createChecksummer() - Method in class org.jgroups.protocols.EncryptBase
-
- createCipher(int, Key, String) - Method in class org.jgroups.protocols.EncryptBase
-
- createCloseHeader(short) - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- createConcurrentMap(int, float, int) - Static method in class org.jgroups.util.Util
-
- createConcurrentMap(int) - Static method in class org.jgroups.util.Util
-
- createConcurrentMap() - Static method in class org.jgroups.util.Util
-
- createConnection(Address) - Method in class org.jgroups.blocks.cs.BaseServer
-
Creates a new connection object to target dest, but doesn't yet connect it
- createConnection(Address) - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- createConnection(Address) - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- createConnection() - Method in class org.jgroups.protocols.GOOGLE_PING
-
- createConnection() - Method in class org.jgroups.protocols.S3_PING
-
- createContainer(String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Create a container, which is equivalent to a bucket
- createDaemons - Variable in class org.jgroups.util.DefaultThreadFactory
-
- createDatagramSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createDatagramSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createDatagramSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createDatagramSocket(String, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createDatagramSocket(String) - Method in interface org.jgroups.util.SocketFactory
-
- createDatagramSocket(String, SocketAddress) - Method in interface org.jgroups.util.SocketFactory
-
- createDatagramSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
-
- createDatagramSocket(String, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
-
- createDatagramSocket(SocketFactory, String, InetAddress, int) - Static method in class org.jgroups.util.Util
-
Creates a DatagramSocket bound to addr.
- createDataHeader(long, short, boolean) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- createDataHeader(long, short, boolean) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- createDataHeader(long, short, boolean) - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- createDeltaView(View, View) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- createDigest(String, long, double) - Static method in class org.jgroups.util.Util
-
- createDiskCacheFile() - Method in class org.jgroups.protocols.PDC
-
- createDisseminateHeader(Address) - Static method in class org.jgroups.protocols.RELAY.RelayHeader
-
- createEmptyArray(int) - Static method in class org.jgroups.util.MutableDigest
-
- createExpireHeader(short) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- createForkStack(String, List<Protocol>, boolean) - Method in class org.jgroups.protocols.FORK
-
Returns the fork stack for fork_stack_id (if exitstent), or creates a new fork-stack from protocols and adds it
into the hashmap of fork-stack (key is fork_stack_id).
- createForkStacks(String) - Method in class org.jgroups.protocols.FORK
-
- createForkStacks(Map<String, List<ProtocolConfiguration>>) - Method in class org.jgroups.protocols.FORK
-
- createHeader(STOMP.StompHeader.Type, String...) - Static method in class org.jgroups.protocols.STOMP.StompHeader
-
Creates a new header
- createHeader(STOMP.StompHeader.Type, Map<String, String>) - Static method in class org.jgroups.protocols.STOMP.StompHeader
-
- createHeaders(int) - Static method in class org.jgroups.Message
-
- createHighestSeqnoHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- createInetAddressMap(List<ProtocolConfiguration>, List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
- createInfo() - Method in class org.jgroups.protocols.MERGE3
-
- createInfo(ViewId, String, PhysicalAddress) - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- createInstance(RspFilter) - Static method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
-
- createLayer(ProtocolStack, ProtocolConfiguration) - Static method in class org.jgroups.stack.Configurator
-
- createLocalAddress() - Method in class org.jgroups.protocols.UDP
-
- createLock(String, Owner) - Method in class org.jgroups.protocols.Locking
-
- createLock(String) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- createMessage(Address, Address, Address, Message) - Method in class org.jgroups.protocols.relay.Route
-
- createMessageHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- createMessageHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- createMessageHeader(short) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- createMonitor() - Method in class org.jgroups.protocols.FD_PING
-
Deprecated.
- createMulticastSocket(String, int) - Method in class org.jgroups.protocols.UDP
-
- createMulticastSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createMulticastSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createMulticastSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createMulticastSocket(String) - Method in interface org.jgroups.util.SocketFactory
-
- createMulticastSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
-
- createMulticastSocket(String, SocketAddress) - Method in interface org.jgroups.util.SocketFactory
-
- createMulticastSocket(SocketFactory, String, InetAddress, int, Log) - Static method in class org.jgroups.util.Util
-
- createMulticastSocketWithBindPort() - Method in class org.jgroups.protocols.UDP
-
Creates a DatagramSocket when bind_port > 0.
- createNewFile() - Method in class org.jgroups.blocks.GridFile
-
- createNewKey() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- createObject(String, String, byte[]) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Create an object (=file)
- 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
-
- createProtocols(ProtocolStack, List<ProtocolConfiguration>) - Static method in class org.jgroups.protocols.FORK
-
Creates a fork-stack from the configuration, initializes all protocols (setting values),
sets the protocol stack as top protocol, connects the protocols and calls init() on them.
- createProtocols(List<ProtocolConfiguration>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
Takes vector of ProtocolConfigurations, iterates through it, creates Protocol for
each ProtocolConfiguration and returns all Protocols in a list.
- createRandomAddress() - Static method in class org.jgroups.util.Util
-
- createRandomAddress(String) - Static method in class org.jgroups.util.Util
-
- createRandomAddresses(int) - Static method in class org.jgroups.util.Util
-
Returns an array of num random addresses, named A, B, C etc
- createRandomAddresses(int, boolean) - Static method in class org.jgroups.util.Util
-
- createReceiverEntry(Address, long, short) - Method in class org.jgroups.protocols.UNICAST3
-
- createRequest(COUNTER.RequestType) - Static method in class org.jgroups.protocols.COUNTER
-
- createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.MessageDispatcher
-
- createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- createRequestCorrelator(Protocol, RequestHandler, Address) - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- createResponse(COUNTER.ResponseType) - Static method in class org.jgroups.protocols.COUNTER
-
- createRootDir() - Method in class org.jgroups.protocols.FILE_PING
-
- createRootDir() - Method in class org.jgroups.protocols.RACKSPACE_PING
-
- createRootDir() - Method in class org.jgroups.protocols.S3_PING
-
- createRootDir() - Method in class org.jgroups.protocols.SWIFT_PING
-
- createSecretKey() - Static method in class org.jgroups.demos.KeyStoreGenerator
-
- createSecretKey(String, int) - Static method in class org.jgroups.demos.KeyStoreGenerator
-
- createSecretKey() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Initialise the symmetric key if none is supplied in a keystore
- createSendFirstSeqnoHeader(long) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- createSendFirstSeqnoHeader(long) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- createSendFirstSeqnoHeader(long) - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- createServerSocket(int, int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
Finds first available port starting at start_port and returns server socket.
- createServerSocket() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- createServerSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createServerSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createServerSocket(String, int, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createServerSocket(String, int, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createServerSocket(String) - Method in interface org.jgroups.util.SocketFactory
-
- createServerSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
-
- createServerSocket(String, int, int) - Method in interface org.jgroups.util.SocketFactory
-
- createServerSocket(String, int, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
-
- createServerSocket(SocketFactory, String, InetAddress, int) - Static method in class org.jgroups.util.Util
-
- createServerSocket(SocketFactory, String, InetAddress, int, int) - Static method in class org.jgroups.util.Util
-
- createServerSocketAndBind(SocketFactory, String, InetAddress, int, int) - Static method in class org.jgroups.util.Util
-
Finds first available port starting at start_port and returns server
socket.
- createServerSocketChannel(InetAddress, int, int) - Static method in class org.jgroups.util.Util
-
- createServerSocketChannelAndBind(InetAddress, int, int) - Static method in class org.jgroups.util.Util
-
- createSingleDestinationHeader(MessageID) - Static method in class org.jgroups.protocols.tom.ToaHeader
-
- createSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createSocket(String, String, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createSocket(String, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createSocket(String, String, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createSocket(String, InetAddress, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
-
- createSocket(String) - Method in interface org.jgroups.util.SocketFactory
-
- createSocket(String, String, int) - Method in interface org.jgroups.util.SocketFactory
-
- createSocket(String, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
-
- createSocket(String, String, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
-
- createSocket(String, InetAddress, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
-
- createSockets() - Method in class org.jgroups.protocols.UDP
-
Creates the UDP sender and receiver sockets
- createSocketTo(Address) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- createStableHeader(short, long, long) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE
-
- createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
Creates an InputStream to the state provider to read the state.
- createStreamToRequester(Address) - Method in class org.jgroups.protocols.pbcast.STATE
-
- createStreamToRequester(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
Creates an OutputStream to the state requester to write the state
- createTable(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- createThreadPool() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- createThreadPool(int, int, long, ThreadFactory) - Static method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) - Static method in class org.jgroups.protocols.TP
-
- createTimer() - Static method in class org.jgroups.util.Util
-
- createViewFromDeltaView(View, DeltaView) - Method in class org.jgroups.protocols.pbcast.GMS
-
- createViewRequest() - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- createViewResponse() - Static method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- createWaitStrategy(String, BiConsumer<Integer, Integer>) - Method in class org.jgroups.protocols.RingBufferBundler
-
- createXmitReqHeader() - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- createXmitReqHeader() - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- createXmitRequestHeader(long, long, Address) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- createXmitRequestHeader(Address) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- createXmitResponseHeader() - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- createXmitResponseHeader() - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- creation_time - Variable in class org.jgroups.util.TimeScheduler3.Task
-
- creator - Variable in class org.jgroups.util.Pool
-
- creator - Variable in class org.jgroups.ViewId
-
- Credit(long, Average) - Constructor for class org.jgroups.protocols.FlowControl.Credit
-
- CREDIT_REQUEST - Static variable in class org.jgroups.protocols.FcHeader
-
- CreditMap - Class in org.jgroups.util
-
Maintains credits for senders, when credits fall below 0, a sender blocks until new credits have been received.
- CreditMap(long) - Constructor for class org.jgroups.util.CreditMap
-
- credits - Variable in class org.jgroups.protocols.MFC
-
Maintains credits per member
- credits - Variable in class org.jgroups.util.CreditMap
-
- credits_available - Variable in class org.jgroups.util.CreditMap
-
- credits_left - Variable in class org.jgroups.protocols.FlowControl.Credit
-
- curr - Variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- curr_id - Variable in class org.jgroups.protocols.FRAG2
-
Used to assign fragmentation-specific sequence IDs (monotonically increasing)
- curr_mbrs - Variable in class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
-
- current - Variable in class org.jgroups.util.RingBufferSeqno.RingBufferIterator
-
- current - Variable in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
-
- current_coord - Variable in class org.jgroups.protocols.Discovery
-
- current_coord - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- current_id - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
-
ID to be used to identify forwarded messages.
- current_id - Variable in class org.jgroups.protocols.RSVP
-
ID to be used to identify messages.
- current_index - Variable in class org.jgroups.util.MessageBatch.BatchIterator
-
- current_lock_id - Static variable in class org.jgroups.protocols.Locking
-
- current_owner - Variable in class org.jgroups.protocols.Locking.ServerLock
-
- current_period_start - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- custom_log_factory - Static variable in class org.jgroups.logging.LogFactory
-
- CustomLogFactory - Interface in org.jgroups.logging
-
An extension interface allowing to plug in a custom log provider.
- CustomRejectionPolicy - Class in org.jgroups.util
-
// TODO: Document this
- CustomRejectionPolicy(String) - Constructor for class org.jgroups.util.CustomRejectionPolicy
-
- d - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- DAISYCHAIN - Class in org.jgroups.protocols
-
Implementation of daisy chaining.
- DAISYCHAIN() - Constructor for class org.jgroups.protocols.DAISYCHAIN
-
- DAISYCHAIN.DaisyHeader - Class in org.jgroups.protocols
-
- DaisyHeader() - Constructor for class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- DaisyHeader(short) - Constructor for class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- data - Variable in class org.jgroups.blocks.GridFilesystem
-
- DATA - Static variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- DATA - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- DATA - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- DATA - Static variable in class org.jgroups.protocols.UNICAST3.Header
-
- DATA - Static variable in class org.jgroups.util.AdditionalDataUUID
-
Deprecated.
- data - Variable in class org.jgroups.util.Responses.PingDataIterator
-
- data_available - Variable in class org.jgroups.blocks.cs.NioConnection.Reader
-
- data_available_cond - Variable in class org.jgroups.blocks.cs.NioConnection.Reader
-
- DATA_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
-
- datasource_jndi_name - Variable in class org.jgroups.protocols.JDBC_PING
-
- debug(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- debug(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- debug(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
-
- debug(String) - Method in interface org.jgroups.logging.Log
-
- debug(String, Object...) - Method in interface org.jgroups.logging.Log
-
- debug(String, Throwable) - Method in interface org.jgroups.logging.Log
-
- debug(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- debug(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- debug(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- DECODE - Static variable in class org.jgroups.util.Base64
-
Specify decoding in first bit.
- decode(byte[]) - Static method in class org.jgroups.util.Base64
-
Low-level access to decoding ASCII characters in
the form of a byte array.
- decode(byte[], int, int, int) - Static method in class org.jgroups.util.Base64
-
Low-level access to decoding ASCII characters in
the form of a byte array.
- decode(String) - Static method in class org.jgroups.util.Base64
-
Decodes data from Base64 notation, automatically
detecting gzip-compressed data and decompressing it.
- decode(String, int) - Static method in class org.jgroups.util.Base64
-
Decodes data from Base64 notation, automatically
detecting gzip-compressed data and decompressing it.
- decode(short) - Static method in class org.jgroups.Version
-
- decodeDataFromStream(DataInput) - Static method in class org.jgroups.auth.Krb5TokenUtils
-
- decodeFileToFile(String, String) - Static method in class org.jgroups.util.Base64
-
Reads infile and decodes it to outfile.
- decodeFromFile(String) - Static method in class org.jgroups.util.Base64
-
Convenience method for reading a base64-encoded
file and decoding it.
- decodeKey(byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- decodeLength(byte) - Static method in class org.jgroups.util.Bits
-
- decodeToFile(String, String) - Static method in class org.jgroups.util.Base64
-
Convenience method for decoding data to a file.
- decodeToObject(String) - Static method in class org.jgroups.util.Base64
-
Attempts to decode Base64 data and deserialize a Java
Object within.
- decodeToObject(String, int, ClassLoader) - Static method in class org.jgroups.util.Base64
-
Attempts to decode Base64 data and deserialize a Java
Object within.
- decoding_ciphers - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- decoding_ciphers - Variable in class org.jgroups.protocols.EncryptBase
-
- decoding_locks - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- decrCount() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- decrement(long) - Method in class org.jgroups.protocols.FlowControl.Credit
-
- decrement(long, long) - Method in class org.jgroups.util.CreditMap
-
Decrements credits bytes from all.
- decrement(long) - Method in class org.jgroups.util.CreditMap
-
- decrementAndAdd(Address, long) - Method in class org.jgroups.util.CreditMap
-
Decrements credits bytes from all elements and add new_credits to member (if non null).
- decrementAndGet() - Method in interface org.jgroups.blocks.atomic.Counter
-
Atomically decrements the counter and returns the new value
- decrementAndGet() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- decrementAndGet(long) - Method in class org.jgroups.protocols.FlowControl.Credit
-
- decrementIfEnoughCredits(long, long) - Method in class org.jgroups.protocols.FlowControl.Credit
-
- decrementInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- decrementStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- decryptChecksum(Cipher, byte[], int, int) - Method in class org.jgroups.protocols.EncryptBase
-
- Decrypter() - Constructor for class org.jgroups.protocols.ENCRYPT.Decrypter
-
Deprecated.
- Decrypter(Cipher) - Constructor for class org.jgroups.protocols.EncryptBase.Decrypter
-
- decryptMessage(Cipher, Message) - Method in class org.jgroups.protocols.EncryptBase
-
Does the actual work for decrypting - if version does not match current cipher then tries the previous cipher
- deepEquals(View) - Method in class org.jgroups.MergeView
-
- deepEquals(View) - Method in class org.jgroups.View
-
- Default() - Constructor for class org.jgroups.conf.PropertyConverters.Default
-
- default_chunk_size - Variable in class org.jgroups.blocks.GridFilesystem
-
- DEFAULT_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- DEFAULT_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- DEFAULT_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST3
-
- DEFAULT_FIRST_UNICAST_SEQNO - Static variable in class org.jgroups.Global
-
- DEFAULT_HEADERS - Static variable in class org.jgroups.Global
-
System prop for defining the default number of headers in a Message
- DEFAULT_HEADERS - Static variable in class org.jgroups.util.Util
-
- DEFAULT_MAX_COMPACTION_TIME - Static variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- DEFAULT_MAX_COMPACTION_TIME - Static variable in class org.jgroups.util.Table
-
- default_pool - Variable in class org.jgroups.protocols.DAISYCHAIN
-
- DEFAULT_PROTOCOL_STACK - Static variable in class org.jgroups.JChannel
-
The default protocol stack used by the default constructor
- default_repl_count - Variable in class org.jgroups.blocks.GridFilesystem
-
- DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.Table
-
- DEFAULT_SYM_ALGO - Static variable in class org.jgroups.protocols.EncryptBase
-
- default_thread_factory - Variable in class org.jgroups.protocols.TP
-
Factory which is used by oob_thread_pool
- defaultHeaders() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- DefaultMembershipPolicy() - Constructor for class org.jgroups.protocols.pbcast.GMS.DefaultMembershipPolicy
-
- DefaultRetransmitter - Class in org.jgroups.stack
-
Maintains a pool of sequence numbers of messages that need to be retransmitted.
- DefaultRetransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.DefaultRetransmitter
-
Create a new Retransmitter associated with the given sender address
- DefaultRetransmitter.SeqnoTask - Class in org.jgroups.stack
-
- DefaultSocketFactory - Class in org.jgroups.util
-
Default implementation, ignores service names
- DefaultSocketFactory() - Constructor for class org.jgroups.util.DefaultSocketFactory
-
- DefaultThreadFactory - Class in org.jgroups.util
-
Thread factory mainly responsible for naming of threads.
- DefaultThreadFactory(String, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
-
- DefaultThreadFactory(String, boolean, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
-
- DefaultTimeScheduler - Class in org.jgroups.util
-
Implementation of
TimeScheduler
by extending
ScheduledThreadPoolExecutor
to keep tasks sorted.
- DefaultTimeScheduler() - Constructor for class org.jgroups.util.DefaultTimeScheduler
-
Create a scheduler that executes tasks in dynamically adjustable intervals
- DefaultTimeScheduler(ThreadFactory) - Constructor for class org.jgroups.util.DefaultTimeScheduler
-
- DefaultTimeScheduler(ThreadFactory, int) - Constructor for class org.jgroups.util.DefaultTimeScheduler
-
- DefaultTimeScheduler(int) - Constructor for class org.jgroups.util.DefaultTimeScheduler
-
- DefaultTimeScheduler.RobustRunnable - Class in org.jgroups.util
-
Class which catches exceptions in run() - https://jira.jboss.org/jira/browse/JGRP-1062
- DefaultTimeScheduler.TaskWrapper<V> - Class in org.jgroups.util
-
- defer_client_bind_addr - Variable in class org.jgroups.protocols.BasicTCP
-
- defer_client_binding - Variable in class org.jgroups.blocks.cs.BaseServer
-
- deferClientBinding() - Method in class org.jgroups.blocks.cs.BaseServer
-
- deferClientBinding(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
-
- deflater_pool - Variable in class org.jgroups.protocols.COMPRESS
-
- defragmentBuffer(byte[][]) - Static method in class org.jgroups.util.Util
-
Concatenates smaller fragments into entire buffers.
- DELAY - Class in org.jgroups.protocols
-
Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n
where n is determined by the user) and nanoseconds (constant amount).
- DELAY() - Constructor for class org.jgroups.protocols.DELAY
-
- delay - Variable in class org.jgroups.util.TimeScheduler3.Task
-
- delayed_message_handler - Variable in class org.jgroups.protocols.DELAY
-
- delayed_messages - Variable in class org.jgroups.protocols.DELAY
-
- delete() - Method in class org.jgroups.blocks.GridFile
-
- delete(boolean) - Method in class org.jgroups.blocks.GridFile
-
- delete(Connection, String, String) - Method in class org.jgroups.protocols.JDBC_PING
-
- delete(String, String) - Method in class org.jgroups.protocols.JDBC_PING
-
- delete_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- deleteCounter(String) - Method in class org.jgroups.blocks.atomic.CounterService
-
Deletes a counter instance (on the coordinator)
- deleteCounter(String) - Method in class org.jgroups.protocols.COUNTER
-
Sent asynchronously - we don't wait for an ack
- deleteFile(File) - Method in class org.jgroups.protocols.FILE_PING
-
- deleteFile(File) - Method in class org.jgroups.protocols.PDC
-
Attempts to delete the provided file.
Logging is performed on the result
- deleteObject(String, String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Delete a object (=file) from the storage
- DeleteRequest() - Constructor for class org.jgroups.protocols.COUNTER.DeleteRequest
-
- DeleteRequest(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.DeleteRequest
-
- deleteSelf() - Method in class org.jgroups.protocols.JDBC_PING
-
- deliver(Message, Address, long, String) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- deliver(Address, Address, Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
- deliver(Message, Event, SEQUENCER.SequencerHeader) - Method in class org.jgroups.protocols.SEQUENCER
-
- deliver(Message, Event, SEQUENCER2.SequencerHeader) - Method in class org.jgroups.protocols.SEQUENCER2
-
- deliver(Message) - Method in interface org.jgroups.protocols.tom.DeliveryProtocol
-
deliver a message
- deliver(Message) - Method in class org.jgroups.protocols.tom.TOA
-
- deliverBatch(MessageBatch) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- deliverBatch(MessageBatch) - Method in class org.jgroups.protocols.SEQUENCER2
-
- deliverBatch(MessageBatch) - Method in class org.jgroups.protocols.UNICAST3
-
- delivered_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
-
- delivered_bcasts - Variable in class org.jgroups.protocols.SEQUENCER2
-
- deliverLocally(SiteAddress, SiteAddress, Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
- deliverMessage(Event, Address, long) - Method in class org.jgroups.protocols.UNICAST3
-
- deliverSingleDestinationMessage(Message, MessageID) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
delivers a message that has only as destination member this node
- delivery_table - Variable in class org.jgroups.protocols.SEQUENCER
-
- delivery_table - Variable in class org.jgroups.util.ForwardQueue
-
- delivery_table_max_size - Variable in class org.jgroups.protocols.SEQUENCER
-
- delivery_table_max_size - Variable in class org.jgroups.util.ForwardQueue
-
Size of the set to store received seqnos (for duplicate checking)
- DELIVERY_TIME - Class in org.jgroups.protocols
-
Protocol measuring delivery times.
- DELIVERY_TIME() - Constructor for class org.jgroups.protocols.DELIVERY_TIME
-
- delivery_times - Variable in class org.jgroups.protocols.DELIVERY_TIME
-
- DeliveryManager - Interface in org.jgroups.protocols.tom
-
The interface that a delivery manager must implement.
- DeliveryManagerImpl - Class in org.jgroups.protocols.tom
-
The implementation of the Delivery Manager
- DeliveryManagerImpl() - Constructor for class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- DeliveryProtocol - Interface in org.jgroups.protocols.tom
-
The interface that the Total Order Anycast protocol must implement.
- deliveryTableSize() - Method in class org.jgroups.util.ForwardQueue
-
Total size of all queues of the delivery table
- DeliveryThread - Class in org.jgroups.protocols.tom
-
The delivery thread.
- DeliveryThread(DeliveryProtocol) - Constructor for class org.jgroups.protocols.tom.DeliveryThread
-
- DELTA_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- DeltaView - Class in org.jgroups.protocols.pbcast
-
Subclass of
View
with a null members field.
- DeltaView() - Constructor for class org.jgroups.protocols.pbcast.DeltaView
-
- DeltaView(ViewId, ViewId, Address[], Address[]) - Constructor for class org.jgroups.protocols.pbcast.DeltaView
-
- DemoHeader() - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
-
- DemoHeader(byte[]) - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
-
- DemoHeader(long) - Constructor for class org.jgroups.auth.DemoToken.DemoHeader
-
- DemoToken - Class in org.jgroups.auth
-
AuthToken implementation which shows how to send messages back and forth in order to perform authentication.
- DemoToken() - Constructor for class org.jgroups.auth.DemoToken
-
- DemoToken.DemoHeader - Class in org.jgroups.auth
-
- DemoToken.Entry - Class in org.jgroups.auth
-
- denied - Variable in class org.jgroups.protocols.Locking.ClientLock
-
- DeprecatedProperty - Annotation Type in org.jgroups.annotations
-
Represents an array of deprecated Protocol properties
- description() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- description() - Method in class org.jgroups.protocols.rules.Rule
-
Describes what the rules does
- description() - Method in class org.jgroups.protocols.rules.SampleRule
-
- description - Static variable in class org.jgroups.Version
-
- deserialize(byte[]) - Static method in class org.jgroups.protocols.Discovery
-
- desired_avg_gossip - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Sends a STABLE gossip every 20 seconds on average.
- dest() - Method in class org.jgroups.Message
-
- dest(Address) - Method in class org.jgroups.Message
-
- dest - Variable in class org.jgroups.protocols.BPING
-
- dest - Variable in class org.jgroups.util.MessageBatch
-
The destination address.
- dest() - Method in class org.jgroups.util.MessageBatch
-
- dest(Address) - Method in class org.jgroups.util.MessageBatch
-
- dest_addr - Variable in class org.jgroups.Message
-
- dest_addr - Variable in class org.jgroups.protocols.BPING
-
- DESTINATION - Static variable in class org.jgroups.demos.StompChat
-
- destinations - Variable in class org.jgroups.AnycastAddress
-
- destroy() - Method in class org.jgroups.auth.AuthToken
-
- destroy() - Method in class org.jgroups.demos.applets.DrawApplet
-
- destroy() - Method in class org.jgroups.demos.wb.Whiteboard
-
- destroy() - Method in class org.jgroups.fork.ForkProtocolStack
-
- destroy() - Method in class org.jgroups.protocols.AUTH
-
- destroy() - Method in class org.jgroups.protocols.BARRIER
-
- destroy() - Method in class org.jgroups.protocols.COMPRESS
-
- destroy() - Method in class org.jgroups.protocols.DELAY
-
- destroy() - Method in class org.jgroups.protocols.MAKE_BATCH
-
- destroy() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- destroy() - Method in class org.jgroups.protocols.RSVP.Entry
-
- destroy() - Method in class org.jgroups.protocols.rules.Rule
-
Called when rule is uninstalled
- destroy() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- destroy() - Method in class org.jgroups.protocols.SASL
-
- destroy() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- destroy() - Method in class org.jgroups.protocols.SHUFFLE
-
- destroy() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- destroy() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- destroy() - Method in class org.jgroups.protocols.TP
-
- destroy() - Method in class org.jgroups.protocols.TUNNEL
-
- destroy() - Method in class org.jgroups.protocols.UDP
-
- destroy() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Destroys the NakReceiverWindow.
- destroy() - Method in class org.jgroups.stack.Protocol
-
- destroy() - Method in class org.jgroups.stack.ProtocolStack
-
- destroy() - Method in class org.jgroups.stack.RouterStub
-
- destroy() - Method in class org.jgroups.util.AckCollector
-
- destroy() - Method in class org.jgroups.util.LazyThreadFactory
-
- destroy() - Method in class org.jgroups.util.RingBufferSeqno
-
- destroy() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- destroySockets() - Method in class org.jgroups.protocols.UDP
-
- destroyStubs() - Method in class org.jgroups.stack.RouterStubManager
-
- detectDifferentViews(Map<Address, View>) - Static method in class org.jgroups.protocols.MERGE3
-
- detectDifferentViews(Map<Address, View>) - Static method in class org.jgroups.util.Util
-
- determineActualMergeCoords(Map<Address, View>) - Static method in class org.jgroups.util.Util
-
- determineCoordinator() - Method in class org.jgroups.protocols.FD_SOCK
-
- determineCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
-
- determineCoordinator() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
Return the first element of members which is not me.
- determineCoordinator() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- determineFlags(View, Digest) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- determineFlags() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- determineIpVersionFromAddresses(Collection<InetAddress>) - Static method in class org.jgroups.stack.Configurator
-
This method takes a set of InetAddresses, represented by an inetAddressmap, and:
- if the resulting set is non-empty, goes through to see if all InetAddress-related
user settings have a consistent IP version: v4 or v6, and throws an exception if not
- if the resulting set is empty, sets the default IP version based on available stacks
and if a dual stack, stack preferences
- sets the IP version to be used in the JGroups session
- determineLeftMembers(List<Address>, List<Address>) - Static method in class org.jgroups.util.Util
-
Returns all members that left between 2 views.
- determineMergeCoords(Map<Address, View>) - Static method in class org.jgroups.protocols.pbcast.Merger
-
Needs to return a map of all subview coordinators and their views (as a collection of members).
- determineMergeCoords(Map<Address, View>) - Static method in class org.jgroups.util.Util
-
- determineMergeLeader(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.Merger
-
Returns the address of the merge leader
- determineMergeParticipants(Map<Address, View>) - Static method in class org.jgroups.util.Util
-
Determines the members which take part in a merge.
- determineMode() - Method in class org.jgroups.util.MessageBatch
-
- determinePingDest() - Method in class org.jgroups.protocols.FD_SOCK
-
- determineSiteMasters(View) - Method in class org.jgroups.protocols.relay.RELAY2
-
Iterates over the list of members and adds every member if the member's rank is below max_site_masters.
- diag_handler - Variable in class org.jgroups.protocols.TP
-
- diag_sock - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- diagnostics_addr - Variable in class org.jgroups.protocols.TP
-
- diagnostics_addr - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- diagnostics_bind_interfaces - Variable in class org.jgroups.protocols.TP
-
- diagnostics_passcode - Variable in class org.jgroups.protocols.TP
-
- diagnostics_port - Variable in class org.jgroups.protocols.TP
-
- diagnostics_port - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- diagnostics_ttl - Variable in class org.jgroups.protocols.TP
-
- DiagnosticsHandler - Class in org.jgroups.stack
-
- DiagnosticsHandler(InetAddress, int, Log, SocketFactory, ThreadFactory) - Constructor for class org.jgroups.stack.DiagnosticsHandler
-
- DiagnosticsHandler(InetAddress, int, Log, SocketFactory, ThreadFactory, String) - Constructor for class org.jgroups.stack.DiagnosticsHandler
-
- DiagnosticsHandler(InetAddress, int, List<NetworkInterface>, int, Log, SocketFactory, ThreadFactory, String) - Constructor for class org.jgroups.stack.DiagnosticsHandler
-
- DiagnosticsHandler.ProbeHandler - Interface in org.jgroups.stack
-
- diff(View, View) - Static method in class org.jgroups.View
-
Returns the difference between 2 views from and to.
- different(T, T) - Static method in class org.jgroups.util.Util
-
- differentViewIds() - Method in class org.jgroups.protocols.MERGE3
-
- digest - Variable in class org.jgroups.protocols.pbcast.JoinRsp
-
- digest - Variable in class org.jgroups.protocols.pbcast.MergeData
-
- digest - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- digest - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- Digest - Class in org.jgroups.util
-
A message digest containing - for each member - the highest seqno delivered (hd) and the highest seqno received (hr).
- Digest() - Constructor for class org.jgroups.util.Digest
-
Used for serialization
- Digest(Address[], long[]) - Constructor for class org.jgroups.util.Digest
-
- Digest(Address[]) - Constructor for class org.jgroups.util.Digest
-
Only used internally, don't use !
- Digest(Digest) - Constructor for class org.jgroups.util.Digest
-
Only used for testing
- Digest(Map<Address, long[]>) - Constructor for class org.jgroups.util.Digest
-
Creates a new digest from an existing map by copying the keys and values from map
- Digest(Address, long, long) - Constructor for class org.jgroups.util.Digest
-
- Digest.Entry - Class in org.jgroups.util
-
Keeps track of one members plus its highest delivered and received seqnos
- Digest.MyIterator - Class in org.jgroups.util
-
- digest_collector - Variable in class org.jgroups.protocols.pbcast.Merger
-
For GET_DIGEST / DIGEST_RSP correlation
- digest_history - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Keeps a bounded list of the last N digest sets
- digest_history - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Keeps a bounded list of the last N digest sets
- DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.FLUSH
-
- DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
-
- digits(long, int) - Static method in class org.jgroups.util.UUID
-
Returns val represented by the specified number of hex digits.
- DIR - Static variable in class org.jgroups.blocks.GridFile.Metadata
-
- DirectExecutor - Class in org.jgroups.util
-
- DirectExecutor() - Constructor for class org.jgroups.util.DirectExecutor
-
- disable_loopback - Variable in class org.jgroups.protocols.UDP
-
- disableDiagnostics() - Method in class org.jgroups.protocols.TP
-
- disableReaping() - Method in class org.jgroups.blocks.Cache
-
- DISCARD - Class in org.jgroups.protocols
-
Discards up or down messages based on a percentage; e.g., setting property 'up' to 0.1 causes 10%
of all up messages to be discarded.
- DISCARD() - Constructor for class org.jgroups.protocols.DISCARD
-
- DISCARD.DiscardDialog - Class in org.jgroups.protocols
-
- discard_all - Variable in class org.jgroups.protocols.DISCARD
-
- discard_delivered_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Messages that have been received in order are sent up the stack (= delivered to the application).
- discard_dialog - Variable in class org.jgroups.protocols.DISCARD
-
- discard_incompatible_packets - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- discard_own_messages - Variable in class org.jgroups.Channel
-
- DISCARD_PAYLOAD - Class in org.jgroups.protocols
-
Discards a message whose sequence number (in the payload, as a Long) matches seqno 2 times,
before passing it down.
- DISCARD_PAYLOAD() - Constructor for class org.jgroups.protocols.DISCARD_PAYLOAD
-
- discard_requests - Variable in class org.jgroups.protocols.COUNTER
-
Set to true during reconciliation process, will cause all requests to be discarded
- DiscardDialog() - Constructor for class org.jgroups.protocols.DISCARD.DiscardDialog
-
- discardUntilNewLine(InputStream) - Static method in class org.jgroups.util.Util
-
Reads and discards all characters from the input stream until a \r\n or EOF is encountered
- disconnect() - Method in class org.jgroups.Channel
-
Disconnects the channel if it is connected.
- disconnect() - Method in class org.jgroups.client.StompConnection
-
- DISCONNECT - Static variable in class org.jgroups.Event
-
- disconnect() - Method in class org.jgroups.fork.ForkChannel
-
Removes the fork-channel from the fork-stack's hashmap and resets its state.
- disconnect() - Method in class org.jgroups.JChannel
-
- disconnect(String, Address) - Method in class org.jgroups.stack.RouterStub
-
- disconnectStubs() - Method in class org.jgroups.stack.RouterStubManager
-
- Discovery - Class in org.jgroups.protocols
-
The Discovery protocol retrieves the initial membership (used by GMS and MERGE3) by sending discovery requests.
- Discovery() - Constructor for class org.jgroups.protocols.Discovery
-
- Discovery.DiscoveryCacheDisseminationTask - Class in org.jgroups.protocols
-
- discovery_cond - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- discovery_lock - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- discovery_rsp_expiry_time - Variable in class org.jgroups.protocols.Discovery
-
- discovery_timeout - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- discovery_timeout - Variable in class org.jgroups.protocols.MERGE3.InfoSender
-
- DiscoveryCacheDisseminationTask(List<Address>, List<Address>, List<Address>) - Constructor for class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
-
- discoveryRequestReceived(Address, String, PhysicalAddress) - Method in class org.jgroups.protocols.Discovery
-
- discoveryRequestReceived(Address, String, PhysicalAddress) - Method in class org.jgroups.protocols.TCPPING
-
- discoveryRspExpiryTime(long) - Method in class org.jgroups.protocols.Discovery
-
- disp - Variable in class org.jgroups.blocks.ReplicatedHashMap
-
- disp - Variable in class org.jgroups.demos.RelayDemoRpc
-
- disp - Variable in class org.jgroups.demos.wb.Whiteboard
-
- dispatch(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
-
- displayMessage(String, String) - Method in class org.jgroups.demos.wb.Whiteboard
-
- dispose() - Method in class org.jgroups.auth.sasl.SaslClientContext
-
- dispose() - Method in interface org.jgroups.auth.sasl.SaslContext
-
- dispose() - Method in class org.jgroups.auth.sasl.SaslServerContext
-
- disseminateDiscoveryInformation(List, List<Address>, List<Address>) - Method in class org.jgroups.protocols.Discovery
-
Disseminates cache information (UUID/IP adddress/port/name) to the given members
- DistributedFuture(Channel, Lock, Condition, Set<Future<?>>, Callable<V>) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Creates a FutureTask that will upon running, execute the
given Callable.
- DistributedFuture(Channel, Lock, Condition, Set<Future<?>>, Runnable, V) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Creates a FutureTask that will upon running, execute the
given Runnable, and arrange that get will return the
given result on successful completion.
- DO_BREAK_LINES - Static variable in class org.jgroups.util.Base64
-
Do break lines when encoding.
- doClose() - Method in class org.jgroups.nio.MockSocketChannel
-
- doFlush(Address) - Method in class org.jgroups.util.ForwardQueue
-
- done() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Protected method invoked when this task transitions to state
isDone (whether normally or via cancellation).
- done(long) - Method in class org.jgroups.blocks.MessageDispatcher
-
- done - Variable in class org.jgroups.blocks.Request
-
- done(long) - Method in class org.jgroups.blocks.RequestCorrelator
-
Used to signal that a certain request may be garbage collected as all responses have been received.
- done - Variable in class org.jgroups.protocols.relay.Relayer
-
Flag set when stop() is called.
- done() - Method in class org.jgroups.protocols.relay.Relayer
-
- done - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
-
- done - Variable in class org.jgroups.util.Responses
-
- done() - Method in class org.jgroups.util.Responses
-
- done - Variable in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- done - Variable in class org.jgroups.util.TimeScheduler3.Task
-
- DONT_BUNDLE - Static variable in class org.jgroups.Message
-
Deprecated.
- DONT_GUNZIP - Static variable in class org.jgroups.util.Base64
-
Specify that gzipped data should not be automatically gunzipped.
- dont_loopback_filter - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- dont_loopback_filter - Static variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- dont_loopback_filter - Static variable in class org.jgroups.protocols.UNICAST3
-
- doSchedule() - Method in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- doSchedule() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- doSchedule(TimeScheduler3.Task, long) - Method in class org.jgroups.util.TimeScheduler3
-
- doSelect() - Method in class org.jgroups.blocks.cs.NioBaseServer.Acceptor
-
- doSend(byte[], int, int, boolean, boolean) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- doSend(AsciiString, byte[], int, int, Address) - Method in class org.jgroups.protocols.TP
-
- DOUBLE_SIZE - Static variable in class org.jgroups.Global
-
- down(Event) - Method in class org.jgroups.Channel
-
Enables access to event mechanism of a channel and is normally not used by clients directly.
- down(Event) - Method in class org.jgroups.fork.ForkChannel
-
- down(Event) - Method in class org.jgroups.fork.ForkProtocol
-
- down(Event) - Method in class org.jgroups.fork.ForkProtocolStack
-
- down(Event) - Method in class org.jgroups.JChannel
-
Sends an event down the protocol stack.
- down(Event) - Method in class org.jgroups.protocols.ABP
-
- down(Event) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- down(Event) - Method in class org.jgroups.protocols.AUTH
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.protocols.BARRIER
-
- down(Event) - Method in class org.jgroups.protocols.COMPRESS
-
We compress the payload if it is larger than min_size
.
- down(Event) - Method in class org.jgroups.protocols.COUNTER
-
- down(Event) - Method in class org.jgroups.protocols.DAISYCHAIN
-
- down(Event) - Method in class org.jgroups.protocols.DELAY
-
- down - Variable in class org.jgroups.protocols.DISCARD
-
- down(Event) - Method in class org.jgroups.protocols.DISCARD
-
- down(Event) - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
-
- down(Event) - Method in class org.jgroups.protocols.Discovery
-
- down(Event) - Method in class org.jgroups.protocols.DUPL
-
- down(Event) - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.EncryptBase
-
- down(Event) - Method in class org.jgroups.protocols.EXAMPLE
-
- down(Event) - Method in class org.jgroups.protocols.Executing
-
- down(Event) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.FD
-
- down(Event) - Method in class org.jgroups.protocols.FD_ALL
-
- down(Event) - Method in class org.jgroups.protocols.FD_ALL2
-
- down(Event) - Method in class org.jgroups.protocols.FD_HOST
-
- down(Event) - Method in class org.jgroups.protocols.FD_SOCK
-
- down(Event) - Method in class org.jgroups.protocols.FILE_PING
-
- down(Event) - Method in class org.jgroups.protocols.FlowControl
-
- down(Event) - Method in class org.jgroups.protocols.FORK
-
- down(Event) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- down(Event) - Method in class org.jgroups.protocols.FRAG
-
Fragment a packet if larger than frag_size (add a header).
- down(Event) - Method in class org.jgroups.protocols.FRAG2
-
Fragment a packet if larger than frag_size (add a header).
- down(Event) - Method in class org.jgroups.protocols.HDRS
-
- down(Event) - Method in class org.jgroups.protocols.JDBC_PING
-
- down(Event) - Method in class org.jgroups.protocols.KeyExchange
-
- down(Event) - Method in class org.jgroups.protocols.Locking
-
- down(Event) - Method in class org.jgroups.protocols.MAKE_BATCH
-
- down(Event) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.MERGE3
-
- down(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- down(Event) - Method in class org.jgroups.protocols.pbcast.GMS
-
- down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Callback.
- down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Callback.
- down(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- down(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- down(Event) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- down(Event) - Method in class org.jgroups.protocols.PDC
-
- down(Event) - Method in class org.jgroups.protocols.PERF
-
- down(Event) - Method in class org.jgroups.protocols.PRIO
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.protocols.RATE_LIMITER
-
- down(Event) - Method in class org.jgroups.protocols.RELAY
-
- down(Event) - Method in class org.jgroups.protocols.relay.RELAY2
-
- down(Event) - Method in class org.jgroups.protocols.RSVP
-
- down(Event) - Method in interface org.jgroups.protocols.rules.EventHandler
-
Called when a down event is received
- down(Event) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- down(Event) - Method in class org.jgroups.protocols.SASL
-
- down(Event) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.SEQUENCER
-
- down(Event) - Method in class org.jgroups.protocols.SEQUENCER2
-
- down(Event) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- down - Variable in class org.jgroups.protocols.SHUFFLE
-
- down(Event) - Method in class org.jgroups.protocols.SHUFFLE
-
- down(Event) - Method in class org.jgroups.protocols.SIZE
-
- down(Event) - Method in class org.jgroups.protocols.STATS
-
- down(Event) - Method in class org.jgroups.protocols.STOMP
-
- down(Event) - Method in class org.jgroups.protocols.TCPPING
-
- down(Event) - Method in class org.jgroups.protocols.tom.TOA
-
- down(Event) - Method in class org.jgroups.protocols.TP
-
Caller by the layer above this layer.
- down(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- down(Event) - Method in class org.jgroups.protocols.TRACE
-
- down(Event) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- down(Event) - Method in class org.jgroups.protocols.UNICAST3
-
- down(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- down(Event) - Method in class org.jgroups.stack.Protocol
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.stack.ProtocolStack
-
- down_msgs - Variable in class org.jgroups.protocols.SHUFFLE
-
- down_prot - Variable in class org.jgroups.stack.Protocol
-
- down_prot - Variable in class org.jgroups.util.ForwardQueue
-
- drainTo(Collection<? super T>) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- drainTo(Collection<? super T>) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- Draw - Class in org.jgroups.demos
-
Shared whiteboard, each new instance joins the same group.
- Draw(String, boolean, boolean, boolean, long, boolean, String, boolean, AddressGenerator) - Constructor for class org.jgroups.demos.Draw
-
- Draw(JChannel) - Constructor for class org.jgroups.demos.Draw
-
- Draw(JChannel, boolean, long) - Constructor for class org.jgroups.demos.Draw
-
- Draw.DrawPanel - Class in org.jgroups.demos
-
- draw_dest - Static variable in class org.jgroups.demos.StompDraw
-
- DrawApplet - Class in org.jgroups.demos.applets
-
- DrawApplet() - Constructor for class org.jgroups.demos.applets.DrawApplet
-
- DrawCommand - Class in org.jgroups.demos
-
Encapsulates information about a draw command.
- DrawCommand() - Constructor for class org.jgroups.demos.DrawCommand
-
- drawNode(Graphics, int, int, String, int) - Method in class org.jgroups.demos.Topology
-
- DrawPanel(boolean) - Constructor for class org.jgroups.demos.Draw.DrawPanel
-
- drawPoint(DrawCommand) - Method in class org.jgroups.demos.Draw.DrawPanel
-
Adds pixel to queue and calls repaint() whenever we have MAX_ITEMS pixels in the queue
or when MAX_TIME msecs have elapsed (whichever comes first).
- drawState() - Method in class org.jgroups.demos.Draw.DrawPanel
-
Draw the entire panel from the state
- drawTopology(Graphics) - Method in class org.jgroups.demos.Topology
-
- drop_down_multicasts - Variable in class org.jgroups.protocols.DISCARD
-
- drop_down_unicasts - Variable in class org.jgroups.protocols.DISCARD
-
- drop_oob_and_dont_loopback_msgs_filter - Variable in class org.jgroups.protocols.UNICAST3
-
- DUMMY - Static variable in class org.jgroups.Global
-
- DUMMY - Static variable in class org.jgroups.util.Seqno
-
- DUMMY_OOB_MSG - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- DUMMY_OOB_MSG - Static variable in class org.jgroups.protocols.UNICAST3
-
- dump() - Method in class org.jgroups.blocks.Cache
-
- dump() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- dump() - Method in class org.jgroups.blocks.ReplCache
-
- dump(String[], long[], long[]) - Static method in class org.jgroups.protocols.COUNTER
-
- dump() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Dumps the seqnos in the table as a list
- dump() - Method in class org.jgroups.util.Table
-
Dumps the seqnos in the table as a list
- Dump() - Constructor for class org.jgroups.util.Table.Dump
-
- dumpAddresssMappings() - Method in class org.jgroups.stack.GossipRouter
-
- dumpCache(String) - Method in class org.jgroups.protocols.Discovery
-
- dumpChannelStats() - Method in class org.jgroups.JChannel
-
- dumpContents() - Method in class org.jgroups.util.RequestTable
-
- dumpMatrix() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Dumps the non-null in the table in a pseudo graphic way
- dumpPendingRequests() - Method in class org.jgroups.blocks.atomic.CounterService
-
- dumpPendingRequests() - Method in class org.jgroups.protocols.COUNTER
-
- dumpQueue(Queue) - Static method in class org.jgroups.util.Util
-
Debugging method used to dump the content of a protocol queue in a
condensed form.
- dumpRoutingTable() - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- dumpRoutingTable() - Method in class org.jgroups.stack.GossipRouter
-
- dumpRules() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- dumpScopes() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- dumpSocketInfo() - Method in class org.jgroups.protocols.UDP
-
- dumpStats() - Method in class org.jgroups.Channel
-
Returns a map of statistics of the various protocols and of the channel itself.
- dumpStats() - Method in class org.jgroups.fork.ForkProtocol
-
- dumpStats() - Method in class org.jgroups.JChannel
-
- dumpStats(String, List<String>) - Method in class org.jgroups.JChannel
-
- dumpStats(String) - Method in class org.jgroups.JChannel
-
- dumpStats() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- dumpStats() - Method in class org.jgroups.protocols.FlowControl
-
- dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- dumpStats() - Method in class org.jgroups.protocols.SEQUENCER
-
- dumpStats() - Method in class org.jgroups.protocols.SEQUENCER2
-
- dumpStats() - Method in class org.jgroups.protocols.UFC
-
- dumpStats() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- dumpStats() - Method in class org.jgroups.protocols.UNICAST3
-
- dumpStats() - Method in class org.jgroups.stack.Protocol
-
- dumpStats() - Method in class org.jgroups.stack.ProtocolStack
-
- dumpStats(String) - Method in class org.jgroups.stack.ProtocolStack
-
- dumpStats(String, List<String>) - Method in class org.jgroups.stack.ProtocolStack
-
- dumpThreads() - Method in class org.jgroups.util.LazyThreadFactory
-
- dumpThreads() - Static method in class org.jgroups.util.Util
-
- dumpTimerQueue() - Method in class org.jgroups.JChannel
-
- dumpTimerTasks() - Method in class org.jgroups.protocols.TP
-
- dumpTimerTasks() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- dumpTimerTasks() - Method in class org.jgroups.util.HashedTimingWheel
-
- dumpTimerTasks() - Method in class org.jgroups.util.MockTimeScheduler
-
- dumpTimerTasks() - Method in interface org.jgroups.util.TimeScheduler
-
Returns a list of tasks currently waiting for execution.
- dumpTimerTasks() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- dumpTimerTasks() - Method in class org.jgroups.util.TimeScheduler3
-
- dumpViewHandlerHistory() - Method in class org.jgroups.protocols.pbcast.GMS
-
- dumpViewHandlerQueue() - Method in class org.jgroups.protocols.pbcast.GMS
-
- dumpViews() - Method in class org.jgroups.protocols.MERGE3
-
- dumpXmitTablesNumCurrentRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- DUPL - Class in org.jgroups.protocols
-
Duplicates outgoing or incoming messages by copying them
- DUPL() - Constructor for class org.jgroups.protocols.DUPL
-
- DUPL(boolean, boolean, int, int) - Constructor for class org.jgroups.protocols.DUPL
-
- DUPL.Direction - Enum in org.jgroups.protocols
-
- duplicate - Variable in class org.jgroups.protocols.DISCARD_PAYLOAD
-
- dx - Variable in class org.jgroups.demos.wb.Node
-
- dy - Variable in class org.jgroups.demos.wb.Node
-
- dynamic_hosts - Variable in class org.jgroups.protocols.TCPPING
-
https://jira.jboss.org/jira/browse/JGRP-989
- EAP_EXCLUDED - Static variable in class org.jgroups.Global
-
- Element(T, Lock) - Constructor for class org.jgroups.util.Pool.Element
-
- element - Variable in class org.jgroups.util.Pool.Element
-
- elementAt(int) - Method in class org.jgroups.Membership
-
Returns the component at the specified index
- elements - Variable in class org.jgroups.util.ArrayIterator
-
- elements_per_row - Variable in class org.jgroups.util.Table
-
Must be a power of 2 for efficient modular arithmetic
- emit_suspect_events - Variable in class org.jgroups.stack.GossipRouter
-
- emitSuspectEvents() - Method in class org.jgroups.stack.GossipRouter
-
- emitSuspectEvents(boolean) - Method in class org.jgroups.stack.GossipRouter
-
- emptyGossipClientStubManager(Protocol) - Static method in class org.jgroups.stack.RouterStubManager
-
- enable_address_tagging - Variable in class org.jgroups.protocols.relay.RELAY2
-
- enable_batching - Variable in class org.jgroups.protocols.TP
-
- enable_bundling - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- enable_diagnostics - Variable in class org.jgroups.protocols.TP
-
- enable_unicast_bundling - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- enableAddressTagging(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
-
- enableAddressTagging() - Method in class org.jgroups.protocols.relay.RELAY2
-
- enableDiagnostics() - Method in class org.jgroups.protocols.TP
-
- enableReaping(long) - Method in class org.jgroups.blocks.Cache
-
Runs the reaper every interval ms, evicts expired items
- enableStats(boolean) - Method in class org.jgroups.JChannel
-
- enableStats(boolean) - Method in class org.jgroups.protocols.tom.TOA
-
- enableStats(boolean) - Method in class org.jgroups.stack.Protocol
-
- ENCODE - Static variable in class org.jgroups.util.Base64
-
Specify encoding in first bit.
- encode(ByteBuffer, ByteBuffer) - Static method in class org.jgroups.util.Base64
-
Performs Base64 encoding on the raw
ByteBuffer,
writing it to the encoded
ByteBuffer.
- encode(ByteBuffer, CharBuffer) - Static method in class org.jgroups.util.Base64
-
Performs Base64 encoding on the raw
ByteBuffer,
writing it to the encoded
CharBuffer.
- encode(int, int, int) - Static method in class org.jgroups.Version
-
Method copied from http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
- encodeBytes(byte[]) - Static method in class org.jgroups.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int) - Static method in class org.jgroups.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int) - Static method in class org.jgroups.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytes(byte[], int, int, int) - Static method in class org.jgroups.util.Base64
-
Encodes a byte array into Base64 notation.
- encodeBytesToBytes(byte[]) - Static method in class org.jgroups.util.Base64
-
- encodeBytesToBytes(byte[], int, int, int) - Static method in class org.jgroups.util.Base64
-
- encodeDataToStream(byte[], DataOutput) - Static method in class org.jgroups.auth.Krb5TokenUtils
-
- encodeFileToFile(String, String) - Static method in class org.jgroups.util.Base64
-
Reads infile and encodes it to outfile.
- encodeFromFile(String) - Static method in class org.jgroups.util.Base64
-
Convenience method for reading a binary file
and base64-encoding it.
- encodeLength(byte, byte) - Static method in class org.jgroups.util.Bits
-
Encodes the number of bytes needed into a single byte.
- encodeObject(Serializable) - Static method in class org.jgroups.util.Base64
-
Serializes an object and returns the Base64-encoded
version of that serialized object.
- encodeObject(Serializable, int) - Static method in class org.jgroups.util.Base64
-
Serializes an object and returns the Base64-encoded
version of that serialized object.
- encodeToFile(byte[], String) - Static method in class org.jgroups.util.Base64
-
Convenience method for encoding data to a file.
- encoding_ciphers - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- encoding_ciphers - Variable in class org.jgroups.protocols.EncryptBase
-
- encoding_locks - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- encrypt(byte[]) - Static method in class org.jgroups.auth.DemoToken
-
- ENCRYPT - Class in org.jgroups.protocols
-
- ENCRYPT() - Constructor for class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- ENCRYPT - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- ENCRYPT - Static variable in class org.jgroups.protocols.EncryptHeader
-
- ENCRYPT.Decrypter - Class in org.jgroups.protocols
-
Deprecated.
Decrypts all messages in a batch, replacing encrypted messages in-place with their decrypted versions
- ENCRYPT.EncryptHeader - Class in org.jgroups.protocols
-
Deprecated.
- encrypt_entire_message - Variable in class org.jgroups.protocols.EncryptBase
-
- ENCRYPT_ENTIRE_MSG - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- encryptAndSend(Message) - Method in class org.jgroups.protocols.EncryptBase
-
- EncryptBase - Class in org.jgroups.protocols
-
- EncryptBase() - Constructor for class org.jgroups.protocols.EncryptBase
-
- EncryptBase.Decrypter - Class in org.jgroups.protocols
-
Decrypts all messages in a batch, replacing encrypted messages in-place with their decrypted versions
- encryptChecksum(long) - Method in class org.jgroups.protocols.EncryptBase
-
- encryptedToken(byte[]) - Method in class org.jgroups.auth.X509Token
-
To be used for testing only
- encryptEntireMessage() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- encryptEntireMessage() - Method in class org.jgroups.protocols.EncryptBase
-
- encryptEntireMessage(boolean) - Method in class org.jgroups.protocols.EncryptBase
-
- EncryptHeader() - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- EncryptHeader(byte, byte[]) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- EncryptHeader - Class in org.jgroups.protocols
-
- EncryptHeader() - Constructor for class org.jgroups.protocols.EncryptHeader
-
- EncryptHeader(byte, byte[]) - Constructor for class org.jgroups.protocols.EncryptHeader
-
- encryptSecretKey(Key, PublicKey) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Encrypts the current secret key with the requester's public key (the requester will decrypt it with its private key)
- end_index - Variable in class org.jgroups.util.Responses.PingDataIterator
-
- endpoint - Variable in class org.jgroups.protocols.STOMP
-
- endpoint_addr - Variable in class org.jgroups.protocols.STOMP
-
- ENDPOINTS - Static variable in class org.jgroups.demos.StompChat
-
- endpoints - Variable in class org.jgroups.protocols.STOMP
-
- enqueue(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- ensureCapacity(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
Grows the buffer; whether it grow linearly or exponentially depends on grow_exponentially
- ensureValidBindAddresses(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Makes sure that all fields annotated with @LocalAddress is (1) an InetAddress and (2) a valid address on any
local network interface
- Entry(byte[]) - Constructor for class org.jgroups.auth.DemoToken.Entry
-
- Entry(V) - Constructor for class org.jgroups.blocks.LazyRemovalCache.Entry
-
- Entry() - Constructor for class org.jgroups.protocols.ABP.Entry
-
- Entry(Address) - Constructor for class org.jgroups.protocols.RSVP.Entry
-
Unicast entry
- Entry(Collection<Address>) - Constructor for class org.jgroups.protocols.RSVP.Entry
-
Multicast entry
- Entry(short, Table<Message>) - Constructor for class org.jgroups.protocols.UNICAST3.Entry
-
- Entry(Address, long) - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- Entry(Address, PhysicalAddress, String) - Constructor for class org.jgroups.stack.GossipRouter.Entry
-
- Entry(Address, long, long) - Constructor for class org.jgroups.util.Digest.Entry
-
- entryRemoved(K) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
-
- entryRemoved(Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- entrySet() - Method in class org.jgroups.blocks.Cache
-
- entrySet() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- entrySet() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- entrySet(K, V) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
-
- entrySet(Object, Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- entrySet() - Method in class org.jgroups.util.RspList
-
- equals(Object) - Method in class org.jgroups.AnycastAddress
-
- equals(Object) - Method in class org.jgroups.blocks.mux.NoMuxHandler
-
- equals(Object) - Method in class org.jgroups.protocols.Executing.Owner
-
- equals(Object) - Method in class org.jgroups.protocols.PingData
-
- equals(Object) - Method in class org.jgroups.protocols.relay.Route
-
- equals(Object) - Method in class org.jgroups.protocols.relay.SiteMaster
-
- equals(Object) - Method in class org.jgroups.protocols.tom.MessageID
-
- equals(Object) - Method in class org.jgroups.stack.IpAddress
-
- equals(Object) - Method in class org.jgroups.stack.RouterStub
-
- equals(Object) - Method in class org.jgroups.stack.RouterStubManager.Target
-
- equals(Object) - Method in class org.jgroups.util.AsciiString
-
- equals(byte[]) - Method in class org.jgroups.util.AsciiString
-
- equals(Object) - Method in class org.jgroups.util.Digest.Entry
-
- equals(Object) - Method in class org.jgroups.util.Digest
-
2 digests are equal if their memberships match and all highest-delivered and highest-received seqnos match
- equals(Object) - Method in class org.jgroups.util.MergeId
-
- equals(Object) - Method in class org.jgroups.util.Owner
-
- equals(Object) - Method in class org.jgroups.util.Range
-
- equals(Object) - Method in class org.jgroups.util.Rsp
-
- equals(Object) - Method in class org.jgroups.util.Seqno
-
- equals(Object) - Method in class org.jgroups.util.SingletonAddress
-
- equals(Object) - Method in class org.jgroups.util.UUID
-
Compares this object to the specified object.
- equals(Object) - Method in class org.jgroups.View
-
- equals(Object) - Method in class org.jgroups.ViewId
-
- ergonomics - Variable in class org.jgroups.stack.Protocol
-
- error(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- error(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- error(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
-
- error(String) - Method in interface org.jgroups.logging.Log
-
- error(String, Object...) - Method in interface org.jgroups.logging.Log
-
- error(String, Throwable) - Method in interface org.jgroups.logging.Log
-
- error(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- error(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- error(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- error_message - Variable in class org.jgroups.protocols.COUNTER.ExceptionResponse
-
- eval() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- eval() - Method in class org.jgroups.protocols.rules.Rule
-
Evaluates the condition.
- eval() - Method in class org.jgroups.protocols.rules.SampleRule
-
- Event - Class in org.jgroups
-
Event is a JGroups internal class used for inter-stack and intra-stack communication.
- Event(int) - Constructor for class org.jgroups.Event
-
- Event(int, Object) - Constructor for class org.jgroups.Event
-
- event_handlers - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- EventHandler - Interface in org.jgroups.protocols.rules
-
Interface which defines 2 callbacks: up() and down().
- eventLoop() - Method in class org.jgroups.demos.PubClient
-
- evictLogicalAddressCache() - Method in class org.jgroups.protocols.TP
-
- evictLogicalAddressCache(boolean) - Method in class org.jgroups.protocols.TP
-
- exact_destination_match - Variable in class org.jgroups.protocols.STOMP
-
- EXAMPLE - Class in org.jgroups.protocols
-
Example of a protocol layer.
- EXAMPLE() - Constructor for class org.jgroups.protocols.EXAMPLE
-
- EXAMPLE.ExampleHeader - Class in org.jgroups.protocols
-
- ExampleHeader() - Constructor for class org.jgroups.protocols.EXAMPLE.ExampleHeader
-
- EXC_RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
-
- exception - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
The exception to throw from get()
- exception - Variable in class org.jgroups.util.StateTransferResult
-
- ExceptionResponse() - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
-
- ExceptionResponse(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
-
- excludeItself - Variable in class org.jgroups.protocols.DISCARD
-
- exclusion_list - Variable in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
Contains a list of members who should not receive the request (others will drop).
- exclusion_list - Variable in class org.jgroups.blocks.RequestOptions
-
A list of members which should be excluded from a call
- exclusionList() - Method in class org.jgroups.blocks.RequestOptions
-
- execute(Runnable) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- execute(Message, boolean) - Method in class org.jgroups.blocks.Request
-
- execute(String) - Static method in class org.jgroups.protocols.FD_HOST.CommandExecutor
-
- execute(String) - Static method in class org.jgroups.protocols.FD_HOST.CommandExecutor2
-
- execute(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
-
- execute(Runnable) - Method in class org.jgroups.util.DirectExecutor
-
- execute(Runnable) - Method in class org.jgroups.util.HashedTimingWheel
-
- execute(Runnable) - Method in class org.jgroups.util.MockTimeScheduler
-
- execute(Runnable) - Method in interface org.jgroups.util.TimeScheduler
-
Executes command with zero required delay.
- execute(Runnable) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- execute(Runnable) - Method in class org.jgroups.util.TimeScheduler3
-
- Executing - Class in org.jgroups.protocols
-
This is the base protocol used for executions.
- Executing() - Constructor for class org.jgroups.protocols.Executing
-
- Executing.ExecutorHeader - Class in org.jgroups.protocols
-
- Executing.Owner - Class in org.jgroups.protocols
-
- Executing.Request - Class in org.jgroups.protocols
-
- Executing.RequestWithThread - Class in org.jgroups.protocols
-
- Executing.Type - Enum in org.jgroups.protocols
-
- execution_service - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- ExecutionCompletionService<V> - Class in org.jgroups.blocks.executor
-
- ExecutionCompletionService(ExecutionService) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
-
Creates an ExecutorCompletionService using the supplied
executor for base task execution and a
LinkedBlockingQueue
as a completion queue.
- ExecutionCompletionService(ExecutionService, BlockingQueue<NotifyingFuture<V>>) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
-
Creates an ExecutorCompletionService using the supplied
executor for base task execution and the supplied queue as its
completion queue.
- ExecutionCompletionService(ExecutionService, BlockingQueue<NotifyingFuture<V>>, ExecutionCompletionService<V>.QueueingListener) - Constructor for class org.jgroups.blocks.executor.ExecutionCompletionService
-
This constructor is here if someone wants to override this class and
provide their own QueueingListener to possibly listen in on futures
being finished
- ExecutionCompletionService.QueueingListener - Class in org.jgroups.blocks.executor
-
- ExecutionRunner - Class in org.jgroups.blocks.executor
-
This class is to be used to pick up execution requests and actually run
them.
- ExecutionRunner(JChannel) - Constructor for class org.jgroups.blocks.executor.ExecutionRunner
-
- ExecutionRunner.Holder<T> - Class in org.jgroups.blocks.executor
-
- Executions - Class in org.jgroups.blocks.executor
-
- executions - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- executions() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- Executions.StreamableCallable - Class in org.jgroups.blocks.executor
-
- ExecutionService - Class in org.jgroups.blocks.executor
-
This is a jgroups implementation of an ExecutorService, where the consumers
are running on any number of nodes.
- ExecutionService() - Constructor for class org.jgroups.blocks.executor.ExecutionService
-
- ExecutionService(Channel) - Constructor for class org.jgroups.blocks.executor.ExecutionService
-
- ExecutionService.DistributedFuture<V> - Class in org.jgroups.blocks.executor
-
This is basically a copy of the FutureTask in java.util.concurrent but
added serializable to it.
- ExecutionService.DistributedFuture.Sync<V> - Class in org.jgroups.blocks.executor
-
Synchronization control for FutureTask.
- ExecutionService.RunnableAdapter<T> - Class in org.jgroups.blocks.executor
-
This is copied from Executors
class which
contains RunnableAdapter.
- ExecutionServiceDemo - Class in org.jgroups.demos
-
- ExecutionServiceDemo(String, String, int) - Constructor for class org.jgroups.demos.ExecutionServiceDemo
-
- ExecutionServiceDemo.ByteBufferStreamable - Class in org.jgroups.demos
-
- ExecutionServiceDemo.SortingByteCallable - Class in org.jgroups.demos
-
- ExecutionServiceDemo.SortingTwoByteCallable - Class in org.jgroups.demos
-
Sorts 2 byte arrys into a larger byte array
- executor - Variable in class org.jgroups.blocks.executor.ExecutionCompletionService
-
- executor - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- ExecutorEvent - Class in org.jgroups.blocks.executor
-
Defines an event class for the execution of an entity.
- ExecutorEvent(int, Object) - Constructor for class org.jgroups.blocks.executor.ExecutorEvent
-
- ExecutorHeader() - Constructor for class org.jgroups.protocols.Executing.ExecutorHeader
-
- ExecutorNotification - Interface in org.jgroups.blocks.executor
-
- exists() - Method in class org.jgroups.blocks.GridFile
-
- exists(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Checks whether a given node exists in the tree
- expected - Variable in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- expected_acks - Variable in class org.jgroups.util.AckCollector
-
- expectedAcks() - Method in class org.jgroups.util.AckCollector
-
- Experimental - Annotation Type in org.jgroups.annotations
-
Elements annotated with this annotation are experimental and may get removed from the distribution at any time
- expiration_interval - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- expiration_time - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- expire(short) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
Multicasts an EXPIRE message to all members, and - on reception - each member removes the scope locally
- EXPIRE - Static variable in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- expired(Address) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
Called by AgeOutCache, to removed expired connections
- expired(Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Called by AgeOutCache, to removed expired connections
- expired(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Called by AgeOutCache, to removed expired connections
- expired(K) - Method in interface org.jgroups.util.AgeOutCache.Handler
-
- expiry_task - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- expiry_time - Variable in class org.jgroups.stack.GossipRouter
-
- ExpiryCache<K> - Class in org.jgroups.util
-
Cache which maintains timestamps for keys, and methods to remove/replace expired keys.
- ExpiryCache(long) - Constructor for class org.jgroups.util.ExpiryCache
-
Creates a new instance
- ExpiryTask() - Constructor for class org.jgroups.protocols.SCOPE.ExpiryTask
-
Deprecated.
- expiryTime() - Method in class org.jgroups.stack.GossipRouter
-
- expiryTime(long) - Method in class org.jgroups.stack.GossipRouter
-
- explanation(boolean, boolean) - Static method in class org.jgroups.blocks.cs.BaseServer
-
- exponential_backoff - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- ExponentialInterval - Class in org.jgroups.stack
-
- ExponentialInterval() - Constructor for class org.jgroups.stack.ExponentialInterval
-
- ExponentialInterval(int) - Constructor for class org.jgroups.stack.ExponentialInterval
-
- expose_all - Variable in class org.jgroups.jmx.ResourceDMBean
-
- exposeManagedAttribute(Method) - Method in class org.jgroups.jmx.ResourceDMBean
-
- extendedStats(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
- extendedStats() - Method in class org.jgroups.blocks.MessageDispatcher
-
- extendedStats() - Method in class org.jgroups.util.RpcStats
-
- extendedStats(boolean) - Method in class org.jgroups.util.RpcStats
-
- ExtendedUUID - Class in org.jgroups.util
-
Subclass of
UUID
accommodating additional data such as a flag and a small hashmap.
- ExtendedUUID() - Constructor for class org.jgroups.util.ExtendedUUID
-
- ExtendedUUID(byte[]) - Constructor for class org.jgroups.util.ExtendedUUID
-
- ExtendedUUID(long, long) - Constructor for class org.jgroups.util.ExtendedUUID
-
- ExtendedUUID(ExtendedUUID) - Constructor for class org.jgroups.util.ExtendedUUID
-
- EXTERNAL_ADDR - Static variable in class org.jgroups.Global
-
- external_addr - Variable in class org.jgroups.protocols.FD_SOCK
-
- external_addr - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- external_addr - Variable in class org.jgroups.protocols.TP
-
- EXTERNAL_PORT - Static variable in class org.jgroups.Global
-
- external_port - Variable in class org.jgroups.protocols.FD_SOCK
-
- external_port - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- external_port - Variable in class org.jgroups.protocols.TP
-
- ExternalPingCommand(String) - Constructor for class org.jgroups.protocols.FD_HOST.ExternalPingCommand
-
- extract(View) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
Returns a map containing the site keys and addresses as values
- f - Static variable in class org.jgroups.protocols.TP
-
- factory - Variable in class org.jgroups.blocks.cs.BaseServer
-
- factory - Variable in class org.jgroups.util.Runner
-
- fail_reason - Variable in class org.jgroups.protocols.pbcast.JoinRsp
-
- FAIL_REASON_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
-
- fatal(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- fatal(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- fatal(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
-
- fatal(String) - Method in interface org.jgroups.logging.Log
-
- fatal(String, Object...) - Method in interface org.jgroups.logging.Log
-
- fatal(String, Throwable) - Method in interface org.jgroups.logging.Log
-
- fatal(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- fatal(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- fatal(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- FC - Class in org.jgroups.protocols
-
- FC() - Constructor for class org.jgroups.protocols.FC
-
Deprecated.
- FcHeader - Class in org.jgroups.protocols
-
Header used by various flow control protocols
- FcHeader() - Constructor for class org.jgroups.protocols.FcHeader
-
- FcHeader(byte) - Constructor for class org.jgroups.protocols.FcHeader
-
- FD - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD() - Constructor for class org.jgroups.protocols.FD
-
- fd - Variable in class org.jgroups.protocols.rules.CheckFDMonitor
-
- FD.Broadcaster - Class in org.jgroups.protocols
-
Task that periodically broadcasts a list of suspected members to the group.
- FD.BroadcastTask - Class in org.jgroups.protocols
-
- FD.FdHeader - Class in org.jgroups.protocols
-
- FD.Monitor - Class in org.jgroups.protocols
-
Task which periodically checks of the last_ack from ping_dest exceeded timeout and - if yes - broadcasts
a SUSPECT message
- FD_ALL - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD_ALL() - Constructor for class org.jgroups.protocols.FD_ALL
-
- FD_ALL.HeartbeatHeader - Class in org.jgroups.protocols
-
- FD_ALL2 - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD_ALL2() - Constructor for class org.jgroups.protocols.FD_ALL2
-
- FD_ALL2.HeartbeatHeader - Class in org.jgroups.protocols
-
- FD_HOST - Class in org.jgroups.protocols
-
Failure detection protocol which detects the crash or hanging of entire hosts and suspects all cluster members
on those hosts.
- FD_HOST() - Constructor for class org.jgroups.protocols.FD_HOST
-
- FD_HOST.CommandExecutor - Class in org.jgroups.protocols
-
- FD_HOST.CommandExecutor2 - Class in org.jgroups.protocols
-
- FD_HOST.ExternalPingCommand - Class in org.jgroups.protocols
-
- FD_HOST.IsReachablePingCommand - Class in org.jgroups.protocols
-
- FD_HOST.PingCommand - Interface in org.jgroups.protocols
-
Command used to check whether a given host is alive, periodically called
- FD_HOST.PingTask - Class in org.jgroups.protocols
-
Selected members run this task periodically.
- FD_PING - Class in org.jgroups.protocols
-
- FD_PING() - Constructor for class org.jgroups.protocols.FD_PING
-
Deprecated.
- FD_PING.Pinger - Class in org.jgroups.protocols
-
Deprecated.
- FD_PING.PingMonitor - Class in org.jgroups.protocols
-
Deprecated.
Executes the ping command.
- FD_SOCK - Class in org.jgroups.protocols
-
Failure detection protocol based on sockets.
- FD_SOCK() - Constructor for class org.jgroups.protocols.FD_SOCK
-
- FD_SOCK.BroadcastTask - Class in org.jgroups.protocols
-
Task that periodically broadcasts a list of suspected members to the group.
- FD_SOCK.ClientConnectionHandler - Class in org.jgroups.protocols
-
Handles a client connection; multiple client can connect at the same time
- FD_SOCK.FdHeader - Class in org.jgroups.protocols
-
- FD_SOCK.ServerSocketHandler - Class in org.jgroups.protocols
-
Handles the server-side of a client-server socket connection.
- FdHeader() - Constructor for class org.jgroups.protocols.FD.FdHeader
-
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD.FdHeader
-
- FdHeader(byte, Collection<Address>, Address) - Constructor for class org.jgroups.protocols.FD.FdHeader
-
- FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
-
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
-
- FdHeader(byte, Address) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
-
- FdHeader(byte, Address, IpAddress) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
-
- FdHeader(byte, Set<Address>) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
-
- FETCH_SECRET_KEY - Static variable in class org.jgroups.Event
-
- fetchAllViews() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- fetchDigestsFromAllMembersInSubPartition(View, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
Multicasts a GET_DIGEST_REQ to all members of this sub partition and waits for all responses
(GET_DIGEST_RSP) or N ms.
- fetching_done - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- fetchLocalAddresses() - Method in class org.jgroups.protocols.TP
-
Grabs the local address (or addresses in the shared transport case) and registers them with the physical address
in the transport's cache
- fetchPhysicalAddrs(List<Address>) - Method in class org.jgroups.protocols.TP
-
- fetchPingAddress(Address) - Method in class org.jgroups.protocols.FD_SOCK
-
Attempts to obtain the ping_addr first from the cache, then by unicasting q request to mbr
,
then by multicasting a request to all members.
- fetchResponsesFromDiscoveryProtocol(List<Address>) - Method in class org.jgroups.protocols.TP
-
- fetchSecretKeyFrom(Address) - Method in class org.jgroups.protocols.KeyExchange
-
Needs to fetch the secret key from a given destination (usually the key server).
- fetchSecretKeyFrom(Address) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- fetchState(long) - Method in class org.jgroups.blocks.ReplicatedTree
-
Fetch the group state from the current coordinator.
- fetchViews() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
Fetches views from members in the cluster.
- field - Variable in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- FieldAccessor(Field, Object) - Constructor for class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- FILE - Static variable in class org.jgroups.blocks.GridFile.Metadata
-
- file - Variable in class org.jgroups.blocks.GridInputStream
-
- file - Variable in class org.jgroups.blocks.GridOutputStream
-
- FILE_PING - Class in org.jgroups.protocols
-
Simple discovery protocol which uses a file on shared storage such as an SMB share, NFS mount or S3.
- FILE_PING() - Constructor for class org.jgroups.protocols.FILE_PING
-
- FILE_PING.InfoWriter - Class in org.jgroups.protocols
-
Class which calls writeAll() a few times.
- fileChanged(File) - Method in interface org.jgroups.auth.sasl.FileObserver
-
- fileChanged(File) - Method in class org.jgroups.auth.sasl.SimpleAuthorizingCallbackHandler.PropertiesReloadFileObserver
-
- filename(String) - Static method in class org.jgroups.blocks.GridFile
-
- FileObserver - Interface in org.jgroups.auth.sasl
-
FileObserver.
- FileWatchTask - Class in org.jgroups.auth.sasl
-
FileWatchTask.
- FileWatchTask(File, FileObserver) - Constructor for class org.jgroups.auth.sasl.FileWatchTask
-
- filter - Static variable in class org.jgroups.protocols.FILE_PING
-
- filter - Variable in class org.jgroups.protocols.PDC
-
- Filter<T> - Interface in org.jgroups.util
-
- filter - Variable in class org.jgroups.util.Table.Remover
-
- filter - Variable in class org.jgroups.util.Table.RemoverOnAdd
-
- final_dest - Variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- FINAL_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
-
- finalizer_task - Variable in class org.jgroups.util.ResponseCollectorTask
-
- find(IpAddress) - Method in class org.jgroups.stack.RouterStubManager
-
- find(Address) - Method in class org.jgroups.util.Digest
-
- find(PingData) - Method in class org.jgroups.util.Responses
-
- FIND_INITIAL_MBRS - Static variable in class org.jgroups.Event
-
- FIND_INITIAL_MBRS_EVT - Static variable in class org.jgroups.Event
-
- FIND_MBRS - Static variable in class org.jgroups.Event
-
- FIND_MBRS_EVT - Static variable in class org.jgroups.Event
-
- findAndNotify() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- findClassesAnnotatedWith(String, Class<? extends Annotation>) - Static method in class org.jgroups.util.Util
-
- findClassesAssignableFrom(String, Class<T>) - Static method in class org.jgroups.util.Util
-
- findField(Object, List<String>) - Static method in class org.jgroups.util.Util
-
- findFields() - Method in class org.jgroups.jmx.ResourceDMBean
-
- findGetter(Object, String) - Static method in class org.jgroups.jmx.ResourceDMBean
-
Finds an accessor for an attribute.
- findHighestSeqno(List<Tuple<Long, T>>) - Method in class org.jgroups.util.Table
-
- findInitialMembersAsString() - Method in class org.jgroups.protocols.Discovery
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.Discovery
-
Fetches information (e.g.
- findMembers(List<Address>, boolean, boolean) - Method in class org.jgroups.protocols.Discovery
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.FILE_PING
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.JDBC_PING
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.PING
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.SHARED_LOOPBACK_PING
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.TCPGOSSIP
-
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.TCPPING
-
- findMethod(Class, String, Object[]) - Static method in class org.jgroups.blocks.MethodCall
-
Called by the ProbeHandler impl.
- findMethod(short) - Method in interface org.jgroups.blocks.MethodLookup
-
- findMethod(Class<?>, String, Class<?>...) - Static method in class org.jgroups.protocols.UDP
-
- findMethod(Object, List<String>, Class<?>...) - Static method in class org.jgroups.util.Util
-
- findMethod(Class<?>, List<String>, Class<?>...) - Static method in class org.jgroups.util.Util
-
- findMethods() - Method in class org.jgroups.jmx.ResourceDMBean
-
- findProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Returns a given protocol or null if not found
- findProtocol(Class<?>) - Method in class org.jgroups.stack.ProtocolStack
-
- findProtocol(Class<?>...) - Method in class org.jgroups.stack.ProtocolStack
-
Finds the first protocol of a list and returns it.
- findProtocolAbove(Class<? extends Protocol>) - Method in class org.jgroups.protocols.KeyExchange
-
- findResponseFrom(Address) - Method in class org.jgroups.util.Responses
-
- findSetter(Object, String) - Static method in class org.jgroups.jmx.ResourceDMBean
-
Finds an accessor for an attribute.
- FindSubgroupsTask() - Constructor for class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- finishConnect() - Method in class org.jgroups.nio.MockSocketChannel
-
- first - Variable in class org.jgroups.protocols.SCOPE.QueueThread
-
Deprecated.
- first() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- first() - Method in class org.jgroups.util.MessageBatch
-
- first - Variable in class org.jgroups.util.OneTimeAddressGenerator
-
- first - Variable in class org.jgroups.util.Table.Dump
-
- first_view_sent - Variable in class org.jgroups.protocols.pbcast.GMS
-
- firstOfAllClients(Address, Responses) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
Handles the case where no coord responses were received.
- fixDigests() - Method in class org.jgroups.protocols.pbcast.GMS
-
- fixDigests() - Method in class org.jgroups.protocols.pbcast.Merger
-
Fetches the digests from all members and installs them again.
- fixed - Variable in class org.jgroups.demos.wb.Node
-
- FixedMembershipToken - Class in org.jgroups.auth
-
The FixedMemberShipToken object predefines a list of IP addresses and ports that can join the group.
- FixedMembershipToken() - Constructor for class org.jgroups.auth.FixedMembershipToken
-
- FixedMembershipToken(String) - Constructor for class org.jgroups.auth.FixedMembershipToken
-
- FixedSizeBitSet - Class in org.jgroups.util
-
Class copied from BitSet
.
- FixedSizeBitSet() - Constructor for class org.jgroups.util.FixedSizeBitSet
-
- FixedSizeBitSet(int) - Constructor for class org.jgroups.util.FixedSizeBitSet
-
Creates a bit set whose initial size is the range 0
through
size-1
.
- fixFields() - Method in class org.jgroups.jmx.ResourceDMBean
-
Provides field-based getter and/or setters for all attributes in atts if not present
- flags - Variable in class org.jgroups.blocks.RequestOptions
-
The flags set in the message in which a request is sent
- flags - Variable in class org.jgroups.Message
-
- flags - Variable in class org.jgroups.protocols.PingData
-
- flags - Variable in class org.jgroups.util.ExtendedUUID
-
- flags - Variable in class org.jgroups.util.Rsp
-
- flagsToString(short) - Static method in class org.jgroups.Message
-
- flagsToString() - Method in class org.jgroups.util.ExtendedUUID
-
- flip() - Method in class org.jgroups.util.FixedSizeBitSet
-
Flips all bits: 1 --> 0 and 0 --> 1
- FLOAT_SIZE - Static variable in class org.jgroups.Global
-
- FlowControl - Class in org.jgroups.protocols
-
Simple flow control protocol based on a credit system.
- FlowControl() - Constructor for class org.jgroups.protocols.FlowControl
-
- FlowControl.Credit - Class in org.jgroups.protocols
-
- flush() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- flush() - Method in class org.jgroups.blocks.GridOutputStream
-
- FLUSH - Static variable in class org.jgroups.Global
-
- FLUSH - Class in org.jgroups.protocols.pbcast
-
Flush, as it name implies, forces group members to flush their pending messages while blocking
them to send any additional messages.
- FLUSH() - Constructor for class org.jgroups.protocols.pbcast.FLUSH
-
- flush(Address) - Method in class org.jgroups.protocols.SEQUENCER
-
- FLUSH - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- flush(Address, List<Address>) - Method in class org.jgroups.util.ForwardQueue
-
- flush() - Method in class org.jgroups.util.OutputStreamAdapter
-
- FLUSH.FlushHeader - Class in org.jgroups.protocols.pbcast
-
- flush_ack - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- FLUSH_BYPASS - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FLUSH_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FLUSH_NOT_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FLUSH_RECONCILE - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FLUSH_RECONCILE_OK - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- flush_supported - Variable in class org.jgroups.JChannel
-
True if a flush protocol is available, false otherwise (set by CONFIG event from FLUSH protocol)
- flush_timeout - Variable in class org.jgroups.protocols.BARRIER
-
- flushAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
-
- flushBase64() - Method in class org.jgroups.util.Base64.OutputStream
-
Method added by PHIL.
- flushBecomeServerQueue() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Flushes the queue.
- flushBecomeServerQueue() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Flushes the queue.
- flusher - Variable in class org.jgroups.protocols.SEQUENCER
-
- Flusher(Address) - Constructor for class org.jgroups.protocols.SEQUENCER.Flusher
-
- flusher - Variable in class org.jgroups.util.ForwardQueue
-
- Flusher(Address) - Constructor for class org.jgroups.util.ForwardQueue.Flusher
-
- FlushHeader() - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FlushHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- FlushHeader(byte, long) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- flushing - Variable in class org.jgroups.protocols.SEQUENCER
-
Set when we block all sending threads to resend all messages from forward_table
- flushing - Variable in class org.jgroups.util.ForwardQueue
-
Set when we block all sending threads to resend all messages from forward_table
- FlushInvoker() - Constructor for class org.jgroups.conf.PropertyConverters.FlushInvoker
-
- flushInvokerClass - Variable in class org.jgroups.protocols.pbcast.GMS
-
- flushMessagesInForwardTable() - Method in class org.jgroups.protocols.SEQUENCER
-
Sends all messages currently in forward_table to the new coordinator (changing the dest field).
- flushMessagesInForwardTable(Address) - Method in class org.jgroups.util.ForwardQueue
-
Sends all messages currently in forward_table to the new target (changing the dest field).
- flushProtocolInStack - Variable in class org.jgroups.protocols.pbcast.GMS
-
- flushProtocolInStack - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- flushProtocolInStack - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- flushQueue(Map<Address, Message>) - Method in class org.jgroups.protocols.BARRIER
-
- flushSupported() - Method in class org.jgroups.Channel
-
- flushSupported() - Method in class org.jgroups.JChannel
-
- focusGained(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- focusLost(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
-
- foo() - Method in class org.jgroups.demos.JmxDemo
-
- foobar() - Method in class org.jgroups.demos.JmxDemo
-
- forAny(RouterStubManager.Consumer) - Method in class org.jgroups.stack.RouterStubManager
-
Applies action to a randomly picked RouterStub that's connected
- force_sending_discovery_rsps - Variable in class org.jgroups.protocols.Discovery
-
- force_sending_discovery_rsps - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- forceCancelMerge() - Method in class org.jgroups.protocols.pbcast.Merger
-
- forceDiscoveryResponses() - Method in class org.jgroups.protocols.Discovery
-
- forceDiscoveryResponses(boolean) - Method in class org.jgroups.protocols.Discovery
-
- forEach(RouterStubManager.Consumer) - Method in class org.jgroups.stack.RouterStubManager
-
Applies action to all RouterStubs that are connected
- forEach(RequestTable.Visitor<T>) - Method in class org.jgroups.util.RequestTable
-
- forEach(long, long, Table.Visitor<T>) - Method in class org.jgroups.util.Table
-
Iterates over the matrix with range [from ..
- forEachNonBlocking(RequestTable.Visitor<T>) - Method in class org.jgroups.util.RequestTable
-
- FORK - Class in org.jgroups.protocols
-
The FORK protocol; multiplexes messages to different forks in a stack (https://issues.jboss.org/browse/JGRP-1613).
- FORK() - Constructor for class org.jgroups.protocols.FORK
-
- FORK.ForkHeader - Class in org.jgroups.protocols
-
- fork_channel_id - Variable in class org.jgroups.fork.ForkChannel
-
- fork_channel_id - Variable in class org.jgroups.protocols.FORK.ForkHeader
-
- fork_channels - Variable in class org.jgroups.fork.ForkProtocolStack
-
- FORK_STACK - Static variable in class org.jgroups.fork.ForkConfig
-
- fork_stack_id - Variable in class org.jgroups.fork.ForkProtocol
-
- fork_stack_id - Variable in class org.jgroups.fork.ForkProtocolStack
-
- fork_stack_id - Variable in class org.jgroups.protocols.FORK.ForkHeader
-
- FORK_STACKS - Static variable in class org.jgroups.fork.ForkConfig
-
- fork_stacks - Variable in class org.jgroups.protocols.FORK
-
- ForkChannel - Class in org.jgroups.fork
-
Implementation of a ForkChannel, which is a light-weight channel.
- ForkChannel(Channel, String, String, boolean, int, Class<? extends Protocol>, Protocol...) - Constructor for class org.jgroups.fork.ForkChannel
-
Creates a new fork-channel from a main-channel.
- ForkChannel(Channel, String, String, Protocol...) - Constructor for class org.jgroups.fork.ForkChannel
-
Creates a new fork-channel from a main-channel.
- ForkConfig - Class in org.jgroups.fork
-
Parses the fork-stacks.xsd schema.
- ForkHeader() - Constructor for class org.jgroups.protocols.FORK.ForkHeader
-
- ForkHeader(String, String) - Constructor for class org.jgroups.protocols.FORK.ForkHeader
-
- ForkProtocol - Class in org.jgroups.fork
-
Acts as bottom protool of a fork-stack.
- ForkProtocol(String) - Constructor for class org.jgroups.fork.ForkProtocol
-
- ForkProtocolStack - Class in org.jgroups.fork
-
Protocol stack which maintains the mapping between fork-channel IDs and ForkChannels
- ForkProtocolStack(UnknownForkHandler, List<Protocol>, String) - Constructor for class org.jgroups.fork.ForkProtocolStack
-
- format(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- format(double) - Static method in class org.jgroups.util.Util
-
- FORWARD - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
-
- forward(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
-
Forwards the message across the TCP link to the other local cluster
- forward(Message, long, boolean) - Method in class org.jgroups.protocols.SEQUENCER
-
- FORWARD - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- forward_non_client_generated_msgs - Variable in class org.jgroups.protocols.STOMP
-
- forward_sm_time - Variable in class org.jgroups.protocols.relay.RELAY2
-
- forward_table - Variable in class org.jgroups.protocols.SEQUENCER
-
Maintains messages forwarded to the coord which which no ack has been received yet.
- forward_table - Variable in class org.jgroups.util.ForwardQueue
-
Maintains messages forwarded to the target which which no ack has been received yet.
- FORWARD_TO_COORD - Static variable in class org.jgroups.Event
-
- FORWARD_TO_COORD - Class in org.jgroups.protocols
-
Forwards a message to the current coordinator.
- FORWARD_TO_COORD() - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD
-
- FORWARD_TO_COORD.ForwardHeader - Class in org.jgroups.protocols
-
- forward_to_local_mbr - Variable in class org.jgroups.protocols.relay.RELAY2
-
Number of messages (received from a remote Sitemaster and) delivered by the local SiteMaster to a local node
- forward_to_local_mbr_time - Variable in class org.jgroups.protocols.relay.RELAY2
-
- forward_to_site_master - Variable in class org.jgroups.protocols.relay.RELAY2
-
Number of messages forwarded to the local SiteMaster
- ForwardConfig(String, String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- forwarded_msgs - Variable in class org.jgroups.protocols.SEQUENCER
-
- ForwardHeader() - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- ForwardHeader(byte, long) - Constructor for class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- forwarding_protocol_present - Variable in class org.jgroups.protocols.relay.RELAY2
-
Whether or not FORWARD_TO_COORD is on the stack
- ForwardQueue - Class in org.jgroups.util
-
Forwards messages in FIFO order to a destination.
- ForwardQueue(Log) - Constructor for class org.jgroups.util.ForwardQueue
-
- ForwardQueue.Flusher - Class in org.jgroups.util
-
- FORWARDS - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
-
- forwards - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- forwardTo(Address, SiteAddress, Address, Message, boolean) - Method in class org.jgroups.protocols.relay.RELAY2
-
- forwardToCoord(Message) - Method in class org.jgroups.protocols.RELAY
-
Wraps the message annd sends it to the current coordinator
- forwardToCoord(long, Message) - Method in class org.jgroups.protocols.SEQUENCER
-
- FRAG - Class in org.jgroups.protocols
-
Fragmentation layer.
- FRAG() - Constructor for class org.jgroups.protocols.FRAG
-
- FRAG2 - Class in org.jgroups.protocols
-
Fragmentation layer.
- FRAG2() - Constructor for class org.jgroups.protocols.FRAG2
-
- FRAG2.FragEntry - Class in org.jgroups.protocols
-
Class represents an entry for a message.
- frag_id - Variable in class org.jgroups.protocols.FragHeader
-
- frag_size - Variable in class org.jgroups.protocols.FlowControl
-
- frag_size - Variable in class org.jgroups.protocols.FRAG2
-
- frag_size - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- FragEntry(int) - Constructor for class org.jgroups.protocols.FRAG2.FragEntry
-
Creates a new entry
- FragHeader - Class in org.jgroups.protocols
-
- FragHeader() - Constructor for class org.jgroups.protocols.FragHeader
-
- FragHeader(long, int, int) - Constructor for class org.jgroups.protocols.FragHeader
-
- fragment(Message) - Method in class org.jgroups.protocols.FRAG2
-
Send all fragments as separate messages (with same ID !).
- fragment_list - Variable in class org.jgroups.protocols.FRAG2
-
- fragmentBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
-
Fragments a byte buffer into smaller fragments of (max.) frag_size.
- fragSize() - Method in class org.jgroups.protocols.FRAG2
-
- fragSize(int) - Method in class org.jgroups.protocols.FRAG2
-
- Frame(String, Map<String, String>, byte[]) - Constructor for class org.jgroups.protocols.STOMP.Frame
-
- from - Variable in class org.jgroups.protocols.FD.FdHeader
-
- fromString(String) - Static method in class org.jgroups.util.UUID
-
Creates a
UUID
from the string standard representation as
described in the
UUID.toString()
method.
- function - Variable in class org.jgroups.util.Runner
-
- FUNCTIONAL - Static variable in class org.jgroups.Global
-
- future - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
The containing future
- future - Variable in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- future - Variable in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- futureDone(Future<V>) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService.QueueingListener
-
- futureDone(Future<T>) - Method in interface org.jgroups.util.FutureListener
-
- FutureListener<T> - Interface in org.jgroups.util
-
A listener that is called back when a future is done.
- futures - Variable in class org.jgroups.stack.RouterStubManager
-
- fwd_queue - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
-
- fwd_queue - Variable in class org.jgroups.protocols.SEQUENCER2
-
- gateway - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- gc() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- generateAddress() - Method in class org.jgroups.JChannel
-
- generateAddress() - Method in interface org.jgroups.stack.AddressGenerator
-
- generateAddress() - Method in class org.jgroups.util.OneTimeAddressGenerator
-
- generateArray(int) - Static method in class org.jgroups.util.Util
-
- generateGlobalView(View, View) - Method in class org.jgroups.protocols.RELAY
-
- generateGlobalView(View, View, boolean) - Method in class org.jgroups.protocols.RELAY
-
- generateLocalName() - Static method in class org.jgroups.util.Util
-
- generatePreSignedUrl(String, String, String, String, String, long) - Static method in class org.jgroups.protocols.S3_PING
-
Use this helper method to generate pre-signed S3 urls for use with S3_PING.
- generateProtocolSchema(Document, Element, String...) - Static method in class org.jgroups.util.XMLSchemaGenerator
-
- generatePubKey(byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Used to reconstitute public key sent in byte form from peer
- generateRandomBytes() - Static method in class org.jgroups.auth.DemoToken
-
- generateRandomBytes() - Static method in class org.jgroups.util.UUID
-
- generateSecuritySubject(String, String, String) - Method in class org.jgroups.auth.Krb5TokenUtils
-
- get() - Method in interface org.jgroups.blocks.atomic.Counter
-
Gets the current value of the counter
- get(K) - Method in class org.jgroups.blocks.Cache
-
- get() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- get(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- get() - Method in class org.jgroups.blocks.GroupRequest
-
- get(long, TimeUnit) - Method in class org.jgroups.blocks.GroupRequest
-
- get(K) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- get(short) - Method in interface org.jgroups.blocks.mux.Muxer
-
Gets the handler registered under the specified id
- get(short) - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
Gets the handler registered under the specified id
- get(K) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- get(K) - Method in class org.jgroups.blocks.ReplCache
-
Returns the value associated with key
- get(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- get(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Finds a node given its name and returns the value associated with a given key in its data
map.
- get() - Method in class org.jgroups.blocks.UnicastRequest
-
- get(long, TimeUnit) - Method in class org.jgroups.blocks.UnicastRequest
-
- get(short) - Static method in class org.jgroups.conf.ClassConfigurator
-
Returns a class for a magic number.
- get(String, ClassLoader) - Static method in class org.jgroups.conf.ClassConfigurator
-
Loads and returns the class from the class name
- get(String) - Static method in class org.jgroups.conf.ClassConfigurator
-
- get(String) - Method in class org.jgroups.fork.ForkProtocolStack
-
- get(Address) - Method in class org.jgroups.MergeView
-
- get(int) - Method in class org.jgroups.nio.Buffers
-
- get() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- get() - Method in class org.jgroups.protocols.FlowControl.Credit
-
- get(String) - Method in class org.jgroups.protocols.FORK
-
- get() - Method in class org.jgroups.protocols.tom.SequenceNumberManager
-
- get(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns the message from xmit_table
- get(long, long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns a list of messages in the range [from ..
- get(Address) - Method in class org.jgroups.util.CreditMap
-
- get() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- get(long, TimeUnit) - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- get(Address) - Method in class org.jgroups.util.Digest
-
Returns the highest delivered and received seqnos associated with a member.
- get(byte[]) - Method in class org.jgroups.util.ExtendedUUID
-
- get(String) - Method in class org.jgroups.util.ExtendedUUID
-
- get(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the value of the bit with the specified index.
- get() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- get(long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- get() - Method in class org.jgroups.util.ImmutableReference
-
Gets the wrapped object, if there is one.
- get() - Method in class org.jgroups.util.NullFuture
-
- get(long, TimeUnit) - Method in class org.jgroups.util.NullFuture
-
- get() - Method in class org.jgroups.util.Pool
-
Gets the next available resource for which the lock can be acquired and returns it and its associated
lock, which needs to be released when the caller is done using the resource.
- get(long) - Method in class org.jgroups.util.RequestTable
-
- get(long) - Method in class org.jgroups.util.Responses
-
Deprecated.
- get(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- get(long, long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- get(long) - Method in class org.jgroups.util.RingBufferSeqno
-
- get(long, long) - Method in class org.jgroups.util.RingBufferSeqno
-
Returns a list of messages in the range [from ..
- get(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- get(long, long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Returns a list of messages in the range [from ..
- get(Object) - Method in class org.jgroups.util.RspList
-
Returns the Rsp associated with address key
- get(long) - Method in class org.jgroups.util.Seqno
-
- get(long) - Method in class org.jgroups.util.SeqnoRange
-
- get(long) - Method in class org.jgroups.util.Table
-
Returns an element at seqno
- get(long, long) - Method in class org.jgroups.util.Table
-
- get() - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- get(long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- get() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- get(long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
-
- get(Address) - Static method in class org.jgroups.util.UUID
-
- get(int) - Method in class org.jgroups.View
-
- GET_APPLSTATE - Static variable in class org.jgroups.Event
-
- GET_CACHE - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- get_cache_promise - Variable in class org.jgroups.protocols.FD_SOCK
-
Used to rendezvous on GET_CACHE and GET_CACHE_RSP
- GET_CACHE_RSP - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- get_cache_timeout - Variable in class org.jgroups.protocols.FD_SOCK
-
- GET_CURRENT_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GET_DIGEST - Static variable in class org.jgroups.Event
-
- GET_DIGEST_EVT - Static variable in class org.jgroups.Event
-
- GET_DIGEST_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GET_DIGEST_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
-
- GET_LOGICAL_PHYSICAL_MAPPINGS - Static variable in class org.jgroups.Event
-
- GET_MBRS_REQ - Static variable in class org.jgroups.protocols.PingHeader
-
- GET_MBRS_RSP - Static variable in class org.jgroups.protocols.PingHeader
-
- get_members_map - Variable in class org.jgroups.stack.RouterStub
-
- GET_PHYSICAL_ADDRESS - Static variable in class org.jgroups.Event
-
- GET_PHYSICAL_ADDRESSES - Static variable in class org.jgroups.Event
-
- GET_PING_DATA - Static variable in class org.jgroups.Event
-
- GET_SECRET_KEY - Static variable in class org.jgroups.Event
-
- GET_STATE - Static variable in class org.jgroups.Event
-
- GET_STATE_OK - Static variable in class org.jgroups.Event
-
- GET_USERS - Static variable in class org.jgroups.demos.StompChat
-
- GET_VIEW_FROM_COORD - Static variable in class org.jgroups.Event
-
- getAccountNumber() - Method in class org.jgroups.demos.JmxDemo
-
- getAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
-
- getAddress() - Method in class org.jgroups.Channel
-
Returns the channel's own address.
- getAddress() - Method in class org.jgroups.JChannel
-
- getAddress() - Method in class org.jgroups.protocols.AUTH
-
- getAddress() - Method in class org.jgroups.protocols.COUNTER
-
- getAddress() - Method in class org.jgroups.protocols.Executing
-
- getAddress() - Method in class org.jgroups.protocols.Executing.Owner
-
- getAddress() - Method in class org.jgroups.protocols.Locking
-
- getAddress() - Method in class org.jgroups.protocols.PingData
-
- getAddress() - Method in class org.jgroups.protocols.SASL
-
- getAddress() - Method in class org.jgroups.protocols.tom.MessageID
-
- getAddress() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getAddress() - Method in class org.jgroups.stack.GossipData
-
- getAddress() - Method in class org.jgroups.util.Owner
-
- getAddress() - Method in class org.jgroups.util.SingletonAddress
-
- getAddress(Util.AddressScope) - Static method in class org.jgroups.util.Util
-
Returns the first address on any interface of the current host, which satisfies scope
- getAddress(NetworkInterface, Util.AddressScope) - Static method in class org.jgroups.util.Util
-
Returns the first address on the given interface on the current host, which satisfies scope
- getAddressAsString() - Method in class org.jgroups.JChannel
-
- getAddressAsString() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getAddressAsUUID() - Method in class org.jgroups.JChannel
-
- getAddressAsUUID() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getAddressByPatternMatch(String) - Static method in class org.jgroups.util.Util
-
Returns a valid interface address based on a pattern.
- getAddresses() - Method in class org.jgroups.AnycastAddress
-
- getAddresses(Map<String, Map<String, Configurator.InetAddressInfo>>) - Static method in class org.jgroups.stack.Configurator
-
Returns all inet addresses found
- getAddressGenerator() - Method in class org.jgroups.JChannel
-
- getAgeOf(InetAddress) - Method in class org.jgroups.protocols.FD_HOST
-
Returns the age (in secs) of the given host
- getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST3
-
- getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST3
-
- getAlgorithm(String) - Static method in class org.jgroups.protocols.EncryptBase
-
- getAllAvailableAddresses() - Static method in class org.jgroups.util.Util
-
- getAllAvailableInterfaces() - Static method in class org.jgroups.util.Util
-
- getAllDeclaredFields(Class) - Static method in class org.jgroups.util.Util
-
- getAllDeclaredFieldsWithAnnotations(Class, Class<? extends Annotation>...) - Static method in class org.jgroups.util.Util
-
- getAllDeclaredMethodsWithAnnotations(Class, Class<? extends Annotation>...) - Static method in class org.jgroups.util.Util
-
- getAllEndpoints() - Method in class org.jgroups.protocols.STOMP
-
- getAllPhysicalAddressesFromCache() - Method in class org.jgroups.protocols.TP
-
- getAllStocks() - Method in class org.jgroups.demos.QuoteServer
-
- getAndDecrementRound() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- getAndIncrement() - Method in class org.jgroups.protocols.tom.SequenceNumberManager
-
- getAnnotation(Class<?>, Class<A>) - Static method in class org.jgroups.util.Util
-
- getAnycastDelivered() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAnycasting() - Method in class org.jgroups.blocks.RequestOptions
-
- getArg() - Method in class org.jgroups.Event
-
- getArgs() - Method in class org.jgroups.blocks.MethodCall
-
returns an ordered list of arguments used for the method invokation
- getAsymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getAsymCipher() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getAsymInit() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getAttribute(String) - Method in class org.jgroups.jmx.ResourceDMBean
-
- getAttributes(String[]) - Method in class org.jgroups.jmx.ResourceDMBean
-
- getAuthClass() - Method in class org.jgroups.protocols.AUTH
-
- getAuthorizationID() - Method in class org.jgroups.auth.sasl.SaslServerContext
-
- getAuthToken() - Method in class org.jgroups.protocols.AUTH
-
- getAuthValue() - Method in class org.jgroups.auth.MD5Token
-
- getAuthValue() - Method in class org.jgroups.auth.SimpleToken
-
- getAverage() - Method in class org.jgroups.util.Average
-
- getAverageBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- getAverageBlockTime() - Method in class org.jgroups.util.CreditMap
-
- getAverageFlushDuration() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.FlowControl
-
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.MFC
-
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.UFC
-
- getAvgAnycastSentDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgBatchSize() - Method in class org.jgroups.protocols.TP
-
- getAvgDataMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgDataMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
-
- getAvgDeliveryTime() - Method in class org.jgroups.protocols.DELIVERY_TIME
-
- getAvgFinalMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgFinalMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
-
- getAvgLastProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgLastProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
-
- getAvgMsgsDeliveringLocally() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getAvgMsgsForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getAvgMsgsForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getAvgMsgsRelaying() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getAvgNumberOfUnicastSentPerAnycast() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgNumberOfUnicastSentPerAnycast() - Method in class org.jgroups.protocols.tom.TOA
-
- getAvgProposeMesageReceivedDuration() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getAvgProposeMessageReceivedDuration() - Method in class org.jgroups.protocols.tom.TOA
-
- getAvgToaSendDuration() - Method in class org.jgroups.protocols.tom.TOA
-
- getBackupCoords() - Method in class org.jgroups.protocols.COUNTER
-
- getBackups() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- getBackups() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- getBecomeServerQueueSizeActual() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getBindAddr() - Method in class org.jgroups.protocols.MPING
-
- getBindAddress() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getBindAddress() - Method in class org.jgroups.protocols.TP
-
- getBindPort() - Method in class org.jgroups.protocols.BPING
-
- getBindPort() - Method in class org.jgroups.protocols.TP
-
- getBits(boolean) - Method in class org.jgroups.util.SeqnoRange
-
Returns ranges of all bit set to value
- getBody() - Method in class org.jgroups.protocols.STOMP.Frame
-
- getBottomProtocol() - Method in class org.jgroups.stack.ProtocolStack
-
- getBridge(String) - Method in class org.jgroups.protocols.relay.RELAY2
-
Returns the bridge channel to a given site
- getBridges() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- getBridgeView() - Method in class org.jgroups.protocols.RELAY
-
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.RELAY2
-
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.Relayer
-
- getBroadcast() - Method in class org.jgroups.protocols.SEQUENCER
-
- getBroadcast() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getBroadcastsSent() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getBuf() - Method in class org.jgroups.util.Buffer
-
- getBuffer(ByteBuffer) - Static method in class org.jgroups.blocks.cs.NioConnection
-
- getBuffer() - Method in class org.jgroups.Message
-
Returns a copy of the buffer if offset and length are used, otherwise a reference.
- getBuffer() - Method in class org.jgroups.stack.GossipData
-
- getBuffer() - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- getBuffer() - Method in class org.jgroups.util.ByteBufferOutputStream
-
- getBuffer() - Method in class org.jgroups.util.StateTransferResult
-
- getBufferAsBuffer() - Method in class org.jgroups.util.ByteBufferOutputStream
-
- getBufferSize() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- getBundler() - Method in class org.jgroups.protocols.TP
-
- getBundlerBufferSize() - Method in class org.jgroups.protocols.TP
-
- getBundlerCapacity() - Method in class org.jgroups.protocols.TP
-
- getBundlerClass() - Method in class org.jgroups.protocols.TP
-
- getByName(String) - Static method in class org.jgroups.util.Util
-
Finds a network interface of sub-interface with the given name
- getByName(String) - Static method in class org.jgroups.util.UUID
-
- getBypassBundling() - Method in class org.jgroups.protocols.COUNTER
-
- getBypassBundling() - Method in class org.jgroups.protocols.Executing
-
- getBypassBundling() - Method in class org.jgroups.protocols.Locking
-
- getByteAt(long, int) - Static method in class org.jgroups.util.Bits
-
- getByteBuffer() - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- getBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getByValue(V) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- getCache() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getCache() - Method in class org.jgroups.util.SuppressLog
-
- getCacheFromCoordinator() - Method in class org.jgroups.protocols.FD_SOCK
-
Determines coordinator C.
- getCachingTime() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getCachingTime() - Method in class org.jgroups.blocks.ReplCache
-
- getCallable() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- getCallTimeout() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getCallTimeout() - Method in class org.jgroups.blocks.ReplCache
-
- getChannel() - Method in class org.jgroups.blocks.MessageDispatcher
-
- getChannel() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- getChannel() - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns the Channel the DistributedTree is connected to
- getChannel() - Method in class org.jgroups.stack.ProtocolStack
-
- getChildrenNames(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns all children of a given node
- getChunkSize() - Method in class org.jgroups.blocks.GridFile
-
- getChunkSize() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- getClassForName(String) - Static method in class org.jgroups.jmx.ResourceDMBean
-
- getClassLoader() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getClientCallbackHandler() - Method in class org.jgroups.protocols.SASL
-
- getClientCallbackHandlerClass() - Method in class org.jgroups.protocols.SASL
-
- getClientSubject() - Method in class org.jgroups.protocols.SASL
-
- getClusterName() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getClusterName() - Method in class org.jgroups.blocks.ReplCache
-
- getClusterName() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- getClusterName() - Method in class org.jgroups.Channel
-
Returns the cluster name of the group of which the channel is a member.
- getClusterName() - Method in class org.jgroups.demos.Draw
-
- getClusterName() - Method in class org.jgroups.JChannel
-
- getClusterName() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
-
- getClusterName() - Method in class org.jgroups.protocols.TP
-
- getClusterName(Message) - Method in class org.jgroups.protocols.TP
-
- getClusterName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getClusterName() - Method in class org.jgroups.protocols.TP.SingleMessageHandler
-
- getClusterName() - Method in class org.jgroups.protocols.TP.SingleMessageHandlerWithClusterName
-
- getClusterName() - Method in class org.jgroups.util.SingletonAddress
-
- getClusterNameAscii() - Method in class org.jgroups.protocols.TP
-
- getClusterSize() - Method in class org.jgroups.blocks.ReplCache
-
- getConfigStream(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
- getConfigStream(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
- getConfigStream(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a JGroups XML configuration InputStream based on the provided properties string.
- getConfigStream(Object) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
- getConfigurableObjects() - Method in class org.jgroups.protocols.AUTH
-
- getConfigurableObjects() - Method in class org.jgroups.stack.Protocol
-
After configuring the protocol itself from the properties defined in the XML config, a protocol might have
additional objects which need to be configured.
- getConnection(Address) - Method in class org.jgroups.blocks.cs.BaseServer
-
Creates a new connection to dest, or returns an existing one
- getConnection() - Method in class org.jgroups.protocols.JDBC_PING
-
- getConnectionTable(long, long, InetAddress, InetAddress, int, int, int) - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getConnects() - Method in class org.jgroups.fork.ForkProtocolStack
-
- getConnExpireTime() - Method in class org.jgroups.protocols.BasicTCP
-
- getConnId() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- getContents() - Static method in class org.jgroups.util.UUID
-
Returns a copy of the cache's contents
- getContext() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- getConvertedValue(Object, Field, Map<String, String>, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
-
- getConvertedValue(Object, Field, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
-
- getConvertedValue(Object, Method, Map<String, String>, String, boolean) - Static method in class org.jgroups.conf.PropertyHelper
-
- getCoord() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- getCoord() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- getCoord() - Method in class org.jgroups.View
-
- getCoordinator(Message, GMS.GmsHeader) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Tries to find out if this is a JOIN_RSP or INSTALL_MERGE_VIEW message and returns the coordinator of the view
- getCoordinator() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- getCoordinator() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
-
- getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getCoordinator(View) - Static method in class org.jgroups.util.Util
-
- getCount() - Method in class org.jgroups.util.Average
-
- getCounter(String) - Method in class org.jgroups.protocols.COUNTER
-
- getCreator() - Method in class org.jgroups.View
-
Returns the creator of this view
if this view was created with the empty constructur, null will be returned
- getCreator() - Method in class org.jgroups.ViewId
-
Returns the address of the member that issued this view
- getCreditRequestHeader() - Method in class org.jgroups.protocols.FlowControl
-
- getCreditRequestHeader() - Method in class org.jgroups.protocols.MFC
-
- getCreditRequestHeader() - Method in class org.jgroups.protocols.UFC
-
- getCurrentCoord() - Method in class org.jgroups.protocols.Discovery
-
- getCurrentCoord() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- getCurrentNumTries() - Method in class org.jgroups.protocols.FD
-
- getCurrentRunningTasks() - Method in class org.jgroups.blocks.executor.ExecutionRunner
-
Returns a copy of the runners being used with the runner and what threads.
- getCurrentSeqno() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getCurrentSeqno() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getCurrentThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- getCurrentThreads() - Method in class org.jgroups.util.HashedTimingWheel
-
- getCurrentThreads() - Method in class org.jgroups.util.MockTimeScheduler
-
- getCurrentThreads() - Method in interface org.jgroups.util.TimeScheduler
-
Returns the current threads in the pool, or -1 if not applicable
- getCurrentThreads() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- getCurrentThreads() - Method in class org.jgroups.util.TimeScheduler3
-
- getCustomLogFactory() - Static method in class org.jgroups.logging.LogFactory
-
- getDataSourceFromJNDI(String) - Method in class org.jgroups.protocols.JDBC_PING
-
- getDefaultHandler() - Method in interface org.jgroups.blocks.mux.Muxer
-
Gets the handler for messages that have no mux header.
- getDefaultHandler() - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
- getDefaultReplicationCount() - Method in class org.jgroups.blocks.ReplCache
-
- getDefaultThreadPool() - Method in class org.jgroups.protocols.TP
-
- getDefaultThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
-
- getDelay(TimeUnit) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- getDelay(TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
-
- getDeliveryTableMaxSize() - Method in class org.jgroups.util.ForwardQueue
-
- getDeliveryTableSize() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- getDesiredAverageGossip() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getDesKey() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getDest() - Method in class org.jgroups.Message
-
- getDestination(MessageID) - Method in class org.jgroups.protocols.tom.SenderManager
-
obtains the destination set of a message
- getDestinations() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- getDifferentClusterMessages() - Method in class org.jgroups.protocols.TP
-
- getDifferentVersionMessages() - Method in class org.jgroups.protocols.TP
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.GMS
-
Grabs the current digest from NAKACK{2}
- getDigest() - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.MergeData
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Returns a message digest: for each member P the highest delivered and received seqno is added
- getDigest(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getDigest() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Returns a message digest: for each member P the highest delivered and received seqno is added
- getDigest(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- getDigest() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- getDigest() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns the lowest, highest delivered and highest received seqnos
- getDigest() - Method in class org.jgroups.util.RingBufferSeqno
-
- getDigest() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getDigest() - Method in class org.jgroups.util.Table
-
- getDiscardOwnMessages() - Method in class org.jgroups.Channel
-
Returns true if this channel will discard its own messages, false otherwise
- getDiscoveryResponsesFor(String) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- getDownDiscardRate() - Method in class org.jgroups.protocols.DISCARD
-
- getDownProt() - Method in class org.jgroups.util.ForwardQueue
-
- getDownProtocol() - Method in class org.jgroups.stack.Protocol
-
- getDownServices() - Method in class org.jgroups.stack.Protocol
-
Returns all services provided by protocols below the current protocol
- getDropDownMulticasts() - Method in class org.jgroups.protocols.DISCARD
-
- getDropDownUnicasts() - Method in class org.jgroups.protocols.DISCARD
-
- getDroppedMessage() - Method in class org.jgroups.protocols.UDP
-
- getDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
-
- getElement() - Method in class org.jgroups.util.Pool.Element
-
- getElements() - Method in class org.jgroups.util.Pool
-
- getElementsPerRow() - Method in class org.jgroups.util.Table
-
- getEndpoints() - Method in class org.jgroups.protocols.STOMP
-
- getEntry(K) - Method in class org.jgroups.blocks.Cache
-
- getEntry(ConcurrentMap<Address, ABP.Entry>, Address) - Method in class org.jgroups.protocols.ABP
-
- getException() - Method in class org.jgroups.util.Rsp
-
- getException() - Method in class org.jgroups.util.StateTransferResult
-
- getExclusionList() - Method in class org.jgroups.blocks.RequestOptions
-
Deprecated.
- getFailReason() - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- getField() - Method in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- getField(Class, String) - Static method in class org.jgroups.util.Util
-
- getField(Field, Object) - Static method in class org.jgroups.util.Util
-
- getFile(String) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFile(String, int) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFile(String, String) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFile(String, String, int) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFile(File, String) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFile(File, String, int) - Method in class org.jgroups.blocks.GridFilesystem
-
- getFillFactor() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Returns the ratio between size and capacity, as a percentage
- getFilter() - Method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
-
- getFirst() - Method in class org.jgroups.util.Queue
-
Returns the first element.
- getFirst() - Method in class org.jgroups.util.RspList
-
Returns the first value in the response set.
- getFirstMessage() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- getFlags() - Method in class org.jgroups.blocks.RequestOptions
-
- getFlags() - Method in class org.jgroups.Message
-
Returns the internal representation of flags.
- getFORK(Channel, int, Class<? extends Protocol>, boolean) - Static method in class org.jgroups.fork.ForkChannel
-
Creates a new FORK protocol, or returns the existing one, or throws an exception.
- getForkChannelId() - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- getForkChannels() - Method in class org.jgroups.fork.ForkProtocolStack
-
- getForkStack(Protocol) - Static method in class org.jgroups.protocols.FORK
-
- getForkStackId() - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- getForkStacks() - Method in class org.jgroups.protocols.FORK
-
- getForkStream(String) - Static method in class org.jgroups.protocols.FORK
-
- getForwarded() - Method in class org.jgroups.protocols.SEQUENCER
-
- getForwards() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- getForwardTableSize() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- getForwardTableSize() - Method in class org.jgroups.protocols.SEQUENCER
-
- getFragSize() - Method in class org.jgroups.protocols.FRAG
-
- getFragSize() - Method in class org.jgroups.protocols.FRAG2
-
- getFuture() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- getFwdQueueSize() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getGateway() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- getGlobalView() - Method in class org.jgroups.protocols.RELAY
-
- getGMSHeader(Event) - Static method in class org.jgroups.protocols.AUTH
-
Get the header from a GMS message
- getGMSHeader(Message) - Static method in class org.jgroups.protocols.AUTH
-
- getGroup() - Method in class org.jgroups.stack.GossipData
-
- getGroupMembersNumber() - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns the number of current members joined to the group
- getGroupName() - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns the name of the group that the DistributedTree is connected to
- getHandler() - Method in class org.jgroups.util.AgeOutCache
-
- getHashFunction() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getHashFunction() - Method in class org.jgroups.blocks.ReplCache
-
- getHashFunctionFactory() - Method in class org.jgroups.blocks.ReplCache
-
- getHashType() - Method in class org.jgroups.auth.MD5Token
-
- getHeader(short) - Method in class org.jgroups.Message
-
- getHeader(Header[], short) - Static method in class org.jgroups.util.Headers
-
Returns the header associated with an ID
- getHeaders() - Method in class org.jgroups.Message
-
Returns a reference to the headers hashmap, which is immutable.
- getHeaders() - Method in class org.jgroups.protocols.STOMP.Frame
-
- getHeaders(Header[]) - Static method in class org.jgroups.util.Headers
-
- getHeartbeatsReceived() - Method in class org.jgroups.protocols.FD_ALL
-
- getHeartbeatsReceived() - Method in class org.jgroups.protocols.FD_ALL2
-
- getHeartbeatsSent() - Method in class org.jgroups.protocols.FD_ALL
-
- getHeartbeatsSent() - Method in class org.jgroups.protocols.FD_ALL2
-
- getHigh() - Method in class org.jgroups.util.SeqnoRange
-
- getHighest() - Method in class org.jgroups.util.Digest.Entry
-
- getHighest() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- getHighestDeliverable() - Method in class org.jgroups.util.Table
-
Returns the highest deliverable (= removable) seqno.
- getHighestDelivered() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns the highest sequence number of a message consumed by the application (by remove()
).
- getHighestDelivered() - Method in class org.jgroups.util.RingBufferSeqno
-
- getHighestDelivered() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getHighestDelivered() - Method in class org.jgroups.util.Table
-
- getHighestDeliveredSeqno() - Method in class org.jgroups.util.Digest.Entry
-
- getHighestPurged() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- getHighestReceived() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns the highest sequence number received so far (which may be
higher than the highest seqno delivered so far; e.g., for
1,2,3,5,6 it would be 6.
- getHighestReceived() - Method in class org.jgroups.util.RingBufferSeqno
-
- getHighestReceived() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getHighestReceived() - Method in class org.jgroups.util.Table
-
- getHighestReceivedSeqno() - Method in class org.jgroups.util.Digest.Entry
-
- getHighSeqno() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- getHoles() - Method in class org.jgroups.protocols.BARRIER
-
- getHostFor(Address) - Method in class org.jgroups.protocols.FD_HOST
-
- getId() - Method in class org.jgroups.blocks.MethodCall
-
- getId() - Method in class org.jgroups.blocks.mux.MuxHeader
-
- getId() - Method in class org.jgroups.blocks.mux.NoMuxHandler
-
- getId() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- getId() - Method in class org.jgroups.stack.Protocol
-
- getId() - Method in class org.jgroups.ViewId
-
returns the lamport time of the view
- getIdsAbove() - Method in class org.jgroups.stack.Protocol
-
Returns the protocol IDs of all protocols above this one (excluding the current protocol)
- getIgnoredMembers() - Method in class org.jgroups.protocols.DISCARD
-
- getImpl() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getImplementation() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getIncomingCopies() - Method in class org.jgroups.protocols.DUPL
-
- getInDelay() - Method in class org.jgroups.protocols.DELAY
-
- getInDelayNanos() - Method in class org.jgroups.protocols.DELAY
-
- getIndex(long) - Method in class org.jgroups.util.SeqnoRange
-
- getInetAddresses(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
- getInetAddresses() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
-
- getInFlightThreadsCount() - Method in class org.jgroups.protocols.BARRIER
-
- getInfo() - Method in class org.jgroups.protocols.BasicTCP
-
- getInfo() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- getInfo() - Method in class org.jgroups.protocols.TP
-
- getInfo() - Method in class org.jgroups.protocols.TUNNEL
-
- getInfo() - Method in class org.jgroups.protocols.UDP
-
- getInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- getInitialHosts() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- getInitialHosts() - Method in class org.jgroups.protocols.TCPPING
-
Returns the list of initial hosts as configured by the user via XML.
- getInitialHostsList() - Method in class org.jgroups.protocols.TCPPING
-
- getInits() - Method in class org.jgroups.fork.ForkProtocolStack
-
- getInput(String) - Method in class org.jgroups.blocks.GridFilesystem
-
- getInput(File) - Method in class org.jgroups.blocks.GridFilesystem
-
- getInsertionTime() - Method in class org.jgroups.blocks.Cache.Value
-
- getInstance(URL) - Static method in class org.jgroups.conf.XmlConfigurator
-
- getInstance(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
-
- getInstance(Element) - Static method in class org.jgroups.conf.XmlConfigurator
-
- getInstance(URL, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
-
- getInstance(InputStream, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
-
- getInternalMap() - Method in class org.jgroups.blocks.Cache
-
This method should not be used to add or remove elements ! It was just added because ReplCacheDemo
requires it for its data model
- getInternalMaxQueueSize() - Method in class org.jgroups.protocols.TP
-
- getInternalMessages() - Method in class org.jgroups.protocols.TP
-
- getInternalPoolSize() - Method in class org.jgroups.protocols.TP
-
- getInternalPoolSizeActive() - Method in class org.jgroups.protocols.TP
-
- getInternalQueueSize() - Method in class org.jgroups.protocols.TP
-
- getInternalThreadPool() - Method in class org.jgroups.protocols.TP
-
- getInternalThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
-
- getInterval() - Method in class org.jgroups.protocols.FD_ALL
-
- getInterval() - Method in class org.jgroups.protocols.FD_ALL2
-
- getIpAddress() - Method in class org.jgroups.stack.IpAddress
-
- getIpStackType() - Static method in class org.jgroups.util.Util
-
- getJoinTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getKeepAliveTime() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- getKeepAliveTime() - Method in class org.jgroups.util.HashedTimingWheel
-
- getKeepAliveTime() - Method in class org.jgroups.util.MockTimeScheduler
-
- getKeepAliveTime() - Method in interface org.jgroups.util.TimeScheduler
-
Returns the keep alive time (in ms) of the thread pool, or -1 if not applicable
- getKeepAliveTime() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- getKeepAliveTime() - Method in class org.jgroups.util.TimeScheduler3
-
- getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Gets the keys of the data
map.
- getKeyServerAddr() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getKeyServerAddress() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- getKpair() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getL1Cache() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getL1Cache() - Method in class org.jgroups.blocks.ReplCache
-
- getL2Cache() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getL2Cache() - Method in class org.jgroups.blocks.ReplCache
-
- getLast() - Method in class org.jgroups.util.Queue
-
Returns the last element.
- getLast() - Method in class org.jgroups.util.SeqnoList
-
Returns the last seqno, this should also be the highest seqno in the list as we're supposed to add seqnos
in order
- getLastUpdate() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- getLeastSignificantBits() - Method in class org.jgroups.util.UUID
-
- getLeftMembers() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- getLength() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- getLength() - Method in class org.jgroups.Message
-
Returns the number of bytes in the buffer
- getLength() - Method in class org.jgroups.stack.GossipData
-
- getLength() - Method in class org.jgroups.util.Buffer
-
- getLength() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- getLevel() - Method in class org.jgroups.logging.JDKLogImpl
-
- getLevel() - Method in interface org.jgroups.logging.Log
-
- getLevel() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- getLevel() - Method in class org.jgroups.stack.Protocol
-
- getLinger() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getList() - Method in class org.jgroups.util.Table.Getter
-
- getList() - Method in class org.jgroups.util.Table.Remover
-
- getLocalAddr() - Method in class org.jgroups.util.ForwardQueue
-
- getLocalAddress() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getLocalAddress() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getLocalAddress() - Method in class org.jgroups.blocks.ReplCache
-
- getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedTree
-
- getLocalAddress() - Method in class org.jgroups.blocks.RequestCorrelator
-
- getLocalAddress() - Method in class org.jgroups.nio.MockSocketChannel
-
- getLocalAddress() - Method in class org.jgroups.protocols.FD
-
- getLocalAddress() - Method in class org.jgroups.protocols.FD_ALL
-
- getLocalAddress() - Method in class org.jgroups.protocols.FD_ALL2
-
- getLocalAddress() - Method in class org.jgroups.protocols.FD_SOCK
-
- getLocalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getLocalAddress() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getLocalAddress() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- getLocalAddress() - Method in class org.jgroups.protocols.SEQUENCER
-
- getLocalAddress() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getLocalAddress() - Method in class org.jgroups.protocols.TP
-
- getLocalAddress() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getLocalAddress() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getLocalAddress() - Method in class org.jgroups.protocols.UNICAST3
-
- getLocalAddressAsString() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getLocalAddressAsString() - Method in class org.jgroups.blocks.ReplCache
-
- getLocalhost(StackType) - Static method in class org.jgroups.util.Util
-
IP related utilities
- getLocalhost() - Static method in class org.jgroups.util.Util
-
- getLocalPhysicalAddress() - Method in class org.jgroups.protocols.TP
-
- getLocalView() - Method in class org.jgroups.protocols.RELAY
-
- getLocation() - Method in class org.jgroups.protocols.FILE_PING
-
- getLock(String) - Method in class org.jgroups.blocks.locking.LockService
-
- getLock(String, Owner, boolean) - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- getLock(String) - Method in class org.jgroups.protocols.Locking
-
- getLock(String, boolean) - Method in class org.jgroups.protocols.Locking
-
- getLock() - Method in class org.jgroups.util.Pool.Element
-
- getLog(Class) - Method in interface org.jgroups.logging.CustomLogFactory
-
- getLog(String) - Method in interface org.jgroups.logging.CustomLogFactory
-
- getLog(Class) - Static method in class org.jgroups.logging.LogFactory
-
- getLog(String) - Static method in class org.jgroups.logging.LogFactory
-
- getLog() - Method in class org.jgroups.stack.Protocol
-
- getLogCollectMessages() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getLogDiscardMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getLogDiscardMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getLogDiscardMessages() - Method in class org.jgroups.protocols.TP
-
- getLogDiscardMessagesVersion() - Method in class org.jgroups.protocols.TP
-
- getLogicalAddr() - Method in class org.jgroups.protocols.PDC.Mapping
-
- getLogicalName() - Method in class org.jgroups.protocols.PDC.Mapping
-
- getLogicalName() - Method in class org.jgroups.protocols.PingData
-
- getLogicalName() - Method in class org.jgroups.stack.GossipData
-
- getLoginModulename() - Method in class org.jgroups.protocols.SASL
-
- getLow() - Method in class org.jgroups.util.RingBufferSeqno
-
- getLow() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getLow() - Method in class org.jgroups.util.Seqno
-
- getLow() - Method in class org.jgroups.util.Table
-
- getMachineId() - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- getMagicNumber(Class) - Static method in class org.jgroups.conf.ClassConfigurator
-
Returns the magic number for the class.
- getMarshaller() - Method in class org.jgroups.blocks.RequestCorrelator
-
- getMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
-
- getMatchingMessages(short, boolean) - Method in class org.jgroups.util.MessageBatch
-
Removes and returns all messages which have a header with ID == id
- getMaxAge() - Method in class org.jgroups.demos.JmxDemo
-
- getMaxBlockTime() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getMaxBlockTime() - Method in class org.jgroups.protocols.FlowControl
-
- getMaxBlockTime(long) - Method in class org.jgroups.protocols.FlowControl
-
- getMaxBlockTimes() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getMaxBlockTimes() - Method in class org.jgroups.protocols.FlowControl
-
- getMaxBundleSize() - Method in class org.jgroups.protocols.TP
-
- getMaxBundleTimeout() - Method in class org.jgroups.protocols.TP
-
- getMaxBundlingTime() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMaxBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getMaxBytes() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- getMaxCompactionTime() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- getMaxCompactionTime() - Method in class org.jgroups.util.Table
-
- getMaxCredits() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getMaxCredits() - Method in class org.jgroups.protocols.FlowControl
-
- getMaxInterval() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- getMaxInterval() - Method in class org.jgroups.protocols.MERGE3
-
- getMaxJoinAttempts() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMaxNumberOfEntries() - Method in class org.jgroups.blocks.Cache
-
- getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST3
-
- getMaxSize() - Method in class org.jgroups.protocols.SHUFFLE
-
- getMaxThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- getMaxThreads() - Method in class org.jgroups.util.HashedTimingWheel
-
- getMaxThreads() - Method in class org.jgroups.util.MockTimeScheduler
-
- getMaxThreads() - Method in interface org.jgroups.util.TimeScheduler
-
Returns the configured max threads, or -1 if not applicable
- getMaxThreads() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- getMaxThreads() - Method in class org.jgroups.util.TimeScheduler3
-
- getMaxTime() - Method in class org.jgroups.protocols.SHUFFLE
-
- getMaxTries() - Method in class org.jgroups.protocols.FD
-
- getMBeanInfo() - Method in class org.jgroups.jmx.ResourceDMBean
-
- getMBeanServer() - Static method in class org.jgroups.util.Util
-
- getMcastAddr() - Method in class org.jgroups.protocols.MPING
-
- getMcastPort() - Method in class org.jgroups.protocols.MPING
-
- getMech() - Method in class org.jgroups.protocols.SASL
-
- getMember() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- getMember() - Method in class org.jgroups.util.Digest.Entry
-
- getMembers() - Method in class org.jgroups.blocks.ReplicatedTree
-
- getMembers() - Method in class org.jgroups.Membership
-
Returns a copy (clone) of the members in this membership.
- getMembers() - Method in class org.jgroups.protocols.FD
-
- getMembers() - Method in class org.jgroups.protocols.FD_ALL
-
- getMembers() - Method in class org.jgroups.protocols.FD_ALL2
-
- getMembers() - Method in class org.jgroups.protocols.FD_SOCK
-
- getMembers() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMembers() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getMembers() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getMembers() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getMembers() - Method in class org.jgroups.protocols.UNICAST3
-
- getMembers(String, RouterStub.MembersNotification) - Method in class org.jgroups.stack.RouterStub
-
Fetches a list of
PingData
from the GossipRouter, one for each member in the given group.
- getMembers() - Method in class org.jgroups.View
-
Returns the member list
- getMembershipChangePolicy() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMembersRaw() - Method in class org.jgroups.util.Digest
-
Don't use, this method is reserved for Bela ! :-)
- getMembersRaw() - Method in class org.jgroups.View
-
Returns the underlying array.
- getMembersWithCreditsLessThan(long) - Method in class org.jgroups.util.CreditMap
-
- getMembersWithInsufficientCredits(long) - Method in class org.jgroups.util.CreditMap
-
- getMergeDataFromSubgroupCoordinators(Map<Address, Collection<Address>>, MergeId, long) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
Sends a MERGE_REQ to all coords and populates a list of MergeData (in merge_rsps).
- getMergeId() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- getMergeId() - Method in class org.jgroups.protocols.pbcast.Merger
-
- getMergeIdAsString() - Method in class org.jgroups.protocols.pbcast.Merger
-
- getMergeIdHistory() - Method in class org.jgroups.protocols.pbcast.Merger
-
- getMerger() - Method in class org.jgroups.protocols.pbcast.GMS
-
Only used for internal testing, don't use this method !
- getMergeTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getMessage() - Method in class org.jgroups.demos.wb.SendDialog
-
- getMessage(String) - Static method in class org.jgroups.util.Util
-
- getMessageID() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- getMessageList() - Method in class org.jgroups.protocols.tom.TOA
-
- getMessageListener() - Method in class org.jgroups.blocks.MessageDispatcher
-
- getMessageSet() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
It is used for testing (see the messages in JMX)
- getMessagesToRetransmit() - Method in class org.jgroups.util.Seqno
-
- getMessagesToRetransmit() - Method in class org.jgroups.util.SeqnoRange
-
- getMethod() - Method in class org.jgroups.blocks.MethodCall
-
- getMethod() - Method in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- getMethodLookup() - Method in class org.jgroups.blocks.RpcDispatcher
-
- getMinCredits() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getMinCredits() - Method in class org.jgroups.protocols.FlowControl
-
- getMinCredits() - Method in class org.jgroups.util.CreditMap
-
- getMinInterval() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- getMinInterval() - Method in class org.jgroups.protocols.MERGE3
-
- getMinThreads() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- getMinThreads() - Method in class org.jgroups.util.HashedTimingWheel
-
- getMinThreads() - Method in class org.jgroups.util.MockTimeScheduler
-
- getMinThreads() - Method in interface org.jgroups.util.TimeScheduler
-
Returns the configured core threads, or -1 if not applicable
- getMinThreads() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- getMinThreads() - Method in class org.jgroups.util.TimeScheduler3
-
- getMinThreshold() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getMinThreshold() - Method in class org.jgroups.protocols.FlowControl
-
- getMissing() - Method in class org.jgroups.util.ResponseCollector
-
Returns a list of members which didn't send a valid response
- getMissing() - Method in class org.jgroups.util.RingBufferSeqno
-
- getMissing() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getMissing() - Method in class org.jgroups.util.Table
-
Returns a list of missing (= null) elements
- getMissing(int) - Method in class org.jgroups.util.Table
-
Returns a list of missing messages
- getMissingElements() - Method in class org.jgroups.util.Table.Missing
-
- getMissingMessages() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getMode() - Method in class org.jgroups.blocks.MethodCall
-
- getMode() - Method in class org.jgroups.blocks.RequestOptions
-
- getModificationTime() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- getMostSignificantBits() - Method in class org.jgroups.util.UUID
-
Returns the most significant 64 bits of this UUID's 128 bit value.
- getMulticastAddress() - Method in class org.jgroups.protocols.UDP
-
- getMulticastPort() - Method in class org.jgroups.protocols.UDP
-
- getMulticastTTL() - Method in class org.jgroups.protocols.UDP
-
Getter for current multicast TTL
- getMyFoo() - Static method in class org.jgroups.demos.JmxDemo
-
- getName() - Method in class org.jgroups.auth.AuthToken
-
Used to return the full package and class name of the implementation.
- getName() - Method in class org.jgroups.auth.DemoToken
-
- getName() - Method in class org.jgroups.auth.FixedMembershipToken
-
- getName() - Method in class org.jgroups.auth.Krb5Token
-
- getName() - Method in class org.jgroups.auth.MD5Token
-
- getName() - Method in class org.jgroups.auth.RegexMembership
-
- getName() - Method in class org.jgroups.auth.SimpleToken
-
- getName() - Method in class org.jgroups.auth.X509Token
-
- getName() - Method in interface org.jgroups.blocks.atomic.Counter
-
- getName() - Method in class org.jgroups.blocks.GridFile
-
- getName() - Method in class org.jgroups.blocks.locking.AwaitInfo
-
- getName() - Method in class org.jgroups.blocks.locking.LockInfo
-
- getName() - Method in class org.jgroups.blocks.MethodCall
-
returns the name of the method to be invoked using this method call object
- getName() - Static method in class org.jgroups.blocks.RpcDispatcher
-
- getName() - Method in class org.jgroups.Channel
-
Returns the logical name of this channel if set.
- getName(Address) - Method in class org.jgroups.Channel
-
Returns the logical name of a given member.
- getName() - Method in class org.jgroups.demos.JmxDemo.MyNotification
-
- getName() - Method in class org.jgroups.JChannel
-
- getName(Address) - Method in class org.jgroups.JChannel
-
- getName() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- getName() - Method in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
- getName() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- getName() - Method in class org.jgroups.protocols.relay.SiteUUID
-
- getName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getName() - Method in class org.jgroups.stack.Protocol
-
- getName() - Method in class org.jgroups.stack.ProtocolStack
-
- getNamedAttribute(String) - Method in class org.jgroups.jmx.ResourceDMBean
-
- GetNetworkInterfaces - Class in org.jgroups.util
-
Lists all network interfaces on a system
- GetNetworkInterfaces() - Constructor for class org.jgroups.util.GetNetworkInterfaces
-
- getNewConnectionId() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNewConnectionId() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getNewConnectionId() - Method in class org.jgroups.protocols.UNICAST3
-
- getNewMembers() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- getNewMembership(Collection<Address>, Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS.DefaultMembershipPolicy
-
Takes the existing membership list and removes suspected and left members, then adds new
members to the end of the list
- getNewMembership(Collection<Collection<Address>>) - Method in class org.jgroups.protocols.pbcast.GMS.DefaultMembershipPolicy
-
Default implementation for a merge.
- getNewMembership(Collection<Collection<Address>>) - Method in class org.jgroups.stack.LargestWinningPolicy
-
Called when a merge happened.
- getNewMembership(Collection<Address>, Collection<Address>, Collection<Address>, Collection<Address>) - Method in interface org.jgroups.stack.MembershipChangePolicy
-
Computes a new membership based on existing, joining, leaving and suspected members.
- getNewMembership(Collection<Collection<Address>>) - Method in interface org.jgroups.stack.MembershipChangePolicy
-
Compute a new membership based on a number of subviews
- getNewMembershipOld(Collection<Collection<Address>>) - Static method in class org.jgroups.protocols.pbcast.GMS.DefaultMembershipPolicy
-
Old default implementation for a merge.
- getNewThreadName(String, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
-
- getNextHigherPowerOfTwo(int) - Static method in class org.jgroups.util.Util
-
- getNextId() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- getNextId() - Method in class org.jgroups.protocols.RSVP
-
- getNextIndex() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getNextMessagesToDeliver() - Method in interface org.jgroups.protocols.tom.DeliveryManager
-
returns an ordered list with the messages to be deliver.
- getNextMessagesToDeliver() - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- getNextMulticastAddress() - Static method in class org.jgroups.util.ResourceManager
-
Returns the next available multicast address, e.g.
- getNextMulticastPort(InetAddress) - Static method in class org.jgroups.util.ResourceManager
-
- getNextRequest() - Method in class org.jgroups.protocols.Locking.ServerLock
-
- getNextTcpPort(InetAddress) - Static method in class org.jgroups.util.ResourceManager
-
- getNextTcpPorts(InetAddress, int) - Static method in class org.jgroups.util.ResourceManager
-
- getNextView(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes the next view.
- getNonLoopbackAddress() - Static method in class org.jgroups.util.Util
-
Returns the first non-loopback address on any interface on the current host.
- getNonMemberMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getNonMemberMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getNonSetMembers() - Method in class org.jgroups.util.MutableDigest
-
Returns an array of members whose seqno is not set.
- getNullMessages(long, long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Returns the number of null elements in the range [from ..
- getNumAcksReceived() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumAcksReceived() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumAcksSent() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumAcksSent() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumActiveThreads() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getNumberAsString() - Method in class org.jgroups.demos.JmxDemo
-
- getNumberOfAnycastMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfAnycastMessagesSent() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getNumberOfAnycastMessagesSent() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfBackups() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- getNumberOfBackups() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- getNumberOfBlockings() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getNumberOfBlockings() - Method in class org.jgroups.protocols.FlowControl
-
- getNumberOfBlockings() - Method in class org.jgroups.protocols.MFC
-
- getNumberOfBlockings() - Method in class org.jgroups.protocols.UFC
-
- getNumberOfConnectionCreations() - Static method in class org.jgroups.blocks.BasicConnectionTable
-
- getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FlowControl
-
- getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FlowControl
-
- getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FlowControl
-
- getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FlowControl
-
- getNumberOfDataMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfDiscoveryRequestsSent() - Method in class org.jgroups.protocols.Discovery
-
- getNumberOfFinalAnycastSent() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfFinalAnycastsSent() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getNumberOfFinalMessagesDelivered() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getNumberOfFinalMessagesDelivered() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfFlushes() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- getNumberOfHeartbeatsSent() - Method in class org.jgroups.protocols.FD
-
- getNumberOfInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
-
- getNumberOfMessages() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getNumberOfMessagesInReceiveWindows() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumberOfMissingMessages() - Method in class org.jgroups.util.Seqno
-
- getNumberOfMissingMessages() - Method in class org.jgroups.util.SeqnoRange
-
- getNumberOfProposeMessageReceived() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfProposeMessageSent() - Method in class org.jgroups.protocols.tom.TOA
-
- getNumberOfProposeMessagesReceived() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getNumberOfProposeMessagesSent() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG
-
- getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG2
-
- getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG
-
- getNumberOfReceivedMessages() - Method in class org.jgroups.util.Seqno
-
- getNumberOfReceivedMessages() - Method in class org.jgroups.util.SeqnoRange
-
- getNumberOfReceiverScopes() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG
-
- getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG2
-
- getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG
-
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getNumberOfTasksInTimer() - Method in class org.jgroups.JChannel
-
- getNumberOfViews() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getNumBlockings() - Method in class org.jgroups.protocols.FlowControl.Credit
-
- getNumBlockings() - Method in class org.jgroups.util.CreditMap
-
- getNumBytesReceived() - Method in class org.jgroups.protocols.TP
-
- getNumBytesSent() - Method in class org.jgroups.protocols.TP
-
- getNumCompactions() - Method in class org.jgroups.util.Table
-
- getNumConnections() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getNumConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
- getNumConnections() - Method in class org.jgroups.protocols.STOMP
-
- getNumConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getNumConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumForwardedToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getNumForwardedToSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getNumHeaders() - Method in class org.jgroups.Message
-
- getNumInitialMembers() - Method in class org.jgroups.protocols.Discovery
-
Deprecated.
- getNumLocalDeliveries() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getNumLocked() - Method in class org.jgroups.util.Pool
-
- getNumMembers() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getNumMessagesReceived() - Method in class org.jgroups.protocols.TP
-
- getNumMessagesReceived() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumMessagesReceived() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumMessagesSent() - Method in class org.jgroups.protocols.TP
-
- getNumMessagesSent() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumMessagesSent() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumMissing() - Method in class org.jgroups.util.Table
-
Returns the number of null elements in the range [hd+1 ..
- getNumMoves() - Method in class org.jgroups.util.Table
-
- getNumOpenConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
- getNumPurges() - Method in class org.jgroups.util.Table
-
- getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumRelayed() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getNumResizes() - Method in class org.jgroups.util.Table
-
- getNumRows() - Method in class org.jgroups.util.Table
-
- getNumRules() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- getNumSubscriptions() - Method in class org.jgroups.protocols.STOMP
-
- getNumSuspectedMembers() - Method in class org.jgroups.protocols.FD_SOCK
-
- getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD
-
- getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD_SOCK
-
- getNumThreads() - Static method in class org.jgroups.protocols.TP
-
- getNumTimerTasks() - Method in class org.jgroups.protocols.TP
-
- getNumUnackedMessages() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
- getNumUnackedMessages() - Method in class org.jgroups.protocols.UNICAST3
-
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
- getNumXmits() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getNumXmits() - Method in class org.jgroups.protocols.UNICAST3
-
- getObject() - Method in class org.jgroups.Message
-
- getObject(ClassLoader) - Method in class org.jgroups.Message
-
Uses custom serialization to create an object from the buffer of the message.
- getOffset() - Method in class org.jgroups.Message
-
Returns the offset into the buffer at which the data starts
- getOffset() - Method in class org.jgroups.stack.GossipData
-
- getOffset() - Method in class org.jgroups.util.Buffer
-
- getOffset() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- getOffset() - Method in class org.jgroups.util.Table
-
- getOOBMaxQueueSize() - Method in class org.jgroups.protocols.TP
-
- getOOBMessages() - Method in class org.jgroups.protocols.TP
-
- getOOBPoolSize() - Method in class org.jgroups.protocols.TP
-
- getOOBPoolSizeActive() - Method in class org.jgroups.protocols.TP
-
- getOOBQueueSize() - Method in class org.jgroups.protocols.TP
-
- getOOBThreadPool() - Method in class org.jgroups.protocols.TP
-
- getOOBThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.TP
-
- getOOBThreadPoolMaxThreads() - Method in class org.jgroups.protocols.TP
-
- getOOBThreadPoolMinThreads() - Method in class org.jgroups.protocols.TP
-
- getOOBThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
-
- getOpenConnections() - Method in class org.jgroups.protocols.TCP
-
- getOpenConnections() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getOpenConnections() - Method in class org.jgroups.protocols.TCP_NIO2
-
- getOption(SocketOption<T>) - Method in class org.jgroups.nio.MockSocketChannel
-
- getOrCreateCounter(String, long) - Method in class org.jgroups.blocks.atomic.CounterService
-
Returns an existing counter, or creates a new one if none exists
- getOrCreateCounter(String, long) - Method in class org.jgroups.protocols.COUNTER
-
- getOrCreateQueue(Address, short) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getOrCreateReceiverEntry(Address, long, short) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getOrCreateReceiverEntry(Address, long, short) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- GetOrCreateRequest() - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateRequest
-
- GetOrCreateResponse() - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateResponse
-
- GetOrCreateResponse(Owner, long, long) - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateResponse
-
- getOriginalProperties() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getOutDelay() - Method in class org.jgroups.protocols.DELAY
-
- getOutDelayNanos() - Method in class org.jgroups.protocols.DELAY
-
- getOutgoingCopies() - Method in class org.jgroups.protocols.DUPL
-
- getOutput(String) - Method in class org.jgroups.blocks.GridFilesystem
-
- getOutput(String, boolean) - Method in class org.jgroups.blocks.GridFilesystem
-
- getOutput(String, boolean, short, int) - Method in class org.jgroups.blocks.GridFilesystem
-
- getOutput(GridFile) - Method in class org.jgroups.blocks.GridFilesystem
-
- getOwner() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- getOwner() - Method in class org.jgroups.protocols.COUNTER
-
- getOwner() - Method in class org.jgroups.protocols.Locking
-
- getParameterString(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
-
- getParameterStringXml(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
-
- getPath() - Method in class org.jgroups.blocks.GridFile
-
- getPayload() - Method in class org.jgroups.protocols.SaslHeader
-
- getPayload() - Method in class org.jgroups.util.PayloadUUID
-
Deprecated.
- getPeerAddressReadTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getPendingMessageIDs() - Method in class org.jgroups.protocols.tom.SenderManager
-
- getPendingRsvpRequests() - Method in class org.jgroups.protocols.RSVP
-
- getPendingXmitRequests() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getPendingXmits() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getPermitToWrite() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- getPhysicalAddr() - Method in class org.jgroups.protocols.PDC.Mapping
-
- getPhysicalAddr() - Method in class org.jgroups.protocols.PingData
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.AUTH
-
- getPhysicalAddress(Address) - Method in class org.jgroups.protocols.FD_HOST
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.TCP
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getPhysicalAddress() - Method in class org.jgroups.protocols.TCP_NIO2
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.TP
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.TUNNEL
-
- getPhysicalAddress() - Method in class org.jgroups.protocols.UDP
-
- getPhysicalAddress() - Method in class org.jgroups.stack.GossipData
-
- getPhysicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
-
- getPhysicalAddrs() - Method in class org.jgroups.protocols.PingData
-
Deprecated.
- getPingableMembers() - Method in class org.jgroups.protocols.FD
-
- getPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
-
- getPingData() - Method in class org.jgroups.stack.GossipData
-
- getPingDest() - Method in class org.jgroups.protocols.FD
-
- getPingDest(List<Address>) - Method in class org.jgroups.protocols.FD
-
- getPingDest() - Method in class org.jgroups.protocols.FD_SOCK
-
- getPort() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getPort() - Method in class org.jgroups.stack.IpAddress
-
- getPortRange() - Method in class org.jgroups.protocols.TCPPING
-
- getPortRange() - Method in class org.jgroups.protocols.TP
-
- getPreferredSize() - Method in class org.jgroups.demos.Draw.DrawPanel
-
- getPriority() - Method in class org.jgroups.protocols.PrioHeader
-
- getProbeHandlers() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- getProcessing() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getProcessing() - Method in class org.jgroups.util.RingBufferSeqno
-
- getProcessing() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- getProcessing() - Method in class org.jgroups.util.Table
-
- getProcessorKeepAliveTime() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getProcessorKeepAliveTime() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getProcessorMaxThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getProcessorMaxThreads() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getProcessorMinThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getProcessorMinThreads() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getProcessorQueueSize() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getProcessorQueueSize() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getProcessorThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getProcessorThreads() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getProperties() - Method in class org.jgroups.Channel
-
- getProperties() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getProperties() - Method in class org.jgroups.JChannel
-
Returns the protocol stack configuration in string format.
- getPropertiesString() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getProperty(String[], Properties, String, String) - Static method in class org.jgroups.util.Util
-
Returns a value associated wither with one or more system properties, or found in the props map
- getProperty(String) - Static method in class org.jgroups.util.Util
-
- getPropertyAsBoolean(String, boolean) - Static method in class org.jgroups.Global
-
- getPropertyAsInteger(String, int) - Static method in class org.jgroups.Global
-
- getPropertyAsLong(String, long) - Static method in class org.jgroups.Global
-
- getPropertyName(Field, Map<String, String>) - Static method in class org.jgroups.conf.PropertyHelper
-
- getPropertyName(Method) - Static method in class org.jgroups.conf.PropertyHelper
-
- getProps() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getProps() - Method in class org.jgroups.blocks.ReplCache
-
- getProtId() - Method in class org.jgroups.Header
-
- getProtocol(short) - Static method in class org.jgroups.conf.ClassConfigurator
-
- getProtocolAdapter() - Method in class org.jgroups.blocks.MessageDispatcher
-
- getProtocolId(Class) - Static method in class org.jgroups.conf.ClassConfigurator
-
- getProtocolName() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getProtocols() - Method in class org.jgroups.fork.ForkProtocolStack
-
- getProtocols() - Method in class org.jgroups.stack.ProtocolStack
-
Returns all protocols in a list, from top to bottom.
- getProtocolStack() - Method in class org.jgroups.Channel
-
- getProtocolStack() - Method in class org.jgroups.conf.PlainConfigurator
-
- getProtocolStack() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
-
- getProtocolStack() - Method in class org.jgroups.conf.XmlConfigurator
-
- getProtocolStack() - Method in class org.jgroups.JChannel
-
Returns the protocol stack
- getProtocolStack() - Method in class org.jgroups.stack.Protocol
-
- getProtocolStackString() - Method in class org.jgroups.conf.PlainConfigurator
-
returns the old style protocol string
- getProtocolStackString() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
-
- getProtocolStackString(boolean) - Method in class org.jgroups.conf.XmlConfigurator
-
- getProtocolStackString() - Method in class org.jgroups.conf.XmlConfigurator
-
- getProtocolString(boolean) - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getProtocolString() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getProtocolStringNewXml() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getQueue() - Method in class org.jgroups.util.ProcessingQueue
-
- getQueueSize() - Method in class org.jgroups.util.HashedTimingWheel
-
- getQueueSize() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- getQueueSize() - Method in class org.jgroups.util.TimeScheduler3
-
- getQuote(String) - Method in class org.jgroups.demos.QuoteServer
-
- getRackId() - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- getRange() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- getRank(Address, View) - Static method in class org.jgroups.protocols.pbcast.STABLE
-
- getRank(View, Address) - Static method in class org.jgroups.util.Util
-
Returns the rank of a member in a given view
- getRank(Collection<Address>, Address) - Static method in class org.jgroups.util.Util
-
- getRawBuffer() - Method in class org.jgroups.Message
-
Returns a reference to the payload (byte buffer).
- getReaderThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getReaderThreads() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getReaperInterval() - Method in class org.jgroups.protocols.BasicTCP
-
- getReceiveBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getReceivedBroadcasts() - Method in class org.jgroups.protocols.SEQUENCER
-
- getReceivedBroadcasts() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getReceivedBytes() - Method in class org.jgroups.JChannel
-
- getReceivedBytes() - Method in class org.jgroups.protocols.STATS
-
- getReceivedForwards() - Method in class org.jgroups.protocols.SEQUENCER
-
- getReceivedMcastBytes() - Method in class org.jgroups.protocols.STATS
-
- getReceivedMcastMessages() - Method in class org.jgroups.protocols.STATS
-
- getReceivedMessages() - Method in class org.jgroups.JChannel
-
- getReceivedMessages() - Method in class org.jgroups.protocols.STATS
-
- getReceivedRequests() - Method in class org.jgroups.protocols.SEQUENCER2
-
- getReceivedUnicastBytes() - Method in class org.jgroups.protocols.STATS
-
- getReceivedUnicastMessages() - Method in class org.jgroups.protocols.STATS
-
- getReceiveInterfaces() - Method in class org.jgroups.protocols.MPING
-
- getReceiveInterfaces() - Method in class org.jgroups.protocols.TP
-
- getReceiver() - Method in class org.jgroups.Channel
-
- getReceiverEntry(Address, long, boolean, short) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getReceiverEntry(Address, long, boolean, short) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getReceiverEntry(Address, long, boolean, short) - Method in class org.jgroups.protocols.UNICAST3
-
- getReconnectInterval() - Method in class org.jgroups.protocols.TUNNEL
-
- getRefViewId() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- getRegularMaxQueueSize() - Method in class org.jgroups.protocols.TP
-
- getRegularMessages() - Method in class org.jgroups.protocols.TP
-
- getRegularPoolSize() - Method in class org.jgroups.protocols.TP
-
- getRegularPoolSizeActive() - Method in class org.jgroups.protocols.TP
-
- getRegularQueueSize() - Method in class org.jgroups.protocols.TP
-
- getRemoteAddress() - Method in class org.jgroups.nio.MockSocketChannel
-
- getRemoteView() - Method in class org.jgroups.protocols.RELAY
-
- getRemoveAllDataOnViewChange() - Method in class org.jgroups.protocols.FILE_PING
-
- getReplenishHeader() - Method in class org.jgroups.protocols.FlowControl
-
- getReplenishHeader() - Method in class org.jgroups.protocols.MFC
-
- getReplenishHeader() - Method in class org.jgroups.protocols.UFC
-
- getReplicationCount() - Method in class org.jgroups.blocks.ReplCache.Value
-
- getRequestId() - Method in class org.jgroups.protocols.Executing.Owner
-
- getRequestMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
-
- getResourceAsStream(String, Class) - Static method in class org.jgroups.util.Util
-
- getResponseMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
-
- getResponsesComplete() - Method in class org.jgroups.blocks.Request
-
- getResult() - Method in class org.jgroups.blocks.UnicastRequest
-
- getResult() - Method in class org.jgroups.protocols.pbcast.NAKACK2.Counter
-
- getResult() - Method in class org.jgroups.util.Promise
-
- getResult(long) - Method in class org.jgroups.util.Promise
-
Returns the result, but never throws a TimeoutException; returns null instead.
- getResult(long, boolean) - Method in class org.jgroups.util.Promise
-
- getResult() - Method in class org.jgroups.util.Table.Counter
-
- getResult() - Method in class org.jgroups.util.Table.Dump
-
- getResult() - Method in class org.jgroups.util.Table.HighestDeliverable
-
- getResults() - Method in class org.jgroups.blocks.GroupRequest
-
Returns the results as a RspList
- getResults() - Method in class org.jgroups.util.ResponseCollector
-
- getResults() - Method in class org.jgroups.util.RspList
-
Returns the results from non-suspected members that are not null.
- getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
-
Blocks until a result is available, or timeout milliseconds have elapsed
- getResultWithTimeout(long, boolean) - Method in class org.jgroups.util.Promise
-
- getRetransmitTableCapacity() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getRetransmitTableFillFactor() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getRetransmitTableOffset() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getRetransmitTableSize() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- getRetryTimeout() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- getRound() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- getRoute(String) - Method in class org.jgroups.protocols.relay.RELAY2
-
Returns the route to a given site
- getRoute(String) - Method in class org.jgroups.protocols.relay.Relayer
-
- getRoute(String, Address) - Method in class org.jgroups.protocols.relay.Relayer
-
- getRoutes(String...) - Method in class org.jgroups.protocols.relay.Relayer
-
- getRouteStatusListener() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getRow(int) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Returns a row.
- getRow(int) - Method in class org.jgroups.util.Table
-
Returns a row.
- getRspFilter() - Method in class org.jgroups.blocks.RequestOptions
-
- getRunnable() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- getSaslClientFactories(ClassLoader, boolean) - Static method in class org.jgroups.auth.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslClientFactory
s where the order is
based on the order of the Provider registration and/or class path order.
- getSaslClientFactories() - Static method in class org.jgroups.auth.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslClientFactory
s where the order is
based on the order of the Provider registration and/or class path order.
- getSaslClientFactory(String, Map<String, ?>) - Static method in class org.jgroups.auth.sasl.SaslUtils
-
- getSaslProps() - Method in class org.jgroups.protocols.SASL
-
- getSaslServerFactories(ClassLoader, boolean) - Static method in class org.jgroups.auth.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslServerFactory
s where the order is
based on the order of the Provider registration and/or class path order.
- getSaslServerFactories() - Static method in class org.jgroups.auth.sasl.SaslUtils
-
Returns an iterator of all of the registered SaslServerFactory
s where the order is
based on the order of the Provider registration and/or class path order.
- getSaslServerFactory(String, Map<String, ?>) - Static method in class org.jgroups.auth.sasl.SaslUtils
-
- getScope() - Method in class org.jgroups.blocks.RequestOptions
-
- getScope() - Method in class org.jgroups.Message
-
- getScope() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- getScope(Message) - Static method in class org.jgroups.util.Util
-
- getScopedInetAddress(Inet6Address) - Static method in class org.jgroups.conf.PropertyConverters.Default
-
- getSecretKey() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getSecretKeyFromAbove() - Method in class org.jgroups.protocols.KeyExchange
-
Fetches the secret key from a protocol above us
- getSendBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getSender() - Method in class org.jgroups.protocols.pbcast.MergeData
-
- getSender() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- getSender() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- getSender() - Method in class org.jgroups.util.Rsp
-
- getSenderEntry(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- getSendInterfaces() - Method in class org.jgroups.protocols.MPING
-
- getSendQueueSize() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getSentBytes() - Method in class org.jgroups.JChannel
-
- getSentBytes() - Method in class org.jgroups.protocols.STATS
-
- getSentMcastBytes() - Method in class org.jgroups.protocols.STATS
-
- getSentMcastMessages() - Method in class org.jgroups.protocols.STATS
-
- getSentMessages() - Method in class org.jgroups.JChannel
-
- getSentMessages() - Method in class org.jgroups.protocols.STATS
-
- getSentUnicastBytes() - Method in class org.jgroups.protocols.STATS
-
- getSentUnicastMessages() - Method in class org.jgroups.protocols.STATS
-
- getSeqno() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- getSeqno() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- getSeqno() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- getSeqno() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- getSeqno() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- getSeqno() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- getSequencerNumber() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- getServerCallbackHandler() - Method in class org.jgroups.protocols.SASL
-
- getServerCallbackHandlerClass() - Method in class org.jgroups.protocols.SASL
-
- getServerName(String) - Method in class org.jgroups.protocols.SASL
-
- getServerObject() - Method in class org.jgroups.blocks.RpcDispatcher
-
- getServerSocketAddress() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- getServerSubject() - Method in class org.jgroups.protocols.SASL
-
- getSessionId() - Method in class org.jgroups.client.StompConnection
-
- getSingletonName() - Method in class org.jgroups.protocols.TP
-
- getSingletonTransports() - Static method in class org.jgroups.stack.ProtocolStack
-
- getSite() - Method in interface org.jgroups.protocols.relay.SiteAddress
-
Returns the ID of the site (all sites need to have a unique site ID)
- getSite() - Method in class org.jgroups.protocols.relay.SiteUUID
-
- getSiteId() - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- getSiteNames() - Method in class org.jgroups.protocols.relay.Relayer
-
- getSites() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getSize() - Method in class org.jgroups.blocks.Cache
-
- getSizeOfAllMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getSizeOfAllMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getSockAddress() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- getSocketConnectionTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getSocketFactory() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getSocketFactory() - Method in class org.jgroups.Channel
-
- getSocketFactory() - Method in class org.jgroups.protocols.TP
-
- getSocketFactory() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getSocketFactory() - Method in class org.jgroups.stack.Protocol
-
Returns the SocketFactory associated with this protocol, if overridden in a subclass, or passes the call down
- getSockets() - Method in class org.jgroups.util.DefaultSocketFactory
-
- getSockets() - Method in interface org.jgroups.util.SocketFactory
-
Returns all open sockets.
- getSrc() - Method in class org.jgroups.Message
-
- getStabilityReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getStabilitySent() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getStableReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getStableSent() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getStableTaskRunning() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- getStackConfigurator(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the XML configuration provided by the specified File.
- getStackConfigurator(InputStream) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
- getStackConfigurator(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the XML configuration provided at the specified URL.
- getStackConfigurator(Element) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the XML configuration provided by the specified XML element.
- getStackConfigurator(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the provided properties string.
- getStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- getStartFlushTimeout() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedTree
-
- getState() - Method in class org.jgroups.Channel
-
- getState(Address, long) - Method in class org.jgroups.Channel
-
Retrieves the full state from the target member.
- getState(OutputStream) - Method in class org.jgroups.demos.Draw
-
- getState(OutputStream) - Method in class org.jgroups.demos.QuoteServer
-
- getState(OutputStream) - Method in class org.jgroups.demos.wb.GraphPanel
-
- getState(OutputStream) - Method in class org.jgroups.demos.wb.Whiteboard
-
- getState(Address, long) - Method in class org.jgroups.fork.ForkChannel
-
- getState(Address, long) - Method in class org.jgroups.JChannel
-
- getState(Address, long, boolean) - Method in class org.jgroups.JChannel
-
Retrieves state from the target member.
- getState(Address, long, Callable<Boolean>) - Method in class org.jgroups.JChannel
-
- getState(OutputStream) - Method in interface org.jgroups.MessageListener
-
Allows an application to write a state through a provided OutputStream.
- getState(OutputStream) - Method in class org.jgroups.ReceiverAdapter
-
Allows an application to write a state through a provided OutputStream.
- getStateFrom(JChannel, Protocol, String, String, DataOutputStream) - Method in class org.jgroups.protocols.FORK
-
- getStateFromApplication(Address, Digest) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- getStateFromApplication(Address, OutputStream, boolean) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getStateFromMainAndForkChannels(Event) - Method in class org.jgroups.protocols.FORK
-
- getStats() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getStubManager() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- getStubManager() - Method in class org.jgroups.protocols.TUNNEL
-
- getSubgroups() - Method in class org.jgroups.MergeView
-
- getSubscriptions() - Method in class org.jgroups.protocols.STOMP
-
- getSubtrees() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- getSuspectedMembers() - Method in class org.jgroups.protocols.FD.Broadcaster
-
- getSuspectedMembers() - Method in class org.jgroups.protocols.FD_ALL
-
- getSuspectedMembers() - Method in class org.jgroups.protocols.FD_ALL2
-
- getSuspectedMembers() - Method in class org.jgroups.protocols.FD_HOST
-
- getSuspectedMembers() - Method in class org.jgroups.protocols.FD_SOCK
-
- getSuspectedMembers() - Method in class org.jgroups.util.RspList
-
- getSuspectEventsSent() - Method in class org.jgroups.protocols.FD_ALL
-
- getSuspectEventsSent() - Method in class org.jgroups.protocols.FD_ALL2
-
- getSuspects() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- getSymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getSymDecodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getSymEncodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getSymInit() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getSymVersion() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- getTcpNodelay() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getter - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- getter() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- getter(ResourceDMBean.Accessor) - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- Getter() - Constructor for class org.jgroups.util.Table.Getter
-
- getTestStack(Protocol...) - Static method in class org.jgroups.util.Util
-
Returns a default stack for testing with transport = SHARED_LOOPBACK
- getThread() - Method in class org.jgroups.protocols.RingBufferBundler
-
- getThread() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- getThread() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- getThread() - Method in class org.jgroups.util.Runner
-
- getThreadFactory() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getThreadFactory() - Method in class org.jgroups.protocols.TP
-
- getThreadFactory() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getThreadFactory() - Method in class org.jgroups.stack.Protocol
-
Supposed to be overwritten by subclasses.
- getThreadId() - Method in class org.jgroups.util.Owner
-
- getThreadName(String, Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
-
- getThreadNamingPattern() - Method in class org.jgroups.protocols.TP
-
Names the current thread.
- getThreadPool() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getThreadPoolCompletedTasks() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getThreadPoolCoreThreads() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getThreadPoolIdleTime() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getThreadPoolKeepAliveTime() - Method in class org.jgroups.protocols.TP
-
- getThreadPoolMaxThreads() - Method in class org.jgroups.blocks.MemcachedConnector
-
- getThreadPoolMaxThreads() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getThreadPoolMaxThreads() - Method in class org.jgroups.protocols.TP
-
- getThreadPoolMinThreads() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- getThreadPoolMinThreads() - Method in class org.jgroups.protocols.TP
-
- getThreadPoolSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- getTimeDeliveringLocally() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getTimeForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getTimeForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getTimeout() - Method in class org.jgroups.blocks.Cache.Value
-
- getTimeout() - Method in class org.jgroups.blocks.locking.LockInfo
-
- getTimeout() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
The timeout (in milliseconds) for blocking updates
- getTimeout() - Method in class org.jgroups.blocks.RequestOptions
-
- getTimeout() - Method in class org.jgroups.protocols.Discovery
-
- getTimeout() - Method in class org.jgroups.protocols.FD
-
- getTimeout() - Method in class org.jgroups.protocols.FD_ALL
-
- getTimeout() - Method in class org.jgroups.protocols.FD_ALL2
-
- getTimeout() - Method in class org.jgroups.protocols.SASL
-
- getTimeout() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getTimeout() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getTimeout() - Method in class org.jgroups.util.AgeOutCache
-
- getTimeout() - Method in class org.jgroups.util.ExpiryCache
-
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL
-
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL2
-
- getTimePeriod() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- getTimer() - Method in class org.jgroups.JChannel
-
- getTimer() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getTimer() - Method in class org.jgroups.protocols.TP
-
- getTimer() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getTimerClass() - Method in class org.jgroups.protocols.TP
-
- getTimeRelaying() - Method in class org.jgroups.protocols.relay.RELAY2
-
- getTimerKeepAliveTime() - Method in class org.jgroups.protocols.TP
-
- getTimerMaxThreads() - Method in class org.jgroups.protocols.TP
-
- getTimerMinThreads() - Method in class org.jgroups.protocols.TP
-
- getTimerQueueSize() - Method in class org.jgroups.protocols.TP
-
- getTimerThreadFactory() - Method in class org.jgroups.protocols.TP
-
- getTimerThreads() - Method in class org.jgroups.JChannel
-
- getTimerThreads() - Method in class org.jgroups.protocols.TP
-
- getTimeService() - Method in class org.jgroups.protocols.TP
-
- getTimestamp() - Method in class org.jgroups.blocks.cs.NioConnection
-
- getTimestamp() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- getTimestamp() - Method in class org.jgroups.protocols.FD_ALL
-
- getTimestamp() - Method in class org.jgroups.protocols.FD_HOST
-
- getTimestamp() - Method in class org.jgroups.protocols.UNICAST3
-
- getTimestamper() - Method in class org.jgroups.protocols.UNICAST3
-
- getTimeUnit() - Method in class org.jgroups.blocks.locking.LockInfo
-
- getTo() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- getToken() - Method in class org.jgroups.protocols.AuthHeader
-
- getTopProtocol() - Method in class org.jgroups.stack.ProtocolStack
-
- getTotalBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- getTotalTimeBlocked() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- getTotalTimeInFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- getTransientFlags() - Method in class org.jgroups.blocks.RequestOptions
-
- getTransientFlags() - Method in class org.jgroups.Message
-
- getTransport() - Method in class org.jgroups.stack.Protocol
-
- getTransport() - Method in class org.jgroups.stack.ProtocolStack
-
Returns the bottom most protocol
- getTransportName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- getTTL() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- getTTL() - Method in class org.jgroups.protocols.MPING
-
- getType() - Method in class org.jgroups.Event
-
- getType() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- getType() - Method in class org.jgroups.protocols.EncryptHeader
-
- getType() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- getType() - Method in class org.jgroups.protocols.Locking.Request
-
- getType() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- getType() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- getType() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
-
- getType() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- getType() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- getType() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- getType() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- getType() - Method in class org.jgroups.protocols.SaslHeader
-
- getType() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- getType() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- getType() - Method in class org.jgroups.stack.GossipData
-
- getUnicastProtocols() - Static method in class org.jgroups.util.Util
-
- getUniqueClusterName(String) - Static method in class org.jgroups.util.ResourceManager
-
- getUniqueClusterName() - Static method in class org.jgroups.util.ResourceManager
-
- getUnknownForkHandler() - Method in class org.jgroups.protocols.FORK
-
- getUpDiscardRate() - Method in class org.jgroups.protocols.DISCARD
-
- getUpHandler() - Method in class org.jgroups.Channel
-
Returns UpHandler installed for this channel
- getUpProt() - Method in class org.jgroups.util.ForwardQueue
-
- getUpProtocol() - Method in class org.jgroups.stack.Protocol
-
- getUpProtocols() - Method in class org.jgroups.protocols.TP
-
- getUpServices() - Method in class org.jgroups.stack.Protocol
-
Returns all services provided by the protocols above the current protocol
- getUserName() - Method in class org.jgroups.demos.wb.UserInfoDialog
-
- getUseSendQueues() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- getVal() - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- getVal() - Method in class org.jgroups.blocks.ReplCache.Value
-
- getVal1() - Method in class org.jgroups.util.Triple
-
- getVal1() - Method in class org.jgroups.util.Tuple
-
- getVal2() - Method in class org.jgroups.util.Triple
-
- getVal2() - Method in class org.jgroups.util.Tuple
-
- getVal3() - Method in class org.jgroups.util.Triple
-
- getValidResults() - Method in class org.jgroups.util.ResponseCollector
-
- getValue() - Method in class org.jgroups.blocks.Cache.Value
-
- getValue() - Method in class org.jgroups.blocks.UnicastRequest
-
- getValue(String) - Method in class org.jgroups.stack.Protocol
-
- getValue() - Method in class org.jgroups.util.Rsp
-
- getValue(Object) - Method in class org.jgroups.util.RspList
-
Returns the value associated with address key
- getValueFromProtocol(Protocol, Field) - Static method in class org.jgroups.stack.Configurator
-
- getValueFromProtocol(Protocol, String) - Static method in class org.jgroups.stack.Configurator
-
- getVerb() - Method in class org.jgroups.protocols.STOMP.Frame
-
- getVersion() - Static method in class org.jgroups.JChannel
-
- getVersion() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- getVersion() - Method in class org.jgroups.protocols.EncryptHeader
-
- getVid() - Method in class org.jgroups.View
-
Deprecated.
- getView() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- getView() - Method in class org.jgroups.blocks.ReplCache
-
- getView() - Method in class org.jgroups.Channel
-
Gets the current view.
- getView() - Method in class org.jgroups.JChannel
-
- getView() - Method in class org.jgroups.protocols.COUNTER
-
- getView() - Method in class org.jgroups.protocols.Discovery
-
- getView() - Method in class org.jgroups.protocols.Executing
-
- getView() - Method in class org.jgroups.protocols.Locking
-
- getView() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getView() - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- getView() - Method in class org.jgroups.protocols.pbcast.MergeData
-
- getView() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- getView() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- getViewAckCollectionTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getViewAndDigest() - Method in class org.jgroups.protocols.pbcast.GMS
-
Returns the current view and digest.
- getViewAsString() - Method in class org.jgroups.JChannel
-
- getViewHandlerSize() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getViewId() - Method in class org.jgroups.protocols.Discovery
-
- getViewID() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- getViewId() - Method in class org.jgroups.protocols.pbcast.GMS
-
- getViewId() - Method in class org.jgroups.View
-
Returns the view ID of this view
if this view was created with the empty constructur, null will be returned
- getViews() - Method in class org.jgroups.protocols.MERGE3
-
- getWindow(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Please don't use this method; it is only provided for unit testing !
- getWindow(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Returns the receive window for sender; only used for testing.
- getWriteIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- getWriteIndex(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- getWriterThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- getWriterThreads() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitStaggerTimeout() - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
- getXmitTableCapacity() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableNumCurrentRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST3
-
- getXmitTableUndeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- Global - Class in org.jgroups
-
Global is a JGroups internal class defining global variables.
- global_thread_factory - Variable in class org.jgroups.protocols.TP
-
Used by all threads created by JGroups outside of the thread pools
- global_view - Variable in class org.jgroups.protocols.RELAY
-
The combined view of local and remote cluster
- global_view - Variable in class org.jgroups.protocols.RELAY.ViewData
-
- global_view_id - Variable in class org.jgroups.protocols.RELAY
-
To generate new global views
- GMS - Class in org.jgroups.protocols.pbcast
-
Group membership protocol.
- GMS() - Constructor for class org.jgroups.protocols.pbcast.GMS
-
- gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
-
- gms - Variable in class org.jgroups.protocols.pbcast.Merger
-
- GMS.DefaultMembershipPolicy - Class in org.jgroups.protocols.pbcast
-
- GMS.GmsHeader - Class in org.jgroups.protocols.pbcast
-
- GMS_ID - Static variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- GMS_ID - Static variable in class org.jgroups.protocols.AUTH
-
- GMS_ID - Static variable in class org.jgroups.protocols.SASL
-
- GmsHeader() - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GmsHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GmsHeader(byte, Address, boolean) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
Used for JOIN_REQ or LEAVE_REQ header
- GmsHeader(byte, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- GmsImpl - Class in org.jgroups.protocols.pbcast
-
- GmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
-
- GmsImpl.Request - Class in org.jgroups.protocols.pbcast
-
- go() - Method in class org.jgroups.demos.applets.DrawApplet
-
- go() - Method in class org.jgroups.demos.Draw
-
- go() - Method in class org.jgroups.demos.StompDraw
-
- GOOGLE_PING - Class in org.jgroups.protocols
-
Discovery protocol for Google Cloud Storage.
- GOOGLE_PING() - Constructor for class org.jgroups.protocols.GOOGLE_PING
-
- GOSSIP_ROUTER - Static variable in class org.jgroups.Global
-
- gossip_router_hosts - Variable in class org.jgroups.protocols.TUNNEL
-
- GossipData - Class in org.jgroups.stack
-
Encapsulates data sent between GossipRouter and GossipClient
- GossipData() - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address, List<PingData>) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address, List<PingData>, PhysicalAddress) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address, String, PhysicalAddress) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address, byte[]) - Constructor for class org.jgroups.stack.GossipData
-
- GossipData(GossipType, String, Address, byte[], int, int) - Constructor for class org.jgroups.stack.GossipData
-
- GossipRouter - Class in org.jgroups.stack
-
Router for TCP based group comunication (using layer TCP instead of UDP).
- GossipRouter(String, int) - Constructor for class org.jgroups.stack.GossipRouter
-
- GossipRouter.Entry - Class in org.jgroups.stack
-
- gossipRouterAddress() - Method in class org.jgroups.stack.RouterStub
-
- GossipType - Enum in org.jgroups.stack
-
Types of requests and responses exchanged between GossipRouter and RouterStubs
- got_cache_from_coord - Variable in class org.jgroups.protocols.FD_SOCK
-
- gr - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- grants - Variable in class org.jgroups.protocols.PEER_LOCK.PeerLock
-
Deprecated.
- GraphPanel - Class in org.jgroups.demos.wb
-
- GraphPanel(Whiteboard) - Constructor for class org.jgroups.demos.wb.GraphPanel
-
- GridFile - Class in org.jgroups.blocks
-
Subclass of File to iterate through directories and files in a grid
- GridFile.Metadata - Class in org.jgroups.blocks
-
- GridFilesystem - Class in org.jgroups.blocks
-
Entry point for GridFile and GridInputStream / GridOutputStream
- GridFilesystem(ReplCache<String, byte[]>, ReplCache<String, GridFile.Metadata>, short, int) - Constructor for class org.jgroups.blocks.GridFilesystem
-
Creates an instance.
- GridFilesystem(ReplCache<String, byte[]>, ReplCache<String, GridFile.Metadata>) - Constructor for class org.jgroups.blocks.GridFilesystem
-
- GridInputStream - Class in org.jgroups.blocks
-
- GridOutputStream - Class in org.jgroups.blocks
-
- groupname - Static variable in class org.jgroups.demos.wb.Whiteboard
-
- GroupRequest<T> - Class in org.jgroups.blocks
-
Sends a message to all members of the group and waits for all responses (or timeout).
- GroupRequest(RequestCorrelator, Collection<Address>, RequestOptions) - Constructor for class org.jgroups.blocks.GroupRequest
-
- grow(int) - Method in class org.jgroups.util.RequestTable
-
Grows the array to at least new_capacity.
- grow_exponentially - Variable in class org.jgroups.util.ByteArrayDataOutputStream
-
- growExponentially() - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- growExponentially(boolean) - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- GuardedBy - Annotation Type in org.jgroups.annotations
-
Copyright (c) 2005 Brian Goetz and Tim Peierls
Released under the Creative Commons Attribution License
(http://creativecommons.org/licenses/by/2.5)
Official home: http://www.jcip.net
Adopted from Java Concurrency in Practice.
- GZIP - Static variable in class org.jgroups.util.Base64
-
Specify that data should be gzip-compressed in second bit.
- i1 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i1 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i10 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i10 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i11 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i11 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i12 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i12 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i13 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i13 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i14 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i14 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i15 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i16 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i2 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i2 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i3 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i3 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i4 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i4 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i5 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i5 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i6 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i6 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i7 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i7 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i8 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i8 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- i9 - Variable in class org.jgroups.util.PaddedAtomicBoolean
-
- i9 - Variable in class org.jgroups.util.PaddedAtomicInteger
-
- I_HAVE_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- ID - Static variable in class org.jgroups.auth.DemoToken
-
- ID - Static variable in class org.jgroups.blocks.MethodCall
-
Use an ID to map to a method
- ID - Static variable in class org.jgroups.fork.ForkConfig
-
- ID - Static variable in class org.jgroups.protocols.FORK
-
- id - Variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- id - Variable in class org.jgroups.protocols.FragHeader
-
- id - Variable in class org.jgroups.protocols.RSVP.RsvpHeader
-
- id - Variable in class org.jgroups.stack.Protocol
-
- id - Variable in class org.jgroups.ViewId
-
- ids - Variable in class org.jgroups.protocols.RSVP
-
Used to store IDs and their acks
- ignore_dont_bundle - Variable in class org.jgroups.protocols.TP
-
- ignore_synchronous_response - Variable in class org.jgroups.protocols.FlowControl
-
Whether an up thread that comes back down should be allowed to bypass blocking if all credits are exhausted.
- ignoredMembers - Variable in class org.jgroups.protocols.DISCARD
-
- img - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- imgsize - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- Immutable - Annotation Type in org.jgroups.annotations
-
Copyright (c) 2005 Brian Goetz and Tim Peierls
Released under the Creative Commons Attribution License
(http://creativecommons.org/licenses/by/2.5)
Official home: http://www.jcip.net
Adopted from Java Concurrency in Practice.
- ImmutableReference<T> - Class in org.jgroups.util
-
Simple class that holds an immutable reference to another object (or to
null
).
- ImmutableReference(T) - Constructor for class org.jgroups.util.ImmutableReference
-
Create a new ImmutableReference.
- impl - Variable in class org.jgroups.protocols.pbcast.GMS
-
- impl_mutex - Variable in class org.jgroups.protocols.pbcast.GMS
-
- implCloseSelectableChannel() - Method in class org.jgroups.nio.MockSocketChannel
-
- implConfigureBlocking(boolean) - Method in class org.jgroups.nio.MockSocketChannel
-
- impls - Variable in class org.jgroups.protocols.pbcast.GMS
-
- in - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- in - Variable in class org.jgroups.client.StompConnection
-
- in - Variable in class org.jgroups.demos.PubClient
-
- in - Variable in class org.jgroups.protocols.STOMP.Connection
-
- in_delay - Variable in class org.jgroups.protocols.DELAY
-
- in_delay_nanos - Variable in class org.jgroups.protocols.DELAY
-
- in_flight_sends - Variable in class org.jgroups.protocols.SEQUENCER
-
Keeps track of the threads sending messages
- in_flight_sends - Variable in class org.jgroups.util.ForwardQueue
-
Keeps track of the threads sending messages
- in_flight_threads - Variable in class org.jgroups.protocols.BARRIER
-
- includeClusterName - Variable in class org.jgroups.util.DefaultThreadFactory
-
- includeLocalAddress - Variable in class org.jgroups.util.DefaultThreadFactory
-
- incoming_copies - Variable in class org.jgroups.protocols.DUPL
-
- inconsistent_view_threshold - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- INCR - Static variable in class org.jgroups.util.MessageBatch
-
- incrBatchesSent() - Method in class org.jgroups.protocols.TP
-
- incrBatchesSent(int) - Method in class org.jgroups.protocols.TP
-
- incrCount() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- increment(long) - Method in class org.jgroups.protocols.FlowControl.Credit
-
- increment(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- increment(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- incrementAndGet() - Method in interface org.jgroups.blocks.atomic.Counter
-
Atomically increments the counter and returns the new value
- incrementAndGet() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- incrementInitCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
Increments init_count, returns the old value before incr
- incrementMessageDeliver() - Method in class org.jgroups.protocols.tom.StatsCollector
-
- incrementRelayed() - Method in class org.jgroups.protocols.relay.RELAY2
-
- incrementStartCount() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- incrInits() - Method in class org.jgroups.fork.ForkProtocolStack
-
- incrSingleMsgsInsteadOfBatches() - Method in class org.jgroups.protocols.TP
-
- index - Variable in class org.jgroups.nio.Buffers.BuffersIterator
-
- index(int) - Method in class org.jgroups.protocols.RingBufferBundler
-
- index(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- index(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- index - Variable in class org.jgroups.util.ArrayIterator
-
- index - Variable in class org.jgroups.util.Digest.MyIterator
-
- index - Variable in class org.jgroups.util.MessageBatch
-
Index of the next message to be inserted
- index(long) - Method in class org.jgroups.util.RequestTable
-
- index(long, int) - Static method in class org.jgroups.util.RequestTable
-
- index - Variable in class org.jgroups.util.Responses
-
- index - Variable in class org.jgroups.util.Responses.PingDataIterator
-
- index(long) - Method in class org.jgroups.util.RingBufferSeqno
-
- index(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- index(long) - Method in class org.jgroups.util.SeqnoList
-
- index - Variable in class org.jgroups.util.SeqnoList.SeqnoListIterator
-
- inflater_pool - Variable in class org.jgroups.protocols.COMPRESS
-
- info - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- info(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- info(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- info(String) - Method in interface org.jgroups.logging.Log
-
- info(String, Object...) - Method in interface org.jgroups.logging.Log
-
- info(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- info(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- info_sender - Variable in class org.jgroups.protocols.MERGE3
-
- info_writer - Variable in class org.jgroups.protocols.FILE_PING
-
- info_writer - Variable in class org.jgroups.protocols.JDBC_PING
-
- info_writer_max_writes_after_view - Variable in class org.jgroups.protocols.FILE_PING
-
- info_writer_max_writes_after_view - Variable in class org.jgroups.protocols.JDBC_PING
-
- info_writer_sleep_time - Variable in class org.jgroups.protocols.FILE_PING
-
- info_writer_sleep_time - Variable in class org.jgroups.protocols.JDBC_PING
-
- InfoSender() - Constructor for class org.jgroups.protocols.MERGE3.InfoSender
-
- InfoWriter(int, long) - Constructor for class org.jgroups.protocols.FILE_PING.InfoWriter
-
- InfoWriter(int, long) - Constructor for class org.jgroups.protocols.JDBC_PING.InfoWriter
-
- init() - Method in class org.jgroups.auth.AuthToken
-
- init() - Method in class org.jgroups.auth.DemoToken
-
- init() - Method in class org.jgroups.auth.RegexMembership
-
- init() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- init() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- init() - Static method in class org.jgroups.conf.ClassConfigurator
-
- init() - Method in class org.jgroups.demos.applets.DrawApplet
-
- init() - Method in class org.jgroups.demos.wb.Whiteboard
-
- init() - Method in class org.jgroups.fork.ForkProtocolStack
-
- init(ProtocolStackConfigurator) - Method in class org.jgroups.JChannel
-
- init(JChannel) - Method in class org.jgroups.JChannel
-
- init() - Method in class org.jgroups.JChannel
-
Initializes all variables.
- init() - Method in class org.jgroups.protocols.ABP
-
- init() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- init() - Method in class org.jgroups.protocols.AUTH
-
- init() - Method in class org.jgroups.protocols.BARRIER
-
- init(TP) - Method in class org.jgroups.protocols.BaseBundler
-
- init() - Method in class org.jgroups.protocols.BasicTCP
-
- init() - Method in class org.jgroups.protocols.BPING
-
- init(TP) - Method in interface org.jgroups.protocols.Bundler
-
Called after creation of the bundler
- init(String) - Method in class org.jgroups.protocols.CertficateCNMatcher
-
- init() - Method in class org.jgroups.protocols.COMPRESS
-
- init() - Method in class org.jgroups.protocols.DAISYCHAIN
-
- init() - Method in class org.jgroups.protocols.DELAY
-
- init() - Method in class org.jgroups.protocols.Discovery
-
- init() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- init() - Method in class org.jgroups.protocols.EncryptBase
-
- init() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- init() - Method in class org.jgroups.protocols.FD
-
- init() - Method in class org.jgroups.protocols.FD_ALL
-
- init() - Method in class org.jgroups.protocols.FD_ALL2
-
- init() - Method in class org.jgroups.protocols.FD_HOST
-
- init() - Method in class org.jgroups.protocols.FD_SOCK
-
- init() - Method in class org.jgroups.protocols.FILE_PING
-
- init() - Method in class org.jgroups.protocols.FlowControl
-
- init() - Method in class org.jgroups.protocols.FORK
-
- init() - Method in class org.jgroups.protocols.FRAG
-
- init() - Method in class org.jgroups.protocols.FRAG2
-
- init() - Method in class org.jgroups.protocols.GOOGLE_PING
-
- init() - Method in class org.jgroups.protocols.JDBC_PING
-
- init() - Method in class org.jgroups.protocols.Locking
-
- init() - Method in class org.jgroups.protocols.MAKE_BATCH
-
- init() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- init() - Method in class org.jgroups.protocols.MERGE3
-
- init() - Method in class org.jgroups.protocols.MFC
-
- init() - Method in class org.jgroups.protocols.MPING
-
- init(TP) - Method in class org.jgroups.protocols.NoBundler
-
- init() - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- init() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- init() - Method in class org.jgroups.protocols.pbcast.GMS
-
- init() - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- init() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- init() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- init() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
- init() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- init() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- init() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- init() - Method in class org.jgroups.protocols.PDC
-
- init() - Method in class org.jgroups.protocols.PERF
-
- init() - Method in class org.jgroups.protocols.RACKSPACE_PING
-
- init() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- init() - Method in class org.jgroups.protocols.RELAY
-
- init() - Method in class org.jgroups.protocols.relay.RELAY2
-
- init(TP) - Method in class org.jgroups.protocols.RingBufferBundler
-
- init(TP) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- init(TP) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- init() - Method in class org.jgroups.protocols.RSVP
-
- init() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- init() - Method in class org.jgroups.protocols.rules.Rule
-
Called when rule is installed
- init() - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- init() - Method in class org.jgroups.protocols.S3_PING
-
- init() - Method in class org.jgroups.protocols.SASL
-
- init() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- init() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- init() - Method in class org.jgroups.protocols.SHARED_LOOPBACK_PING
-
- init() - Method in class org.jgroups.protocols.SHUFFLE
-
- init() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- init(String) - Method in interface org.jgroups.protocols.SSL_KEY_EXCHANGE.SessionVerifier
-
Called after creation with session_verifier_arg
- init() - Method in class org.jgroups.protocols.SWIFT_PING
-
- init() - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
- init() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- init() - Method in class org.jgroups.protocols.TCPPING
-
- init() - Method in class org.jgroups.protocols.TP
-
- init(TP) - Method in class org.jgroups.protocols.TransferQueueBundler
-
- init() - Method in class org.jgroups.protocols.TUNNEL
-
- init() - Method in class org.jgroups.protocols.UDP
-
- init() - Method in class org.jgroups.protocols.UFC
-
- init() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- init() - Method in class org.jgroups.protocols.UNICAST3
-
- init() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- init() - Method in class org.jgroups.stack.Protocol
-
Called after instance has been created (null constructor) and before protocol is started.
- init() - Method in class org.jgroups.stack.ProtocolStack
-
- init() - Method in class org.jgroups.util.HashedTimingWheel
-
- init() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- initial_buf_size - Variable in class org.jgroups.protocols.NoBundler
-
- initial_delay - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
-
- INITIAL_MCAST_ADDR - Static variable in class org.jgroups.Global
-
- INITIAL_MCAST_PORT - Static variable in class org.jgroups.Global
-
- INITIAL_TCP_PORT - Static variable in class org.jgroups.Global
-
- initial_val - Variable in class org.jgroups.util.OneTimeAddressGenerator
-
- initial_value - Variable in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
-
- initialBufSize() - Method in class org.jgroups.protocols.NoBundler
-
- initialBufSize(int) - Method in class org.jgroups.protocols.NoBundler
-
- InitialHosts() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts
-
- InitialHosts2() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts2
-
- initialize_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- initialized - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- initiateSecurityContext(Subject, String) - Static method in class org.jgroups.auth.Krb5TokenUtils
-
- initKeyPair() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Generates the public/private key pair from the init params
- initKeyPair() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
Generates the public/private key pair from the init params
- initMetadata() - Method in class org.jgroups.blocks.GridFile
-
- initProtocolStack() - Method in class org.jgroups.stack.ProtocolStack
-
- inits - Variable in class org.jgroups.fork.ForkProtocolStack
-
- initSymCiphers(String, Key) - Method in class org.jgroups.protocols.EncryptBase
-
Initialises the ciphers for both encryption and decryption using the generated or supplied secret key
- initSymKey() - Static method in class org.jgroups.demos.KeyStoreGenerator
-
- initSymKey() - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
Used to initialise the symmetric key if none is supplied in a keystore.
- input - Variable in class org.jgroups.util.InputStreamAdapter
-
- input_stream - Variable in class org.jgroups.protocols.pbcast.STATE
-
If use_default_transport is true, we consume bytes off of this blocking queue.
- InputStream(InputStream) - Constructor for class org.jgroups.util.Base64.InputStream
-
- InputStream(InputStream, int) - Constructor for class org.jgroups.util.Base64.InputStream
-
- InputStreamAdapter - Class in org.jgroups.util
-
- InputStreamAdapter(ByteArrayDataInputStream) - Constructor for class org.jgroups.util.InputStreamAdapter
-
- insert(Connection, PingData, String, String) - Method in class org.jgroups.protocols.JDBC_PING
-
- insert_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- insertProtocol(Protocol, int, String) - Method in class org.jgroups.stack.ProtocolStack
-
Inserts an already created (and initialized) protocol into the protocol list.
- insertProtocol(Protocol, int, Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
-
- insertProtocol(Protocol, int, Class<? extends Protocol>...) - Method in class org.jgroups.stack.ProtocolStack
-
- insertProtocolAtTop(Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
- insertProtocolInStack(Protocol, Protocol, int) - Method in class org.jgroups.stack.ProtocolStack
-
- INSTALL_DIGEST - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- INSTALL_MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- INSTALL_MERGE_VIEW_OK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- install_view_locally_first - Variable in class org.jgroups.protocols.pbcast.GMS
-
- installNodes(List<Address>) - Method in class org.jgroups.blocks.ReplCache.ConsistentHashFunction
-
- installNodes(List<Address>) - Method in interface org.jgroups.blocks.ReplCache.HashFunction
-
When the topology changes, this method will be called.
- installRule(long, Rule) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
Installs a new rule
- installRule(String, long, Rule) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
Installs a new rule
- installRule(String, long, String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- installRule(long, String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- installUpHandler(UpHandler, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sets the given UpHandler as the UpHandler for the channel, or, if the
channel already has a Muxer installed as it's UpHandler, sets the given
handler as the Muxer's
default handler
.
- installView(View) - Method in class org.jgroups.protocols.pbcast.GMS
-
- installView(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
- installView(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
-
- installViewIfValidJoinRsp(Promise<JoinRsp>, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- INT_SIZE - Static variable in class org.jgroups.Global
-
- IntegerArray() - Constructor for class org.jgroups.conf.PropertyConverters.IntegerArray
-
- interfaceHasIPAddresses(NetworkInterface, StackType) - Static method in class org.jgroups.util.Util
-
A function to check if an interface supports an IP version (i.e has addresses
defined for that IP version).
- internal_thread_factory - Variable in class org.jgroups.protocols.TP
-
Factory which is used by internal_thread_pool
- internal_thread_pool - Variable in class org.jgroups.protocols.TP
-
The thread pool which handles JGroups internal messages (Flag.INTERNAL)
- internal_thread_pool_enabled - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- internal_thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.TP
-
- internal_thread_pool_max_threads - Variable in class org.jgroups.protocols.TP
-
- internal_thread_pool_min_threads - Variable in class org.jgroups.protocols.TP
-
- internal_thread_pool_queue - Variable in class org.jgroups.protocols.TP
-
Used if thread_pool is a ThreadPoolExecutor and thread_pool_queue_enabled is true
- internal_thread_pool_queue_enabled - Variable in class org.jgroups.protocols.TP
-
- internal_thread_pool_queue_max_size - Variable in class org.jgroups.protocols.TP
-
- internal_thread_pool_rejection_policy - Variable in class org.jgroups.protocols.TP
-
- internalAdd(Address) - Method in class org.jgroups.AnycastAddress
-
- interrupt() - Method in class org.jgroups.protocols.tom.DeliveryThread
-
- interruptAndWaitToDie(Thread) - Static method in class org.jgroups.util.Util
-
- interruptAndWaitToDie(Thread, long) - Static method in class org.jgroups.util.Util
-
- interrupted(Runnable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- interrupted(Runnable) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
-
- interrupted(int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- interruptPingerThread(boolean) - Method in class org.jgroups.protocols.FD_SOCK
-
Interrupts the pinger thread.
- interval - Variable in class org.jgroups.protocols.FD_ALL
-
- interval - Variable in class org.jgroups.protocols.FD_ALL2
-
- interval - Variable in class org.jgroups.protocols.FD_HOST
-
- interval - Variable in class org.jgroups.protocols.FILE_PING
-
Deprecated.
- INTERVAL - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- Interval - Interface in org.jgroups.stack
-
Interface which returns a time series, one value at a time calling next()
- interval - Variable in class org.jgroups.stack.RouterStubManager
-
- interval - Variable in class org.jgroups.util.TimeService
-
- interval() - Method in class org.jgroups.util.TimeService
-
- interval(long) - Method in class org.jgroups.util.TimeService
-
- intervals - Variable in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- intf - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
network interface to be used to send the ICMP packets
- inView(Address, String) - Method in class org.jgroups.protocols.EncryptBase
-
- invoke(Object) - Method in class org.jgroups.blocks.MethodCall
-
Invokes the method with the supplied arguments against the target object.
- invoke(Object, Object[]) - Method in class org.jgroups.blocks.MethodCall
-
- invoke(Object) - Method in interface org.jgroups.jmx.ResourceDMBean.Accessor
-
Invokes a getter or setter.
- invoke(Object) - Method in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- invoke(String, Object[], String[]) - Method in class org.jgroups.jmx.ResourceDMBean
-
- invoke(Object) - Method in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- invoke(Object) - Method in class org.jgroups.jmx.ResourceDMBean.NoopAccessor
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- invokeCallback(int, Object) - Method in class org.jgroups.JChannel
-
- IP_ADDR - Static variable in interface org.jgroups.Address
-
- ip_mcast - Variable in class org.jgroups.protocols.UDP
-
- ip_ttl - Variable in class org.jgroups.protocols.UDP
-
- IpAddress - Class in org.jgroups.stack
-
Network-dependent address (Internet).
- IpAddress() - Constructor for class org.jgroups.stack.IpAddress
-
- IpAddress(String) - Constructor for class org.jgroups.stack.IpAddress
-
e.g.
- IpAddress(String, int) - Constructor for class org.jgroups.stack.IpAddress
-
- IpAddress(InetAddress, int) - Constructor for class org.jgroups.stack.IpAddress
-
- IpAddress(int) - Constructor for class org.jgroups.stack.IpAddress
-
- IpAddress(int, boolean) - Constructor for class org.jgroups.stack.IpAddress
-
- IpAddress(InetSocketAddress) - Constructor for class org.jgroups.stack.IpAddress
-
- IPv4 - Static variable in class org.jgroups.Global
-
- IPV4_SIZE - Static variable in class org.jgroups.Global
-
- IPv6 - Static variable in class org.jgroups.Global
-
- IPV6_MCAST_PREFIX - Static variable in class org.jgroups.Global
-
- IPV6_SIZE - Static variable in class org.jgroups.Global
-
- is_android - Static variable in class org.jgroups.protocols.UDP
-
- is_coord - Variable in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- is_coord - Variable in class org.jgroups.protocols.CENTRAL_LOCK
-
- is_coord - Variable in class org.jgroups.protocols.Discovery
-
- is_coord - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- is_coord - Variable in class org.jgroups.protocols.MERGE3
-
- is_coord - Static variable in class org.jgroups.protocols.PingData
-
- is_coord - Variable in class org.jgroups.protocols.RELAY
-
- is_coord - Variable in class org.jgroups.protocols.SEQUENCER
-
- is_coord - Variable in class org.jgroups.protocols.SEQUENCER2
-
- is_coord - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
- IS_EXCEPTION - Static variable in class org.jgroups.util.Rsp
-
Set when the value is an exception
- is_leaving - Variable in class org.jgroups.protocols.Discovery
-
- IS_LOG4J2_AVAILABLE - Static variable in class org.jgroups.logging.LogFactory
-
- is_mac - Static variable in class org.jgroups.protocols.UDP
-
- IS_MERGE_IN_PROGRESS - Static variable in class org.jgroups.Event
-
- is_server - Variable in class org.jgroups.protocols.Discovery
-
- is_server - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- is_server - Static variable in class org.jgroups.protocols.PingData
-
- is_server - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
- is_site_master - Variable in class org.jgroups.protocols.relay.RELAY2
-
- is_trylock - Variable in class org.jgroups.blocks.locking.LockInfo
-
- is_trylock - Variable in class org.jgroups.protocols.Locking.ClientLock
-
- is_trylock - Variable in class org.jgroups.protocols.Locking.Request
-
- isAcceptable(Object, Address) - Method in class org.jgroups.blocks.mux.NoMuxHandlerRspFilter
-
- isAcceptable(Object, Address) - Method in interface org.jgroups.blocks.RspFilter
-
Determines whether a response from a given sender should be added to the response list of the request
- isAcceptorRunning() - Method in class org.jgroups.protocols.TCP_NIO2
-
- isAlive() - Method in class org.jgroups.blocks.cs.BaseServer.Reaper
-
- isAlive(InetAddress, long) - Method in class org.jgroups.protocols.FD_HOST.ExternalPingCommand
-
- isAlive(String) - Method in class org.jgroups.protocols.FD_HOST
-
- isAlive(InetAddress, long) - Method in class org.jgroups.protocols.FD_HOST.IsReachablePingCommand
-
- isAlive(InetAddress, long) - Method in interface org.jgroups.protocols.FD_HOST.PingCommand
-
Checks whether a given host is alive
- isAll() - Method in class org.jgroups.blocks.locking.AwaitInfo
-
- isAsciiString(String) - Static method in class org.jgroups.util.Util
-
- isAuthorizationRequired() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- isAutomaticPurging() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- isAvailable(String) - Static method in class org.jgroups.logging.LogFactory
-
- isBinaryCompatible(short) - Static method in class org.jgroups.Version
-
Checks whether ver is binary compatible with the current version.
- isBinaryCompatible(short, short) - Static method in class org.jgroups.Version
-
- isBlockingUpdates() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- isCancelled() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- isCancelled() - Method in class org.jgroups.blocks.Request
-
- isCancelled() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- isCancelled() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- isCancelled() - Method in class org.jgroups.util.NullFuture
-
- isCancelled() - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- isCancelled() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- isChildOf(String, String) - Static method in class org.jgroups.blocks.GridFile
-
Verifies whether child is a child (dir or file) of parent
- isClosed() - Method in class org.jgroups.Channel
-
Determines whether the channel is in the closed state.
- isClosed() - Method in class org.jgroups.protocols.BARRIER
-
- isClosed() - Method in class org.jgroups.util.BlockingInputStream
-
- isComplete() - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
returns true if this fragmentation is complete
ie, all fragmentations have been received for this buffer
- isConnected() - Method in interface org.jgroups.blocks.cs.Client
-
- isConnected() - Method in class org.jgroups.blocks.cs.Connection
-
- isConnected() - Method in class org.jgroups.blocks.cs.NioClient
-
- isConnected() - Method in class org.jgroups.blocks.cs.NioConnection
-
- isConnected() - Method in class org.jgroups.blocks.cs.TcpClient
-
- isConnected() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- isConnected() - Method in class org.jgroups.Channel
-
Determines whether the channel is connected to a group.
- isConnected() - Method in class org.jgroups.client.StompConnection
-
- isConnected() - Method in class org.jgroups.nio.MockSocketChannel
-
- isConnected() - Method in class org.jgroups.stack.RouterStub
-
- isConnecting() - Method in class org.jgroups.Channel
-
Determines whether the channel is in the connecting state; this means
Channel.connect(String)
has been
called, but hasn't returned yet
- isConnectionPending() - Method in class org.jgroups.blocks.cs.Connection
-
- isConnectionPending() - Method in class org.jgroups.blocks.cs.NioConnection
-
- isConnectionPending() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- isConnectionPending() - Method in class org.jgroups.nio.MockSocketChannel
-
- isConnectionReaperRunning() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- isConnectionReaperRunning() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- isCoord() - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- isCoord() - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- isCoord(Address) - Method in class org.jgroups.protocols.Discovery
-
- isCoord() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isCoord() - Method in class org.jgroups.protocols.PingData
-
- isCoord() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- isCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
-
- isCoordinator() - Method in class org.jgroups.protocols.SEQUENCER2
-
- isCoordinator(JChannel) - Static method in class org.jgroups.util.Util
-
- isCoordinator(View, Address) - Static method in class org.jgroups.util.Util
-
- isCopyMulticastMsgs() - Method in class org.jgroups.protocols.DUPL
-
- isCopyUnicastMsgs() - Method in class org.jgroups.protocols.DUPL
-
- isDebugEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isDebugEnabled() - Method in interface org.jgroups.logging.Log
-
- isDebugEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isDefaulThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
-
- isDiagnosticsHandlerRunning() - Method in class org.jgroups.protocols.TP
-
- isDigestNeeded() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
When FLUSH is used we do not need to pass digests between members
see JGroups/doc/design/PartialStateTransfer.txt see
JGroups/doc/design/FLUSH.txt
- isDigestNeeded() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
When FLUSH is used we do not need to pass digests between members (see JGroups/doc/design/FLUSH.txt)
- isDirectory() - Method in class org.jgroups.blocks.GridFile
-
- isDirectory() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- isDiscardAll() - Method in class org.jgroups.protocols.DISCARD
-
- isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- isDiscardIncompatiblePackets() - Static method in class org.jgroups.protocols.TP
-
Deprecated.
- isDone() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- isDone() - Method in class org.jgroups.blocks.Request
-
- isDone() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- isDone() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- isDone() - Method in class org.jgroups.util.NullFuture
-
- isDone() - Method in class org.jgroups.util.ResponseCollectorTask
-
- isDone() - Method in class org.jgroups.util.Responses
-
- isDone() - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- isDone() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- isDown() - Method in class org.jgroups.protocols.SHUFFLE
-
- isDummy() - Method in class org.jgroups.util.Seqno
-
- isDynamic() - Method in class org.jgroups.protocols.Discovery
-
- isDynamic() - Method in class org.jgroups.protocols.FILE_PING
-
- isDynamic() - Method in class org.jgroups.protocols.JDBC_PING
-
- isDynamic() - Method in class org.jgroups.protocols.PING
-
- isDynamic() - Method in class org.jgroups.protocols.SHARED_LOOPBACK_PING
-
- isDynamic() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- isDynamic() - Method in class org.jgroups.protocols.TCPPING
-
- isEmpty() - Method in class org.jgroups.protocols.Locking.ServerLock
-
- isEmpty() - Method in class org.jgroups.util.MessageBatch
-
- isEmpty() - Method in class org.jgroups.util.Responses
-
- isEmpty() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- isEmpty() - Method in class org.jgroups.util.RingBuffer
-
- isEmpty() - Method in class org.jgroups.util.RspList
-
- isEmpty() - Method in class org.jgroups.util.SeqnoList
-
- isEmpty() - Method in class org.jgroups.util.Table
-
- isEnableBundling() - Static method in class org.jgroups.protocols.TP
-
Deprecated.
- isEnableUnicastBundling() - Static method in class org.jgroups.protocols.TP
-
Deprecated.
- isErgonomics() - Method in class org.jgroups.stack.Protocol
-
- isErrorEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isErrorEnabled() - Method in interface org.jgroups.logging.Log
-
- isErrorEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isExcluded(Route, String...) - Static method in class org.jgroups.protocols.relay.Relayer
-
- isExcludeItself() - Method in class org.jgroups.protocols.DISCARD
-
- isExpired(long) - Method in class org.jgroups.blocks.cs.Connection
-
- isExpired(long) - Method in class org.jgroups.blocks.cs.NioConnection
-
- isExpired(long) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- isFatalEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isFatalEnabled() - Method in interface org.jgroups.logging.Log
-
- isFatalEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isFile() - Method in class org.jgroups.blocks.GridFile
-
- isFile() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- isFirst() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- isFlag() - Static method in class org.jgroups.demos.JmxDemo
-
- isFlagSet(Message.Flag) - Method in class org.jgroups.blocks.RequestOptions
-
- isFlagSet(short, Message.Flag) - Static method in class org.jgroups.Message
-
- isFlagSet(Message.Flag) - Method in class org.jgroups.Message
-
Checks if a given flag is set
- isFlagSet(short) - Method in class org.jgroups.util.ExtendedUUID
-
- isFlagSet(byte, byte) - Static method in class org.jgroups.util.Util
-
- isGetMethod(Method) - Static method in class org.jgroups.jmx.ResourceDMBean
-
- isGreaterThanOrEqual(Digest, Digest) - Static method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Returns true if all senders of the current digest have their seqnos >= the ones from other
- isGreaterThanOrEqual(Digest, Digest) - Static method in class org.jgroups.protocols.pbcast.NAKACK2
-
Returns true if all senders of the current digest have their seqnos >= the ones from other
- isHeartbeatSenderRunning() - Method in class org.jgroups.protocols.FD_ALL
-
- isHeartbeatSenderRunning() - Method in class org.jgroups.protocols.FD_ALL2
-
- isInfoEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isInfoEnabled() - Method in interface org.jgroups.logging.Log
-
- isInfoEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isInfoSenderRunning() - Method in class org.jgroups.protocols.MERGE3
-
- isInfoWriterRunning() - Method in class org.jgroups.protocols.FILE_PING
-
- isInfoWriterRunning() - Method in class org.jgroups.protocols.JDBC_PING
-
- isInMembersList(IpAddress) - Method in class org.jgroups.auth.FixedMembershipToken
-
- isIsMethod(Method) - Static method in class org.jgroups.jmx.ResourceDMBean
-
- isJoinResponseValid(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- isKeyServer() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- isL1CacheEnabled() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- isL1CacheEnabled() - Method in class org.jgroups.blocks.ReplCache
-
- isLocal(Address) - Method in class org.jgroups.protocols.RELAY
-
Does the payload match the 'site' ID.
- isLockInterruptibly() - Method in class org.jgroups.blocks.locking.LockInfo
-
- isLogicalAddressCacheReaperRunning() - Method in class org.jgroups.protocols.TP
-
- isLogSuspectedMessages() - Method in class org.jgroups.protocols.FD_SOCK
-
- isLoopback() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- isMergeInProgress() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isMergeInProgress() - Method in class org.jgroups.protocols.pbcast.Merger
-
- isMergeKillerRunning() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isMergeKillerTaskRunning() - Method in class org.jgroups.protocols.pbcast.Merger
-
- isMergeRejected() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- isMergeRunning() - Method in class org.jgroups.protocols.Discovery
-
- isMergeRunning() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- isMergeRunning() - Method in class org.jgroups.protocols.MERGE3
-
- isMergeTaskRunning() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- isMergeTaskRunning() - Method in class org.jgroups.protocols.MERGE3
-
- isMergeTaskRunning() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isMergeTaskRunning() - Method in class org.jgroups.protocols.pbcast.Merger
-
- isMet() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- isMet() - Method in class org.jgroups.blocks.Request
-
- isMet() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- isMet() - Method in interface org.jgroups.util.Condition
-
Return true if the condition is met and false otherwise
- isMet() - Method in class org.jgroups.util.Promise
-
- isMet() - Method in class org.jgroups.util.ResponseCollector
-
- isMet() - Method in class org.jgroups.util.Responses
-
- isMigrateData() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- isMigrateData() - Method in class org.jgroups.blocks.ReplCache
-
- isMonitorRunning() - Method in class org.jgroups.protocols.FD
-
- isMulticastCapable() - Method in class org.jgroups.protocols.TP
-
- isNodeCrashMonitorRunning() - Method in class org.jgroups.protocols.FD_SOCK
-
- isOOBThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
-
- isOpen() - Method in interface org.jgroups.blocks.cs.Client
-
- isOpen() - Method in class org.jgroups.blocks.cs.Connection
-
- isOpen() - Method in class org.jgroups.blocks.cs.NioClient
-
- isOpen() - Method in class org.jgroups.blocks.cs.NioConnection
-
- isOpen() - Method in class org.jgroups.blocks.cs.TcpClient
-
- isOpen() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- isOpen() - Method in class org.jgroups.Channel
-
Determines whether the channel is open; ie.
- isOpenerScheduled() - Method in class org.jgroups.protocols.BARRIER
-
- isPinger(Address) - Method in class org.jgroups.protocols.FD_HOST
-
- isPingerRunning() - Method in class org.jgroups.protocols.FD_HOST
-
- isPingerThreadRunning() - Method in class org.jgroups.protocols.FD_SOCK
-
- isPrimitiveType(Class<?>) - Static method in class org.jgroups.blocks.MethodCall
-
- isPropertySet(String) - Static method in class org.jgroups.logging.LogFactory
-
- IsReachablePingCommand() - Constructor for class org.jgroups.protocols.FD_HOST.IsReachablePingCommand
-
- isReapingEnabled() - Method in class org.jgroups.blocks.Cache
-
- isReceived(Address) - Method in class org.jgroups.util.RspList
-
- isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
-
- isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.TP
-
- isRemovable() - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- isRequestPresent(Locking.Type, Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
-
Checks if a certain request from a given owner is already in the queue
- isResendTaskRunning() - Method in class org.jgroups.protocols.RSVP
-
- isRunning() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- isRunning() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- isRunning() - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- isRunning() - Method in class org.jgroups.protocols.FD_ALL
-
- isRunning() - Method in class org.jgroups.protocols.FD_ALL2
-
- isRunning() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- isRunning() - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- isRunning() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- isRunning() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- isRunning() - Method in class org.jgroups.util.Runner
-
- isRunning() - Method in class org.jgroups.util.TimeScheduler3
-
- isSame(short) - Static method in class org.jgroups.Version
-
Compares the specified version number against the current version number.
- isSameMachine(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- isSameRack(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- isSameSite(TopologyUUID) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- isSelectorOpen() - Method in class org.jgroups.protocols.TCP_NIO2
-
- isSenderUsed() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- isSendOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
-
- isServer() - Method in class org.jgroups.protocols.PingData
-
- isServer() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- isSetMethod(Method) - Static method in class org.jgroups.jmx.ResourceDMBean
-
- isSetPropertyMethod(Method) - Static method in class org.jgroups.stack.Configurator
-
- isShutdown() - Method in class org.jgroups.blocks.executor.ExecutionService
-
- isShutdown() - Method in class org.jgroups.util.HashedTimingWheel
-
- isShutdown() - Method in class org.jgroups.util.MockTimeScheduler
-
- isShutdown() - Method in interface org.jgroups.util.TimeScheduler
-
Returns true if stop() has been called, false otherwise
- isShutdown() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- isShutdown() - Method in class org.jgroups.util.TimeScheduler3
-
- isSingleton() - Method in class org.jgroups.protocols.TP
-
- isSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY2
-
- isStackAvailable(boolean) - Static method in class org.jgroups.util.Util
-
- isSuccessful() - Method in class org.jgroups.auth.sasl.SaslClientContext
-
- isSuccessful() - Method in interface org.jgroups.auth.sasl.SaslContext
-
- isSuccessful() - Method in class org.jgroups.auth.sasl.SaslServerContext
-
- isSuspected(Address) - Method in class org.jgroups.util.RspList
-
- isTerminated() - Method in class org.jgroups.blocks.executor.ExecutionService
-
- isTimeoutCheckerRunning() - Method in class org.jgroups.protocols.FD_ALL
-
- isTimeoutCheckerRunning() - Method in class org.jgroups.protocols.FD_ALL2
-
- isTraceEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isTraceEnabled() - Method in interface org.jgroups.logging.Log
-
- isTraceEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isTransientFlagSet(Message.TransientFlag) - Method in class org.jgroups.blocks.RequestOptions
-
- isTransientFlagSet(short, Message.TransientFlag) - Static method in class org.jgroups.Message
-
- isTransientFlagSet(Message.TransientFlag) - Method in class org.jgroups.Message
-
- isTrylock() - Method in class org.jgroups.blocks.locking.LockInfo
-
- isUp() - Method in class org.jgroups.protocols.SHUFFLE
-
- isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- isUseTimeout() - Method in class org.jgroups.blocks.locking.LockInfo
-
- isViewBundling() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isViewConsistencyCheckerRunning() - Method in class org.jgroups.protocols.MERGE3
-
- isViewHandlerSuspended() - Method in class org.jgroups.protocols.pbcast.GMS
-
- isWarnEnabled() - Method in class org.jgroups.logging.JDKLogImpl
-
- isWarnEnabled() - Method in interface org.jgroups.logging.Log
-
- isWarnEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
-
- isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- isXmitTaskRunning() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST3
-
- iterator() - Method in class org.jgroups.nio.Buffers
-
- iterator() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- iterator() - Method in class org.jgroups.util.Digest
-
- iterator() - Method in class org.jgroups.util.MessageBatch
-
Iterator which iterates only over non-null messages, skipping null messages
- iterator() - Method in class org.jgroups.util.Responses
-
- iterator() - Method in class org.jgroups.util.RingBufferSeqno
-
Returns an iterator over the elements of the ring buffer in the range [HD+1 ..
- iterator() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Returns an iterator over the elements of the ring buffer in the range [HD+1 ..
- iterator() - Method in class org.jgroups.util.RspList
-
- iterator() - Method in class org.jgroups.util.SeqnoList
-
- iterator() - Method in class org.jgroups.View
-
- MACHINE_ID - Static variable in class org.jgroups.util.TopologyUUID
-
Deprecated.
- MAGIC_NUMBER_FILE - Static variable in class org.jgroups.conf.ClassConfigurator
-
- MAGIC_NUMBER_FILE - Static variable in class org.jgroups.Global
-
- main(String[]) - Static method in class org.jgroups.blocks.ReplicatedTree
-
- main(String[]) - Static method in class org.jgroups.client.StompConnection
-
- main(String[]) - Static method in class org.jgroups.conf.XmlConfigurator
-
- main(String[]) - Static method in class org.jgroups.demos.Chat
-
- main(String[]) - Static method in class org.jgroups.demos.CounterServiceDemo
-
- main(String[]) - Static method in class org.jgroups.demos.Draw
-
- main(String[]) - Static method in class org.jgroups.demos.ExecutionServiceDemo
-
- main(String[]) - Static method in class org.jgroups.demos.JmxDemo
-
- main(String[]) - Static method in class org.jgroups.demos.KeyStoreGenerator
-
- main(String[]) - Static method in class org.jgroups.demos.LockServiceDemo
-
- main(String[]) - Static method in class org.jgroups.demos.MemcachedServer
-
- main(String[]) - Static method in class org.jgroups.demos.PartitionedHashMapDemo
-
- main(String[]) - Static method in class org.jgroups.demos.ProgrammaticChat
-
- main(String[]) - Static method in class org.jgroups.demos.PubClient
-
- main(String[]) - Static method in class org.jgroups.demos.PubServer
-
- main(String[]) - Static method in class org.jgroups.demos.PubSub
-
- main(String[]) - Static method in class org.jgroups.demos.QuoteClient
-
- main(String[]) - Static method in class org.jgroups.demos.QuoteServer
-
- main(String[]) - Static method in class org.jgroups.demos.RelayDemo
-
- main(String[]) - Static method in class org.jgroups.demos.RelayDemoRpc
-
- main(String[]) - Static method in class org.jgroups.demos.ReplCacheDemo
-
- main(String[]) - Static method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- main(String[]) - Static method in class org.jgroups.demos.StompChat
-
- main(String[]) - Static method in class org.jgroups.demos.StompDraw
-
- main(String[]) - Static method in class org.jgroups.demos.Topology
-
- main(String[]) - Static method in class org.jgroups.demos.TotalOrder
-
- main(String[]) - Static method in class org.jgroups.demos.ViewDemo
-
- main(String[]) - Static method in class org.jgroups.demos.wb.Whiteboard
-
- main(String[]) - Static method in class org.jgroups.fork.ForkConfig
-
- main(String[]) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- main(String[]) - Static method in class org.jgroups.stack.GossipRouter
-
- main(String[]) - Static method in class org.jgroups.util.GetNetworkInterfaces
-
- main(String[]) - Static method in class org.jgroups.util.Pool
-
- main(String[]) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
- main(String[]) - Static method in class org.jgroups.util.ResourceManager
-
- main(String[]) - Static method in class org.jgroups.util.XMLSchemaGenerator
-
- main(String[]) - Static method in class org.jgroups.Version
-
Prints the value of the description and cvs fields to System.out.
- main_channel - Variable in class org.jgroups.fork.ForkChannel
-
- major - Static variable in class org.jgroups.Version
-
- MAKE_BATCH - Class in org.jgroups.protocols
-
Intercepts individual up messages and creates batches from them, passing the batches up.
- MAKE_BATCH() - Constructor for class org.jgroups.protocols.MAKE_BATCH
-
- MAKE_BATCH.Batcher - Class in org.jgroups.protocols
-
- makeChar(byte[], int) - Static method in class org.jgroups.util.Bits
-
- makeInt(byte[], int, int) - Static method in class org.jgroups.util.Bits
-
- makeLengthBuffer(ByteBuffer) - Static method in class org.jgroups.blocks.cs.NioConnection
-
- makeLong(byte[], int, int) - Static method in class org.jgroups.util.Bits
-
- makeReply() - Method in class org.jgroups.Message
-
- makeShort(byte, byte) - Static method in class org.jgroups.util.Bits
-
- makeShort(byte) - Static method in class org.jgroups.util.Bits
-
- makeSpace() - Method in class org.jgroups.nio.Buffers
-
- ManagedAttribute - Annotation Type in org.jgroups.annotations
-
Indicates that a public method or a field (any visibility) in
an MBean class defines an MBean attribute.
- ManagedOperation - Annotation Type in org.jgroups.annotations
-
Indicates that a method in an MBean class defines an MBean
operation.
- map - Variable in class org.jgroups.blocks.ReplicatedHashMap
-
wrapped map instance
- map - Variable in class org.jgroups.util.ExpiryCache
-
- map(MessageBatch.Visitor<T>) - Method in class org.jgroups.util.MessageBatch
-
Applies a function to all messages and returns a list of the function results
- map - Variable in class org.jgroups.util.SuppressCache
-
- Mapping() - Constructor for class org.jgroups.protocols.PDC.Mapping
-
- Mapping(Address, PhysicalAddress, String) - Constructor for class org.jgroups.protocols.PDC.Mapping
-
- mapToString(Map<? extends Object, ? extends Object>) - Static method in class org.jgroups.util.Util
-
- markReadyToDeliver(MessageID, long) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
marks the message as ready to deliver and set the final sequence number (to be ordered)
- markSent(MessageID) - Method in class org.jgroups.protocols.tom.SenderManager
-
Mark the message as sent
- markSupported() - Method in class org.jgroups.util.InputStreamAdapter
-
- marshal(PingData) - Static method in class org.jgroups.protocols.Discovery
-
- marshal(LazyRemovalCache<Address, IpAddress>) - Static method in class org.jgroups.protocols.FD_SOCK
-
- marshal(View) - Static method in class org.jgroups.protocols.MERGE3
-
- marshal(Collection<? extends Address>, Digest) - Static method in class org.jgroups.protocols.pbcast.FLUSH
-
- marshal(View, Digest) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- marshal(JoinRsp) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- marshal(Collection<? extends Address>) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- marshal(ViewId) - Static method in class org.jgroups.protocols.pbcast.GMS
-
- marshal(Digest) - Static method in class org.jgroups.protocols.pbcast.STABLE
-
- marshalledSize(Header[]) - Static method in class org.jgroups.util.Headers
-
- marshaller - Variable in class org.jgroups.blocks.RequestCorrelator
-
Possibility for an external marshaller to marshal/unmarshal responses
- marshalMessagesToSameDestination(Address, Message[], int, int, int) - Method in class org.jgroups.protocols.RingBufferBundler
-
- marshalMessagesToSameDestination(Address, Message[], int, int, int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- marshalMessagesToSameDestination(Address, Message[], int, int, int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- marshalPrimitiveType(byte, Object) - Static method in class org.jgroups.util.Util
-
- match(IpAddress, InetSocketAddress) - Static method in class org.jgroups.auth.FixedMembershipToken
-
- match(String, String, boolean) - Static method in class org.jgroups.fork.ForkConfig
-
- match(String, String, boolean) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- match(String, String, boolean) - Static method in class org.jgroups.protocols.rules.SUPERVISOR
-
- match(T, T) - Static method in class org.jgroups.util.Util
-
- match(long[], long[]) - Static method in class org.jgroups.util.Util
-
- MATCH_ADDR - Static variable in class org.jgroups.Global
-
- MATCH_HOST - Static variable in class org.jgroups.Global
-
- MATCH_INTF - Static variable in class org.jgroups.Global
-
- match_ip_address - Variable in class org.jgroups.auth.RegexMembership
-
- match_logical_name - Variable in class org.jgroups.auth.RegexMembership
-
- match_string - Variable in class org.jgroups.auth.RegexMembership
-
- matchMergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
- matrix - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- matrix - Variable in class org.jgroups.util.Table
-
- max - Variable in class org.jgroups.util.AverageMinMax
-
- max() - Method in class org.jgroups.util.AverageMinMax
-
- max() - Method in class org.jgroups.util.RpcStats.Result
-
- max_block_time - Variable in class org.jgroups.protocols.FlowControl
-
Max time (in milliseconds) to block.
- max_block_times - Variable in class org.jgroups.protocols.FlowControl
-
Defines the max number of milliseconds for a message to block before being sent, based on the length of
the message.
- max_bundle_size - Variable in class org.jgroups.protocols.TP
-
Maximum number of bytes for messages to be queued until they are sent.
- max_bundle_timeout - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- max_bundling_time - Variable in class org.jgroups.protocols.pbcast.GMS
-
- max_bytes - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Total amount of bytes from incoming messages (default = 0 = disabled).
- max_bytes - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- max_bytes - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- max_close_time - Variable in class org.jgroups.protocols.BARRIER
-
- max_compaction_time - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
Time (in ms) after which a compaction should take place.
- max_compaction_time - Variable in class org.jgroups.util.Table
-
Time (in nanoseconds) after which a compaction should take place.
- max_credits - Variable in class org.jgroups.protocols.FlowControl
-
Max number of bytes to send per receiver until an ack must be received before continuing sending
- max_credits - Variable in class org.jgroups.util.CreditMap
-
- MAX_DATAGRAM_PACKET_SIZE - Static variable in class org.jgroups.Global
-
- max_dynamic_hosts - Variable in class org.jgroups.protocols.TCPPING
-
- max_interval - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- max_interval - Variable in class org.jgroups.protocols.MERGE3
-
- max_join_attempts - Variable in class org.jgroups.protocols.pbcast.GMS
-
- MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.Global
-
- max_list_print_size - Static variable in class org.jgroups.stack.ProtocolStack
-
- MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.util.Util
-
The max size of an address list, e.g.
- max_members_in_discovery_request - Variable in class org.jgroups.protocols.Discovery
-
- max_msg_batch_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- max_msg_batch_size - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- max_msg_batch_size - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- max_msg_batch_size - Variable in class org.jgroups.protocols.UNICAST3
-
- max_num_msgs - Variable in class org.jgroups.util.Table.Missing
-
- max_participants_in_merge - Variable in class org.jgroups.protocols.MERGE3
-
- max_pool - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- MAX_PORT - Static variable in class org.jgroups.util.Util
-
- max_rebroadcast_timeout - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- max_results - Variable in class org.jgroups.util.Table.Remover
-
- max_retransmit_time - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- max_retransmit_time - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- max_retransmit_time - Variable in class org.jgroups.protocols.UNICAST3
-
- max_send_buffers - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- max_send_buffers - Variable in class org.jgroups.protocols.TCP_NIO2
-
- max_site_masters - Variable in class org.jgroups.protocols.relay.RELAY2
-
- max_size - Variable in class org.jgroups.protocols.SHUFFLE
-
- max_size - Variable in class org.jgroups.util.BoundedHashMap
-
- max_stable_msgs - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- MAX_SUSPEND_TIME - Static variable in class org.jgroups.protocols.pbcast.STABLE
-
- MAX_SUSPEND_TIMEOUT - Static variable in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- max_time - Variable in class org.jgroups.protocols.SHUFFLE
-
- max_tries - Variable in class org.jgroups.protocols.FD
-
- max_writes - Variable in class org.jgroups.protocols.FILE_PING.InfoWriter
-
- max_writes - Variable in class org.jgroups.protocols.JDBC_PING.InfoWriter
-
- max_xmit_req_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- max_xmit_req_size - Variable in class org.jgroups.protocols.UNICAST3
-
- maxSendBuffers() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- maxSendBuffers(int) - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- maxSeqnos(View, List<Digest>) - Static method in class org.jgroups.protocols.pbcast.FLUSH
-
Returns a digest which contains, for all members of view, the highest delivered and received
seqno of all digests
- MBean - Annotation Type in org.jgroups.annotations
-
Optional annotation that exposes all public methods in the class
hierarchy (excluding Object) as MBean operations.
- MBEAN_DESCRITION - Static variable in class org.jgroups.jmx.ResourceDMBean
-
- mbr - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- mbr - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- mbr(Address) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- mbrs - Variable in class org.jgroups.protocols.FD.FdHeader
-
- mbrs - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- mbrs - Variable in class org.jgroups.protocols.PingData
-
- mbrs(Collection<? extends Address>) - Method in class org.jgroups.protocols.PingData
-
- mbrs() - Method in class org.jgroups.protocols.PingData
-
- mcast_addr - Variable in class org.jgroups.protocols.UDP
-
The multicast address (mcast address and port) this member uses
- mcast_group_addr - Variable in class org.jgroups.protocols.UDP
-
- mcast_port - Variable in class org.jgroups.protocols.UDP
-
- mcast_queue - Variable in class org.jgroups.protocols.BARRIER
-
- mcast_receiver - Variable in class org.jgroups.protocols.UDP
-
Runnable to receive multicast packets
- mcast_recv_buf_size - Variable in class org.jgroups.protocols.UDP
-
- mcast_send_buf_size - Variable in class org.jgroups.protocols.UDP
-
- mcast_sock - Variable in class org.jgroups.protocols.UDP
-
IP multicast socket for receiving multicast packets
- mcastEntries() - Method in class org.jgroups.blocks.ReplCache
-
- md5(String) - Static method in class org.jgroups.util.Util
-
Converts a java.lang.String in to a MD5 hashed String
- MD5Token - Class in org.jgroups.auth
-
This is an example of using a preshared token that is encrypted using an MD5/SHA hash for
authentication purposes.
- MD5Token() - Constructor for class org.jgroups.auth.MD5Token
-
- MD5Token(String) - Constructor for class org.jgroups.auth.MD5Token
-
- MD5Token(String, String) - Constructor for class org.jgroups.auth.MD5Token
-
- mech - Variable in class org.jgroups.protocols.SASL
-
- member - Variable in exception org.jgroups.UnreachableException
-
- member - Variable in class org.jgroups.util.Digest.Entry
-
- members - Variable in class org.jgroups.blocks.MessageDispatcher
-
- members - Variable in class org.jgroups.protocols.DISCARD
-
- members - Variable in class org.jgroups.protocols.Discovery
-
- members - Variable in class org.jgroups.protocols.FD
-
- members - Variable in class org.jgroups.protocols.FD_ALL
-
- members - Variable in class org.jgroups.protocols.FD_ALL2
-
- members - Variable in class org.jgroups.protocols.FD_HOST
-
- members - Variable in class org.jgroups.protocols.FD_SOCK
-
- members - Variable in class org.jgroups.protocols.FRAG2
-
- members - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- members - Variable in class org.jgroups.protocols.pbcast.GMS
-
- members - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- members - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- members - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- members - Variable in class org.jgroups.protocols.relay.RELAY2
-
- members - Variable in class org.jgroups.protocols.RSVP
-
- members - Variable in class org.jgroups.protocols.SIZE
-
- members(List<PingData>) - Method in class org.jgroups.protocols.TCPGOSSIP
-
- members - Variable in class org.jgroups.protocols.TP
-
The members of this group (updated when a member joins or leaves).
- members - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- members - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- members - Variable in class org.jgroups.protocols.UNICAST3
-
- members(List<PingData>) - Method in interface org.jgroups.stack.RouterStub.MembersNotification
-
- members - Variable in class org.jgroups.util.Digest
-
- members - Variable in class org.jgroups.View
-
An array containing all the members of the view.
- Membership - Class in org.jgroups
-
Represents a membership of a cluster group.
- Membership() - Constructor for class org.jgroups.Membership
-
Creates a member ship object with zero members
- Membership(Collection<Address>) - Constructor for class org.jgroups.Membership
-
Creates a Membership with a given initial members.
- membership_change_policy - Variable in class org.jgroups.protocols.pbcast.GMS
-
- membership_listener - Variable in class org.jgroups.blocks.MessageDispatcher
-
- MembershipChangePolicy - Interface in org.jgroups.stack
-
Policy used to determine the new membership after a membership change (join, leave) or a merge.
- MembershipListener - Interface in org.jgroups
-
Allows a listener to be notified when group membership changes.
- MemcachedConnector - Class in org.jgroups.blocks
-
Class which listens on a server socket for memcached clients, reads the requests, forwards them to an instance of
PartitionedHashMap and sends the response.
- MemcachedConnector(InetAddress, int, PartitionedHashMap<String, byte[]>) - Constructor for class org.jgroups.blocks.MemcachedConnector
-
- MemcachedConnector.Request - Class in org.jgroups.blocks
-
- MemcachedConnector.Request.Type - Enum in org.jgroups.blocks
-
- MemcachedServer - Class in org.jgroups.demos
-
Server process which listens for memcached requests and forwards them to an instance of PartitionedHashMap.
- MemcachedServer() - Constructor for class org.jgroups.demos.MemcachedServer
-
- MERGE - Static variable in class org.jgroups.Event
-
- merge(Collection<Address>, Collection<Address>) - Method in class org.jgroups.Membership
-
Merges membership with the new members and removes suspects.
- merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.Merger
-
Invoked upon receiving a MERGE event from the MERGE layer.
- merge(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
-
Invoked upon receiving a MERGE event from the MERGE layer.
- merge(T) - Method in class org.jgroups.util.Average
-
Merges this average with another one
- merge(T) - Method in class org.jgroups.util.AverageMinMax
-
- merge(Digest) - Method in class org.jgroups.util.MutableDigest
-
Adds a digest to this digest.
- merge(Address, long, long) - Method in class org.jgroups.util.MutableDigest
-
Similar to set(), but if the sender already exists, its seqnos will be modified (no new entry) as follows:
this.highest_delivered_seqno=max(this.highest_delivered_seqno, highest_delivered_seqno)
this.highest_received_seqno=max(this.highest_received_seqno, highest_received_seqno)
- MERGE2 - Class in org.jgroups.protocols
-
- MERGE2() - Constructor for class org.jgroups.protocols.MERGE2
-
Deprecated.
- MERGE2.FindSubgroupsTask - Class in org.jgroups.protocols
-
Deprecated.
Task periodically executing (if role is coordinator).
- MERGE2.MergeHeader - Class in org.jgroups.protocols
-
Deprecated.
- MERGE3 - Class in org.jgroups.protocols
-
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
- MERGE3() - Constructor for class org.jgroups.protocols.MERGE3
-
- MERGE3.InfoSender - Class in org.jgroups.protocols
-
- MERGE3.MergeHeader - Class in org.jgroups.protocols
-
- MERGE3.MergeHeader.Type - Enum in org.jgroups.protocols
-
- MERGE3.ViewConsistencyChecker - Class in org.jgroups.protocols
-
- merge_ack_collector - Variable in class org.jgroups.protocols.pbcast.GMS
-
- merge_candidates - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- MERGE_DIGEST - Static variable in class org.jgroups.Event
-
- merge_fast - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- merge_fast_delay - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- merge_id - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- merge_id - Variable in class org.jgroups.protocols.pbcast.Merger
-
- merge_id_history - Variable in class org.jgroups.protocols.pbcast.Merger
-
- MERGE_ID_PRESENT - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- merge_killer - Variable in class org.jgroups.protocols.pbcast.Merger
-
- MERGE_REJECTED - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- merge_rejected - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- merge_rejected - Variable in class org.jgroups.protocols.pbcast.MergeData
-
- MERGE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- MERGE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- merge_rsps - Variable in class org.jgroups.protocols.pbcast.Merger
-
For MERGE_REQ/MERGE_RSP correlation, contains MergeData elements
- merge_task - Variable in class org.jgroups.protocols.pbcast.Merger
-
- merge_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
-
- MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- MergeData - Class in org.jgroups.protocols.pbcast
-
Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW (handleMergeView()).
Note that since MergeData is never sent across the network, it doesn't need to be Streamable.
- MergeData(Address, View, Digest, boolean) - Constructor for class org.jgroups.protocols.pbcast.MergeData
-
- MergeData(Address, View, Digest) - Constructor for class org.jgroups.protocols.pbcast.MergeData
-
- mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Send down a MERGE_DIGEST event
- mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
For all members of the digest, adjust the retransmit buffers in xmit_table.
- mergeFast(Address, Address) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- MergeHeader() - Constructor for class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- MergeHeader(byte, View) - Constructor for class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- MergeHeader() - Constructor for class org.jgroups.protocols.MERGE3.MergeHeader
-
- MergeHeader(MERGE3.MergeHeader.Type, ViewId, String, PhysicalAddress) - Constructor for class org.jgroups.protocols.MERGE3.MergeHeader
-
- mergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- MergeId - Class in org.jgroups.util
-
ID to uniquely identify a merge
- MergeId() - Constructor for class org.jgroups.util.MergeId
-
- merger - Variable in class org.jgroups.protocols.pbcast.GMS
-
- merger - Variable in class org.jgroups.protocols.pbcast.GmsImpl
-
- Merger - Class in org.jgroups.protocols.pbcast
-
Handles merging.
- Merger(GMS) - Constructor for class org.jgroups.protocols.pbcast.Merger
-
- Merger.MergeKiller - Class in org.jgroups.protocols.pbcast
-
- Merger.MergeTask - Class in org.jgroups.protocols.pbcast
-
Starts the merge protocol (only run by the merge leader).
- mergeRejected(boolean) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- MergeTask() - Constructor for class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- MergeView - Class in org.jgroups
-
A view that is sent as a result of a cluster merge.
- MergeView() - Constructor for class org.jgroups.MergeView
-
- MergeView(ViewId, List<Address>, List<View>) - Constructor for class org.jgroups.MergeView
-
Creates a new merge view
- MergeView(ViewId, Address[], List<View>) - Constructor for class org.jgroups.MergeView
-
- MergeView(Address, long, List<Address>, List<View>) - Constructor for class org.jgroups.MergeView
-
Creates a new view
- Message - Class in org.jgroups
-
A Message encapsulates data sent to members of a group.
- Message(Address) - Constructor for class org.jgroups.Message
-
Constructs a Message given a destination Address
- Message(Address, Address, byte[]) - Constructor for class org.jgroups.Message
-
Constructs a Message given a destination Address, a source Address and the payload byte buffer
- Message(Address, byte[]) - Constructor for class org.jgroups.Message
-
- Message(Address, Address, byte[], int, int) - Constructor for class org.jgroups.Message
-
Constructs a message.
- Message(Address, byte[], int, int) - Constructor for class org.jgroups.Message
-
- Message(Address, Address, Object) - Constructor for class org.jgroups.Message
-
Constructs a Message given a destination Address, a source Address and the payload Object
- Message(Address, Object) - Constructor for class org.jgroups.Message
-
- Message() - Constructor for class org.jgroups.Message
-
- Message(boolean) - Constructor for class org.jgroups.Message
-
- Message.Flag - Enum in org.jgroups
-
- Message.TransientFlag - Enum in org.jgroups
-
- message_format - Variable in class org.jgroups.util.SuppressLog
-
- MessageBatch - Class in org.jgroups.util
-
Represents a message batch; multiple messages from the same sender to the same receiver(s).
- MessageBatch(int) - Constructor for class org.jgroups.util.MessageBatch
-
- MessageBatch(Collection<Message>) - Constructor for class org.jgroups.util.MessageBatch
-
- MessageBatch(Address, Address, AsciiString, boolean, Collection<Message>) - Constructor for class org.jgroups.util.MessageBatch
-
- MessageBatch(Address, Address, AsciiString, boolean, Collection<Message>, Filter<Message>) - Constructor for class org.jgroups.util.MessageBatch
-
- MessageBatch(Address, Address, AsciiString, boolean, MessageBatch.Mode, int) - Constructor for class org.jgroups.util.MessageBatch
-
- MessageBatch.BatchIterator - Class in org.jgroups.util
-
Iterates over non-null elements of a batch, skipping null elements
- MessageBatch.Mode - Enum in org.jgroups.util
-
- MessageBatch.Visitor<T> - Interface in org.jgroups.util
-
Used for iteration over the messages
- MessageDialog - Class in org.jgroups.demos.wb
-
- MessageDialog(Frame, String, String) - Constructor for class org.jgroups.demos.wb.MessageDialog
-
- MessageDispatcher - Class in org.jgroups.blocks
-
Provides synchronous and asynchronous message sending with request-response
correlation; i.e., matching responses with the original request.
- MessageDispatcher() - Constructor for class org.jgroups.blocks.MessageDispatcher
-
- MessageDispatcher(Channel, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.MessageDispatcher
-
- MessageDispatcher(Channel, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
-
- MessageDispatcher(Channel, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
-
- messageGapDetected(long, long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
-
Deprecated.
- MessageID - Class in org.jgroups.protocols.tom
-
The represents an unique identifier for the messages processed by the Total Order Anycast protocol
Note: it is similar to the ViewId (address + counter)
- MessageID() - Constructor for class org.jgroups.protocols.tom.MessageID
-
- MessageID(Address, long) - Constructor for class org.jgroups.protocols.tom.MessageID
-
- MessageListener - Interface in org.jgroups
-
MessageListener allows a listener to be notified when a
Message
or a state transfer
events arrives to a node.
- MessageQueue() - Constructor for class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- MESSAGES - Static variable in class org.jgroups.demos.StompChat
-
- messages - Variable in class org.jgroups.util.MessageBatch
-
The storage of the messages; removed messages have a null element
- messageToByteBuffer(Message) - Static method in class org.jgroups.util.Util
-
- Metadata() - Constructor for class org.jgroups.blocks.GridFile.Metadata
-
- Metadata(int, long, int, byte) - Constructor for class org.jgroups.blocks.GridFile.Metadata
-
- metadata - Variable in class org.jgroups.blocks.GridFilesystem
-
- method - Variable in class org.jgroups.blocks.MethodCall
-
The Method of the call.
- METHOD - Static variable in class org.jgroups.blocks.MethodCall
-
Explicitly ship the method, caller has to determine method himself.
- method - Variable in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- method_id - Variable in class org.jgroups.blocks.MethodCall
-
The ID of a method, maps to a java.lang.reflect.Method
- method_lookup - Variable in class org.jgroups.blocks.RpcDispatcher
-
- method_name - Variable in class org.jgroups.blocks.MethodCall
-
The name of the method, case sensitive.
- MethodAccessor(Method, Object) - Constructor for class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- MethodCall - Class in org.jgroups.blocks
-
A method call is the JGroups representation of a remote method.
- MethodCall() - Constructor for class org.jgroups.blocks.MethodCall
-
Creates an empty method call, this is always invalid, until
setName()
has been called.
- MethodCall(Method) - Constructor for class org.jgroups.blocks.MethodCall
-
- MethodCall(Method, Object...) - Constructor for class org.jgroups.blocks.MethodCall
-
- MethodCall(short, Object...) - Constructor for class org.jgroups.blocks.MethodCall
-
- MethodCall(String, Object[], Class[]) - Constructor for class org.jgroups.blocks.MethodCall
-
- MethodLookup - Interface in org.jgroups.blocks
-
- methodNameToAttributeName(String) - Static method in class org.jgroups.util.Util
-
Converts a method name to an attribute name, e.g.
- methodNameToJavaAttributeName(String) - Static method in class org.jgroups.util.Util
-
Converts a method name to a Java attribute name, e.g.
- methods - Static variable in class org.jgroups.blocks.PartitionedHashMap
-
- methods - Static variable in class org.jgroups.blocks.ReplCache
-
- methods - Static variable in class org.jgroups.blocks.ReplicatedHashMap
-
- MFC - Class in org.jgroups.protocols
-
Simple flow control protocol based on a credit system.
- MFC() - Constructor for class org.jgroups.protocols.MFC
-
- MFC_CREDIT_REQUEST_HDR - Static variable in class org.jgroups.protocols.MFC
-
- MFC_REPLENISH_HDR - Static variable in class org.jgroups.protocols.MFC
-
- micro - Static variable in class org.jgroups.Version
-
- micros() - Static method in class org.jgroups.util.Util
-
- min - Variable in class org.jgroups.util.AverageMinMax
-
- min() - Method in class org.jgroups.util.AverageMinMax
-
- min() - Method in class org.jgroups.util.RpcStats.Result
-
- min_credits - Variable in class org.jgroups.protocols.FlowControl
-
Computed as max_credits times min_theshold.
- min_credits - Variable in class org.jgroups.util.CreditMap
-
- min_interval - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- min_interval - Variable in class org.jgroups.protocols.MERGE3
-
- MIN_NUMBER_OF_BUNDLING_TASKS - Static variable in class org.jgroups.protocols.SenderSendsWithTimerBundler
-
Deprecated.
- min_size - Variable in class org.jgroups.protocols.COMPRESS
-
- min_size - Variable in class org.jgroups.protocols.SIZE
-
Min size in bytes above which msgs should be printed
- min_threshold - Variable in class org.jgroups.protocols.FlowControl
-
If we're down to (min_threshold * max_credits) bytes for P, we send more credits to P.
- min_time_between_key_requests - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- MIN_WAIT_BETWEEN_DISCOVERIES - Static variable in class org.jgroups.protocols.TP
-
- minor - Static variable in class org.jgroups.Version
-
- minTimeBetweenKeyRequests() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- minTimeBetweenKeyRequests(long) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- missing() - Method in class org.jgroups.util.RingBufferSeqno
-
- missing() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- Missing(long, int) - Constructor for class org.jgroups.util.Table.Missing
-
- missing_acks - Variable in class org.jgroups.util.AckCollector
-
List of members from whom we haven't received an ACK yet
- missing_elements - Variable in class org.jgroups.util.Table.Missing
-
- missingMessageReceived(long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
-
Deprecated.
- mkdir() - Method in class org.jgroups.blocks.GridFile
-
- mkdirs() - Method in class org.jgroups.blocks.GridFile
-
- MockSocketChannel - Class in org.jgroups.nio
-
A mock SocketChannel
for testing
- MockSocketChannel() - Constructor for class org.jgroups.nio.MockSocketChannel
-
- MockSocketChannel(SelectorProvider) - Constructor for class org.jgroups.nio.MockSocketChannel
-
Initializes a new instance of this class.
- MockTimeScheduler - Class in org.jgroups.util
-
- MockTimeScheduler() - Constructor for class org.jgroups.util.MockTimeScheduler
-
- mode - Variable in class org.jgroups.blocks.MethodCall
-
Which mode to use.
- mode - Variable in class org.jgroups.blocks.RequestOptions
-
The mode of a request.
- mode - Variable in class org.jgroups.util.MessageBatch
-
Whether this message batch contains only OOB messages, or only regular messages
- mode() - Method in class org.jgroups.util.MessageBatch
-
- mode(MessageBatch.Mode) - Method in class org.jgroups.util.MessageBatch
-
- modifyStateResponseHeader(StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- modifyStateResponseHeader(StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- Monitor() - Constructor for class org.jgroups.protocols.FD.Monitor
-
- monitor_future - Variable in class org.jgroups.protocols.FD
-
- mostSigBits - Variable in class org.jgroups.util.UUID
-
- mouseClicked(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
-
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.Draw.DrawPanel
-
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mouseEntered(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mouseExited(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
-
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.Draw.DrawPanel
-
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mousePressed(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- mouseReleased(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
-
- move(int) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Moves contents of matrix num_rows down.
- move(int) - Method in class org.jgroups.util.Table
-
Moves contents of matrix num_rows down.
- moveNode(Node) - Method in class org.jgroups.demos.wb.GraphPanel
-
- moveNode(Node) - Method in class org.jgroups.demos.wb.Whiteboard
-
- moveStubToReconnects(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
-
- MPING - Class in org.jgroups.protocols
-
Uses its own IP multicast socket to send and receive discovery requests/responses.
- MPING() - Constructor for class org.jgroups.protocols.MPING
-
- MPING_IP_TTL - Static variable in class org.jgroups.Global
-
- MPING_MCAST_ADDR - Static variable in class org.jgroups.Global
-
- MPING_MCAST_PORT - Static variable in class org.jgroups.Global
-
- MSG - Static variable in class org.jgroups.Event
-
- MSG - Static variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
-
- MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- MSG - Static variable in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- msg - Variable in class org.jgroups.protocols.TP.SingleMessageHandler
-
- MSG_BUF_SIZE - Static variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- msg_counts_as_heartbeat - Variable in class org.jgroups.protocols.FD_ALL
-
- msg_counts_as_heartbeat - Variable in class org.jgroups.protocols.FD_ALL2
-
- msg_listener - Variable in class org.jgroups.blocks.MessageDispatcher
-
- MSG_OVERHEAD - Static variable in class org.jgroups.protocols.TP
-
- msg_queue - Variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- msg_sender - Variable in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- msgFromXmitRsp(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- msgs - Variable in class org.jgroups.protocols.BaseBundler
-
Keys are destinations, values are lists of Messages
- msgs - Variable in class org.jgroups.protocols.UNICAST3.Entry
-
- msgs_forwarded - Variable in class org.jgroups.protocols.DAISYCHAIN
-
- msgs_per_row - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
Must be a power of 2 for efficient modular arithmetic
- msgs_sent - Variable in class org.jgroups.protocols.DAISYCHAIN
-
- MULTICAST - Static variable in class org.jgroups.protocols.TP
-
- multicast - Variable in class org.jgroups.util.MessageBatch
-
Whether all messages have dest == null (multicast) or not
- multicast() - Method in class org.jgroups.util.MessageBatch
-
- multicasts - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- multicasts(boolean) - Method in class org.jgroups.protocols.MAKE_BATCH
-
- multicasts(boolean) - Method in class org.jgroups.util.RpcStats
-
- MultiDestinationHeader() - Constructor for class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
- MultiDestinationHeader(byte, long, short, Address[]) - Constructor for class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
- MutableDigest - Class in org.jgroups.util
-
A mutable version of Digest.
- MutableDigest(Address[]) - Constructor for class org.jgroups.util.MutableDigest
-
- MutableDigest(Digest) - Constructor for class org.jgroups.util.MutableDigest
-
Only used for testing
- MUX_ID - Static variable in class org.jgroups.blocks.mux.MuxRequestCorrelator
-
- Muxer<T> - Interface in org.jgroups.blocks.mux
-
Allows registration/deregistrator of multiplexed handlers by mux id.
- MuxHeader - Class in org.jgroups.blocks.mux
-
Header that identifies the target handler for multiplexed dispatches.
- MuxHeader() - Constructor for class org.jgroups.blocks.mux.MuxHeader
-
- MuxHeader(short) - Constructor for class org.jgroups.blocks.mux.MuxHeader
-
- MuxMessageDispatcher - Class in org.jgroups.blocks.mux
-
A multiplexed message dispatcher.
- MuxMessageDispatcher(short) - Constructor for class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- MuxMessageDispatcher(short, Channel, MessageListener, MembershipListener, RequestHandler) - Constructor for class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- MuxRequestCorrelator - Class in org.jgroups.blocks.mux
-
A request correlator that adds a mux header to incoming and outgoing messages.
- MuxRequestCorrelator(short, Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.mux.MuxRequestCorrelator
-
- MuxRpcDispatcher - Class in org.jgroups.blocks.mux
-
A multiplexed message dispatcher.
- MuxRpcDispatcher(short) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- MuxRpcDispatcher(short, Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- MuxRpcDispatcher(short, Channel, MessageListener, MembershipListener, Object, MethodLookup) - Constructor for class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- MuxUpHandler - Class in org.jgroups.blocks.mux
-
Allows up handler multiplexing.
- MuxUpHandler() - Constructor for class org.jgroups.blocks.mux.MuxUpHandler
-
Creates a multiplexing up handler, with no default handler.
- MuxUpHandler(UpHandler) - Constructor for class org.jgroups.blocks.mux.MuxUpHandler
-
Creates a multiplexing up handler using the specified default handler.
- my_addr - Variable in class org.jgroups.demos.wb.GraphPanel
-
- my_digest - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- my_merge_id - Variable in class org.jgroups.protocols.pbcast.Merger.MergeKiller
-
- my_view - Variable in class org.jgroups.JChannel
-
- MyFuture() - Constructor for class org.jgroups.blocks.ConnectionTableNIO.MyFuture
-
- MyIterator() - Constructor for class org.jgroups.util.Digest.MyIterator
-
- MyNotification(String, Object, long) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
-
- MyNotification(String, Object, long, String) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
-
- MyNotification(String, Object, long, long) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
-
- MyNotification(String, Object, long, long, String) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
-
- MyProbeHandler() - Constructor for class org.jgroups.blocks.RequestCorrelator.MyProbeHandler
-
- MyReceiver<T> - Class in org.jgroups.util
-
Generic receiver for a JChannel
- MyReceiver() - Constructor for class org.jgroups.util.MyReceiver
-
- MyTask(Runnable, int) - Constructor for class org.jgroups.util.HashedTimingWheel.MyTask
-
- MyTask(Runnable) - Constructor for class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- p1 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p2 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p3 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p4 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p5 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p6 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- p7 - Variable in class org.jgroups.util.PaddedAtomicLong
-
- PACKAGES - Static variable in class org.jgroups.util.XMLSchemaGenerator
-
- PacketReceiver(DatagramSocket, String, Runnable) - Constructor for class org.jgroups.protocols.UDP.PacketReceiver
-
- PaddedAtomicBoolean - Class in org.jgroups.util
-
- PaddedAtomicBoolean(boolean) - Constructor for class org.jgroups.util.PaddedAtomicBoolean
-
- PaddedAtomicInteger - Class in org.jgroups.util
-
- PaddedAtomicInteger(int) - Constructor for class org.jgroups.util.PaddedAtomicInteger
-
- PaddedAtomicLong - Class in org.jgroups.util
-
Copied from http://mechanical-sympathy.blogspot.ch/2011/08/false-sharing-java-7.html.
- PaddedAtomicLong(long) - Constructor for class org.jgroups.util.PaddedAtomicLong
-
- paint(Graphics) - Method in class org.jgroups.demos.applets.DrawApplet
-
- paint(Graphics) - Method in class org.jgroups.demos.Topology
-
- paintComponent(Graphics) - Method in class org.jgroups.demos.Draw.DrawPanel
-
- paintNode(Graphics, Node, FontMetrics) - Method in class org.jgroups.demos.wb.GraphPanel
-
- PARK - Static variable in class org.jgroups.protocols.RingBufferBundler
-
- parker - Variable in class org.jgroups.protocols.Locking.ClientCondition
-
This is okay only having 1 since a client condition is 1 per
lock_name, thread id combination.
- parse(InputStream) - Static method in class org.jgroups.conf.ClassConfigurator
-
- parse(InputStream, Boolean) - Static method in class org.jgroups.conf.XmlConfigurator
-
- parse(Element) - Static method in class org.jgroups.conf.XmlConfigurator
-
- parse(InputStream) - Static method in class org.jgroups.fork.ForkConfig
-
Parses the input and returns a map of fork-stack IDs and lists of ProtocolConfigurations
- parse(Node) - Static method in class org.jgroups.fork.ForkConfig
-
- parse(Node) - Method in class org.jgroups.protocols.FORK
-
- parse(InputStream, Map<String, RelayConfig.SiteConfig>) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
Parses site names and their configuration (e.g.
- parse(Node, Map<String, RelayConfig.SiteConfig>) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- parse(Node) - Method in class org.jgroups.protocols.relay.RELAY2
-
- parse(Node) - Method in class org.jgroups.stack.Protocol
-
Called by the XML parser when subelements are found in the configuration of a protocol.
- parseBridges(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- parseBridgesAndForwards(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- parseClassData(Node) - Static method in class org.jgroups.conf.ClassConfigurator
-
- parseCommaDelimitedHosts(String, int) - Static method in class org.jgroups.util.Util
-
Input is "daddy[8880],sindhu[8880],camille[5555].
- parseCommaDelimitedHosts2(String, int) - Static method in class org.jgroups.util.Util
-
Input is "daddy[8880],sindhu[8880],camille[5555].
- parseCommaDelimitedInts(String) - Static method in class org.jgroups.util.Util
-
Parses comma-delimited longs; e.g., 2000,4000,8000.
- parseCommaDelimitedLongs(String) - Static method in class org.jgroups.util.Util
-
Parses comma-delimited longs; e.g., 2000,4000,8000.
- parseCommaDelimitedProps(String) - Static method in class org.jgroups.util.Util
-
- parseCommaDelimitedStrings(String) - Static method in class org.jgroups.util.Util
-
e.g.
- parseConfig(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- parseConfigurations(String) - Static method in class org.jgroups.stack.Configurator
-
Return a number of ProtocolConfigurations in a vector
- parseForkStack(Map<String, List<ProtocolConfiguration>>, Node) - Static method in class org.jgroups.fork.ForkConfig
-
- parseForwards(RelayConfig.SiteConfig, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- parseInterfaceList(String) - Static method in class org.jgroups.util.Util
-
- parseLockNames(String) - Static method in class org.jgroups.demos.LockServiceDemo
-
- parsePropertiesString(Map<String, String>) - Method in class org.jgroups.conf.ProtocolConfiguration
-
- parseProtocols(Element) - Static method in class org.jgroups.conf.XmlConfigurator
-
- parseRejectionPolicy(String) - Static method in class org.jgroups.util.Util
-
- parseRule(Node) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- parseRules(InputStream) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- parseSiteConfiguration(Map<String, RelayConfig.SiteConfig>) - Method in class org.jgroups.protocols.relay.RELAY2
-
Parses the configuration by reading the config file.
- parseSiteMasters(String) - Static method in class org.jgroups.demos.RelayDemoRpc
-
- parseSites(Map<String, RelayConfig.SiteConfig>, Node) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
-
- parseStringList(String, String) - Static method in class org.jgroups.util.Util
-
- PART - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- partial_writes - Variable in class org.jgroups.blocks.cs.NioConnection
-
- ParticipantGmsImpl - Class in org.jgroups.protocols.pbcast
-
- ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
- PARTICIPANTS_PRESENT - Static variable in class org.jgroups.protocols.pbcast.FLUSH
-
- PartitionedHashMap<K,V> - Class in org.jgroups.blocks
-
Hashmap which distributes its keys and values across the cluster.
- PartitionedHashMap(String, String) - Constructor for class org.jgroups.blocks.PartitionedHashMap
-
- PartitionedHashMap.ConsistentHashFunction<K> - Class in org.jgroups.blocks
-
- PartitionedHashMap.HashFunction<K> - Interface in org.jgroups.blocks
-
- PartitionedHashMapDemo - Class in org.jgroups.demos
-
- PartitionedHashMapDemo() - Constructor for class org.jgroups.demos.PartitionedHashMapDemo
-
- passBatchUp(MessageBatch, boolean, boolean) - Method in class org.jgroups.protocols.TP
-
- passcode - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- passMessageUp(Message, AsciiString, boolean, boolean, boolean) - Method in class org.jgroups.protocols.TP
-
- passToAllUpProtocols(Event) - Method in class org.jgroups.protocols.TP
-
- password - Variable in class org.jgroups.client.StompConnection
-
- password - Variable in class org.jgroups.protocols.SWIFT_PING
-
- pattern - Variable in class org.jgroups.auth.RegexMembership
-
- pattern - Variable in class org.jgroups.protocols.CertficateCNMatcher
-
- patternMatch(String, String) - Static method in class org.jgroups.util.Util
-
- payload - Variable in class org.jgroups.auth.DemoToken.DemoHeader
-
- payload(byte[]) - Method in class org.jgroups.protocols.SaslHeader
-
- PAYLOAD - Static variable in class org.jgroups.util.PayloadUUID
-
Deprecated.
- PayloadUUID - Class in org.jgroups.util
-
- PayloadUUID() - Constructor for class org.jgroups.util.PayloadUUID
-
Deprecated.
- PayloadUUID(byte[], String) - Constructor for class org.jgroups.util.PayloadUUID
-
Deprecated.
- PDC - Class in org.jgroups.protocols
-
Persistent Discovery Cache.
- PDC() - Constructor for class org.jgroups.protocols.PDC
-
- PDC.Mapping - Class in org.jgroups.protocols
-
- peek() - Method in class org.jgroups.util.Queue
-
returns the first object on the queue, without removing it.
- peek(long) - Method in class org.jgroups.util.Queue
-
returns the first object on the queue, without removing it.
- peer_addr - Variable in class org.jgroups.blocks.cs.Connection
-
- peer_addr_read_timeout - Variable in class org.jgroups.blocks.cs.TcpBaseServer
-
- peer_addr_read_timeout - Variable in class org.jgroups.protocols.BasicTCP
-
- PEER_LOCK - Class in org.jgroups.protocols
-
- PEER_LOCK() - Constructor for class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- PEER_LOCK.PeerLock - Class in org.jgroups.protocols
-
Deprecated.
Lock implementation which grants a lock when all non faulty cluster members OK it.
- peerAddress() - Method in class org.jgroups.blocks.cs.Connection
-
- peerAddress() - Method in class org.jgroups.blocks.cs.NioConnection
-
- peerAddress() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- peerAddressReadTimeout() - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- peerAddressReadTimeout(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- PeerLock(String) - Constructor for class org.jgroups.protocols.PEER_LOCK.PeerLock
-
Deprecated.
- pending_release_reqs - Variable in class org.jgroups.protocols.Locking.ClientLockTable
-
- pending_requests - Variable in class org.jgroups.auth.DemoToken
-
- pending_requests - Variable in class org.jgroups.protocols.COUNTER
-
- PERF - Class in org.jgroups.protocols
-
Protocol measuring latency between stacks.
- PERF() - Constructor for class org.jgroups.protocols.PERF
-
- PERF.PerfHeader - Class in org.jgroups.protocols
-
- PerfHeader() - Constructor for class org.jgroups.protocols.PERF.PerfHeader
-
- PerfHeader(long) - Constructor for class org.jgroups.protocols.PERF.PerfHeader
-
- period - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
-
- periodic_task - Variable in class org.jgroups.util.ResponseCollectorTask
-
- phys_addr - Variable in class org.jgroups.stack.GossipRouter.Entry
-
- phys_addr - Variable in class org.jgroups.stack.RouterStubManager
-
- physical_addr - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
-
- physical_addr - Variable in class org.jgroups.protocols.PDC.Mapping
-
- physical_addr - Variable in class org.jgroups.protocols.PingData
-
- physical_addr - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
- physical_addr_max_fetch_attempts - Variable in class org.jgroups.protocols.TP
-
- PhysicalAddress - Interface in org.jgroups
-
Represents a physical (as opposed to logical) address
- pickNext(List<T>, T) - Static method in class org.jgroups.util.Util
-
Returns the object next to element in list
- pickNext(List<T>, T, int) - Static method in class org.jgroups.util.Util
-
Returns the next min(N,list.size()) elements after obj
- pickRandomElement(List<T>) - Static method in class org.jgroups.util.Util
-
- pickRandomElement(T[]) - Static method in class org.jgroups.util.Util
-
- pickRoute(String, List<Route>, Address) - Method in interface org.jgroups.protocols.relay.SiteMasterPicker
-
Picks a route to a given remote site from a list of routes.
- pickSiteMaster(Address) - Method in class org.jgroups.protocols.relay.RELAY2
-
Returns a site master from site_masters
- pickSiteMaster(List<Address>, Address) - Method in interface org.jgroups.protocols.relay.SiteMasterPicker
-
Needs to pick a member from a list of addresses of site masters
- pickSubset(List<Address>, double) - Static method in class org.jgroups.util.Util
-
Selects a random subset of members according to subset_percentage and returns them.
- pickThreadPool(boolean, boolean) - Method in class org.jgroups.protocols.TP
-
- PING - Class in org.jgroups.protocols
-
The PING protocol retrieves the initial membership by mcasting a discovery request (via the multicast capable
transport) to all current cluster members
The responses should allow us to determine the coordinator which we have to contact, e.g.
- PING() - Constructor for class org.jgroups.protocols.PING
-
- ping_addr_promise - Variable in class org.jgroups.protocols.FD_SOCK
-
- ping_command - Variable in class org.jgroups.protocols.FD_HOST
-
The command to detect whether a target is alive
- ping_dest - Variable in class org.jgroups.protocols.FD
-
- ping_dest - Variable in class org.jgroups.protocols.FD_SOCK
-
- ping_input - Variable in class org.jgroups.protocols.FD_SOCK
-
- ping_responses - Variable in class org.jgroups.protocols.Discovery
-
- ping_rsps - Variable in class org.jgroups.util.Responses
-
- ping_sock - Variable in class org.jgroups.protocols.FD_SOCK
-
- ping_task_future - Variable in class org.jgroups.protocols.FD_HOST
-
- pingable_mbrs - Variable in class org.jgroups.protocols.FD
-
Members from which we select ping_dest.
- pingable_mbrs - Variable in class org.jgroups.protocols.FD_SOCK
-
- pingCommand(FD_HOST.PingCommand) - Method in class org.jgroups.protocols.FD_HOST
-
- PingData - Class in org.jgroups.protocols
-
Encapsulates information about a cluster node, e.g.
- PingData() - Constructor for class org.jgroups.protocols.PingData
-
- PingData(Address, boolean) - Constructor for class org.jgroups.protocols.PingData
-
- PingData(Address, View, boolean, String, Collection<PhysicalAddress>) - Constructor for class org.jgroups.protocols.PingData
-
- PingData(Address, boolean, String, PhysicalAddress) - Constructor for class org.jgroups.protocols.PingData
-
- PingData(Address, View, ViewId, boolean, String, Collection<PhysicalAddress>) - Constructor for class org.jgroups.protocols.PingData
-
- PingDataIterator(PingData[], int) - Constructor for class org.jgroups.util.Responses.PingDataIterator
-
- Pinger() - Constructor for class org.jgroups.protocols.FD_PING.Pinger
-
Deprecated.
- pinger_thread - Variable in class org.jgroups.protocols.FD_SOCK
-
- PingHeader - Class in org.jgroups.protocols
-
- PingHeader() - Constructor for class org.jgroups.protocols.PingHeader
-
- PingHeader(byte) - Constructor for class org.jgroups.protocols.PingHeader
-
- PingMonitor() - Constructor for class org.jgroups.protocols.FD_PING.PingMonitor
-
Deprecated.
- PingTask() - Constructor for class org.jgroups.protocols.FD_HOST.PingTask
-
- PlainConfigurator - Class in org.jgroups.conf
-
A ProtocolStackConfigurator for the old style properties.
- PlainConfigurator(String) - Constructor for class org.jgroups.conf.PlainConfigurator
-
Instantiates a PlainConfigurator with old style properties
- poll() - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
- poll(long, TimeUnit) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
- poll() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- poll(long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- poll() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- poll(long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- pool - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- Pool<T> - Class in org.jgroups.util
-
Manages a fixed pool of resources (e.g.
- Pool(int, Pool.Creator<T>) - Constructor for class org.jgroups.util.Pool
-
- pool - Variable in class org.jgroups.util.Pool
-
- pool - Variable in class org.jgroups.util.TimeScheduler3
-
Thread pool used to execute the tasks
- Pool.Creator<T> - Interface in org.jgroups.util
-
- Pool.Element<T> - Class in org.jgroups.util
-
- pool_size - Variable in class org.jgroups.protocols.COMPRESS
-
- pool_size - Variable in class org.jgroups.protocols.NoBundler
-
- pool_thread_keep_alive - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- poolSize(int) - Method in class org.jgroups.protocols.NoBundler
-
- poolSize() - Method in class org.jgroups.protocols.NoBundler
-
- port - Variable in class org.jgroups.protocols.S3_PING
-
- port - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
- port - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- port - Variable in class org.jgroups.protocols.STOMP
-
- port - Variable in class org.jgroups.stack.GossipRouter
-
- port() - Method in class org.jgroups.stack.GossipRouter
-
- port(int) - Method in class org.jgroups.stack.GossipRouter
-
- port_range - Variable in class org.jgroups.protocols.BPING
-
- port_range - Variable in class org.jgroups.protocols.FD_SOCK
-
- port_range - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- port_range - Variable in class org.jgroups.protocols.TP
-
- pos - Variable in class org.jgroups.util.ByteArrayDataInputStream
-
- pos - Variable in class org.jgroups.util.ByteArrayDataOutputStream
-
- position - Variable in class org.jgroups.nio.Buffers
-
- position() - Method in class org.jgroups.nio.Buffers
-
- position(int) - Method in class org.jgroups.nio.Buffers
-
- position(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- position() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- position(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- position() - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- pre_signed_delete_url - Variable in class org.jgroups.protocols.S3_PING
-
- pre_signed_put_url - Variable in class org.jgroups.protocols.S3_PING
-
- preferred_size - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- PREFIX - Static variable in class org.jgroups.Global
-
- prefix - Variable in class org.jgroups.protocols.S3_PING
-
- prepareResponse(Message) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
-
- prepareResponse(Message) - Method in class org.jgroups.blocks.RequestCorrelator
-
- preregistered_probe_handlers - Variable in class org.jgroups.protocols.TP
-
- PRESENT - Static variable in class org.jgroups.protocols.Executing
-
This is a placeholder for a key value to make a concurrent hash map
a concurrent hash set
- present_global_views - Variable in class org.jgroups.protocols.RELAY
-
- prev_members - Variable in class org.jgroups.protocols.pbcast.GMS
-
Keeps track of old members (up to num_prev_mbrs)
- prev_views - Variable in class org.jgroups.protocols.pbcast.GMS
-
Stores the last 20 views
- previousSetBit(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the index of the nearest bit that is set to true
that occurs on or before the specified starting index.
- primitives - Static variable in class org.jgroups.jmx.ResourceDMBean
-
- print(K, V) - Method in interface org.jgroups.blocks.LazyRemovalCache.Printable
-
- print(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Prints a representation of the node defined by fqn
.
- print(List<PingData>) - Static method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- print(Responses) - Static method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
- print(boolean) - Method in class org.jgroups.protocols.relay.SiteUUID
-
- print(BiConsumer<Integer, Integer>) - Static method in class org.jgroups.protocols.RingBufferBundler
-
- print() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- print() - Method in class org.jgroups.protocols.TUNNEL
-
- print() - Method in class org.jgroups.stack.RouterStubManager
-
- print() - Method in class org.jgroups.util.ExtendedUUID
-
- print() - Method in class org.jgroups.util.Responses
-
- print() - Method in class org.jgroups.util.Seqno
-
- print() - Method in class org.jgroups.util.SeqnoRange
-
- print(Collection<T>) - Static method in class org.jgroups.util.Util
-
- print(Map<T, T>) - Static method in class org.jgroups.util.Util
-
- print(ByteBuffer) - Static method in class org.jgroups.util.Util
-
- print(List<NetworkInterface>) - Static method in class org.jgroups.util.Util
-
- print(short) - Static method in class org.jgroups.Version
-
Method copied from http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
- print16(PublicKey) - Static method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- print_down - Variable in class org.jgroups.protocols.HDRS
-
- print_function - Static variable in class org.jgroups.protocols.TP
-
- print_function - Static variable in class org.jgroups.util.UUID
-
- print_local_addr - Variable in class org.jgroups.protocols.pbcast.GMS
-
- print_msg - Variable in class org.jgroups.protocols.SIZE
-
- print_physical_addrs - Variable in class org.jgroups.protocols.pbcast.GMS
-
- print_stability_history_on_failed_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
When not finding a message on an XMIT request, include the last N stability messages in the error message
- print_stability_history_on_failed_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Deprecated.
- print_up - Variable in class org.jgroups.protocols.HDRS
-
- PRINT_UUIDS - Static variable in class org.jgroups.Global
-
- print_uuids - Static variable in class org.jgroups.util.UUID
-
- printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST3
-
- printAllStocks() - Method in class org.jgroups.demos.QuoteClient
-
- printAllStocks() - Method in class org.jgroups.demos.QuoteServer
-
- printBits(boolean) - Method in class org.jgroups.util.SeqnoRange
-
- printBuffers() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
Prints send and receive buffers for all connections
- printBuffers() - Method in class org.jgroups.protocols.TCP_NIO2
-
- printBytes(long) - Static method in class org.jgroups.util.Util
-
MByte nowadays doesn't mean 1024 * 1024 bytes, but 1 million bytes, see http://en.wikipedia.org/wiki/Megabyte
- printBytes(double) - Static method in class org.jgroups.util.Util
-
- printCache() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- printCache(LazyRemovalCache.Printable) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- printCache() - Method in class org.jgroups.protocols.FD_SOCK
-
- printCache() - Method in class org.jgroups.protocols.PDC
-
- printCache() - Static method in class org.jgroups.util.UUID
-
- printClassMap() - Static method in class org.jgroups.conf.ClassConfigurator
-
- printConfigurations(Collection<ProtocolConfiguration>) - Static method in class org.jgroups.stack.Configurator
-
- printConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
- printConnections() - Method in class org.jgroups.protocols.BasicTCP
-
- printConnections() - Method in class org.jgroups.protocols.TCP
-
- printConnections() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- printConnections() - Method in class org.jgroups.protocols.TCP_NIO2
-
- printConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- printConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- printConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- printCounters() - Method in class org.jgroups.blocks.atomic.CounterService
-
- printCounters() - Method in class org.jgroups.protocols.COUNTER
-
- printCreditors() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- printCredits() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- printCredits() - Method in class org.jgroups.protocols.FlowControl
-
- printCredits() - Method in class org.jgroups.protocols.MFC
-
- printCredits() - Method in class org.jgroups.protocols.UFC
-
- printDescription() - Static method in class org.jgroups.Version
-
Returns the catenation of the description and cvs fields.
- printDigest(Digest) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- printDigestHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printDigestHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- printEvents(List<Integer>) - Static method in class org.jgroups.stack.Configurator
-
- printHeaders() - Method in class org.jgroups.Message
-
- printHeaders(Header[]) - Static method in class org.jgroups.util.Headers
-
- printHeaders() - Method in class org.jgroups.util.MessageBatch
-
- printHosts() - Method in class org.jgroups.protocols.FD_HOST
-
- printInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
-
- printListWithDelimiter(Collection<T>, String) - Static method in class org.jgroups.util.Util
-
- printListWithDelimiter(Collection<T>, String, int) - Static method in class org.jgroups.util.Util
-
- printListWithDelimiter(Collection<T>, String, int, boolean) - Static method in class org.jgroups.util.Util
-
- printListWithDelimiter(T[], String, int) - Static method in class org.jgroups.util.Util
-
- printLocks() - Method in class org.jgroups.blocks.locking.LockService
-
- printLocks() - Method in class org.jgroups.demos.LockServiceDemo
-
- printLocks() - Method in class org.jgroups.protocols.Locking
-
- printLogicalAddressCache() - Method in class org.jgroups.protocols.TP
-
- printLossRate() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- printLossRates() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printMagicMap() - Static method in class org.jgroups.conf.ClassConfigurator
-
- printMap(Map<Address, FlowControl.Credit>) - Static method in class org.jgroups.protocols.FlowControl
-
- printMapWithDelimiter(Map<T, T>, String) - Static method in class org.jgroups.util.Util
-
- printMergeIdHistory() - Method in class org.jgroups.protocols.pbcast.GMS
-
- printMessageList(List<Message>) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- printMessageList(List<Message>) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- printMessageList(List<Tuple<Long, Message>>) - Method in class org.jgroups.protocols.UNICAST3
-
- printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- printMessages() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Prints xmit_table.
- printMissing() - Method in class org.jgroups.util.AckCollector
-
- printNanos(double) - Static method in class org.jgroups.util.Util
-
- printObjectHeaders() - Method in class org.jgroups.Message
-
- printObjectHeaders(Header[]) - Static method in class org.jgroups.util.Headers
-
- printOrderByDest() - Method in class org.jgroups.util.RpcStats
-
- printOthers() - Method in class org.jgroups.protocols.relay.SiteUUID
-
- printPingData(List<PingData>) - Static method in class org.jgroups.util.Util
-
- printPreviousMembers() - Method in class org.jgroups.protocols.pbcast.GMS
-
- printPreviousViews() - Method in class org.jgroups.protocols.pbcast.GMS
-
- printProtocols(Protocol[]) - Static method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
-
- printProtocolSpec(boolean) - Method in class org.jgroups.JChannel
-
Returns a pretty-printed form of all the protocols.
- printProtocolSpec(boolean) - Method in class org.jgroups.stack.ProtocolStack
-
Prints the names of the protocols, from the bottom to top.
- printProtocolSpecAsPlainString() - Method in class org.jgroups.stack.ProtocolStack
-
- printProtocolSpecAsXML() - Method in class org.jgroups.stack.ProtocolStack
-
- printReceiverCredits() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- printReceiverCredits() - Method in class org.jgroups.protocols.FlowControl
-
- printReceiveWindowMessages() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- printReceiveWindowMessages() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- printReceiveWindowMessages() - Method in class org.jgroups.protocols.UNICAST3
-
- printReconnectList() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- printReconnectList() - Method in class org.jgroups.protocols.TUNNEL
-
- printReconnectList() - Method in class org.jgroups.stack.RouterStubManager
-
- printRetransmitStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printRetransmitStats() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- printRetransmitTableSizes() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printRoutes() - Method in class org.jgroups.protocols.relay.RELAY2
-
- printRoutes() - Method in class org.jgroups.protocols.relay.Relayer
-
- printSenderCredits() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- printSenderCredits() - Method in class org.jgroups.protocols.FlowControl
-
- printSenderCredits() - Method in class org.jgroups.protocols.MFC
-
- printSenderCredits() - Method in class org.jgroups.protocols.UFC
-
- printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST3
-
- printServerLocks() - Method in class org.jgroups.protocols.Locking
-
- printStabilityHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printStabilityHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- printStats() - Method in class org.jgroups.protocols.SEQUENCER
-
- printStats() - Method in class org.jgroups.protocols.SEQUENCER2
-
- printStats() - Method in class org.jgroups.protocols.STATS
-
- printStats() - Method in class org.jgroups.stack.Protocol
-
- printStats() - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
- printStubs() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- printStubs() - Method in class org.jgroups.protocols.TUNNEL
-
- printStubs() - Method in class org.jgroups.stack.RouterStubManager
-
- printSuspected() - Method in class org.jgroups.util.AckCollector
-
- printSuspectHistory() - Method in class org.jgroups.protocols.FD
-
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_ALL
-
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_ALL2
-
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_HOST
-
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK
-
- printTime(long, TimeUnit) - Static method in class org.jgroups.util.Util
-
- printTimestamps() - Method in class org.jgroups.protocols.FD_ALL
-
- printTimestamps() - Method in class org.jgroups.protocols.FD_ALL2
-
- printTimestamps() - Method in class org.jgroups.protocols.FD_HOST
-
- printType() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- printType() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- printValues - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- printVersion() - Static method in class org.jgroups.Version
-
Returns the version field as a String.
- printViews(JChannel...) - Static method in class org.jgroups.util.Util
-
- printViews(Collection<View>) - Static method in class org.jgroups.util.Util
-
- printWhoHasCache() - Method in class org.jgroups.protocols.TP
-
- PRIO - Class in org.jgroups.protocols
-
This protocol will provide message sending and receiving prioritization.
- PRIO() - Constructor for class org.jgroups.protocols.PRIO
-
- PRIO.PriorityMessage - Class in org.jgroups.protocols
-
This class is a simple wrapper to contain the Event, timestamp and priority of the message.
- PrioHeader - Class in org.jgroups.protocols
-
This Header class is used in conjunction with the PRIO protocol to prioritize message sending/receiving
Priority values are from 0 to 255 where 0 is the highest priority
Example of setting a message priority:
// Create a message to send to everyone
Message message = new Message( null, null, messagePayload );
// Add the priority protocol header
PrioHeader header = new PrioHeader( 1 );
short protocolId = ClassConfigurator.getProtocolId(PRIO.class);
message.putHeader( protocolId, header);
- PrioHeader() - Constructor for class org.jgroups.protocols.PrioHeader
-
- PrioHeader(byte) - Constructor for class org.jgroups.protocols.PrioHeader
-
- PriorityMessage(Event, byte) - Constructor for class org.jgroups.protocols.PRIO.PriorityMessage
-
- probe_handler - Variable in class org.jgroups.blocks.RequestCorrelator
-
- probe_handler - Variable in class org.jgroups.JChannel
-
- process(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- process(Message) - Method in class org.jgroups.protocols.EncryptBase
-
Whether or not to process this received message
- process(Socket) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- process() - Method in class org.jgroups.util.ProcessingQueue
-
- process_state_events - Variable in class org.jgroups.protocols.FORK
-
- processing - Variable in class org.jgroups.util.RingBufferSeqno
-
- processing - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
- processing - Variable in class org.jgroups.util.Table
-
- ProcessingQueue<T> - Class in org.jgroups.util
-
A queue with many producers and consumers.
- ProcessingQueue() - Constructor for class org.jgroups.util.ProcessingQueue
-
- ProcessingQueue.Handler<T> - Interface in org.jgroups.util
-
- processInternalMessage(Table<Message>, Address) - Method in class org.jgroups.protocols.UNICAST3
-
- processQueue() - Method in class org.jgroups.protocols.Locking.ServerLock
-
- producer_lock - Variable in class org.jgroups.util.ProcessingQueue
-
- productGreaterThan(long, long, long) - Static method in class org.jgroups.util.Util
-
- ProgrammaticBridgeConfig(String, Protocol[]) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
-
- ProgrammaticChat - Class in org.jgroups.demos
-
- ProgrammaticChat() - Constructor for class org.jgroups.demos.ProgrammaticChat
-
- ProgressCheckRejectionPolicy - Class in org.jgroups.util
-
Detects
- ProgressCheckRejectionPolicy(String) - Constructor for class org.jgroups.util.ProgressCheckRejectionPolicy
-
- Promise<T> - Class in org.jgroups.util
-
Allows a thread to submit an asynchronous request and to wait for the result.
- Promise() - Constructor for class org.jgroups.util.Promise
-
- PropertiesBridgeConfig(String, String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
-
- PropertiesToAsciidoc - Class in org.jgroups.util
-
Iterates over all concrete Protocol classes and creates tables with Protocol's properties.
- PropertiesToAsciidoc() - Constructor for class org.jgroups.util.PropertiesToAsciidoc
-
- propertiesToString() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- Property - Annotation Type in org.jgroups.annotations
-
Represents a Protocol property assigned from corresponding field in JGroups
properties file.
- PropertyConverter - Interface in org.jgroups.conf
-
Represents a property converter that takes an input from corresponding field
in JGroups properties file as a String and converts it to a matching Java
type.
- PropertyConverters - Class in org.jgroups.conf
-
Groups a set of standard PropertyConverter(s) supplied by JGroups.
- PropertyConverters.BindInterface - Class in org.jgroups.conf
-
- PropertyConverters.Default - Class in org.jgroups.conf
-
- PropertyConverters.FlushInvoker - Class in org.jgroups.conf
-
- PropertyConverters.InitialHosts - Class in org.jgroups.conf
-
- PropertyConverters.InitialHosts2 - Class in org.jgroups.conf
-
- PropertyConverters.IntegerArray - Class in org.jgroups.conf
-
- PropertyConverters.LongArray - Class in org.jgroups.conf
-
- PropertyConverters.NetworkInterfaceList - Class in org.jgroups.conf
-
- PropertyConverters.StringProperties - Class in org.jgroups.conf
-
- PropertyHelper - Class in org.jgroups.conf
-
- PROPOSE_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
-
- props - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- props - Variable in class org.jgroups.demos.LockServiceDemo
-
- props_handler - Variable in class org.jgroups.stack.ProtocolStack
-
- prot_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
-
- prot_id - Variable in class org.jgroups.Header
-
The ID of the protocol which added a header to a message.
- PROT_PACKAGE - Static variable in class org.jgroups.util.XMLSchemaGenerator
-
- prot_stack - Variable in class org.jgroups.JChannel
-
- Protocol - Class in org.jgroups.stack
-
The Protocol class provides a set of common services for protocol layers.
- Protocol() - Constructor for class org.jgroups.stack.Protocol
-
- PROTOCOL_ID_FILE - Static variable in class org.jgroups.conf.ClassConfigurator
-
- PROTOCOL_ID_FILE - Static variable in class org.jgroups.Global
-
- protocol_prefix - Static variable in class org.jgroups.conf.ProtocolConfiguration
-
- ProtocolAdapter(AsciiString, Address, short, Protocol, Protocol, String) - Constructor for class org.jgroups.protocols.TP.ProtocolAdapter
-
- ProtocolConfiguration - Class in org.jgroups.conf
-
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
- ProtocolConfiguration(String) - Constructor for class org.jgroups.conf.ProtocolConfiguration
-
Creates a new ProtocolConfiguration.
- ProtocolConfiguration(String, Map<String, String>) - Constructor for class org.jgroups.conf.ProtocolConfiguration
-
- ProtocolConfiguration(String, Map<String, String>, ClassLoader) - Constructor for class org.jgroups.conf.ProtocolConfiguration
-
- ProtocolHook - Interface in org.jgroups.stack
-
Provides hook(s) that are called when a protocol has been created
- protocols - Variable in class org.jgroups.fork.ForkProtocolStack
-
- protocols - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
-
- ProtocolStack - Class in org.jgroups.stack
-
A ProtocolStack manages a number of protocols layered above each other.
- ProtocolStack(JChannel) - Constructor for class org.jgroups.stack.ProtocolStack
-
- ProtocolStack() - Constructor for class org.jgroups.stack.ProtocolStack
-
Used for programmatic creation of ProtocolStack
- ProtocolStack.RefCounter - Class in org.jgroups.stack
-
Keeps track of the number os times init()/destroy() and start()/stop have been called.
- ProtocolStackConfigurator - Interface in org.jgroups.conf
-
- prots_above - Variable in class org.jgroups.protocols.relay.RELAY2
-
- providedDownServices() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- providedDownServices() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- providedDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
-
- providedDownServices() - Method in class org.jgroups.stack.Protocol
-
List of events that are provided to layers below (they will be handled when sent down below)
- providedUpServices() - Method in class org.jgroups.protocols.Discovery
-
- providedUpServices() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- providedUpServices() - Method in class org.jgroups.protocols.KeyExchange
-
- providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- providedUpServices() - Method in class org.jgroups.stack.Protocol
-
List of events that are provided to layers above (they will be handled when sent down from above)
- provider - Variable in class org.jgroups.protocols.EncryptBase
-
- PubClient - Class in org.jgroups.demos
-
Demo of a client which connects to a server (
PubServer
) and sends it messages which are forwarded to all
connected clients
- PubClient(String) - Constructor for class org.jgroups.demos.PubClient
-
- publishReadIndex(int) - Method in class org.jgroups.util.RingBuffer
-
- PubServer - Class in org.jgroups.demos
-
Demo which starts an
NioServer
that accepts messages from clients (
PubClient
) and forwards them to
all connected clients
- PubServer() - Constructor for class org.jgroups.demos.PubServer
-
- PubSub - Class in org.jgroups.demos
-
Simple pub-sub program using a shared transport: every topic creates a new channel
- PubSub() - Constructor for class org.jgroups.demos.PubSub
-
- PUNCH_HOLE - Static variable in class org.jgroups.Event
-
- punchHoleFor(Address) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- punchHoleFor(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- purge(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Removes all messages less than or equal to seqno from the table.
- purge(long) - Method in class org.jgroups.util.Table
-
Removes all elements less than or equal to seqno from the table.
- purge(long, boolean) - Method in class org.jgroups.util.Table
-
Removes all elements less than or equal to seqno from the table.
- put(K, V, long) - Method in class org.jgroups.blocks.Cache
-
- put(K, V) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- put(K, V, long) - Method in class org.jgroups.blocks.PartitionedHashMap
-
Adds a key/value to the cache, replacing a previous item if there was one
- put(K, V, short, long, boolean) - Method in class org.jgroups.blocks.ReplCache
-
Places a key/value pair into one or several nodes in the cluster.
- put(K, V, short, long) - Method in class org.jgroups.blocks.ReplCache
-
Places a key/value pair into one or several nodes in the cluster.
- put(K, V) - Method in class org.jgroups.blocks.ReplCache
-
- put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Maps the specified key to the specified value in this table.
- put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a new node to the tree and sets its data.
- put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a key and value to a given node.
- put(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- put(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- put(byte[], byte[]) - Method in class org.jgroups.util.ExtendedUUID
-
- put(int, byte[], byte[]) - Method in class org.jgroups.util.ExtendedUUID
-
- put(String, byte[]) - Method in class org.jgroups.util.ExtendedUUID
-
- put(long, Message) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Adds a new message to the index computed as a function of seqno
- put(T) - Method in class org.jgroups.util.RingBuffer
-
Tries to add a new element at the current write index and advances the write index.
- put(Address, Rsp<T>) - Method in class org.jgroups.util.RspList
-
- putAll(Map<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Copies all of the mappings from the specified map to this one.
- putAll(Map<? extends Address, ? extends Rsp<T>>) - Method in class org.jgroups.util.RspList
-
- putHeader(short, Header) - Method in class org.jgroups.Message
-
Puts a header given an ID into the hashmap.
- putHeader(Header[], short, Header, boolean) - Static method in class org.jgroups.util.Headers
-
Adds hdr at the next available slot.
- putHeaderIfAbsent(short, Header) - Method in class org.jgroups.Message
-
Puts a header given a key into the map, only if the key doesn't exist yet
- putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- putIfAbsent(String, JChannel) - Method in class org.jgroups.fork.ForkProtocolStack
-
- putIfAbsent(String, Protocol) - Method in class org.jgroups.protocols.FORK
-
- putIfAbsent(Address) - Method in class org.jgroups.util.CreditMap
-
- putIfAbsent(long, Message) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Adds a message if the element at the given index is null.
- putIfAbsent(T, long) - Method in class org.jgroups.util.SuppressCache
-
Adds a new key to the hashmap, or updates the Value associated with the existing key if present.
- RACK_ID - Static variable in class org.jgroups.util.TopologyUUID
-
Deprecated.
- RACKSPACE_PING - Class in org.jgroups.protocols
-
Discovery protocol based on Rackspace Cloud Files storage solution
- RACKSPACE_PING() - Constructor for class org.jgroups.protocols.RACKSPACE_PING
-
- rackspaceClient - Variable in class org.jgroups.protocols.RACKSPACE_PING
-
- RAN - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
State value representing that task ran
- random - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- random(long) - Static method in class org.jgroups.util.Util
-
Returns a random value in the range [1 - range]
- randomUUID(boolean) - Static method in class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- randomUUID(String, boolean) - Static method in class org.jgroups.protocols.relay.CanBeSiteMaster
-
Deprecated.
- randomUUID(byte[]) - Static method in class org.jgroups.util.AdditionalDataUUID
-
Deprecated.
- randomUUID(String, byte[]) - Static method in class org.jgroups.util.AdditionalDataUUID
-
Deprecated.
- randomUUID() - Static method in class org.jgroups.util.ExtendedUUID
-
- randomUUID(String) - Static method in class org.jgroups.util.ExtendedUUID
-
- randomUUID(String) - Static method in class org.jgroups.util.PayloadUUID
-
Deprecated.
- randomUUID(String, String) - Static method in class org.jgroups.util.PayloadUUID
-
Deprecated.
- randomUUID(String, String, String) - Static method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- randomUUID(String, String, String, String) - Static method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- randomUUID() - Static method in class org.jgroups.util.UUID
-
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
- range - Variable in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
-
- Range - Class in org.jgroups.util
-
- Range() - Constructor for class org.jgroups.util.Range
-
For externalization
- Range(long, long) - Constructor for class org.jgroups.util.Range
-
- RangeBasedRetransmitter - Class in org.jgroups.stack
-
This retransmitter is specialized in maintaining ranges of seqnos, e.g.
- RangeBasedRetransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.RangeBasedRetransmitter
-
Create a new Retransmitter associated with the given sender address
- RangeBasedRetransmitter.RangeTask - Class in org.jgroups.stack
-
- RangeTask(Seqno, Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
-
- RATE_LIMITER - Class in org.jgroups.protocols
-
Protocol which sends at most max_bytes in time_period milliseconds.
- RATE_LIMITER() - Constructor for class org.jgroups.protocols.RATE_LIMITER
-
- raw_buffer - Variable in class org.jgroups.protocols.SIZE
-
- raw_msgs - Variable in class org.jgroups.util.MyReceiver
-
- rawMsgs(boolean) - Method in class org.jgroups.util.MyReceiver
-
- rb - Variable in class org.jgroups.protocols.RingBufferBundler
-
- read() - Method in class org.jgroups.blocks.GridInputStream
-
- read(byte[]) - Method in class org.jgroups.blocks.GridInputStream
-
- read(byte[], int, int) - Method in class org.jgroups.blocks.GridInputStream
-
- read(SocketChannel) - Method in class org.jgroups.nio.Buffers
-
Performs a scattering read into all (contiguous) non-null buffers in range [position ..
- read(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
-
- read(ByteBuffer[], int, int) - Method in class org.jgroups.nio.MockSocketChannel
-
- read(InputStream) - Method in class org.jgroups.protocols.Discovery
-
- read(File) - Method in class org.jgroups.protocols.FILE_PING
-
- read(InputStream) - Method in class org.jgroups.protocols.FILE_PING
-
- read() - Method in class org.jgroups.util.Base64.InputStream
-
Reads enough of the input stream to convert
to/from Base64 and returns the next byte.
- read(byte[], int, int) - Method in class org.jgroups.util.Base64.InputStream
-
- read() - Method in class org.jgroups.util.BlockingInputStream
-
- read(byte[]) - Method in class org.jgroups.util.BlockingInputStream
-
- read(byte[], int, int) - Method in class org.jgroups.util.BlockingInputStream
-
- read() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
Reads the next byte of data from buf.
- read(byte[], int, int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- read(DataInput) - Method in class org.jgroups.util.ExtendedUUID
-
- read() - Method in class org.jgroups.util.InputStreamAdapter
-
- read(byte[]) - Method in class org.jgroups.util.InputStreamAdapter
-
- read(byte[], int, int) - Method in class org.jgroups.util.InputStreamAdapter
-
- read(Class<T>, DataInput) - Static method in class org.jgroups.util.Util
-
- READ_ADDRS - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- read_index - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- read_index - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- read_pos - Variable in class org.jgroups.util.BlockingInputStream
-
Index into buf at which the next bytes will be read.
- readAddress(DataInput) - Static method in class org.jgroups.util.Util
-
- readAddresses(DataInput, Class) - Static method in class org.jgroups.util.Util
-
- readAddresses(DataInput) - Static method in class org.jgroups.util.Util
-
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.FILE_PING
-
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.JDBC_PING
-
- readAll(Connection, List<Address>, String, Responses) - Method in class org.jgroups.protocols.JDBC_PING
-
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.RACKSPACE_PING
-
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.S3_PING
-
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.SWIFT_PING
-
- readArgs(DataInput) - Method in class org.jgroups.blocks.MethodCall
-
- readAsciiString(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads an AsciiString from buf.
- readAsciiString(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads an AsciiString from buf.
- readAuthToken(DataInput) - Static method in class org.jgroups.protocols.AuthHeader
-
- readBoolean() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readBoolean() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readByte() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readByte() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readByteBuffer(DataInput) - Static method in class org.jgroups.util.Util
-
- readBytesDouble(String) - Static method in class org.jgroups.util.Util
-
- readBytesInteger(String) - Static method in class org.jgroups.util.Util
-
- readBytesLong(String) - Static method in class org.jgroups.util.Util
-
- readCacheFromDisk() - Method in class org.jgroups.protocols.PDC
-
Reads all mappings from disk
- readChar(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readChar() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readChar() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readClass(DataInput) - Static method in class org.jgroups.util.Util
-
- readContents(InputStream) - Static method in class org.jgroups.util.Util
-
- readDigest(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- readDouble(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads a double from a buffer.
- readDouble(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads a double from an input stream
- readDouble(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readDouble() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readDouble() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readDoubleFromStdin(String) - Static method in class org.jgroups.util.Util
-
- reader - Variable in class org.jgroups.blocks.cs.NioConnection
-
- Reader() - Constructor for class org.jgroups.blocks.cs.NioConnection.Reader
-
- reader_idle_time - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- reader_idle_time - Variable in class org.jgroups.blocks.cs.NioConnection
-
- reader_idle_time - Variable in class org.jgroups.protocols.TCP_NIO2
-
- readerIdleTime() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- readerIdleTime(long) - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- readerIdleTime() - Method in class org.jgroups.blocks.cs.NioConnection
-
- readerIdleTime(long) - Method in class org.jgroups.blocks.cs.NioConnection
-
- readerIdleTime(long) - Method in class org.jgroups.protocols.TCP_NIO2
-
- readerRunning() - Method in class org.jgroups.blocks.cs.NioConnection
-
- readExternal(ObjectInput) - Method in class org.jgroups.AnycastAddress
-
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.Cache.Value
-
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.MethodCall
-
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.tom.MessageID
-
- readExternal(ObjectInput) - Method in class org.jgroups.stack.IpAddress
-
- readExternal(ObjectInput) - Method in class org.jgroups.util.ExtendedUUID
-
- readExternal(ObjectInput) - Method in class org.jgroups.util.SingletonAddress
-
- readExternal(ObjectInput) - Method in class org.jgroups.util.UUID
-
- readFile(String) - Static method in class org.jgroups.util.Util
-
- readFileContents(InputStream) - Static method in class org.jgroups.util.Util
-
- readFloat(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads a a float from a buffer.
- readFloat(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads a a float from an input stream.
- readFloat(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readFloat() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readFloat() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readFrame(DataInputStream) - Static method in class org.jgroups.protocols.STOMP
-
- readFrom(DataInput) - Method in class org.jgroups.AnycastAddress
-
- readFrom(DataInput) - Method in class org.jgroups.auth.DemoToken.DemoHeader
-
- readFrom(DataInput) - Method in class org.jgroups.auth.DemoToken
-
- readFrom(DataInput) - Method in class org.jgroups.auth.FixedMembershipToken
-
- readFrom(DataInput) - Method in class org.jgroups.auth.Krb5Token
-
- readFrom(DataInput) - Method in class org.jgroups.auth.MD5Token
-
- readFrom(DataInput) - Method in class org.jgroups.auth.RegexMembership
-
Required to deserialize the object when read in from the wire
- readFrom(DataInput) - Method in class org.jgroups.auth.SimpleToken
-
Required to deserialize the object when read in from the wire
- readFrom(DataInput) - Method in class org.jgroups.auth.X509Token
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.GridFile.Metadata
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.MethodCall
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.mux.MuxHeader
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- readFrom(DataInput) - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
- readFrom(DataInput) - Method in class org.jgroups.demos.DrawCommand
-
- readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.ByteBufferStreamable
-
- readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
-
- readFrom(DataInput) - Method in class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
-
- readFrom(DataInput) - Method in class org.jgroups.MergeView
-
- readFrom(DataInput) - Method in class org.jgroups.Message
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.ABP.ABPHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.AuthHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.BooleanResponse
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.CounterHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SetRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.SimpleResponse
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.COUNTER.ValueResponse
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- readFrom(DataInput) - Method in class org.jgroups.protocols.EncryptHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.ExecutorHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.Request
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.Executing.RequestWithThread
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FcHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD.FdHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD_ALL2.HeartbeatHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.FragHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.Locking.LockingHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.Locking.Request
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- readFrom(DataInput) - Method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.PDC.Mapping
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.PERF.PerfHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.PingData
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.PingHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.PrioHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.RELAY.RelayHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.RELAY.ViewData
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.RSVP.RsvpHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.SaslHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- readFrom(DataInput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.STOMP.StompHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.tom.MessageID
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.tom.ToaHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.TpHeader
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- readFrom(DataInput) - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- readFrom(DataInput) - Method in class org.jgroups.protocols.UNICAST3.Header
-
- readFrom(DataInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
-
- readFrom(DataInput) - Method in class org.jgroups.stack.GossipData
-
- readFrom(DataInput) - Method in class org.jgroups.stack.IpAddress
-
- readFrom(DataInput) - Method in class org.jgroups.util.Average
-
- readFrom(DataInput) - Method in class org.jgroups.util.AverageMinMax
-
- readFrom(DataInput) - Method in class org.jgroups.util.Digest
-
- readFrom(DataInput, boolean) - Method in class org.jgroups.util.Digest
-
- readFrom(DataInput) - Method in class org.jgroups.util.ExtendedUUID
-
- readFrom(DataInput) - Method in class org.jgroups.util.MergeId
-
- readFrom(DataInput) - Method in class org.jgroups.util.Owner
-
- readFrom(DataInput) - Method in class org.jgroups.util.Range
-
- readFrom(DataInput) - Method in class org.jgroups.util.SeqnoList
-
- readFrom(DataInput) - Method in class org.jgroups.util.SingletonAddress
-
- readFrom(DataInput) - Method in interface org.jgroups.util.Streamable
-
Read the state of the current object (including superclasses) from instream
Note that the input stream must not be closed
- readFrom(DataInput) - Method in class org.jgroups.util.UUID
-
- readFrom(DataInput) - Method in class org.jgroups.View
-
- readFrom(DataInput) - Method in class org.jgroups.ViewId
-
- readFromSkipPayload(ByteArrayDataInputStream) - Method in class org.jgroups.Message
-
Reads the message's contents from an input stream, but skips the buffer and instead returns the
position (offset) at which the buffer starts
- readFully(byte[]) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readFully(byte[], int, int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readFully(byte[]) - Method in class org.jgroups.util.ByteBufferInputStream
-
- readFully(byte[], int, int) - Method in class org.jgroups.util.ByteBufferInputStream
-
- readGenericStreamable(DataInput) - Static method in class org.jgroups.util.Util
-
- readGenericStreamable(DataInput, ClassLoader) - Static method in class org.jgroups.util.Util
-
- readHeader(DataInput) - Static method in class org.jgroups.Message
-
- readIn(Rsp<T>) - Method in class org.jgroups.util.Rsp
-
- readIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- readIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- readIndex() - Method in class org.jgroups.util.RingBuffer
-
- readIndexLockless() - Method in class org.jgroups.util.RingBuffer
-
- readInt(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads an int from a buffer.
- readInt(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads an int from an input stream
- readInt(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readInt() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readInt() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readIntCompressed(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readIntFromStdin(String) - Static method in class org.jgroups.util.Util
-
- readJoinRsp(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.GMS
-
- readLengthAndData(SocketChannel) - Method in class org.jgroups.nio.Buffers
-
Reads length and then length bytes into the data buffer, which is grown if needed.
- readLine() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readLine() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readLine(InputStream) - Static method in class org.jgroups.util.Util
-
Reads a line of text.
- readLong(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads a long from a buffer.
- readLong(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads a variable-length encoded long from an input stream.
- readLong(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readLong() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readLong() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readLongCompressed(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readLongFromStdin(String) - Static method in class org.jgroups.util.Util
-
- readLongSequence(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads 2 compressed longs from buf.
- readLongSequence(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads 2 compressed longs from in.
- readMappings(String) - Static method in class org.jgroups.conf.ClassConfigurator
-
try to read the magic number configuration file as a Resource form the classpath using getResourceAsStream
if this fails this method tries to read the configuration file from mMagicNumberFile using a FileInputStream (not in classpath but somewhere else in the disk)
- readMembers(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.GMS
-
- readMessage(DataInput) - Static method in class org.jgroups.protocols.TP
-
- readMessage(DataInput) - Static method in class org.jgroups.util.Util
-
- readMessageBatch(DataInput, boolean) - Static method in class org.jgroups.protocols.TP
-
Reads a list of messages into 4 MessageBatches:
regular
OOB
INTERNAL-OOB (INTERNAL and OOB)
INTERNAL (INTERNAL)
- readMessageBatch(DataInput, boolean) - Static method in class org.jgroups.util.Util
-
Reads a list of messages into 4 MessageBatches:
regular
OOB
INTERNAL-OOB (INTERNAL and OOB)
INTERNAL (INTERNAL)
- readMessageList(DataInput, short) - Static method in class org.jgroups.protocols.TP
-
- readMessageList(DataInput, short) - Static method in class org.jgroups.util.Util
-
- readMessages() - Method in class org.jgroups.protocols.RingBufferBundler
-
- readMessages() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- readMessages() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- readMethod(DataInput) - Method in class org.jgroups.blocks.MethodCall
-
- readObject(String, String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Read the content of a file
- readObject(DataInput) - Static method in class org.jgroups.util.Util
-
- readParticipantsAndDigest(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- readPeerAddress() - Method in class org.jgroups.blocks.cs.NioConnection
-
- readPeerAddress(Socket) - Method in class org.jgroups.blocks.cs.TcpConnection
-
Reads the peer's address.
- readPingData(byte[], int, int) - Method in class org.jgroups.protocols.Discovery
-
- readReconciliationLongs(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
-
- readReconciliationNames(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
-
- readRequest(ByteArrayDataInputStream) - Method in class org.jgroups.stack.GossipRouter
-
- readResponse(S3_PING.GetResponse, List<Address>, Responses) - Method in class org.jgroups.protocols.S3_PING
-
- reads - Variable in class org.jgroups.protocols.FILE_PING
-
- readSecretKeyFromKeystore() - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
Initialisation if a supplied key is defined in the properties.
- readShort(byte[], int) - Static method in class org.jgroups.util.Bits
-
- readShort() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readShort() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readState(InputStream) - Method in class org.jgroups.demos.Draw.DrawPanel
-
- readStreamable(Class, DataInput) - Static method in class org.jgroups.util.Util
-
- readString(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads a string from buf.
- readString(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads a string from buf.
- readStringFromStdin(String) - Static method in class org.jgroups.util.Util
-
- readToken(InputStream) - Static method in class org.jgroups.util.Util
-
Returns whitespace-separated strings from the input stream, or null if the end of the stream has been reached
- readTypes(DataInput) - Method in class org.jgroups.blocks.MethodCall
-
- readUnsignedByte() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readUnsignedByte() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readUnsignedShort() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readUnsignedShort() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readUTF() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- readUTF() - Method in class org.jgroups.util.ByteBufferInputStream
-
- readView(byte[], int, int) - Method in class org.jgroups.protocols.MERGE3
-
- readView(DataInput) - Static method in class org.jgroups.util.Util
-
- readViewAndDigest(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.GMS
-
- readViewId(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.GMS
-
- readViewId(DataInput) - Static method in class org.jgroups.util.Util
-
- realIndex(int) - Method in class org.jgroups.util.RingBuffer
-
Apparently much more efficient than mod (%)
- reaper - Variable in class org.jgroups.blocks.cs.BaseServer
-
- Reaper() - Constructor for class org.jgroups.blocks.cs.BaseServer.Reaper
-
- reaper_interval - Variable in class org.jgroups.protocols.BasicTCP
-
- reaperInterval - Variable in class org.jgroups.blocks.cs.BaseServer
-
- reaperInterval() - Method in class org.jgroups.blocks.cs.BaseServer
-
- reaperInterval(long) - Method in class org.jgroups.blocks.cs.BaseServer
-
- reapIdleConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- reapIdleConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- REBROADCAST - Static variable in class org.jgroups.Event
-
- rebroadcast_digest - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- rebroadcast_digest_lock - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- rebroadcast_done - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- rebroadcast_lock - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- rebroadcasting - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- rebroadcastMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Takes the argument highest_seqnos and compares it to the current digest.
- receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Calls the receiver callback.
- receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.BasicConnectionTable.Receiver
-
- receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.BaseServer
-
Called by a
Connection
implementation when a message has been received.
- receive(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
-
Called by a
Connection
implementation when a message has been received
- receive() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
Called by the selector when data is ready to be read from the SocketChannel
- receive() - Method in class org.jgroups.blocks.cs.NioConnection
-
Read the length first, then the actual data.
- receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.cs.Receiver
-
Delivers a message from a given sender to the application
- receive(Address, ByteBuffer) - Method in interface org.jgroups.blocks.cs.Receiver
-
Delivers a message from a given sender to the application
- receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.ReceiverAdapter
-
- receive(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.ReceiverAdapter
-
The default implementation assumes that Buffer.flip()
or Buffer.rewind()
was called on
buf before invoking this callback
- receive(Message) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- receive(Message) - Method in class org.jgroups.blocks.ReplicatedTree
-
Callback.
- receive(Event) - Method in class org.jgroups.blocks.RequestCorrelator
-
Callback.
- receive(Message) - Method in class org.jgroups.demos.Chat
-
- receive(Message) - Method in class org.jgroups.demos.Draw
-
- receive(Address, ByteBuffer) - Method in class org.jgroups.demos.PubClient
-
- receive(Address, byte[], int, int) - Method in class org.jgroups.demos.PubClient
-
- receive(Address, ByteBuffer) - Method in class org.jgroups.demos.PubServer
-
- receive(Address, byte[], int, int) - Method in class org.jgroups.demos.PubServer
-
- receive(Message) - Method in class org.jgroups.demos.wb.Whiteboard
-
- receive(Message) - Method in interface org.jgroups.MessageListener
-
Called when a message is received.
- receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
-
BaseServer.Receiver interface
- receive(Address, ByteBuffer) - Method in class org.jgroups.protocols.BasicTCP
-
- receive(Message) - Method in class org.jgroups.protocols.RELAY.Receiver
-
- receive(Message) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
- receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Subclasses must call this method when a unicast or multicast message has been received.
- receive(GossipData) - Method in class org.jgroups.protocols.TUNNEL
-
- receive(Message) - Method in class org.jgroups.ReceiverAdapter
-
Called when a message is received.
- receive(Address, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
-
- receive(Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
-
- receive(Address, ByteBuffer) - Method in class org.jgroups.stack.RouterStub
-
- receive(GossipData) - Method in interface org.jgroups.stack.RouterStub.StubReceiver
-
- receive(long, Message) - Method in class org.jgroups.util.ForwardQueue
-
- receive(Message) - Method in class org.jgroups.util.MyReceiver
-
- receive_interfaces - Variable in class org.jgroups.protocols.TP
-
List of interfaces to receive multicasts on.
- receive_on_all_interfaces - Variable in class org.jgroups.protocols.TP
-
- receiveBufferSize() - Method in class org.jgroups.blocks.cs.BaseServer
-
- receiveBufferSize(int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- received - Variable in class org.jgroups.protocols.FlowControl
-
Keeps track of credits per member at the receiver.
- received - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- RECEIVED - Static variable in class org.jgroups.util.Rsp
-
Flag that represents whether the response was received
- RECEIVED - Static variable in class org.jgroups.util.Seqno
-
- received() - Method in class org.jgroups.util.Seqno
-
- received_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
-
- received_bcasts - Variable in class org.jgroups.protocols.SEQUENCER2
-
- received_bytes - Variable in class org.jgroups.JChannel
-
- received_bytes - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- received_forwards - Variable in class org.jgroups.protocols.SEQUENCER
-
- received_msgs - Variable in class org.jgroups.JChannel
-
- received_msgs - Variable in class org.jgroups.protocols.SEQUENCER2
-
- received_msgs - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
-
Deprecated.
- received_msgs - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- received_not_coord - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
-
Set when NOT_COORD message has been received.
- received_requests - Variable in class org.jgroups.protocols.SEQUENCER2
-
- received_responses - Variable in class org.jgroups.protocols.SEQUENCER2
-
- receiveMessage(Message) - Method in class org.jgroups.blocks.RequestCorrelator
-
Handles a message coming from a layer below
- receiveMessageBatch(MessageBatch) - Method in class org.jgroups.blocks.RequestCorrelator
-
- receiver - Variable in class org.jgroups.blocks.cs.BaseServer
-
- receiver() - Method in class org.jgroups.blocks.cs.BaseServer
-
- receiver(Receiver) - Method in class org.jgroups.blocks.cs.BaseServer
-
- Receiver - Interface in org.jgroups.blocks.cs
-
Receiver interface to be used with
BaseServer
instances
- receiver - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- Receiver(ThreadFactory) - Constructor for class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- receiver - Variable in class org.jgroups.Channel
-
- receiver(Receiver) - Method in class org.jgroups.JChannel
-
- receiver - Variable in class org.jgroups.protocols.BPING
-
- Receiver() - Constructor for class org.jgroups.protocols.RELAY.Receiver
-
- Receiver - Interface in org.jgroups
-
Defines the callbacks that are invoked when messages, views etc are received on a channel
- receiver - Variable in class org.jgroups.stack.RouterStub
-
- receiver(RouterStub.StubReceiver) - Method in class org.jgroups.stack.RouterStub
-
- receiver() - Method in class org.jgroups.stack.RouterStub
-
- receiver - Variable in class org.jgroups.stack.RouterStubManager.Target
-
- ReceiverAdapter - Class in org.jgroups.blocks.cs
-
- ReceiverAdapter() - Constructor for class org.jgroups.blocks.cs.ReceiverAdapter
-
- ReceiverAdapter - Class in org.jgroups
-
An adapter implementing the Receiver interface with no-op implementations.
- ReceiverAdapter() - Constructor for class org.jgroups.ReceiverAdapter
-
- ReceiverEntry(Table<Message>, short) - Constructor for class org.jgroups.protocols.UNICAST.ReceiverEntry
-
Deprecated.
- ReceiverEntry(Table<Message>, short) - Constructor for class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- ReceiverEntry(Table<Message>, short) - Constructor for class org.jgroups.protocols.UNICAST3.ReceiverEntry
-
- receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.GroupRequest
-
Callback (called by RequestCorrelator or Transport).
- receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.Request
-
- receiveResponse(Object, Address, boolean) - Method in class org.jgroups.blocks.UnicastRequest
-
Callback (called by RequestCorrelator or Transport).
- receiveSuspect(Address) - Method in class org.jgroups.blocks.RequestCorrelator
-
Event.SUSPECT event received from a layer below.
- receiveView(View) - Method in class org.jgroups.blocks.RequestCorrelator
-
Event.VIEW_CHANGE event received from a layer below.
- receiving - Variable in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- ReconcileRequest() - Constructor for class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- ReconcileRequest(String[], long[], long[]) - Constructor for class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- ReconcileResponse() - Constructor for class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- ReconcileResponse(String[], long[], long[]) - Constructor for class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- reconciliation_task - Variable in class org.jgroups.protocols.COUNTER
-
- reconciliation_task_future - Variable in class org.jgroups.protocols.COUNTER
-
- reconciliation_timeout - Variable in class org.jgroups.protocols.COUNTER
-
- ReconciliationTask() - Constructor for class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- reconnect - Variable in class org.jgroups.client.StompConnection
-
- reconnect(RouterStubManager.Target) - Method in class org.jgroups.stack.RouterStubManager
-
- reconnect_interval - Variable in class org.jgroups.protocols.TUNNEL
-
- reconnect_list - Variable in class org.jgroups.stack.RouterStubManager
-
- reconnector_task - Variable in class org.jgroups.stack.RouterStubManager
-
- recorder - Variable in class org.jgroups.nio.MockSocketChannel
-
- recorder(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
-
- recorder() - Method in class org.jgroups.nio.MockSocketChannel
-
- RecurringTask(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit) - Constructor for class org.jgroups.util.TimeScheduler3.RecurringTask
-
- recv - Variable in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- recv_buf - Variable in class org.jgroups.blocks.cs.NioConnection
-
- recv_buf_size - Variable in class org.jgroups.blocks.cs.BaseServer
-
- recv_buf_size - Variable in class org.jgroups.protocols.BasicTCP
-
- recv_conn_id - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
-
Deprecated.
- recv_conn_id - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- recv_map - Variable in class org.jgroups.protocols.ABP
-
- recv_table - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- recv_table - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- recv_table - Variable in class org.jgroups.protocols.UNICAST3
-
- recv_table_lock - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- recv_table_lock - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- recv_table_lock - Variable in class org.jgroups.protocols.UNICAST3
-
- ref_view_id - Variable in class org.jgroups.protocols.pbcast.DeltaView
-
The fields left_members and new_members refer to the view corresponding to ref_view_id
- RefCounter(short, short) - Constructor for class org.jgroups.stack.ProtocolStack.RefCounter
-
- reg_lock - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- reg_map_mcast - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- reg_map_ucast - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- RegexMembership - Class in org.jgroups.auth
-
Matches the IP address or logical name of a joiner against a regular expression and accepts or rejects based on
pattern matching
- RegexMembership() - Constructor for class org.jgroups.auth.RegexMembership
-
- regexp - Static variable in class org.jgroups.protocols.FILE_PING
-
- region - Variable in class org.jgroups.protocols.RACKSPACE_PING
-
- register(SelectableChannel, int, NioConnection) - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- register(int) - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- register(Object, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- register(AUTH.UpHandler) - Method in class org.jgroups.protocols.AUTH
-
- register(EventHandler) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- register(AsciiString, Address, SHARED_LOOPBACK) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- register_shutdown_hook - Variable in class org.jgroups.protocols.JDBC_PING
-
- registerChannel(JChannel, MBeanServer, String, String, boolean) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Registers an already created channel with the given MBeanServer.
- registerChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Registers an already created channel with the given MBeanServer.
- registerChannel(JChannel, String) - Static method in class org.jgroups.util.Util
-
- registerLocalAddress(Address) - Method in class org.jgroups.protocols.TP
-
Associates the address with the physical address fetched from the cache
- registerProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
-
- registerProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.protocols.TP
-
- registerProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.stack.DiagnosticsHandler
-
- registerSelectionKey(int) - Method in class org.jgroups.blocks.cs.NioConnection
-
- registration - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- regular_sock_close - Variable in class org.jgroups.protocols.FD_SOCK
-
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.jgroups.util.CustomRejectionPolicy
-
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.jgroups.util.ProgressCheckRejectionPolicy
-
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.jgroups.util.ShutdownRejectedExecutionHandler
-
- RELAY - Class in org.jgroups.protocols
-
Simple relaying protocol: RELAY is added to the top of the stack, creates a channel to a bridge cluster,
and - if coordinator - relays all multicast messages via the bridge cluster to the remote cluster.
This is
not a big virtual cluster, e.g.
- RELAY() - Constructor for class org.jgroups.protocols.RELAY
-
- relay - Variable in class org.jgroups.protocols.RELAY
-
- relay - Variable in class org.jgroups.protocols.relay.Relayer
-
- relay - Variable in class org.jgroups.protocols.relay.Route
-
- RELAY.Receiver - Class in org.jgroups.protocols
-
- RELAY.RelayHeader - Class in org.jgroups.protocols
-
- RELAY.RelayHeader.Type - Enum in org.jgroups.protocols
-
- RELAY.RemoteViewFetcher - Class in org.jgroups.protocols
-
- RELAY.ViewData - Class in org.jgroups.protocols
-
Contains local and remote views, and UUID information
- RELAY2 - Class in org.jgroups.protocols.relay
-
Design: ./doc/design/RELAY2.txt and at https://github.com/belaban/JGroups/blob/master/doc/design/RELAY2.txt.
JIRA: https://issues.jboss.org/browse/JGRP-1433
- RELAY2() - Constructor for class org.jgroups.protocols.relay.RELAY2
-
- RELAY2.Relay2Header - Class in org.jgroups.protocols.relay
-
- Relay2Header() - Constructor for class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- Relay2Header(byte, Address, Address) - Constructor for class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- RELAY_CONFIG - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
-
- relay_multicasts - Variable in class org.jgroups.protocols.relay.RELAY2
-
- RelayConfig - Class in org.jgroups.protocols.relay.config
-
Parses and maintains the RELAY2 configuration (in memory)
- RelayConfig.BridgeConfig - Class in org.jgroups.protocols.relay.config
-
- RelayConfig.ForwardConfig - Class in org.jgroups.protocols.relay.config
-
- RelayConfig.ProgrammaticBridgeConfig - Class in org.jgroups.protocols.relay.config
-
- RelayConfig.PropertiesBridgeConfig - Class in org.jgroups.protocols.relay.config
-
- RelayConfig.SiteConfig - Class in org.jgroups.protocols.relay.config
-
- RelayDemo - Class in org.jgroups.demos
-
Demos RELAY.
- RelayDemo() - Constructor for class org.jgroups.demos.RelayDemo
-
- RelayDemoRpc - Class in org.jgroups.demos
-
Demos RELAY.
- RelayDemoRpc() - Constructor for class org.jgroups.demos.RelayDemoRpc
-
- relayed - Variable in class org.jgroups.protocols.relay.RELAY2
-
Number of messages relayed by the local SiteMaster to a remote SiteMaster
- relayed_time - Variable in class org.jgroups.protocols.relay.RELAY2
-
Total time spent relaying messages from the local SiteMaster to remote SiteMasters (in ns)
- relayer - Variable in class org.jgroups.protocols.relay.RELAY2
-
- Relayer - Class in org.jgroups.protocols.relay
-
Maintains bridges and routing table.
- Relayer(RELAY2, Log) - Constructor for class org.jgroups.protocols.relay.Relayer
-
- Relayer.Bridge - Class in org.jgroups.protocols.relay
-
- RelayHeader() - Constructor for class org.jgroups.protocols.RELAY.RelayHeader
-
- relayMulticasts(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
-
- relayMulticasts() - Method in class org.jgroups.protocols.relay.RELAY2
-
- release() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- remaining() - Method in class org.jgroups.nio.Buffers
-
- remaining() - Method in class org.jgroups.util.BlockingInputStream
-
- remainingCapacity() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- remainingCapacity() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- remote - Variable in class org.jgroups.stack.RouterStub
-
- remote() - Method in class org.jgroups.stack.RouterStub
-
- remote_addr - Variable in class org.jgroups.blocks.cs.NioClient
-
- remote_addr - Variable in class org.jgroups.blocks.cs.TcpClient
-
- remote_view - Variable in class org.jgroups.protocols.RELAY
-
The view of the remote cluster
- remote_view - Variable in class org.jgroups.protocols.RELAY.ViewData
-
- remote_view_fetcher_future - Variable in class org.jgroups.protocols.RELAY
-
- remoteAddress() - Method in interface org.jgroups.blocks.cs.Client
-
- remoteAddress() - Method in class org.jgroups.blocks.cs.NioClient
-
- remoteAddress(IpAddress) - Method in class org.jgroups.blocks.cs.NioClient
-
Sets the address of the server.
- remoteAddress() - Method in class org.jgroups.blocks.cs.TcpClient
-
- remoteAddress(IpAddress) - Method in class org.jgroups.blocks.cs.TcpClient
-
Sets the address of the server.
- RemoteViewFetcher() - Constructor for class org.jgroups.protocols.RELAY.RemoteViewFetcher
-
- removable - Variable in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- remove(K) - Method in class org.jgroups.blocks.Cache
-
- remove(String, boolean) - Method in class org.jgroups.blocks.GridFilesystem
-
- remove(K) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- remove(K, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- remove(short) - Method in interface org.jgroups.blocks.mux.Muxer
-
Unregisters the handler associated with the specifed mux identifier
- remove(short) - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
Unregisters the handler associated with the specifed mux identifier
- remove(K) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- remove(K) - Method in class org.jgroups.blocks.ReplCache
-
Removes key in all nodes in the cluster, both from their local hashmaps and L1 caches
- remove(K, boolean) - Method in class org.jgroups.blocks.ReplCache
-
Removes key in all nodes in the cluster, both from their local hashmaps and L1 caches
- remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Removes the key (and its corresponding value) from this map.
- remove(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Removes the node from the tree.
- remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Removes key
from the node's hashmap
- remove(String) - Method in class org.jgroups.fork.ForkProtocolStack
-
- remove(Address) - Method in class org.jgroups.Membership
-
Removes an member from the membership.
- remove(Collection<Address>) - Method in class org.jgroups.Membership
-
Removes all the members contained in v from this membership
- remove() - Method in class org.jgroups.nio.Buffers.BuffersIterator
-
- remove(int) - Method in class org.jgroups.nio.Buffers
-
Nulls the buffer at index
- remove(String, Address) - Method in class org.jgroups.protocols.FILE_PING
-
- remove(String) - Method in class org.jgroups.protocols.FORK
-
- remove(String, Address) - Method in class org.jgroups.protocols.JDBC_PING
-
- remove(String, Address) - Method in class org.jgroups.protocols.RACKSPACE_PING
-
- remove(String, Address) - Method in class org.jgroups.protocols.S3_PING
-
- remove() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- remove() - Method in class org.jgroups.protocols.STOMP.Connection
-
- remove(String, Address) - Method in class org.jgroups.protocols.SWIFT_PING
-
- remove(long) - Method in class org.jgroups.stack.DefaultRetransmitter
-
Remove the given sequence number from the list of seqnos eligible
for retransmission.
- remove(long, boolean) - Method in class org.jgroups.stack.DefaultRetransmitter
-
Removes the given seqno and all seqnos lower than it
- remove() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- remove(boolean, boolean) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- remove(long) - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
Remove the given sequence number from the list of seqnos eligible
for retransmission.
- remove(long) - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
Remove the given sequence number from retransmission
- remove(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
-
- remove(RouterStubManager.Target) - Method in class org.jgroups.stack.RouterStubManager
-
- remove(K) - Method in class org.jgroups.util.AgeOutCache
-
- remove() - Method in class org.jgroups.util.ArrayIterator
-
- remove(Object) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- remove(Object) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- remove(Address) - Method in class org.jgroups.util.CreditMap
-
- remove() - Method in class org.jgroups.util.Digest.MyIterator
-
- remove(K) - Method in class org.jgroups.util.ExpiryCache
-
- remove(byte[]) - Method in class org.jgroups.util.ExtendedUUID
-
- remove(String) - Method in class org.jgroups.util.ExtendedUUID
-
- remove() - Method in class org.jgroups.util.MessageBatch.BatchIterator
-
- remove(Message) - Method in class org.jgroups.util.MessageBatch
-
Removes the current message (found by indentity (==)) by nulling it in the message array
- remove(Filter<Message>) - Method in class org.jgroups.util.MessageBatch
-
Removes all messages which match filter
- remove() - Method in class org.jgroups.util.Queue
-
Removes 1 element from head or blocks
until next element has been added or until queue has been closed
- remove(long) - Method in class org.jgroups.util.Queue
-
Removes 1 element from the head.
- remove(long) - Method in class org.jgroups.util.RequestTable
-
Removes the element at the index matching seqno.
- remove(Address) - Method in class org.jgroups.util.ResponseCollector
-
- remove(List<Address>) - Method in class org.jgroups.util.ResponseCollector
-
- remove() - Method in class org.jgroups.util.Responses.PingDataIterator
-
- remove(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Removes the message with seqno from the table, nulls the index
- remove(boolean) - Method in class org.jgroups.util.RingBufferSeqno
-
Removes the next element (at hd +1).
- remove() - Method in class org.jgroups.util.RingBufferSeqno
-
Removes the next element (at hd +1).
- remove() - Method in class org.jgroups.util.RingBufferSeqno.RingBufferIterator
-
- remove(boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Removes the next element (at hd +1).
- remove() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Removes the next element (at hd +1).
- remove() - Method in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
-
- remove(Object) - Method in class org.jgroups.util.RspList
-
- remove() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
-
- remove() - Method in class org.jgroups.util.Table
-
- remove(boolean) - Method in class org.jgroups.util.Table
-
Removes the next non-null element and nulls the index if nullify=true
- remove(Address) - Static method in class org.jgroups.util.UUID
-
- REMOVE_ADDRESS - Static variable in class org.jgroups.Event
-
- remove_all_files_on_view_change - Variable in class org.jgroups.protocols.FILE_PING
-
- remove_old_coords_on_view_change - Variable in class org.jgroups.protocols.FILE_PING
-
- remove_queue - Variable in class org.jgroups.protocols.TransferQueueBundler
-
- removeAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
-
- removeAddressMapping(String, Address) - Method in class org.jgroups.stack.GossipRouter
-
- removeAll(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- removeAll(Collection<K>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- removeAll() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- removeAll(String) - Method in class org.jgroups.protocols.FILE_PING
-
Removes all files for the given cluster name
- removeAll(String) - Method in class org.jgroups.protocols.RACKSPACE_PING
-
- removeAll(String) - Method in class org.jgroups.protocols.S3_PING
-
- removeAll(String) - Method in class org.jgroups.protocols.SWIFT_PING
-
- removeAll(Collection<K>) - Method in class org.jgroups.util.AgeOutCache
-
- removeAll(Collection<K>) - Method in class org.jgroups.util.ExpiryCache
-
- removeAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
-
- removeAll(Collection<Address>) - Static method in class org.jgroups.util.UUID
-
- removeAllConnections() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
- removeAllConnections() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
- removeAllConnections() - Method in class org.jgroups.protocols.UNICAST3
-
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
- removeAllQueues() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- removeAndDeliver(AtomicBoolean, Table<Message>, Address) - Method in class org.jgroups.protocols.SEQUENCER2
-
- removeAndDeliver(AtomicBoolean, Table<Message>, Address) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
Try to remove as many messages as possible from the table as pass them up.
- removeAndDeliver(AtomicBoolean, Table<Message>, Address) - Method in class org.jgroups.protocols.UNICAST3
-
Try to remove as many messages as possible from the table as pass them up.
- removeAndDispatchNonBundledMessages(MessageBatch...) - Method in class org.jgroups.protocols.TP
-
Removes messages with flags DONT_BUNDLE and OOB set and executes them in the oob or internal thread pool.
- removeAndPassUp(Table<Message>, Address, boolean, AsciiString) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Efficient way of checking whether another thread is already processing messages from sender.
- removeAndPassUp(Table<Message>, Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Try to remove as many messages as possible and pass them up.
- removeCallback(StompConnection.ConnectionCallback) - Method in class org.jgroups.client.StompConnection
-
- removeChangeListener(Cache.ChangeListener) - Method in class org.jgroups.blocks.Cache
-
- removeChangeListener(ReplCache.ChangeListener) - Method in class org.jgroups.blocks.ReplCache
-
- removeChannelListener(ChannelListener) - Method in class org.jgroups.blocks.MessageDispatcher
-
- removeChannelListener(ChannelListener) - Method in class org.jgroups.Channel
-
Removes a ChannelListener previously installed
- removeClientLock(String, Owner) - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- removeConnection(Address) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Remove addr
from connection table.
- removeConnection(Address) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
Removes and resets from connection table (which is already locked).
- removeConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Removes and resets from connection table (which is already locked).
- removeConnectionIfPresent(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
-
Only removes the connection if conns.get(address) == conn
- removeConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- removeConnectionListener(ConnectionListener) - Method in class org.jgroups.blocks.cs.BaseServer
-
- removeDeprecatedProperties(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
-
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.jgroups.util.BoundedHashMap
-
- removeElement(Object) - Method in class org.jgroups.util.Queue
-
removes a specific object from the queue.
- removeEntry(long) - Method in class org.jgroups.blocks.RequestCorrelator
-
- removeExpired(long) - Method in class org.jgroups.util.SuppressCache
-
- removeExpired(long) - Method in class org.jgroups.util.SuppressLog
-
- removeExpiredConnections() - Method in class org.jgroups.protocols.UNICAST3
-
- removeExpiredElements() - Method in class org.jgroups.util.ExpiryCache
-
- removeFromAddressMappings(Address) - Method in class org.jgroups.stack.GossipRouter
-
- removeFromHead() - Method in class org.jgroups.util.BoundedList
-
- removeFromPendingReleaseRequests(Locking.ClientLock) - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- removeHigherThan(long) - Method in class org.jgroups.util.SeqnoList
-
Removes all seqnos > seqno
- removeIgnoredMember(Address) - Method in class org.jgroups.protocols.DISCARD
-
- removeInitialHost(String, int) - Method in class org.jgroups.protocols.TCPGOSSIP
-
- removeKeyForValue(Map<V, K>, K) - Static method in class org.jgroups.protocols.Executing
-
- removeLeavers(Collection<Address>) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- removeLeavers(MessageID, Collection<Address>) - Method in class org.jgroups.protocols.tom.SenderManager
-
- removeListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
-
- removeLockListener(LockNotification) - Method in class org.jgroups.blocks.locking.LockService
-
- removeLockListener(LockNotification) - Method in class org.jgroups.protocols.Locking
-
- removeLogicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
-
- removeMany(AtomicBoolean) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Removes as many messages as possible
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Removes as many messages as possible
- removeMany(boolean, int) - Method in class org.jgroups.util.RingBufferSeqno
-
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBufferSeqno
-
- removeMany(boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- removeMany(boolean, int) - Method in class org.jgroups.util.Table
-
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.Table
-
- removeMany(AtomicBoolean, boolean, int, Filter<T>) - Method in class org.jgroups.util.Table
-
Removes between 0 and max_results elements from the table and returns them in a list.
- removeMarkedElements(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
Removes elements marked as removable
- removeMarkedElements() - Method in class org.jgroups.blocks.LazyRemovalCache
-
Removes elements marked as removable
- removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.ReplCache
-
- removeNode(Object) - Method in class org.jgroups.demos.Topology
-
- removeNode(Object) - Method in class org.jgroups.demos.wb.GraphPanel
-
- removeNode(Object) - Method in class org.jgroups.demos.wb.Whiteboard
-
- removeNodeFromDisk(Address) - Method in class org.jgroups.protocols.PDC
-
- removeNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- removeProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Removes a protocol from the stack.
- removeProtocol(Class...) - Method in class org.jgroups.stack.ProtocolStack
-
- removeProtocol(Class) - Method in class org.jgroups.stack.ProtocolStack
-
- removeProtocol(Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
- removeProtocols(String...) - Method in class org.jgroups.stack.ProtocolStack
-
- removeProvidedDownServices(Protocol, List<Integer>) - Static method in class org.jgroups.stack.Configurator
-
Removes all events provided by the protocol above protocol from events
- removeProvidedUpServices(Protocol, List<Integer>) - Static method in class org.jgroups.stack.Configurator
-
Removes all events provided by the protocol below protocol from events
- removeQueueSize() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- removeQueueSize(int) - Method in class org.jgroups.protocols.TransferQueueBundler
-
- Remover(boolean, int) - Constructor for class org.jgroups.util.Table.Remover
-
- Remover(boolean, int, Filter<T>) - Constructor for class org.jgroups.util.Table.Remover
-
- removeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- removeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- removeReceiveConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- removeRejectedMergeRequests(Collection<Address>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
Removed rejected merge requests from merge_rsps and coords.
- removeReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
-
- removeRequest(Locking.Type, Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
-
- removeResponse(String, RouterStub.MembersNotification) - Method in class org.jgroups.stack.RouterStub
-
- RemoverOnAdd(Filter<T>) - Constructor for class org.jgroups.util.Table.RemoverOnAdd
-
- removes_till_compaction - Variable in class org.jgroups.util.RequestTable
-
- removeScope(Address, short) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- removeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- removeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- removeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- removesTillCompaction() - Method in class org.jgroups.util.RequestTable
-
- removesTillCompaction(int) - Method in class org.jgroups.util.RequestTable
-
- removeSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- removeSuspectedMember(Address) - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- removeTerminatedThreads() - Method in class org.jgroups.util.LazyThreadFactory
-
- removeWait(long) - Method in class org.jgroups.util.Queue
-
- removeWaiter(Owner) - Method in class org.jgroups.protocols.Locking.ServerCondition
-
- renameThread(String, Thread) - Method in class org.jgroups.util.DefaultThreadFactory
-
- renameThread(String, Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
-
Names a thread according to base_name, cluster name and local address.
- renameThread(Thread) - Method in class org.jgroups.util.DefaultThreadFactory
-
- renameThread(String, Thread) - Method in interface org.jgroups.util.ThreadFactory
-
- renameThreads() - Method in class org.jgroups.util.LazyThreadFactory
-
- repaint() - Method in class org.jgroups.demos.wb.Whiteboard
-
- replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(String, String, String) - Static method in class org.jgroups.conf.XmlConfigurator
-
- replace(Message, Message) - Method in class org.jgroups.util.MessageBatch
-
Replaces a message in the batch with another one
- replace(Filter<Message>, Message, boolean) - Method in class org.jgroups.util.MessageBatch
-
Replaces all messages which match a given filter with a replacement message
- replaceConnection(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
-
- replaceProperties(String, Properties) - Static method in class org.jgroups.util.Util
-
Go through the input string and replace any occurance of ${p} with the
props.getProperty(p) value.
- replaceProtocol(Protocol, Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
Replaces one protocol instance with another.
- ReplCache<K,V> - Class in org.jgroups.blocks
-
Cache which allows for replication factors per data items; the factor determines how many replicas
of a key/value we create across the cluster.
See doc/design/ReplCache.txt for details.
- ReplCache(String, String) - Constructor for class org.jgroups.blocks.ReplCache
-
- ReplCache.ChangeListener - Interface in org.jgroups.blocks
-
- ReplCache.ConsistentHashFunction<K> - Class in org.jgroups.blocks
-
- ReplCache.HashFunction<K> - Interface in org.jgroups.blocks
-
- ReplCache.HashFunctionFactory<K> - Interface in org.jgroups.blocks
-
- ReplCache.Value<V> - Class in org.jgroups.blocks
-
- ReplCacheDemo - Class in org.jgroups.demos
-
GUI demo of ReplCache
- ReplCacheDemo() - Constructor for class org.jgroups.demos.ReplCacheDemo
-
- REPLENISH - Static variable in class org.jgroups.protocols.FcHeader
-
- replenish(Address, long) - Method in class org.jgroups.util.CreditMap
-
- replenishAll() - Method in class org.jgroups.util.CreditMap
-
- ReplicatedHashMap<K,V> - Class in org.jgroups.blocks
-
Implementation of a ConcurrentMap
with replication of the contents across a cluster.
- ReplicatedHashMap(Channel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Constructs a new ReplicatedHashMap with channel.
- ReplicatedHashMap(ConcurrentMap<K, V>, Channel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Constructs a new ReplicatedHashMap using provided map instance.
- ReplicatedHashMap.Notification<K,V> - Interface in org.jgroups.blocks
-
- ReplicatedHashMapDemo - Class in org.jgroups.demos
-
Uses the ReplicatedHashMap building block, which subclasses java.util.HashMap and overrides
the methods that modify the hashmap (e.g.
- ReplicatedHashMapDemo() - Constructor for class org.jgroups.demos.ReplicatedHashMapDemo
-
- ReplicatedMap<K,V> - Interface in org.jgroups.blocks
-
- ReplicatedTree - Class in org.jgroups.blocks
-
A tree-like structure that is replicated across several members.
- ReplicatedTree(String, String, long) - Constructor for class org.jgroups.blocks.ReplicatedTree
-
Creates a channel with the given properties.
- ReplicatedTree(String, String, long, boolean) - Constructor for class org.jgroups.blocks.ReplicatedTree
-
- ReplicatedTree() - Constructor for class org.jgroups.blocks.ReplicatedTree
-
- ReplicatedTree(JChannel) - Constructor for class org.jgroups.blocks.ReplicatedTree
-
Expects an already connected channel.
- ReplicatedTree.Node - Class in org.jgroups.blocks
-
- ReplicatedTree.ReplicatedTreeListener - Interface in org.jgroups.blocks
-
- REQ - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
-
- req - Variable in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
-
- REQ - Static variable in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- REQ - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
-
- req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
-
- req_id - Variable in class org.jgroups.blocks.Request
-
- req_id - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
The request id (unique for each blocking request), 0 means no response is expected
- req_id - Variable in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
-
- req_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
-
Marshaller to marshall requests at the caller and unmarshal requests at the receiver(s)
- REQ_ONLY - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
-
- Request() - Constructor for class org.jgroups.blocks.MemcachedConnector.Request
-
- Request - Class in org.jgroups.blocks
-
Abstract class for a unicast or multicast request
- Request(RequestCorrelator, RequestOptions) - Constructor for class org.jgroups.blocks.Request
-
- REQUEST - Static variable in class org.jgroups.protocols.COUNTER
-
- Request() - Constructor for class org.jgroups.protocols.COUNTER.Request
-
- Request() - Constructor for class org.jgroups.protocols.Executing.Request
-
- Request(Executing.Type, Object, long) - Constructor for class org.jgroups.protocols.Executing.Request
-
- request - Variable in class org.jgroups.protocols.Executing.Request
-
- Request() - Constructor for class org.jgroups.protocols.Locking.Request
-
- Request(Locking.Type, String, Owner, long) - Constructor for class org.jgroups.protocols.Locking.Request
-
- Request(Locking.Type, String, Owner, long, boolean) - Constructor for class org.jgroups.protocols.Locking.Request
-
- REQUEST - Static variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- request_handler - Variable in class org.jgroups.blocks.RequestCorrelator
-
The handler for the incoming requests.
- REQUEST_ID - Static variable in class org.jgroups.blocks.RequestCorrelator
-
To generate unique request IDs
- request_msgs - Variable in class org.jgroups.protocols.SEQUENCER2
-
- RequestCorrelator - Class in org.jgroups.blocks
-
Framework to send requests and receive matching responses (on request ID).
- RequestCorrelator(short, Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
-
Constructor.
- RequestCorrelator(Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
-
- RequestCorrelator.Header - Class in org.jgroups.blocks
-
The header for RequestCorrelator messages
- RequestCorrelator.MultiDestinationHeader - Class in org.jgroups.blocks
-
- RequestCorrelator.MyProbeHandler - Class in org.jgroups.blocks
-
- RequestCorrelator.ResponseImpl - Class in org.jgroups.blocks
-
- requester - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
-
- requestFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
-
- RequestHandler - Interface in org.jgroups.blocks
-
- requestId(long) - Method in class org.jgroups.blocks.Request
-
- requestId() - Method in class org.jgroups.blocks.Request
-
- requestId(long) - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- requestId() - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- requestId - Variable in class org.jgroups.protocols.Executing.Owner
-
- RequestOptions - Class in org.jgroups.blocks
-
Class which captures a bunch of options relevant to remote method invocation or message sending
- RequestOptions() - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(ResponseMode, long, boolean, RspFilter, Message.Flag...) - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(ResponseMode, long, boolean, RspFilter, short) - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(ResponseMode, long, boolean, RspFilter) - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(ResponseMode, long) - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(ResponseMode, long, boolean) - Constructor for class org.jgroups.blocks.RequestOptions
-
- RequestOptions(RequestOptions) - Constructor for class org.jgroups.blocks.RequestOptions
-
- requests - Variable in class org.jgroups.blocks.GroupRequest
-
Correlates requests and responses
- requests - Variable in class org.jgroups.blocks.RequestCorrelator
-
The table of pending requests (keys=Long (request IDs), values=RequestEntry)
- RequestTable<T> - Class in org.jgroups.util
-
Table for storing requests associated with monotonically increasing sequence numbers (seqnos).
Used for example in
RequestCorrelator
.
- RequestTable(int) - Constructor for class org.jgroups.util.RequestTable
-
- RequestTable(int, long, long) - Constructor for class org.jgroups.util.RequestTable
-
- RequestTable.Visitor<T> - Interface in org.jgroups.util
-
- requestToBuffer(COUNTER.Request) - Static method in class org.jgroups.protocols.COUNTER
-
- requestToRequestType(COUNTER.Request) - Static method in class org.jgroups.protocols.COUNTER
-
- RequestWithThread() - Constructor for class org.jgroups.protocols.Executing.RequestWithThread
-
- RequestWithThread(Executing.Type, Object, long, long) - Constructor for class org.jgroups.protocols.Executing.RequestWithThread
-
- require_client_authentication - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
-
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- requiredDownServices() - Method in class org.jgroups.stack.Protocol
-
List of events that are required to be answered by some layer below
- requiredUpServices() - Method in class org.jgroups.protocols.KeyExchange
-
- requiredUpServices() - Method in class org.jgroups.stack.Protocol
-
List of events that are required to be answered by some layer above
- resend_delay - Variable in class org.jgroups.protocols.FORWARD_TO_COORD
-
Deprecated.
- resend_interval - Variable in class org.jgroups.protocols.ABP
-
- resend_interval - Variable in class org.jgroups.protocols.RSVP
-
- resend_last_seqno - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- resend_last_seqno_max_times - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- resend_task - Variable in class org.jgroups.protocols.RSVP
-
- resendPendingLockRequests() - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- ResendPendingRequests() - Constructor for class org.jgroups.protocols.COUNTER.ResendPendingRequests
-
- ResendTask() - Constructor for class org.jgroups.protocols.RSVP.ResendTask
-
- resendTaskRunning() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- reset() - Static method in class org.jgroups.protocols.EXAMPLE
-
Just remove if you don't need to reset any state
- reset() - Method in class org.jgroups.protocols.FlowControl.Credit
-
- reset() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- reset() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- reset() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- reset() - Method in class org.jgroups.stack.DefaultRetransmitter
-
Reset the retransmitter: clear all msgs and cancel all the
respective tasks
- reset() - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
Reset the retransmitter: clear all msgs and cancel all the respective tasks
- reset() - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
Reset the retransmitter: clear all msgs and cancel all the respective tasks
- reset(Collection<Address>) - Method in class org.jgroups.util.AckCollector
-
- reset() - Method in class org.jgroups.util.ByteBufferOutputStream
-
- reset() - Method in class org.jgroups.util.CreditMap
-
- reset() - Method in class org.jgroups.util.InputStreamAdapter
-
- reset() - Method in class org.jgroups.util.MyReceiver
-
- reset() - Method in class org.jgroups.util.Promise
-
Causes all waiting threads to return
- reset(boolean) - Method in class org.jgroups.util.Promise
-
- reset() - Method in class org.jgroups.util.Queue
-
resets the queue.
- reset() - Method in class org.jgroups.util.ResponseCollector
-
- reset(Collection<Address>) - Method in class org.jgroups.util.ResponseCollector
-
- reset(Address...) - Method in class org.jgroups.util.ResponseCollector
-
- reset() - Method in class org.jgroups.util.RpcStats
-
- resetDigest() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- resetIgnoredMembers() - Method in class org.jgroups.protocols.DISCARD
-
- resetNumBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- resetStatistics() - Method in class org.jgroups.stack.Protocol
-
- resetStats() - Method in class org.jgroups.JChannel
-
- resetStats() - Method in class org.jgroups.protocols.DAISYCHAIN
-
- resetStats() - Method in class org.jgroups.protocols.DELIVERY_TIME
-
- resetStats() - Method in class org.jgroups.protocols.DISCARD
-
- resetStats() - Method in class org.jgroups.protocols.Discovery
-
- resetStats() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- resetStats() - Method in class org.jgroups.protocols.FD
-
- resetStats() - Method in class org.jgroups.protocols.FD_ALL
-
- resetStats() - Method in class org.jgroups.protocols.FD_ALL2
-
- resetStats() - Method in class org.jgroups.protocols.FD_HOST
-
- resetStats() - Method in class org.jgroups.protocols.FD_SOCK
-
- resetStats() - Method in class org.jgroups.protocols.FILE_PING
-
- resetStats() - Method in class org.jgroups.protocols.FlowControl
-
- resetStats() - Method in class org.jgroups.protocols.FRAG
-
- resetStats() - Method in class org.jgroups.protocols.FRAG2
-
- resetStats() - Method in class org.jgroups.protocols.MFC
-
- resetStats() - Method in class org.jgroups.protocols.pbcast.GMS
-
- resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- resetStats() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- resetStats() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- resetStats() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- resetStats() - Method in class org.jgroups.protocols.PERF
-
- resetStats() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- resetStats() - Method in class org.jgroups.protocols.relay.RELAY2
-
- resetStats() - Method in class org.jgroups.protocols.SEQUENCER
-
- resetStats() - Method in class org.jgroups.protocols.SEQUENCER2
-
- resetStats() - Method in class org.jgroups.protocols.STATS
-
- resetStats() - Method in class org.jgroups.protocols.tom.TOA
-
- resetStats() - Method in class org.jgroups.protocols.TP
-
- resetStats() - Method in class org.jgroups.protocols.UFC
-
- resetStats() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- resetStats() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- resetStats() - Method in class org.jgroups.protocols.UNICAST3
-
- resetStats() - Method in class org.jgroups.stack.Protocol
-
- resetStats() - Method in class org.jgroups.util.Table
-
- resize(int) - Method in class org.jgroups.util.ExtendedUUID
-
- resize(Header[]) - Static method in class org.jgroups.util.Headers
-
Increases the capacity of the array and copies the contents of the old into the new array
- resize() - Method in class org.jgroups.util.MessageBatch
-
- resize(int) - Method in class org.jgroups.util.Responses
-
- resize(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Moves rows down the matrix, by removing purged rows.
- resize(long) - Method in class org.jgroups.util.Table
-
Moves rows down the matrix, by removing purged rows.
- resize_factor - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- resize_factor - Variable in class org.jgroups.util.Table
-
- RESOLVE_DNS - Static variable in class org.jgroups.Global
-
- resolveAndAssignField(Object, Field, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
-
- resolveAndAssignFields(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
-
- resolveAndInvokePropertyMethod(Object, Method, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
-
- resolveAndInvokePropertyMethods(Object, Map<String, String>) - Static method in class org.jgroups.stack.Configurator
-
- resolveClass(ObjectStreamClass) - Method in class org.jgroups.util.ObjectInputStreamWithClassloader
-
- resource_bundle - Static variable in class org.jgroups.util.Util
-
- ResourceDMBean - Class in org.jgroups.jmx
-
A DynamicMBean wrapping an annotated object instance and exposing attributes annotated with @ManagedAttribute and
operations annotated with @ManagedOperation.
- ResourceDMBean(Object) - Constructor for class org.jgroups.jmx.ResourceDMBean
-
- ResourceDMBean.Accessor - Interface in org.jgroups.jmx
-
- ResourceDMBean.AttributeEntry - Class in org.jgroups.jmx
-
- ResourceDMBean.FieldAccessor - Class in org.jgroups.jmx
-
- ResourceDMBean.MethodAccessor - Class in org.jgroups.jmx
-
- ResourceDMBean.NoopAccessor - Class in org.jgroups.jmx
-
- ResourceManager - Class in org.jgroups.util
-
Manages resources such as multicast addresses and multicast ports, and TCP
ports.
- ResourceManager.IpAddressRep - Interface in org.jgroups.util
-
- RESPONSE - Static variable in class org.jgroups.auth.DemoToken.DemoHeader
-
- Response - Interface in org.jgroups.blocks
-
- RESPONSE - Static variable in class org.jgroups.protocols.COUNTER
-
- Response() - Constructor for class org.jgroups.protocols.COUNTER.Response
-
- Response(Locking.Type, Owner, String, int) - Constructor for class org.jgroups.protocols.Locking.Response
-
- RESPONSE - Static variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- response_msgs - Variable in class org.jgroups.protocols.SEQUENCER2
-
- ResponseCollector<T> - Class in org.jgroups.util
-
Similar to AckCollector, but collects responses from cluster members, not just acks.
- ResponseCollector(Collection<Address>) - Constructor for class org.jgroups.util.ResponseCollector
-
- ResponseCollector(Address...) - Constructor for class org.jgroups.util.ResponseCollector
-
- ResponseCollector() - Constructor for class org.jgroups.util.ResponseCollector
-
- ResponseCollectorTask<T> - Class in org.jgroups.util
-
Task which is seeded with an initial membership.
- ResponseCollectorTask() - Constructor for class org.jgroups.util.ResponseCollectorTask
-
- ResponseCollectorTask(Collection<Address>) - Constructor for class org.jgroups.util.ResponseCollectorTask
-
- ResponseCollectorTask(Address...) - Constructor for class org.jgroups.util.ResponseCollectorTask
-
- ResponseCollectorTask.Consumer<C> - Interface in org.jgroups.util
-
- responseFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
-
- ResponseImpl(Message, long) - Constructor for class org.jgroups.blocks.RequestCorrelator.ResponseImpl
-
- ResponseMode - Enum in org.jgroups.blocks
-
Enum capturing the various response modes for RPCs
- responseReceived() - Method in class org.jgroups.blocks.UnicastRequest
-
- responses - Variable in class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- Responses - Class in org.jgroups.util
-
Manages responses for the discovery protocol.
- Responses(boolean) - Constructor for class org.jgroups.util.Responses
-
- Responses(int, boolean) - Constructor for class org.jgroups.util.Responses
-
- Responses(int, boolean, int) - Constructor for class org.jgroups.util.Responses
-
- Responses.PingDataIterator - Class in org.jgroups.util
-
- responsesComplete() - Method in class org.jgroups.blocks.GroupRequest
-
- responsesComplete() - Method in class org.jgroups.blocks.Request
-
- responsesComplete(long) - Method in class org.jgroups.blocks.Request
-
This method runs with lock locked (called by execute()
).
- responsesComplete() - Method in class org.jgroups.blocks.UnicastRequest
-
- responseToBuffer(COUNTER.Response) - Static method in class org.jgroups.protocols.COUNTER
-
- responseToResponseType(COUNTER.Response) - Static method in class org.jgroups.protocols.COUNTER
-
- result - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
The result to return from get()
- result - Variable in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- result - Variable in class org.jgroups.blocks.UnicastRequest
-
- result - Variable in class org.jgroups.protocols.COUNTER.BooleanResponse
-
- result - Variable in class org.jgroups.protocols.COUNTER.ValueResponse
-
- result - Variable in class org.jgroups.protocols.pbcast.NAKACK2.Counter
-
- result - Variable in class org.jgroups.util.Promise
-
- Result() - Constructor for class org.jgroups.util.RpcStats.Result
-
- result - Variable in class org.jgroups.util.Table.Counter
-
- resultReturned(Object) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- resultReturned(Object) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
-
- RESUME - Static variable in class org.jgroups.Event
-
- resume() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- RESUME_STABLE - Static variable in class org.jgroups.Event
-
- resume_task_future - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- resume_task_mutex - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- resume_task_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
-
- resumeEncoding() - Method in class org.jgroups.util.Base64.OutputStream
-
Resumes encoding of the stream.
- resumeStable() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- resumeStable() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- ResumeTask() - Constructor for class org.jgroups.protocols.pbcast.STABLE.ResumeTask
-
- resumeViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
-
- retainAll(Collection<Address>) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Removes all connections from ConnectionTable which are not in current_mbrs
- retainAll(Collection<Address>) - Method in class org.jgroups.blocks.cs.BaseServer
-
Removes all connections which are not in current_mbrs
- retainAll(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- retainAll(Collection<K>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
- retainAll(Collection<Address>) - Method in class org.jgroups.Membership
-
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.BasicTCP
-
- retainAll(List<Address>) - Method in class org.jgroups.protocols.PEER_LOCK.PeerLock
-
Deprecated.
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.RSVP.Entry
-
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP
-
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP_NIO2
-
- retainAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
-
- retainAll(Collection<T>) - Method in class org.jgroups.util.ProcessingQueue
-
- retainAll(List<Address>) - Method in class org.jgroups.util.ResponseCollector
-
- retainAll(List<Address>) - Method in class org.jgroups.util.ResponseCollectorTask
-
- retainAll(Collection<Address>) - Method in class org.jgroups.util.RpcStats
-
- retainAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
-
- retainAll(Collection<Address>) - Static method in class org.jgroups.util.UUID
-
- retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Implementation of Retransmitter.RetransmitCommand.
- retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- retransmit(SeqnoList, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- retransmit(Message) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
Called by AckSenderWindow to resend messages for which no ACK has been received yet
- retransmit(SeqnoList, Address) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- retransmit(SeqnoList, Address) - Method in class org.jgroups.protocols.UNICAST3
-
Sends a retransmit request to the given sender
- retransmit(Message) - Method in class org.jgroups.protocols.UNICAST3
-
Called by the sender to resend messages for which no ACK has been received yet
- retransmit(long, long, Address) - Method in interface org.jgroups.stack.Retransmitter.RetransmitCommand
-
Deprecated.
Get the missing messages between sequence numbers first_seqno
and last_seqno
.
- retransmit_timeouts - Variable in class org.jgroups.stack.Retransmitter
-
Deprecated.
Default retransmit intervals (ms) - exponential approx.
- RetransmitTable - Class in org.jgroups.util
-
Deprecated.
- RetransmitTable() - Constructor for class org.jgroups.util.RetransmitTable
-
Deprecated.
- RetransmitTable(int, int, long) - Constructor for class org.jgroups.util.RetransmitTable
-
Deprecated.
- RetransmitTable(int, int, long, double) - Constructor for class org.jgroups.util.RetransmitTable
-
Deprecated.
- RetransmitTable(int, int, long, double, long, boolean) - Constructor for class org.jgroups.util.RetransmitTable
-
Deprecated.
- RetransmitTask() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
-
- RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST.RetransmitTask
-
Deprecated.
- RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST2.RetransmitTask
-
Deprecated.
- RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST3.RetransmitTask
-
- Retransmitter - Class in org.jgroups.stack
-
Deprecated.
- Retransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.Retransmitter
-
Deprecated.
Create a new Retransmitter associated with the given sender address
- Retransmitter.RetransmitCommand - Interface in org.jgroups.stack
-
Deprecated.
Retransmit command (see Gamma et al.) used to retrieve missing messages
- Retransmitter.Task - Class in org.jgroups.stack
-
Deprecated.
- return_entire_cache - Variable in class org.jgroups.protocols.Discovery
-
- returnEntireCache() - Method in class org.jgroups.protocols.Discovery
-
- returnEntireCache(boolean) - Method in class org.jgroups.protocols.Discovery
-
- ri - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- ri - Variable in class org.jgroups.util.RingBuffer
-
- RingBuffer<T> - Class in org.jgroups.util
-
Ring buffer of fixed capacity designed for multiple writers but only a single reader.
- RingBuffer(Class<T>, int) - Constructor for class org.jgroups.util.RingBuffer
-
- RingBufferBundler - Class in org.jgroups.protocols
-
- RingBufferBundler() - Constructor for class org.jgroups.protocols.RingBufferBundler
-
- RingBufferBundler(RingBuffer<Message>) - Constructor for class org.jgroups.protocols.RingBufferBundler
-
- RingBufferBundler(int) - Constructor for class org.jgroups.protocols.RingBufferBundler
-
- RingBufferBundlerLockless - Class in org.jgroups.protocols
-
Bundler which doesn't use locks but relies on CAS.
- RingBufferBundlerLockless() - Constructor for class org.jgroups.protocols.RingBufferBundlerLockless
-
- RingBufferBundlerLockless(int) - Constructor for class org.jgroups.protocols.RingBufferBundlerLockless
-
- RingBufferBundlerLockless2 - Class in org.jgroups.protocols
-
Lockless bundler using a reader thread which is unparked by (exactly one) writer thread.
- RingBufferBundlerLockless2() - Constructor for class org.jgroups.protocols.RingBufferBundlerLockless2
-
- RingBufferBundlerLockless2(int) - Constructor for class org.jgroups.protocols.RingBufferBundlerLockless2
-
- RingBufferBundlerLockless2(int, boolean) - Constructor for class org.jgroups.protocols.RingBufferBundlerLockless2
-
- RingBufferIterator(T[]) - Constructor for class org.jgroups.util.RingBufferSeqno.RingBufferIterator
-
- RingBufferIterator(AtomicReferenceArray<T>) - Constructor for class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
-
- RingBufferSeqno<T> - Class in org.jgroups.util
-
Ring buffer, implemented with a circular array.
- RingBufferSeqno(int, long) - Constructor for class org.jgroups.util.RingBufferSeqno
-
Creates a RingBuffer
- RingBufferSeqno.RingBufferIterator - Class in org.jgroups.util
-
- RingBufferSeqnoLockless<T> - Class in org.jgroups.util
-
Ring buffer, implemented with a circular array.
- RingBufferSeqnoLockless(int, long) - Constructor for class org.jgroups.util.RingBufferSeqnoLockless
-
Creates a RingBuffer
- RingBufferSeqnoLockless.RingBufferIterator - Class in org.jgroups.util
-
- RobustRunnable(Runnable) - Constructor for class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
-
- root_dir - Variable in class org.jgroups.protocols.FILE_PING
-
- root_dir - Variable in class org.jgroups.protocols.PDC
-
- ROTATION_TIME - Variable in class org.jgroups.util.HashedTimingWheel
-
- round - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
-
- route(SiteAddress, SiteAddress, Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
Routes the message to the target destination, used by a site master (coordinator)
- Route - Class in org.jgroups.protocols.relay
-
Class which maintains the destination address for sending messages to a given site, and the bridge channel to do so.
- Route(Address, JChannel, RELAY2, Log) - Constructor for class org.jgroups.protocols.relay.Route
-
- route(String, Address, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
-
- route_status_listener - Variable in class org.jgroups.protocols.relay.RELAY2
-
- router_addr - Variable in class org.jgroups.stack.RouterStubManager.Target
-
- RouterStub - Class in org.jgroups.stack
-
Client stub that talks to a remote GossipRouter via blocking or non-blocking TCP
- RouterStub(InetAddress, int, InetAddress, int, boolean, RouterStub.CloseListener) - Constructor for class org.jgroups.stack.RouterStub
-
Creates a stub to a remote GossipRouter
- RouterStub(IpAddress, IpAddress, boolean, RouterStub.CloseListener) - Constructor for class org.jgroups.stack.RouterStub
-
- RouterStub.CloseListener - Interface in org.jgroups.stack
-
- RouterStub.MembersNotification - Interface in org.jgroups.stack
-
- RouterStub.StubReceiver - Interface in org.jgroups.stack
-
- RouterStubManager - Class in org.jgroups.stack
-
Manages a list of RouterStubs (e.g.
- RouterStubManager(Protocol, String, Address, String, PhysicalAddress, long) - Constructor for class org.jgroups.stack.RouterStubManager
-
- RouterStubManager.Consumer - Interface in org.jgroups.stack
-
Interface to iterate through stubs.
- RouterStubManager.Target - Class in org.jgroups.stack
-
- routes - Variable in class org.jgroups.protocols.relay.Relayer
-
The routing table.
- RouteStatusListener - Interface in org.jgroups.protocols.relay
-
Gets notified when a site comes up or goes down
- rpc_stats - Variable in class org.jgroups.blocks.MessageDispatcher
-
- rpc_stats - Variable in class org.jgroups.blocks.RequestCorrelator
-
- RPC_TIMEOUT - Static variable in class org.jgroups.demos.RelayDemoRpc
-
- RpcDispatcher - Class in org.jgroups.blocks
-
This class allows a programmer to invoke remote methods in all (or single)
group members and optionally wait for the return value(s).
- RpcDispatcher() - Constructor for class org.jgroups.blocks.RpcDispatcher
-
- RpcDispatcher(Channel, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
-
- RpcDispatcher(Channel, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
-
- RpcDispatcher.Marshaller - Interface in org.jgroups.blocks
-
- rpcStats() - Method in class org.jgroups.blocks.MessageDispatcher
-
- RpcStats - Class in org.jgroups.util
-
Keeps track of stats for sync and async unicasts and multicasts
- RpcStats(boolean) - Constructor for class org.jgroups.util.RpcStats
-
- RpcStats.Result - Class in org.jgroups.util
-
- RpcStats.Type - Enum in org.jgroups.util
-
- RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
-
- RSP - Static variable in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- RSP - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
-
- Rsp<T> - Class in org.jgroups.util
-
Class that represents a response from a communication
- Rsp(Address) - Constructor for class org.jgroups.util.Rsp
-
- Rsp(Address, T) - Constructor for class org.jgroups.util.Rsp
-
- Rsp(Address, Throwable) - Constructor for class org.jgroups.util.Rsp
-
- rsp_filter - Variable in class org.jgroups.blocks.RequestOptions
-
Allows for filtering of responses
- rsp_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
-
Marshaller to marshal responses at the receiver(s) and unmarshal responses at the caller
- rspExpected() - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- RspFilter - Interface in org.jgroups.blocks
-
Interface defining when a group request is done.
- RspList<T> - Class in org.jgroups.util
-
Contains responses from all members.
- RspList() - Constructor for class org.jgroups.util.RspList
-
- RspList(Collection<Rsp<T>>) - Constructor for class org.jgroups.util.RspList
-
Adds a list of responses
- RSVP - Static variable in class org.jgroups.Message
-
Deprecated.
- RSVP - Class in org.jgroups.protocols
-
Protocol which implements synchronous messages (https://issues.jboss.org/browse/JGRP-1389).
- RSVP() - Constructor for class org.jgroups.protocols.RSVP
-
- RSVP.Entry - Class in org.jgroups.protocols
-
- RSVP.ResendTask - Class in org.jgroups.protocols
-
- RSVP.RsvpHeader - Class in org.jgroups.protocols
-
- RsvpHeader() - Constructor for class org.jgroups.protocols.RSVP.RsvpHeader
-
- RsvpHeader(byte, short) - Constructor for class org.jgroups.protocols.RSVP.RsvpHeader
-
- Rule - Class in org.jgroups.protocols.rules
-
A rule with a condition and (optional) action.
- Rule() - Constructor for class org.jgroups.protocols.rules.Rule
-
- RULE - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- rules - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- RULES - Static variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- run() - Method in class org.jgroups.auth.sasl.FileWatchTask
-
- run() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
Acceptor thread.
- run() - Method in class org.jgroups.blocks.cs.BaseServer.Reaper
-
- run() - Method in class org.jgroups.blocks.cs.NioBaseServer.Acceptor
-
- run() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- run() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- run() - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- run() - Method in class org.jgroups.blocks.cs.TcpServer.Acceptor
-
Acceptor thread.
- run() - Method in class org.jgroups.blocks.executor.ExecutionRunner
-
- run() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Sets this Future to the result of its computation
unless it has been cancelled.
- run() - Method in class org.jgroups.blocks.MemcachedConnector
-
- run() - Method in class org.jgroups.client.StompConnection
-
- run() - Method in class org.jgroups.protocols.ABP.Entry
-
- run() - Method in class org.jgroups.protocols.BPING
-
- run() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- run() - Method in class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
-
- run() - Method in class org.jgroups.protocols.FD.BroadcastTask
-
- run() - Method in class org.jgroups.protocols.FD.Monitor
-
- run() - Method in class org.jgroups.protocols.FD_HOST.PingTask
-
- run() - Method in class org.jgroups.protocols.FD_PING.PingMonitor
-
Deprecated.
- run() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- run() - Method in class org.jgroups.protocols.FD_SOCK.ClientConnectionHandler
-
- run() - Method in class org.jgroups.protocols.FD_SOCK
-
Runs as long as there are 2 members and more.
- run() - Method in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
Only accepts 1 client connection at a time (saving threads)
- run() - Method in class org.jgroups.protocols.FILE_PING.InfoWriter
-
- run() - Method in class org.jgroups.protocols.JDBC_PING.InfoWriter
-
- run() - Method in class org.jgroups.protocols.MAKE_BATCH.Batcher
-
- run() - Method in class org.jgroups.protocols.MERGE3.InfoSender
-
- run() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
-
- run() - Method in class org.jgroups.protocols.MPING
-
- run() - Method in class org.jgroups.protocols.pbcast.Merger.MergeKiller
-
- run() - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- run() - Method in class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
-
- run() - Method in class org.jgroups.protocols.pbcast.STABLE.ResumeTask
-
- run() - Method in class org.jgroups.protocols.pbcast.STABLE.StabilitySendTask
-
- run() - Method in class org.jgroups.protocols.pbcast.STABLE.StableTask
-
- run() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- run() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
-
- run() - Method in class org.jgroups.protocols.RELAY.RemoteViewFetcher
-
- run() - Method in class org.jgroups.protocols.RSVP.ResendTask
-
- run() - Method in class org.jgroups.protocols.rules.Rule
-
- run() - Method in class org.jgroups.protocols.SCOPE.ExpiryTask
-
Deprecated.
- run() - Method in class org.jgroups.protocols.SCOPE.QueueThread
-
Deprecated.
Try to remove as many messages as possible from the queue and pass them up.
- run() - Method in class org.jgroups.protocols.SenderSendsWithTimerBundler
-
Deprecated.
- run() - Method in class org.jgroups.protocols.SEQUENCER.Flusher
-
- run() - Method in class org.jgroups.protocols.STOMP.Connection
-
- run() - Method in class org.jgroups.protocols.STOMP
-
- run() - Method in class org.jgroups.protocols.tom.DeliveryThread
-
- run() - Method in class org.jgroups.protocols.TP.BatchHandler
-
- run() - Method in class org.jgroups.protocols.TP.SingleMessageHandler
-
- run() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- run() - Method in class org.jgroups.protocols.UDP.PacketReceiver
-
- run() - Method in class org.jgroups.protocols.UNICAST.ConnectionReaper
-
Deprecated.
- run() - Method in class org.jgroups.protocols.UNICAST.RetransmitTask
-
Deprecated.
- run() - Method in class org.jgroups.protocols.UNICAST2.ConnectionReaper
-
Deprecated.
- run() - Method in class org.jgroups.protocols.UNICAST2.RetransmitTask
-
Deprecated.
- run() - Method in class org.jgroups.protocols.UNICAST3.RetransmitTask
-
- run() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
Started when a suspected member is added to suspects.
- run() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- run() - Method in class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- run() - Method in class org.jgroups.stack.RouterStubManager
-
- run() - Method in class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
-
- run() - Method in class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- run() - Method in class org.jgroups.util.ForwardQueue.Flusher
-
- run() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- run() - Method in class org.jgroups.util.HashedTimingWheel
-
- run() - Method in class org.jgroups.util.Runner
-
- run() - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- run() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- run() - Method in class org.jgroups.util.TimeScheduler3.RecurringTask
-
- run() - Method in class org.jgroups.util.TimeScheduler3
-
- run() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- run() - Method in class org.jgroups.util.TimeService
-
- run_function - Variable in class org.jgroups.protocols.RingBufferBundler
-
- run_function - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- run_function - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- runnable - Variable in class org.jgroups.util.TimeScheduler3.Task
-
- RunnableAdapter() - Constructor for class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- RunnableAdapter(Runnable, T) - Constructor for class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- runner - Variable in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- runner - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
The thread running task.
- runner - Variable in class org.jgroups.client.StompConnection
-
- runner - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- runner - Variable in class org.jgroups.util.ResponseCollectorTask
-
- Runner - Class in org.jgroups.util
-
Runs a given function in a loop (in a separate thread) until it is stopped
- Runner(ThreadFactory, String, Runnable, Runnable) - Constructor for class org.jgroups.util.Runner
-
- runner - Variable in class org.jgroups.util.TimeScheduler3
-
Thread which removes tasks ready to be executed from the queue and submits them to the pool for execution
- running - Variable in class org.jgroups.blocks.cs.BaseServer
-
- running() - Method in class org.jgroups.blocks.cs.BaseServer
-
- running - Variable in class org.jgroups.blocks.cs.NioConnection.Reader
-
- RUNNING - Static variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
State value representing that task is running
- running - Variable in class org.jgroups.client.StompConnection
-
- running - Variable in class org.jgroups.demos.PubClient
-
- running - Variable in class org.jgroups.protocols.DAISYCHAIN
-
- running - Variable in class org.jgroups.protocols.FlowControl
-
Whether FlowControl is still running, this is set to false when the protocol terminates (on stop())
- running - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- running - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- running - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- running - Variable in class org.jgroups.protocols.SEQUENCER
-
- running - Variable in class org.jgroups.protocols.SEQUENCER2
-
- running - Variable in class org.jgroups.protocols.TransferQueueBundler
-
- running - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- running - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- running - Variable in class org.jgroups.protocols.UNICAST3
-
- running - Variable in class org.jgroups.stack.GossipRouter
-
- running() - Method in class org.jgroups.stack.GossipRouter
-
- running - Variable in class org.jgroups.util.ForwardQueue
-
- running - Variable in class org.jgroups.util.HashedTimingWheel
-
- running - Variable in class org.jgroups.util.RingBufferSeqno
-
- running - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
- running - Variable in class org.jgroups.util.Runner
-
- running - Variable in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- running() - Method in class org.jgroups.util.TimeService
-
- runRequest(Address, ByteBuffer) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- S3_PING - Class in org.jgroups.protocols
-
Discovery protocol using Amazon's S3 storage.
- S3_PING() - Constructor for class org.jgroups.protocols.S3_PING
-
- same(List<Digest>) - Static method in class org.jgroups.protocols.pbcast.FLUSH
-
- sameAddresses(InetAddress, InetAddress) - Static method in class org.jgroups.util.Util
-
Returns true if the 2 addresses are of the same type (IPv4 or IPv6)
- sameCluster(String) - Method in class org.jgroups.stack.DiagnosticsHandler
-
- sameHost(Address, Address) - Static method in class org.jgroups.util.Util
-
Checks whether 2 Addresses are on the same host
- SampleRule - Class in org.jgroups.protocols.rules
-
- SampleRule() - Constructor for class org.jgroups.protocols.rules.SampleRule
-
- sanitize(String) - Static method in class org.jgroups.protocols.S3_PING
-
Sanitizes bucket and folder names according to AWS guidelines
- sanitizeViews(Map<Address, View>) - Static method in class org.jgroups.protocols.pbcast.Merger
-
Removes all members from a given view which don't have us in their view
(https://jira.jboss.org/browse/JGRP-1061).
- sanityCheck(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Throws an exception if sanity check fails.
- sanityCheck(byte[], int, int) - Static method in class org.jgroups.util.BlockingInputStream
-
Verifies that length doesn't exceed a buffer's length
- SASL - Class in org.jgroups.protocols
-
The SASL protocol implements authentication and, if requested by the mech, encryption
- SASL() - Constructor for class org.jgroups.protocols.SASL
-
- sasl_context - Variable in class org.jgroups.protocols.SASL
-
- SASL_ID - Static variable in class org.jgroups.protocols.SASL
-
- sasl_props - Variable in class org.jgroups.protocols.SASL
-
- SASL_PROTOCOL_NAME - Static variable in class org.jgroups.protocols.SASL
-
- SaslClientCallbackHandler - Class in org.jgroups.auth.sasl
-
SaslClientCallbackHandler.
- SaslClientCallbackHandler(String, char[]) - Constructor for class org.jgroups.auth.sasl.SaslClientCallbackHandler
-
- SaslClientContext - Class in org.jgroups.auth.sasl
-
- SaslClientContext(SaslClientFactory, String, String, CallbackHandler, Map<String, String>, Subject) - Constructor for class org.jgroups.auth.sasl.SaslClientContext
-
- SaslContext - Interface in org.jgroups.auth.sasl
-
- SaslHeader - Class in org.jgroups.protocols
-
- SaslHeader() - Constructor for class org.jgroups.protocols.SaslHeader
-
- SaslHeader(SaslHeader.Type, byte[]) - Constructor for class org.jgroups.protocols.SaslHeader
-
- SaslHeader.Type - Enum in org.jgroups.protocols
-
- SaslServerContext - Class in org.jgroups.auth.sasl
-
- SaslServerContext(SaslServerFactory, String, String, CallbackHandler, Map<String, String>, Subject) - Constructor for class org.jgroups.auth.sasl.SaslServerContext
-
- SaslUtils - Class in org.jgroups.auth.sasl
-
Utility methods for handling SASL authentication
- saturation() - Method in class org.jgroups.util.RingBufferSeqno
-
- saturation() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- saved_index - Variable in class org.jgroups.util.MessageBatch.BatchIterator
-
- sayName() - Method in class org.jgroups.demos.JmxDemo
-
- sb - Variable in class org.jgroups.util.Table.Dump
-
- schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
-
- schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
-
- schedule(Runnable, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
-
Creates and executes a one-shot action that becomes enabled after the given delay.
- schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- schedule(Runnable, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
-
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
-
Creates and executes a periodic action that becomes enabled first
after the given initial delay, and subsequently with the given
period; that is executions will commence after
initialDelay then initialDelay+period, then
initialDelay + 2 * period, and so on.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
-
- scheduleBarrierOpener() - Method in class org.jgroups.protocols.BARRIER
-
- scheduleRecurring(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
-
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.DefaultTimeScheduler
-
Schedule a task for execution at varying intervals.
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.HashedTimingWheel
-
Schedule a task for execution at varying intervals.
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.MockTimeScheduler
-
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in interface org.jgroups.util.TimeScheduler
-
Schedule a task for execution at varying intervals.
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
Schedule a task for execution at varying intervals.
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler3
-
Schedule a task for execution at varying intervals.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.DefaultTimeScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.HashedTimingWheel
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.MockTimeScheduler
-
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.jgroups.util.TimeScheduler
-
Creates and executes a periodic action that becomes enabled first after the given initial delay, and
subsequently with the given delay between the termination of one execution and the commencement of the next.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3
-
- scope - Variable in class org.jgroups.blocks.RequestOptions
-
The scope of a message, allows for concurrent delivery of messages from the same sender
- SCOPE - Class in org.jgroups.protocols
-
- SCOPE() - Constructor for class org.jgroups.protocols.SCOPE
-
Deprecated.
- SCOPE.ExpiryTask - Class in org.jgroups.protocols
-
Deprecated.
- SCOPE.MessageQueue - Class in org.jgroups.protocols
-
Deprecated.
- SCOPE.QueueThread - Class in org.jgroups.protocols
-
Deprecated.
- SCOPE.ScopeHeader - Class in org.jgroups.protocols
-
Deprecated.
- SCOPE_ID - Static variable in class org.jgroups.Global
-
- SCOPED - Static variable in class org.jgroups.Message
-
Deprecated.
- ScopeHeader() - Constructor for class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- secret_access_key - Variable in class org.jgroups.protocols.S3_PING
-
- secret_key - Variable in class org.jgroups.protocols.EncryptBase
-
- secret_key_algorithm - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- SECRET_KEY_REQ - Static variable in class org.jgroups.protocols.EncryptHeader
-
- SECRET_KEY_RSP - Static variable in class org.jgroups.protocols.EncryptHeader
-
- SECRETKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- secretKey - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- secretKey() - Method in class org.jgroups.protocols.EncryptBase
-
- secretKey(Key) - Method in class org.jgroups.protocols.EncryptBase
-
- segment_capacity - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- select_all_pingdata_sql - Variable in class org.jgroups.protocols.JDBC_PING
-
- selector - Variable in class org.jgroups.blocks.cs.NioBaseServer
-
- selectorOpen() - Method in class org.jgroups.blocks.cs.NioBaseServer
-
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
-
- send(byte[], int, int) - Method in interface org.jgroups.blocks.cs.Client
-
Sends data to the remote server.
- send(ByteBuffer) - Method in interface org.jgroups.blocks.cs.Client
-
Sends data to the remote server.
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.Connection
-
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.Connection
-
- send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.NioClient
-
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.NioClient
-
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.NioClient
-
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.NioClient
-
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.NioConnection
-
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.NioConnection
-
Sends a message.
- send() - Method in class org.jgroups.blocks.cs.NioConnection
-
- send(ByteBuffer, boolean) - Method in class org.jgroups.blocks.cs.NioConnection
-
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpClient
-
- send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpClient
-
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpClient
-
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpClient
-
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- send(Object, boolean) - Method in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
-
- send(Message, boolean) - Method in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
-
- send(Object, boolean) - Method in interface org.jgroups.blocks.Response
-
- send(Message, boolean) - Method in interface org.jgroups.blocks.Response
-
- send(Message) - Method in class org.jgroups.Channel
-
Sends a message.
- send(Address, Object) - Method in class org.jgroups.Channel
-
- send(Address, byte[]) - Method in class org.jgroups.Channel
-
Sends a message.
- send(Address, byte[], int, int) - Method in class org.jgroups.Channel
-
Sends a message to a destination.
- send(String, byte[], int, int, String...) - Method in class org.jgroups.client.StompConnection
-
- send(String, String...) - Method in class org.jgroups.client.StompConnection
-
Sends an INFO without body
- send(String, byte[], int, int) - Method in class org.jgroups.client.StompConnection
-
- send(String, byte[]) - Method in class org.jgroups.client.StompConnection
-
- send(String) - Method in class org.jgroups.demos.StompChat
-
- send(Message) - Method in class org.jgroups.fork.ForkChannel
-
- send(Message) - Method in class org.jgroups.JChannel
-
- send(Address, Object) - Method in class org.jgroups.JChannel
-
- send(Address, byte[]) - Method in class org.jgroups.JChannel
-
- send(Address, byte[], int, int) - Method in class org.jgroups.JChannel
-
- send(Message) - Method in class org.jgroups.protocols.ABP.Entry
-
- send(Message) - Method in class org.jgroups.protocols.BaseBundler
-
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
-
- send(Message) - Method in interface org.jgroups.protocols.Bundler
-
- send(Address, Buffer) - Method in class org.jgroups.protocols.COUNTER
-
- send(Address, long, byte) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- send(Address, Locking.Request) - Method in class org.jgroups.protocols.Locking
-
- send(Message) - Method in class org.jgroups.protocols.NoBundler
-
- send(Event, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Adds the message to the sent_msgs table and then passes it down the stack.
- send(Event, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Adds the message to the sent_msgs table and then passes it down the stack.
- send(Address, Address, Message) - Method in class org.jgroups.protocols.relay.Route
-
- send(Message) - Method in class org.jgroups.protocols.RingBufferBundler
-
- send(Message) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- send(Message) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- send(Message) - Method in class org.jgroups.protocols.SenderSendsBundler
-
- send(Message) - Method in class org.jgroups.protocols.SenderSendsWithTimerBundler
-
Deprecated.
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
-
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP_NIO2
-
- send(Message, Address) - Method in class org.jgroups.protocols.TP
-
Serializes and sends a message.
- send(Message) - Method in class org.jgroups.protocols.TransferQueueBundler
-
- send(Message, Address) - Method in class org.jgroups.protocols.TUNNEL
-
- send(long, Message) - Method in class org.jgroups.util.ForwardQueue
-
- send_ack - Variable in class org.jgroups.protocols.UNICAST3.ReceiverEntry
-
- send_buf - Variable in class org.jgroups.blocks.cs.NioConnection
-
- send_buf_size - Variable in class org.jgroups.blocks.cs.BaseServer
-
- send_buf_size - Variable in class org.jgroups.protocols.BasicTCP
-
- send_cache_on_join - Variable in class org.jgroups.protocols.Discovery
-
- send_cond - Variable in class org.jgroups.protocols.SEQUENCER
-
- send_cond - Variable in class org.jgroups.util.ForwardQueue
-
- SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST3.Header
-
- send_info - Variable in class org.jgroups.protocols.STOMP
-
- send_lock - Variable in class org.jgroups.blocks.cs.NioConnection
-
- send_lock - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- send_lock - Variable in class org.jgroups.protocols.SEQUENCER
-
- send_lock - Variable in class org.jgroups.util.ForwardQueue
-
- send_map - Variable in class org.jgroups.protocols.ABP
-
- send_own_state_on_merge - Variable in class org.jgroups.demos.Draw
-
- send_queue - Variable in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- send_queue - Variable in class org.jgroups.protocols.ABP.Entry
-
- send_queue_size - Variable in class org.jgroups.blocks.cs.TcpBaseServer
-
- send_queue_size - Variable in class org.jgroups.protocols.BasicTCP
-
Deprecated.
- send_stable_msgs_to_coord_only - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- send_table - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- send_table - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- send_table - Variable in class org.jgroups.protocols.UNICAST3
-
- sendAck(Address, long) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- sendAck(Address, long, short) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- sendAck(Address, long, short) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- sendAck(Address, long, short) - Method in class org.jgroups.protocols.UNICAST3
-
- sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
-
- sendAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendBufferSize() - Method in class org.jgroups.blocks.cs.BaseServer
-
- sendBufferSize(int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- sendBundledMessages() - Method in class org.jgroups.protocols.BaseBundler
-
Sends all messages in the map.
- sendBundledMessages(Message[], int, int) - Method in class org.jgroups.protocols.RingBufferBundler
-
Read and send messages in range [read-index ..
- sendBundledMessages(Message[], int, int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
Read and send messages in range [read-index ..
- sendBundledMessages(Message[], int, int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
Read and send messages in range [read-index+1 ..
- sendBundledMessages() - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- sendCacheInformation() - Method in class org.jgroups.protocols.Discovery
-
- sendClearPanelMsg() - Method in class org.jgroups.demos.applets.DrawApplet
-
- sendClearPanelMsg() - Method in class org.jgroups.demos.Draw
-
- sendClearPanelMsg() - Method in class org.jgroups.demos.StompDraw
-
- sendClose(Address, short) - Method in class org.jgroups.protocols.UNICAST3
-
- sendConnect() - Method in class org.jgroups.client.StompConnection
-
- sendCounterNotFoundExceptionResponse(Address, Owner, String) - Method in class org.jgroups.protocols.COUNTER
-
- sendCreateLockRequest(Address, String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendCredit(Address, long) - Method in class org.jgroups.protocols.FlowControl
-
- sendCreditRequest(Address, long) - Method in class org.jgroups.protocols.FlowControl
-
We cannot send this request as OOB message, as the credit request needs to queue up behind the regular messages;
if a receiver cannot process the regular messages, that is a sign that the sender should be throttled !
- sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.Locking
-
- sendDeleteAwaitConditionRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendDeleteLockRequest(Address, String) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- SendDialog - Class in org.jgroups.demos.wb
-
- SendDialog(Frame, Node, String, RpcDispatcher) - Constructor for class org.jgroups.demos.wb.SendDialog
-
- sendDiscoveryRequest(String, List<Address>) - Method in class org.jgroups.protocols.PING
-
- sendDiscoveryResponse(Address, PhysicalAddress, String, Address, boolean) - Method in class org.jgroups.protocols.Discovery
-
- sendEof(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- sender - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- Sender(ThreadFactory, int) - Constructor for class org.jgroups.blocks.cs.TcpConnection.Sender
-
- sender - Variable in class org.jgroups.protocols.pbcast.MergeData
-
- sender - Variable in class org.jgroups.protocols.PingData
-
- sender - Variable in class org.jgroups.stack.Retransmitter
-
Deprecated.
- sender - Variable in class org.jgroups.util.MessageBatch
-
The sender of the message batch
- sender() - Method in class org.jgroups.util.MessageBatch
-
- sender(Address) - Method in class org.jgroups.util.MessageBatch
-
- sender - Variable in class org.jgroups.util.Rsp
-
The sender of this response
- SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST.SenderEntry
-
Deprecated.
- SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST3.SenderEntry
-
- SenderManager - Class in org.jgroups.protocols.tom
-
Keeps track of all sent messages, until the final sequence number is known
- SenderManager() - Constructor for class org.jgroups.protocols.tom.SenderManager
-
- SenderSendsBundler - Class in org.jgroups.protocols
-
- SenderSendsBundler() - Constructor for class org.jgroups.protocols.SenderSendsBundler
-
- SenderSendsWithTimerBundler - Class in org.jgroups.protocols
-
Deprecated.
- SenderSendsWithTimerBundler() - Constructor for class org.jgroups.protocols.SenderSendsWithTimerBundler
-
Deprecated.
- sendException(Address, Throwable) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- sendException(Address, Throwable) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- sendGetUsers() - Method in class org.jgroups.demos.StompChat
-
- sendGrantLockRequest(String, int, Owner, long, boolean) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendGrantLockRequest(String, int, Owner, long, boolean) - Method in class org.jgroups.protocols.Locking
-
- sendGrantLockRequest(String, int, Owner, long, boolean) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendHeartbeatResponse(Address) - Method in class org.jgroups.protocols.FD
-
- sendIHaveSockMessage(Address, Address, IpAddress) - Method in class org.jgroups.protocols.FD_SOCK
-
Sends or broadcasts a I_HAVE_SOCK response.
- sendInfo() - Method in class org.jgroups.protocols.MERGE3
-
- sendInfo() - Method in class org.jgroups.protocols.STOMP.Connection
-
- sendJoinRejectionMessage(Address, String) - Method in class org.jgroups.protocols.AUTH
-
- sendJoinRejectionMessage(Address, String) - Method in class org.jgroups.protocols.SASL
-
- sendJoinResponse(JoinRsp, Address) - Method in class org.jgroups.protocols.pbcast.GMS
-
- sendJoinResponses(JoinRsp, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
- sendKeyRequest() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- sendKeyRequest(Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
send client's public key to server and request server's public key
- sendLocalAddress(Address) - Method in class org.jgroups.blocks.cs.NioConnection
-
- sendLocalAddress(Address) - Method in class org.jgroups.blocks.cs.TcpConnection
-
Send the cookie first, then the our port number.
- sendLockResponse(Locking.Type, Owner, String, int) - Method in class org.jgroups.protocols.Locking
-
- sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.BPING
-
- sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.MPING
-
- sendMcastDiscoveryRequest(Message) - Method in class org.jgroups.protocols.PING
-
- sendMergeCancelledMessage(Collection<Address>, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
- sendMergeRejectedResponse(Address, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- sendMergeRejectedResponse(Address, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
- sendMergeRejectionMessage(Address) - Method in class org.jgroups.protocols.AUTH
-
- sendMergeRejectionMessage(Address) - Method in class org.jgroups.protocols.SASL
-
- sendMergeResponse(Address, View, Digest, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
Send back a response containing view and digest to sender
- sendMergeSolicitation() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
Discovers members and detects whether we have multiple coordinator.
- sendMergeView(Collection<Address>, MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
Sends the new view and digest to all subgroup coordinors in coords.
- sendMessage(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a unicast message and - depending on the options - returns a result
- sendMessage(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- sendMessageList(Address, Address, byte[], List<Message>) - Method in class org.jgroups.protocols.BaseBundler
-
- sendMessageWithFuture(Message, RequestOptions, FutureListener<T>) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a unicast message to the target defined by msg.getDest() and returns a future
- sendMessageWithFuture(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a unicast message to the target defined by msg.getDest() and returns a future
- sendMulticast(AsciiString, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
-
- sendMulticast(AsciiString, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- sendMulticast(AsciiString, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Send to all members in the group.
- sendMulticast(AsciiString, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
-
- sendMulticast(AsciiString, byte[], int, int) - Method in class org.jgroups.protocols.UDP
-
- sendNewConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- sendNewConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
-
- sendNewKeyserverAck(Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- sendNewRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- sendNewRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
-
- sendNotCoord(Address, long) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- sendOnLocalCluster(byte[], int, int) - Method in class org.jgroups.protocols.RELAY
-
- sendOwnState(Map<Point, Color>) - Method in class org.jgroups.demos.Draw
-
- sendPendingAcks() - Method in class org.jgroups.protocols.UNICAST3
-
- sendPingSignal(int) - Method in class org.jgroups.protocols.FD_SOCK
-
- sendPingTermination() - Method in class org.jgroups.protocols.FD_SOCK
-
- sendQueueSize() - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- sendQueueSize(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- sendRejectionMessage(byte, Address, String) - Method in class org.jgroups.protocols.AUTH
-
- sendRejectionMessage(byte, Address, String) - Method in class org.jgroups.protocols.SASL
-
- sendReleaseLockRequest(String, int, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendReleaseLockRequest(String, int, Owner) - Method in class org.jgroups.protocols.Locking
-
- sendReleaseLockRequest(String, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendReleaseLockRequest(String, int, Owner) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendRemoveConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- sendRemoveConsumerRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
-
- sendRemoveRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- sendRemoveRunRequest(Executing.Owner) - Method in class org.jgroups.protocols.Executing
-
- sendReply(Message, long, Object, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
-
- sendRequest(Message) - Method in class org.jgroups.blocks.GroupRequest
-
- sendRequest(Collection<Address>, Message, Request, RequestOptions) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
-
- sendRequest(Message) - Method in class org.jgroups.blocks.Request
-
- sendRequest(List<Address>, Message, Request) - Method in class org.jgroups.blocks.RequestCorrelator
-
- sendRequest(Collection<Address>, Message, Request, RequestOptions) - Method in class org.jgroups.blocks.RequestCorrelator
-
Sends a request to a group.
- sendRequest(Message) - Method in class org.jgroups.blocks.UnicastRequest
-
- sendRequest(Address, COUNTER.Request) - Method in class org.jgroups.protocols.COUNTER
-
- sendRequest(Address, Executing.Type, long, Object) - Method in class org.jgroups.protocols.Executing
-
- sendRequest(Address, Locking.Type, String, Owner, long, boolean) - Method in class org.jgroups.protocols.Locking
-
- sendRequest(Address, Locking.Type, String, int, Owner, long, boolean) - Method in class org.jgroups.protocols.Locking
-
- sendRequestForFirstSeqno(Address, long) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- sendRequestForFirstSeqno(Address, long) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- sendRequestForFirstSeqno(Address) - Method in class org.jgroups.protocols.UNICAST3
-
- sendResponse(Message, long, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
-
- sendResponse(Address, COUNTER.Response) - Method in class org.jgroups.protocols.COUNTER
-
- sendResponse(Address, short) - Method in class org.jgroups.protocols.RSVP
-
- sendResponse(DatagramSocket, SocketAddress, byte[]) - Method in class org.jgroups.stack.DiagnosticsHandler
-
- sendSecretKey(Key, PublicKey, Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- sendSeqnoRequest(int) - Method in class org.jgroups.protocols.SEQUENCER2
-
- sendSeqnoResponse(Address, long, int) - Method in class org.jgroups.protocols.SEQUENCER2
-
- sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.Locking
-
- sendSignalConditionRequest(String, boolean) - Method in class org.jgroups.protocols.PEER_LOCK
-
Deprecated.
- sendSignalResponse(Owner, String) - Method in class org.jgroups.protocols.Locking
-
- sendSingleMessage(Message) - Method in class org.jgroups.protocols.BaseBundler
-
- sendSingleMessage(Message, ByteArrayDataOutputStream) - Method in class org.jgroups.protocols.NoBundler
-
- sendSingleMessage(Message, ByteArrayDataOutputStream) - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- sendSiteUnreachableTo(Address, String) - Method in class org.jgroups.protocols.relay.RELAY2
-
Sends a SITE-UNREACHABLE message to the sender of the message.
- sendStabilityMessage(Digest, ViewId) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Schedules a stability message to be mcast after a random number of milliseconds (range 1-5 secs).
- sendStableMessage(boolean) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Broadcasts a STABLE message of the current digest to all members (or the coordinator only).
- sendStableMessage(Address, short, long, long) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- sendStableMessages() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- sendSubscribe(String) - Method in class org.jgroups.client.StompConnection
-
- sendThreadRequest(Address, long, Executing.Type, long, Object) - Method in class org.jgroups.protocols.Executing
-
- sendToAll(byte[], int, int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- sendToAll(ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
-
- sendToAllMembers(String, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
-
- sendToAllMembers(String, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
-
- sendToAllMembersInGroup(Set<Map.Entry<Address, GossipRouter.Entry>>, GossipData) - Method in class org.jgroups.stack.GossipRouter
-
- sendToAllMembersInGroup(Set<Map.Entry<Address, GossipRouter.Entry>>, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
-
- sendToBridges(Address, Message, String...) - Method in class org.jgroups.protocols.relay.RELAY2
-
Sends the message via all bridges excluding the excluded_sites bridges
- sendToCoordinator(Executing.Type, long, Address) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- sendToCoordinator(Executing.Type, long, Address) - Method in class org.jgroups.protocols.Executing
-
- sendToMember(Address, GossipData) - Method in class org.jgroups.stack.GossipRouter
-
- sendToMember(Address, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
-
- sendToMember(String, Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
-
- sendToMembers(Collection<Address>, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Fetches the physical addrs for mbrs and sends the msg to each physical address.
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
- sendToSingleMember(String, Address, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
-
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
-
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Send a unicast to 1 member.
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
-
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.UDP
-
- sendUnicastRequest(Address, Message, Request) - Method in class org.jgroups.blocks.mux.MuxRequestCorrelator
-
- sendUnicastRequest(Address, Message, Request) - Method in class org.jgroups.blocks.RequestCorrelator
-
Sends a request to a single destination
- sendUnsubscribe(String) - Method in class org.jgroups.client.StompConnection
-
- sendViewOnLocalCluster(View, View, boolean, List<Address>) - Method in class org.jgroups.protocols.RELAY
-
- sendViewOnLocalCluster(RELAY.ViewData, boolean, List<Address>) - Method in class org.jgroups.protocols.RELAY
-
- sendViewOnLocalCluster(List<Address>, byte[]) - Method in class org.jgroups.protocols.RELAY
-
- sendViewToRemote(RELAY.ViewData, boolean) - Method in class org.jgroups.protocols.RELAY
-
- sendXmitRsp(Address, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Sends a message msg to the requester.
- sent - Variable in class org.jgroups.protocols.UFC
-
Map
: keys are members, values are credits left.
- sent_bytes - Variable in class org.jgroups.JChannel
-
- sent_msgs - Variable in class org.jgroups.JChannel
-
- sent_requests - Variable in class org.jgroups.protocols.SEQUENCER2
-
- sent_responses - Variable in class org.jgroups.protocols.SEQUENCER2
-
- SEPARATOR - Static variable in class org.jgroups.blocks.ReplicatedTree
-
- seqno - Variable in class org.jgroups.protocols.DISCARD_PAYLOAD
-
- seqno - Variable in class org.jgroups.protocols.SEQUENCER
-
- seqno - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- seqno - Variable in class org.jgroups.protocols.SEQUENCER2
-
- seqno - Variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- seqno() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- Seqno - Class in org.jgroups.util
-
Keeps track of a single message to retransmit
- Seqno(long) - Constructor for class org.jgroups.util.Seqno
-
- Seqno(long, boolean) - Constructor for class org.jgroups.util.Seqno
-
Only used to compare a long against a range in a TreeSet / TreeMap.
- seqno(int) - Method in class org.jgroups.util.SeqnoList
-
- seqno_reqs - Variable in class org.jgroups.protocols.SEQUENCER2
-
- SeqnoComparator - Class in org.jgroups.util
-
- SeqnoComparator() - Constructor for class org.jgroups.util.SeqnoComparator
-
- SeqnoList - Class in org.jgroups.util
-
A bitset of missing messages with a fixed size.
- SeqnoList() - Constructor for class org.jgroups.util.SeqnoList
-
Only to be used by serialization
- SeqnoList(int, long) - Constructor for class org.jgroups.util.SeqnoList
-
Creates a SeqnoList with a capacity for size elements.
- SeqnoList(int) - Constructor for class org.jgroups.util.SeqnoList
-
- SeqnoList.SeqnoListIterator - Class in org.jgroups.util
-
- SeqnoListIterator() - Constructor for class org.jgroups.util.SeqnoList.SeqnoListIterator
-
- SeqnoRange - Class in org.jgroups.util
-
Keeps track of a range of messages to be retransmitted.
- SeqnoRange(long, long) - Constructor for class org.jgroups.util.SeqnoRange
-
- seqnos - Variable in class org.jgroups.util.Digest
-
- SeqnoTask(long, Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
-
- SequenceNumberManager - Class in org.jgroups.protocols.tom
-
Manages the messages sequence number (keeps it up-to-date)
- SequenceNumberManager() - Constructor for class org.jgroups.protocols.tom.SequenceNumberManager
-
- SEQUENCER - Class in org.jgroups.protocols
-
Implementation of total order protocol using a sequencer.
- SEQUENCER() - Constructor for class org.jgroups.protocols.SEQUENCER
-
- SEQUENCER.Flusher - Class in org.jgroups.protocols
-
- SEQUENCER.SequencerHeader - Class in org.jgroups.protocols
-
- SEQUENCER2 - Class in org.jgroups.protocols
-
Implementation of total order protocol using a sequencer_uum.
- SEQUENCER2() - Constructor for class org.jgroups.protocols.SEQUENCER2
-
- SEQUENCER2.SequencerHeader - Class in org.jgroups.protocols
-
- SequencerHeader() - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- SequencerHeader(byte) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- SequencerHeader(byte, long) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- SequencerHeader() - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- SequencerHeader(byte) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- SequencerHeader(byte, long) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- SequencerHeader(byte, long, int) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- serializableCallable(Constructor<? extends Callable>, Object...) - Static method in class org.jgroups.blocks.executor.Executions
-
This method should be used to convert a callable that would not normally
be serializable, externalizable or streamable but has serializable,
externalizable or streamable arguments to a constructor to construct it.
- serializedSize() - Method in class org.jgroups.MergeView
-
- serializedSize() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- serializedSize() - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- serializedSize() - Method in class org.jgroups.protocols.tom.MessageID
-
- serializedSize(boolean) - Method in class org.jgroups.util.Digest
-
- serializedSize() - Method in class org.jgroups.util.Range
-
- serializedSize() - Method in class org.jgroups.util.SeqnoList
-
- serializedSize() - Method in class org.jgroups.View
-
- serializedSize() - Method in class org.jgroups.ViewId
-
- serializeWithoutView(PingData) - Method in class org.jgroups.protocols.Discovery
-
Creates a byte[] representation of the PingData, but DISCARDING the view it contains.
- server - Variable in class org.jgroups.blocks.cs.NioConnection
-
- server - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- server - Variable in class org.jgroups.demos.PubServer
-
- server(boolean) - Method in class org.jgroups.protocols.PingData
-
- server - Variable in class org.jgroups.protocols.TCP_NIO2
-
- server - Variable in class org.jgroups.stack.GossipRouter
-
- server_callback_handler - Variable in class org.jgroups.protocols.SASL
-
- server_destinations - Variable in class org.jgroups.client.StompConnection
-
- server_locks - Variable in class org.jgroups.protocols.Locking
-
- server_name - Variable in class org.jgroups.protocols.SASL
-
- server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
-
- server_subject - Variable in class org.jgroups.protocols.SASL
-
- serverChallenge(GMS.GmsHeader, SaslHeader, Message) - Method in class org.jgroups.protocols.SASL
-
- ServerCondition(Locking.ServerLock) - Constructor for class org.jgroups.protocols.Locking.ServerCondition
-
- ServerGmsImpl - Class in org.jgroups.protocols.pbcast
-
Common super class for CoordGmsImpl and ParticipantGmsImpl
- ServerGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ServerGmsImpl
-
- ServerLock(String) - Constructor for class org.jgroups.protocols.Locking.ServerLock
-
- ServerLock(String, Owner) - Constructor for class org.jgroups.protocols.Locking.ServerLock
-
- serverSocket - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- ServerSocketHandler() - Constructor for class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
- SERVICE_PRINCIPAL_NAME - Static variable in class org.jgroups.auth.Krb5Token
-
- service_principal_name - Variable in class org.jgroups.auth.Krb5Token
-
- session_id - Variable in class org.jgroups.client.StompConnection
-
- session_id - Variable in class org.jgroups.protocols.STOMP.Connection
-
- session_verifier - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- session_verifier_arg - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- session_verifier_class - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- set(long) - Method in interface org.jgroups.blocks.atomic.Counter
-
Sets the counter to a new value
- set(Object) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
-
- set(V) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Sets the result of this Future to the given value unless
this future has already been set or has been cancelled.
- set(Collection<Address>) - Method in class org.jgroups.Membership
-
Clears the membership and adds all members of v This method will clear out all the old members
of this membership by invoking the Clear
method.
- set(Membership) - Method in class org.jgroups.Membership
-
Clears the membership and adds all members of a given membership parameter.
- set(int, ByteBuffer) - Method in class org.jgroups.nio.Buffers
-
- set(long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- set(long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
-
- set(long) - Method in class org.jgroups.protocols.FlowControl.Credit
-
- set(int, Message) - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
adds on fragmentation buffer to the message
- set(String, Object) - Method in class org.jgroups.stack.RouterStub
-
- set(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Sets the bit at the specified index to true
.
- set(int, int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Sets the bits from the specified from
(inclusive) to the
specified to
(inclusive) to true
.
- set(Address, long, long) - Method in class org.jgroups.util.MutableDigest
-
- set(Digest) - Method in class org.jgroups.util.MutableDigest
-
- set(long) - Method in class org.jgroups.util.Seqno
-
- set(long) - Method in class org.jgroups.util.SeqnoRange
-
- set(long...) - Method in class org.jgroups.util.SeqnoRange
-
- SET_DIGEST - Static variable in class org.jgroups.Event
-
- SET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
-
- SET_PHYSICAL_ADDRESS - Static variable in class org.jgroups.Event
-
- SET_SECRET_KEY - Static variable in class org.jgroups.Event
-
- setAccountNumber(int) - Method in class org.jgroups.demos.JmxDemo
-
- setAddress() - Method in class org.jgroups.JChannel
-
Generates new UUID and sets local address.
- setAddress(String) - Method in class org.jgroups.util.DefaultThreadFactory
-
- setAddress(String) - Method in class org.jgroups.util.LazyThreadFactory
-
- setAddress(String) - Method in interface org.jgroups.util.ThreadFactory
-
- setAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
-
- setAnycasting(boolean) - Method in class org.jgroups.blocks.RequestOptions
-
- setArgs(Object...) - Method in class org.jgroups.blocks.MethodCall
-
- setAttribute(Attribute) - Method in class org.jgroups.jmx.ResourceDMBean
-
- setAttributes(AttributeList) - Method in class org.jgroups.jmx.ResourceDMBean
-
- setAuth(AUTH) - Method in class org.jgroups.auth.AuthToken
-
- setAuthClass(String) - Method in class org.jgroups.protocols.AUTH
-
- setAuthCoord(boolean) - Method in class org.jgroups.protocols.AUTH
-
- setAuthToken(AuthToken) - Method in class org.jgroups.protocols.AUTH
-
- setAuthValue(String) - Method in class org.jgroups.auth.MD5Token
-
- setAuthValue(String) - Method in class org.jgroups.auth.SimpleToken
-
- setAutomaticPurging(boolean) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- setBindAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
-
- setBindAddress(InetAddress) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.TP
-
- setBindPort(int) - Method in class org.jgroups.protocols.BPING
-
- setBindPort(int) - Method in class org.jgroups.protocols.TP
-
- setBindToAllInterfaces(boolean) - Method in class org.jgroups.protocols.TP
-
- setBlockingUpdates(boolean) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Whether updates across the cluster should be asynchronous (default) or synchronous)
- setBuffer(byte[]) - Method in class org.jgroups.Message
-
Note that the byte[] buffer passed as argument must not be modified.
- setBuffer(byte[], int, int) - Method in class org.jgroups.Message
-
Sets the internal buffer to point to a subset of a given buffer.
Note that the byte[] buffer passed as argument must not be modified.
- setBuffer(Buffer) - Method in class org.jgroups.Message
-
Note that the byte[] buffer passed as argument must not be modified.
- setBufferSize(DatagramSocket, int, int) - Method in class org.jgroups.protocols.UDP
-
- setBundler(Bundler) - Method in class org.jgroups.protocols.TP
-
Installs a bundler.
- setBypass(boolean) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- setBypassBundling(boolean) - Method in class org.jgroups.protocols.COUNTER
-
- setBypassBundling(boolean) - Method in class org.jgroups.protocols.Executing
-
- setBypassBundling(boolean) - Method in class org.jgroups.protocols.Locking
-
- setCache(PartitionedHashMap<String, byte[]>) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setCachingTime(long) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setCachingTime(long) - Method in class org.jgroups.blocks.ReplCache
-
- setCallTimeout(long) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setCallTimeout(long) - Method in class org.jgroups.blocks.ReplCache
-
- setCertificate() - Method in class org.jgroups.auth.X509Token
-
Used during setup to get the certification from the keystore and encrypt the auth_value with
the private key
- setCertPassword(String) - Method in class org.jgroups.auth.X509Token
-
- setChannel(Channel) - Method in class org.jgroups.blocks.atomic.CounterService
-
- setChannel(JChannel) - Method in class org.jgroups.blocks.executor.ExecutionRunner
-
- setChannel(Channel) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- setChannel(Channel) - Method in class org.jgroups.blocks.locking.LockService
-
- setChannel(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
-
- setChannel(JChannel) - Method in class org.jgroups.stack.ProtocolStack
-
- setClientCallbackHandler(CallbackHandler) - Method in class org.jgroups.protocols.SASL
-
- setClientCallbackHandlerClass(String) - Method in class org.jgroups.protocols.SASL
-
- setClientSubject(Subject) - Method in class org.jgroups.protocols.SASL
-
- setClusterName(String) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setClusterName(String) - Method in class org.jgroups.blocks.ReplCache
-
- setClusterName(String) - Method in class org.jgroups.demos.Draw
-
- setClusterName(String) - Method in class org.jgroups.util.DefaultThreadFactory
-
- setClusterName(String) - Method in class org.jgroups.util.LazyThreadFactory
-
- setClusterName(String) - Method in interface org.jgroups.util.ThreadFactory
-
- setCommand(String) - Method in class org.jgroups.protocols.FD_HOST
-
- setConnExpireTime(long) - Method in class org.jgroups.protocols.BasicTCP
-
- setCopyMulticastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
-
- setCopyUnicastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
-
- setCustomLogFactory(CustomLogFactory) - Static method in class org.jgroups.logging.LogFactory
-
- setDefaultHandler(T) - Method in interface org.jgroups.blocks.mux.Muxer
-
Sets the handler for messages that have no mux header.
- setDefaultHandler(UpHandler) - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
- setDefaultReplicationCount(short) - Method in class org.jgroups.blocks.ReplCache
-
- setDefaultThreadPool(Executor) - Method in class org.jgroups.protocols.TP
-
- setDefaultThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
-
- setDefaultValues(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
- setDefaultValues(List<ProtocolConfiguration>, List<Protocol>, StackType) - Static method in class org.jgroups.stack.Configurator
-
- setDefaultValues(List<Protocol>, StackType) - Static method in class org.jgroups.stack.Configurator
-
- setDeliveryTableMaxSize(int) - Method in class org.jgroups.protocols.SEQUENCER
-
- setDeliveryTableMaxSize(int) - Method in class org.jgroups.util.ForwardQueue
-
- setDesiredAverageGossip(long) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- setDest(Address) - Method in class org.jgroups.Message
-
- setDiagnosticsHandler(DiagnosticsHandler) - Method in class org.jgroups.protocols.TP
-
- setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Send down a SET_DIGEST event
- setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Creates a retransmit buffer for each sender in the digest according to the sender's seqno.
- setDigest(Digest, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Sets or merges the digest.
- setDiscardAll(boolean) - Method in class org.jgroups.protocols.DISCARD
-
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setDiscardIncompatiblePackets(boolean) - Static method in class org.jgroups.protocols.TP
-
Deprecated.
- setDiscardOwnMessages(boolean) - Method in class org.jgroups.Channel
-
When set to true, all messages sent by a member A will be discarded by A.
- setDown(boolean) - Method in class org.jgroups.protocols.SHUFFLE
-
- setDownDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
-
- setDownProt(Protocol) - Method in class org.jgroups.util.ForwardQueue
-
- setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
-
- setDropDownMulticasts(int) - Method in class org.jgroups.protocols.DISCARD
-
- setDropDownUnicasts(int) - Method in class org.jgroups.protocols.DISCARD
-
Drop the next N unicasts down the stack
- setEnableBundling(boolean) - Method in class org.jgroups.protocols.TP
-
Deprecated.
- setEnableUnicastBundling(boolean) - Method in class org.jgroups.protocols.TP
-
Deprecated.
- setErgonomics(boolean) - Method in class org.jgroups.stack.Protocol
-
- setException(Throwable) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
-
- setException(Throwable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Causes this future to report an ExecutionException
with the given throwable as its cause, unless this Future has
already been set or has been cancelled.
- setException(Throwable) - Method in class org.jgroups.util.Rsp
-
- setExcludeItself(boolean) - Method in class org.jgroups.protocols.DISCARD
-
- setExclusionList(Address...) - Method in class org.jgroups.blocks.RequestOptions
-
- setFailReason(String) - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- setField(Field, Object, Object) - Static method in class org.jgroups.util.Util
-
- setFinalizerTask(ResponseCollectorTask.Consumer<ResponseCollectorTask<T>>) - Method in class org.jgroups.util.ResponseCollectorTask
-
- setFixedMembersSeparator(String) - Method in class org.jgroups.auth.FixedMembershipToken
-
- setFlag(Message.Flag...) - Method in class org.jgroups.Message
-
Sets a number of flags in a message
- setFlag(short) - Method in class org.jgroups.Message
-
Sets the flags from a short.
- setFlag(short) - Method in class org.jgroups.util.ExtendedUUID
-
- setFlag(byte, byte) - Static method in class org.jgroups.util.Util
-
- setFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
-
- setForceSendingDiscoveryRsps(boolean) - Method in class org.jgroups.protocols.Discovery
-
- setForkChannelId(String) - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- setForkStackId(String) - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- setFragSize(int) - Method in class org.jgroups.protocols.FRAG
-
- setFragSize(int) - Method in class org.jgroups.protocols.FRAG2
-
- setGossipRouterHosts(String) - Method in class org.jgroups.protocols.TUNNEL
-
- setHandler(AgeOutCache.Handler) - Method in class org.jgroups.util.AgeOutCache
-
- setHandler(ProcessingQueue.Handler<T>) - Method in class org.jgroups.util.ProcessingQueue
-
- setHashFunction(PartitionedHashMap.HashFunction<K>) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setHashFunction(ReplCache.HashFunction<K>) - Method in class org.jgroups.blocks.ReplCache
-
- setHashFunctionFactory(ReplCache.HashFunctionFactory<K>) - Method in class org.jgroups.blocks.ReplCache
-
- setHashType(String) - Method in class org.jgroups.auth.MD5Token
-
- setHeader(Message) - Method in class org.jgroups.fork.ForkChannel
-
- setHighestDelivered(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- setHighestDelivered(long) - Method in class org.jgroups.util.RingBufferSeqno
-
- setHighestDelivered(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- setHighestDelivered(long) - Method in class org.jgroups.util.Table
-
Only used internally by JGroups on a state transfer.
- setId(short) - Method in class org.jgroups.blocks.MethodCall
-
- setId(short) - Method in class org.jgroups.stack.Protocol
-
- setImpl(GmsImpl) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setInAllThreadFactories(String, Address, String) - Method in class org.jgroups.protocols.TP
-
- setIncludeClusterName(boolean) - Method in class org.jgroups.util.DefaultThreadFactory
-
- setIncludeClusterName(boolean) - Method in interface org.jgroups.util.ThreadFactory
-
- setIncomingCopies(int) - Method in class org.jgroups.protocols.DUPL
-
- setInDelay(int) - Method in class org.jgroups.protocols.DELAY
-
- setInDelayNanos(int) - Method in class org.jgroups.protocols.DELAY
-
- setInitialHosts(List<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPGOSSIP
-
- setInitialHosts(List<PhysicalAddress>) - Method in class org.jgroups.protocols.TCPPING
-
- setInterface(InetAddress, MulticastSocket) - Method in class org.jgroups.protocols.UDP
-
- setInternalThreadPool(Executor) - Method in class org.jgroups.protocols.TP
-
- setInternalThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
-
- setInterval(long) - Method in class org.jgroups.protocols.FD_ALL
-
- setInterval(long) - Method in class org.jgroups.protocols.FD_ALL2
-
- setJoinTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setKeepAliveTime(long) - Method in class org.jgroups.util.DefaultTimeScheduler
-
- setKeepAliveTime(long) - Method in class org.jgroups.util.HashedTimingWheel
-
- setKeepAliveTime(long) - Method in class org.jgroups.util.MockTimeScheduler
-
- setKeepAliveTime(long) - Method in interface org.jgroups.util.TimeScheduler
-
Sets the keep alive time (in ms) of the thread pool.
- setKeepAliveTime(long) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- setKeepAliveTime(long) - Method in class org.jgroups.util.TimeScheduler3
-
- setKeys(SecretKey, byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- setKeyServerAddr(Address) - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- setKeyStorePassword(String) - Method in class org.jgroups.auth.X509Token
-
- setL1Cache(Cache<K, V>) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setL1Cache(Cache<K, V>) - Method in class org.jgroups.blocks.ReplCache
-
- setL2Cache(Cache<K, V>) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setL2Cache(Cache<K, ReplCache.Value<V>>) - Method in class org.jgroups.blocks.ReplCache
-
- setLength(int) - Method in class org.jgroups.blocks.GridFile.Metadata
-
- setLevel(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- setLevel(String) - Method in interface org.jgroups.logging.Log
-
Sets the level of a logger.
- setLevel(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- setLevel(String) - Method in class org.jgroups.stack.Protocol
-
Sets the level of a logger.
- setLinger(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setListener(FutureListener<V>) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- setListener(FutureListener) - Method in class org.jgroups.blocks.Request
-
- setListener(NakReceiverWindow.Listener) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- setListener(FutureListener<T>) - Method in interface org.jgroups.util.NotifyingFuture
-
Attaches a listener and returns the same future instance, to allow for 'building' futures.
- setListener(FutureListener<T>) - Method in class org.jgroups.util.NullFuture
-
- setLocalAddr(Address) - Method in class org.jgroups.util.ForwardQueue
-
- setLocalAddress(Address) - Method in class org.jgroups.blocks.RequestCorrelator
-
- setLocalAddress(Address) - Method in class org.jgroups.fork.ForkChannel
-
- setLocalAddress(Address) - Method in class org.jgroups.fork.ForkProtocolStack
-
- setLocalAddress(Address) - Method in class org.jgroups.protocols.DISCARD
-
- setLocalAddress(Address) - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- setLocalAddress(String) - Method in class org.jgroups.protocols.tom.DeliveryThread
-
- setLocation(String) - Method in class org.jgroups.protocols.FILE_PING
-
- setLogCollectMessages(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.TP
-
- setLogDiscardMessagesVersion(boolean) - Method in class org.jgroups.protocols.TP
-
- setLogDiscardMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- setLoginModuleName(String) - Method in class org.jgroups.protocols.SASL
-
- setLogNotFoundMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setLogSuspectedMessages(boolean) - Method in class org.jgroups.protocols.FD_SOCK
-
- setLoopback(boolean) - Method in class org.jgroups.protocols.TP
-
Deprecated.
- setMachineId(String) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RequestCorrelator
-
- setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
-
- setMaxAge(int) - Method in class org.jgroups.demos.JmxDemo
-
- setMaxBlockTime(long) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- setMaxBlockTime(long) - Method in class org.jgroups.protocols.FlowControl
-
- setMaxBlockTimes(String) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- setMaxBlockTimes(String) - Method in class org.jgroups.protocols.FlowControl
-
- setMaxBundleSize(int) - Method in class org.jgroups.protocols.TP
-
- setMaxBundleSize(int) - Method in class org.jgroups.protocols.UDP
-
- setMaxBundleTimeout(long) - Method in class org.jgroups.protocols.TP
-
- setMaxBundlingTime(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setMaxBytes(long) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- setMaxBytes(long) - Method in class org.jgroups.protocols.RATE_LIMITER
-
- setMaxCompactionTime(long) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- setMaxCompactionTime(long) - Method in class org.jgroups.util.Table
-
- setMaxCredits(long) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- setMaxCredits(long) - Method in class org.jgroups.protocols.FlowControl
-
- setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE3
-
- setMaxJoinAttempts(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setMaxMessageBatchSize(int) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- setMaxMessageBatchSize(int) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- setMaxMessageBatchSize(int) - Method in class org.jgroups.protocols.UNICAST3
-
- setMaxNumberOfEntries(int) - Method in class org.jgroups.blocks.Cache
-
- setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST3
-
- setMaxSize(int) - Method in class org.jgroups.protocols.SHUFFLE
-
- setMaxThreads(int) - Method in class org.jgroups.util.DefaultTimeScheduler
-
- setMaxThreads(int) - Method in class org.jgroups.util.HashedTimingWheel
-
- setMaxThreads(int) - Method in class org.jgroups.util.MockTimeScheduler
-
- setMaxThreads(int) - Method in interface org.jgroups.util.TimeScheduler
-
Sets the max pool size.
- setMaxThreads(int) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- setMaxThreads(int) - Method in class org.jgroups.util.TimeScheduler3
-
- setMaxTime(long) - Method in class org.jgroups.protocols.SHUFFLE
-
- setMaxTries(int) - Method in class org.jgroups.protocols.FD
-
- setMcastAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
-
- setMcastPort(int) - Method in class org.jgroups.protocols.MPING
-
- setMcastPort(int) - Method in class org.jgroups.protocols.UDP
-
- setMech(String) - Method in class org.jgroups.protocols.SASL
-
- setMemberList(String) - Method in class org.jgroups.auth.FixedMembershipToken
-
- setMembers(List<Address>) - Method in class org.jgroups.blocks.MessageDispatcher
-
If this dispatcher is using a user-provided PullPushAdapter, then need to set the members from the adapter
initially since viewChange has most likely already been called in PullPushAdapter.
- setMembershipChangePolicy(MembershipChangePolicy) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setMembershipChangePolicy(String) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MessageDispatcher
-
- setMergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- setMergeId(MergeId, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
- setMergeRejected(boolean) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- setMergeTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageDispatcher
-
- setMethod(Method) - Method in class org.jgroups.blocks.MethodCall
-
- setMethodLookup(MethodLookup) - Method in class org.jgroups.blocks.RpcDispatcher
-
- setMigrateData(boolean) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setMigrateData(boolean) - Method in class org.jgroups.blocks.ReplCache
-
- setMinCredits(long) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- setMinCredits(long) - Method in class org.jgroups.protocols.FlowControl
-
- setMinInterval(long) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- setMinInterval(long) - Method in class org.jgroups.protocols.MERGE3
-
- setMinThreads(int) - Method in class org.jgroups.util.DefaultTimeScheduler
-
- setMinThreads(int) - Method in class org.jgroups.util.HashedTimingWheel
-
- setMinThreads(int) - Method in class org.jgroups.util.MockTimeScheduler
-
- setMinThreads(int) - Method in interface org.jgroups.util.TimeScheduler
-
Sets the core pool size.
- setMinThreads(int) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- setMinThreads(int) - Method in class org.jgroups.util.TimeScheduler3
-
- setMinThreshold(double) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- setMinThreshold(double) - Method in class org.jgroups.protocols.FlowControl
-
- setMode(ResponseMode) - Method in class org.jgroups.blocks.RequestOptions
-
- setModificationTime(long) - Method in class org.jgroups.blocks.GridFile.Metadata
-
- setMulticastAddress(String) - Method in class org.jgroups.protocols.MPING
-
- setMulticastAddress(InetAddress) - Method in class org.jgroups.protocols.UDP
-
- setMulticastPort(int) - Method in class org.jgroups.protocols.UDP
-
- setMulticastTTL(int) - Method in class org.jgroups.protocols.UDP
-
Set the ttl for multicast socket
- setMyNumber(long) - Method in class org.jgroups.demos.JmxDemo
-
- setName(String) - Method in class org.jgroups.blocks.MethodCall
-
sets the name for this MethodCall and allowing you to reuse the same object for
a different method invokation of a different method
- setName(String) - Method in class org.jgroups.Channel
-
Sets the logical name for the channel.
- setName(String) - Method in class org.jgroups.demos.JmxDemo.MyNotification
-
- setName(String) - Method in class org.jgroups.fork.ForkChannel
-
- setName(String) - Method in class org.jgroups.JChannel
-
- setNamedAttribute(Attribute) - Method in class org.jgroups.jmx.ResourceDMBean
-
- setNumber(int) - Method in class org.jgroups.demos.JmxDemo
-
- setNumberOfBackups(int) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- setNumberOfBackups(int) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- setNumInitialMembers(int) - Method in class org.jgroups.protocols.Discovery
-
Deprecated.
- setObject(Object) - Method in class org.jgroups.Message
-
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the
message.
- setOOBRejectionPolicy(String) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPool(Executor) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPoolQueueEnabled(boolean) - Method in class org.jgroups.protocols.TP
-
- setOOBThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
-
- setOption(SocketOption<T>, T) - Method in class org.jgroups.nio.MockSocketChannel
-
- setOtherNumber(int) - Method in class org.jgroups.demos.JmxDemo
-
- setOutDelay(int) - Method in class org.jgroups.protocols.DELAY
-
- setOutDelayNanos(int) - Method in class org.jgroups.protocols.DELAY
-
- setOutgoingCopies(int) - Method in class org.jgroups.protocols.DUPL
-
- setOwner(Owner) - Method in class org.jgroups.protocols.Locking.ServerLock
-
- setPattern(String) - Method in class org.jgroups.util.DefaultThreadFactory
-
- setPattern(String) - Method in interface org.jgroups.util.ThreadFactory
-
- setPayload(byte[]) - Method in class org.jgroups.protocols.SaslHeader
-
- setPayload(String) - Method in class org.jgroups.util.PayloadUUID
-
Deprecated.
- setPeerAddressReadTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setPeriodicTask(ResponseCollectorTask.Consumer<ResponseCollectorTask<T>>) - Method in class org.jgroups.util.ResponseCollectorTask
-
- setPingData(PingData) - Method in class org.jgroups.protocols.TP
-
- setPingData(List<PingData>) - Method in class org.jgroups.stack.GossipData
-
- setPort(int) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setPortRange(int) - Method in class org.jgroups.protocols.TCPPING
-
- setPortRange(int) - Method in class org.jgroups.protocols.TP
-
- setPrintLocalAddr(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setPrintLocalAddress(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setPriority(byte) - Method in class org.jgroups.protocols.PrioHeader
-
- setProcessorKeepAliveTime(long) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setProcessorMaxThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setProcessorMinThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setProcessorQueueSize(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setProcessorThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setProps(String) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- setProps(String) - Method in class org.jgroups.blocks.ReplCache
-
- setProtId(short) - Method in class org.jgroups.Header
-
- setProtocolStack(ProtocolStack) - Method in class org.jgroups.JChannel
-
- setProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Protocol
-
- setQuote(String, Float) - Method in class org.jgroups.demos.QuoteClient
-
- setQuote(String, Float) - Method in class org.jgroups.demos.QuoteServer
-
- setRackId(String) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- setReaderThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setReaperInterval(long) - Method in class org.jgroups.protocols.BasicTCP
-
- setReceiveBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setReceived() - Method in class org.jgroups.util.Rsp
-
- setReceiver(BasicConnectionTable.Receiver) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setReceiver(Receiver) - Method in class org.jgroups.Channel
-
Sets the receiver for this channel.
- setReconnectInterval(long) - Method in class org.jgroups.protocols.TUNNEL
-
- setRegularRejectionPolicy(String) - Method in class org.jgroups.protocols.TP
-
- setRelay(boolean) - Method in class org.jgroups.protocols.RELAY
-
- setRemoteCalls(boolean) - Method in class org.jgroups.blocks.ReplicatedTree
-
- setRemovable(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- setRemoveAllDataOnViewChange(boolean) - Method in class org.jgroups.protocols.FILE_PING
-
- SetRequest() - Constructor for class org.jgroups.protocols.COUNTER.SetRequest
-
- SetRequest(Owner, String, long) - Constructor for class org.jgroups.protocols.COUNTER.SetRequest
-
- setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.MessageDispatcher
-
- setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.RequestCorrelator
-
- setRequestMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
-
- setResendLastSeqno(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setResponse(long) - Method in class org.jgroups.auth.DemoToken.Entry
-
- setResponseFilter(RspFilter) - Method in class org.jgroups.blocks.Request
-
- setResponseMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
-
- setResult(T) - Method in class org.jgroups.util.Promise
-
Sets the result and notifies any threads waiting for it
- setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
- setRetryTimeout(long) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- setRootNode(ReplicatedTree.Node) - Method in class org.jgroups.blocks.ReplicatedTree
-
- setRound(int) - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- setRouteStatusListener(RouteStatusListener) - Method in class org.jgroups.protocols.relay.RELAY2
-
- setRspFilter(RspFilter) - Method in class org.jgroups.blocks.RequestOptions
-
- setSaslProps(Map<String, String>) - Method in class org.jgroups.protocols.SASL
-
- setScope(short) - Method in class org.jgroups.blocks.RequestOptions
-
- setScope(short) - Method in class org.jgroups.Message
-
- setScope(Message, short) - Static method in class org.jgroups.util.Util
-
- setSecretKeyAbove(Tuple<SecretKey, byte[]>) - Method in class org.jgroups.protocols.KeyExchange
-
Sets the secret key in a protocol above us
- setSendBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setSendQueueSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setSequencerNumber(long) - Method in class org.jgroups.protocols.tom.ToaHeader
-
- setServerCallbackHandler(CallbackHandler) - Method in class org.jgroups.protocols.SASL
-
- setServerCallbackHandlerClass(String) - Method in class org.jgroups.protocols.SASL
-
- setServerName(String) - Method in class org.jgroups.protocols.SASL
-
- setServerObject(Object) - Method in class org.jgroups.blocks.RpcDispatcher
-
- setServerSubject(Subject) - Method in class org.jgroups.protocols.SASL
-
- setSiteId(String) - Method in class org.jgroups.util.TopologyUUID
-
Deprecated.
- setSiteUnreachable(String) - Method in class org.jgroups.blocks.RequestCorrelator
-
An entire site is down; mark all requests that point to that site as unreachable (used by RELAY2)
- setSocketConnectionTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.Channel
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TCP
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TP
-
- setSocketFactory(SocketFactory) - Method in class org.jgroups.stack.Protocol
-
Sets a SocketFactory.
- setSocketParameters(Socket) - Method in class org.jgroups.blocks.cs.NioConnection
-
- setSocketParameters(Socket) - Method in class org.jgroups.blocks.cs.TcpConnection
-
- setSourceAddress(Message) - Method in class org.jgroups.protocols.TP
-
If the sender is null, set our own address.
- setSrc(Address) - Method in class org.jgroups.Message
-
- setStartFlushTimeout(long) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- setState(InputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- setState(InputStream) - Method in class org.jgroups.blocks.ReplicatedTree
-
- setState(InputStream) - Method in class org.jgroups.demos.Draw
-
- setState(InputStream) - Method in class org.jgroups.demos.QuoteServer
-
- setState(InputStream) - Method in class org.jgroups.demos.wb.GraphPanel
-
- setState(InputStream) - Method in class org.jgroups.demos.wb.Whiteboard
-
- setState(InputStream) - Method in interface org.jgroups.MessageListener
-
Allows an application to read a state through a provided InputStream.
- setState(InputStream) - Method in class org.jgroups.ReceiverAdapter
-
Allows an application to read a state through a provided InputStream.
- setStateInApplication(InputStream, Object, Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- setStateInMainAndForkChannels(InputStream) - Method in class org.jgroups.protocols.FORK
-
- setStatsEnabled(boolean) - Method in class org.jgroups.protocols.tom.StatsCollector
-
- setSuspected() - Method in class org.jgroups.util.Rsp
-
- setTcpNodelay(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setter - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- setter() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- setter(ResourceDMBean.Accessor) - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.DefaultTimeScheduler
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.HashedTimingWheel
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.MockTimeScheduler
-
- setThreadFactory(ThreadFactory) - Method in interface org.jgroups.util.TimeScheduler
-
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.TimeScheduler3
-
- setThreadNames() - Method in class org.jgroups.protocols.TP
-
- setThreadPool(Executor) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setThreadPoolCoreThreads(int) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setThreadPoolIdleTime(long) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- setThreadPoolKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
-
- setThreadPoolMaxThreads(int) - Method in class org.jgroups.blocks.MemcachedConnector
-
- setThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- setThreadPoolMaxThreads(int) - Method in class org.jgroups.protocols.TP
-
- setThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- setThreadPoolMinThreads(int) - Method in class org.jgroups.protocols.TP
-
- setThreadPoolQueueEnabled(boolean) - Method in class org.jgroups.protocols.TP
-
- setThreshold(int) - Method in class org.jgroups.protocols.SEQUENCER
-
- setTimeout(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Sets the cluster call timeout (until all acks have been received)
- setTimeout(long) - Method in class org.jgroups.blocks.RequestOptions
-
- setTimeout(long) - Method in class org.jgroups.protocols.Discovery
-
- setTimeout(long) - Method in class org.jgroups.protocols.FD
-
- setTimeout(long) - Method in class org.jgroups.protocols.FD_ALL
-
- setTimeout(long) - Method in class org.jgroups.protocols.FD_ALL2
-
- setTimeout(long) - Method in class org.jgroups.protocols.SASL
-
- setTimeout(int[]) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- setTimeout(int[]) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- setTimeout(long) - Method in class org.jgroups.util.AgeOutCache
-
- setTimeout(long) - Method in class org.jgroups.util.ExpiryCache
-
- setTimeoutCheckInterval(long) - Method in class org.jgroups.protocols.FD_ALL
-
- setTimeoutCheckInterval(long) - Method in class org.jgroups.protocols.FD_ALL2
-
- setTimePeriod(long) - Method in class org.jgroups.protocols.RATE_LIMITER
-
- setTimer(TimeScheduler) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Only used for unit tests, don't use !
- setTimer(TimeScheduler) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Only used for unit tests, don't use !
- setTimer(TimeScheduler) - Method in class org.jgroups.protocols.TP
-
Sets a new timer.
- setTimer(TimeScheduler) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Only used for unit tests, don't use !
- setTimerKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
-
- setTimerMaxThreads(int) - Method in class org.jgroups.protocols.TP
-
- setTimerMinThreads(int) - Method in class org.jgroups.protocols.TP
-
- setTimerThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
-
- setTimeService(TimeService) - Method in class org.jgroups.protocols.TP
-
- setTimeToLive(int, MulticastSocket) - Method in class org.jgroups.protocols.UDP
-
- setToken(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
-
- setTransientFlag(Message.TransientFlag...) - Method in class org.jgroups.Message
-
- setTransientFlag(short) - Method in class org.jgroups.Message
-
- setTransientFlagIfAbsent(Message.TransientFlag) - Method in class org.jgroups.Message
-
Atomically checks if a given flag is set and - if not - sets it.
- setTransientFlags(Message.TransientFlag...) - Method in class org.jgroups.blocks.RequestOptions
-
- setTTL(short) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- setTTL(int) - Method in class org.jgroups.protocols.MPING
-
- setTUNNELPolicy(TUNNEL.TUNNELPolicy) - Method in class org.jgroups.protocols.TUNNEL
-
- setType(SaslHeader.Type) - Method in class org.jgroups.protocols.SaslHeader
-
- setUnknownForkHandler(UnknownForkHandler) - Method in class org.jgroups.protocols.FORK
-
- setUnreachable() - Method in class org.jgroups.util.Rsp
-
- setUp(boolean) - Method in class org.jgroups.protocols.SHUFFLE
-
- setup(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.ProtocolStack
-
- setup(ProtocolStack) - Method in class org.jgroups.stack.ProtocolStack
-
- setUpDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
-
- setUpHandler(UpHandler) - Method in class org.jgroups.Channel
-
Sets this channel event handler to be a recipient off all events .
- setupPingSocket(IpAddress) - Method in class org.jgroups.protocols.FD_SOCK
-
Creates a socket to dest
, and assigns it to ping_sock.
- setUpProt(Protocol) - Method in class org.jgroups.util.ForwardQueue
-
- setUpProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
-
- setupProtocolStack(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.Configurator
-
- setupProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Configurator
-
- setupProtocolStack(List<ProtocolConfiguration>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
The configuration string has a number of entries, separated by a ':' (colon).
- setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setUseMcastXmitReq(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setUseSendQueues(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
-
- setVal1(V1) - Method in class org.jgroups.util.Triple
-
- setVal1(V1) - Method in class org.jgroups.util.Tuple
-
- setVal2(V2) - Method in class org.jgroups.util.Triple
-
- setVal2(V2) - Method in class org.jgroups.util.Tuple
-
- setVal3(V3) - Method in class org.jgroups.util.Triple
-
- setValue(Properties) - Method in class org.jgroups.auth.Krb5Token
-
- setValue(String, Object) - Method in class org.jgroups.stack.Protocol
-
- setValue(T) - Method in class org.jgroups.util.Rsp
-
- setValues(Map<String, Object>) - Method in class org.jgroups.stack.Protocol
-
- setViewAckCollectionTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setViewBundling(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
-
- setWriterThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- setXmitStaggerTimeout(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- setXmitStaggerTimeout(long) - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
- sha(String) - Static method in class org.jgroups.util.Util
-
Converts a java.lang.String in to a SHA hashed String
- SHARED_LOOPBACK - Class in org.jgroups.protocols
-
Loopback transport shared by all channels within the same VM.
- SHARED_LOOPBACK() - Constructor for class org.jgroups.protocols.SHARED_LOOPBACK
-
- SHARED_LOOPBACK_PING - Class in org.jgroups.protocols
-
- SHARED_LOOPBACK_PING() - Constructor for class org.jgroups.protocols.SHARED_LOOPBACK_PING
-
- SHORT_SIZE - Static variable in class org.jgroups.Global
-
- shortName(String) - Static method in class org.jgroups.util.Util
-
- shortName(InetAddress) - Static method in class org.jgroups.util.Util
-
- shouldDropUpMessage(Message, Address) - Method in class org.jgroups.protocols.DISCARD
-
Checks if a message should be passed up, or not
- showLastBlockingTimes() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- showStatus(String) - Method in class org.jgroups.demos.StompChat
-
- SHUFFLE - Class in org.jgroups.protocols
-
Reorders messages by buffering them and shuffling the result after TIMEOUT ms.
- SHUFFLE() - Constructor for class org.jgroups.protocols.SHUFFLE
-
- shutdown() - Method in class org.jgroups.blocks.executor.ExecutionService
-
- shutdown(Channel) - Static method in class org.jgroups.util.Util
-
Drops messages to/from other members and then closes the channel.
- shutdownInput() - Method in class org.jgroups.nio.MockSocketChannel
-
- shutdownNow() - Method in class org.jgroups.blocks.executor.ExecutionService
-
- shutdownOutput() - Method in class org.jgroups.nio.MockSocketChannel
-
- ShutdownRejectedExecutionHandler - Class in org.jgroups.util
-
ShutdownRejectedExecutionHandler is a decorator RejectedExecutionHandler used
in all JGroups ThreadPoolExecutor(s).
- ShutdownRejectedExecutionHandler(RejectedExecutionHandler) - Constructor for class org.jgroups.util.ShutdownRejectedExecutionHandler
-
- shutdownThreadPool(Executor) - Static method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- shutdownThreadPool(Executor) - Static method in class org.jgroups.protocols.TP
-
- shuttin_down - Variable in class org.jgroups.protocols.FD_SOCK
-
- sign_msgs - Variable in class org.jgroups.protocols.EncryptBase
-
- signal() - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- signal(boolean) - Method in class org.jgroups.protocols.Locking.ServerCondition
-
- signal(boolean) - Method in class org.jgroups.util.CondVar
-
Wakes up one (signal_all=false) or all (signal_all=true) blocked threads.
- signalAll() - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- signaled - Variable in class org.jgroups.protocols.Locking.ClientCondition
-
- signaled() - Method in class org.jgroups.protocols.Locking.ClientCondition
-
- signalToString(int) - Static method in class org.jgroups.protocols.FD_SOCK
-
- signature - Variable in class org.jgroups.protocols.EncryptHeader
-
- signature() - Method in class org.jgroups.protocols.EncryptHeader
-
- signature(byte[]) - Method in class org.jgroups.protocols.EncryptHeader
-
- signMessages() - Method in class org.jgroups.protocols.EncryptBase
-
- signMessages(boolean) - Method in class org.jgroups.protocols.EncryptBase
-
- SimpleAuthorizingCallbackHandler - Class in org.jgroups.auth.sasl
-
SimpleAuthorizingCallbackHandler.
- SimpleAuthorizingCallbackHandler() - Constructor for class org.jgroups.auth.sasl.SimpleAuthorizingCallbackHandler
-
- SimpleAuthorizingCallbackHandler(Properties) - Constructor for class org.jgroups.auth.sasl.SimpleAuthorizingCallbackHandler
-
- SimpleAuthorizingCallbackHandler.PropertiesReloadFileObserver - Class in org.jgroups.auth.sasl
-
- SimpleRequest() - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
-
- SimpleRequest(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
-
- SimpleResponse() - Constructor for class org.jgroups.protocols.COUNTER.SimpleResponse
-
- SimpleResponse(Owner, long) - Constructor for class org.jgroups.protocols.COUNTER.SimpleResponse
-
- SimpleToken - Class in org.jgroups.auth
-
This is an example of using a preshared token for authentication purposes.
- SimpleToken() - Constructor for class org.jgroups.auth.SimpleToken
-
- SimpleToken(String) - Constructor for class org.jgroups.auth.SimpleToken
-
- SimplifiedTransferQueueBundler - Class in org.jgroups.protocols
-
This bundler uses the same logic as
TransferQueueBundler
but does not allocate
memory except for the buffer itself and does not use complex data structures.
- SimplifiedTransferQueueBundler() - Constructor for class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- SimplifiedTransferQueueBundler(int) - Constructor for class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- SINGLE_DESTINATION_MESSAGE - Static variable in class org.jgroups.protocols.tom.ToaHeader
-
- SingleMessageHandler(Message) - Constructor for class org.jgroups.protocols.TP.SingleMessageHandler
-
- SingleMessageHandlerWithClusterName(Message, AsciiString) - Constructor for class org.jgroups.protocols.TP.SingleMessageHandlerWithClusterName
-
- SINGLETON_NAME - Static variable in class org.jgroups.Global
-
- singleton_name - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- singleton_transports - Static variable in class org.jgroups.stack.ProtocolStack
-
Holds the shared transports, keyed by 'TP.singleton_name'.
- SingletonAddress - Class in org.jgroups.util
-
Address with a cluster name.
- SingletonAddress(byte[], Address) - Constructor for class org.jgroups.util.SingletonAddress
-
- SingletonAddress() - Constructor for class org.jgroups.util.SingletonAddress
-
- SITE - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
-
- site - Variable in class org.jgroups.protocols.relay.RELAY2
-
- site(String) - Method in class org.jgroups.protocols.relay.RELAY2
-
- site() - Method in class org.jgroups.protocols.relay.RELAY2
-
- site - Variable in class org.jgroups.protocols.RELAY
-
- site_config - Variable in class org.jgroups.protocols.relay.RELAY2
-
- SITE_ID - Static variable in class org.jgroups.protocols.RELAY
-
- SITE_ID - Static variable in class org.jgroups.util.TopologyUUID
-
Deprecated.
- SITE_MASTER - Static variable in interface org.jgroups.Address
-
- site_master - Variable in class org.jgroups.protocols.relay.Route
-
SiteUUID: address of the site master
- site_master - Static variable in class org.jgroups.util.ExtendedUUID
-
- site_master_picker - Variable in class org.jgroups.protocols.relay.RELAY2
-
- site_master_picker_impl - Variable in class org.jgroups.protocols.relay.RELAY2
-
- site_masters - Variable in class org.jgroups.protocols.relay.RELAY2
-
- SITE_NAME - Static variable in class org.jgroups.protocols.relay.SiteUUID
-
- SITE_UNREACHABLE - Static variable in class org.jgroups.Event
-
- SITE_UNREACHABLE - Static variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- SITE_UUID - Static variable in interface org.jgroups.Address
-
- SiteAddress - Interface in org.jgroups.protocols.relay
-
Address with a site suffix
- SiteConfig(String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- siteMaster() - Method in class org.jgroups.protocols.relay.Route
-
- SiteMaster - Class in org.jgroups.protocols.relay
-
Special address with the UUID part being 0: identifies the current (relay) coordinator of a given site.
- SiteMaster() - Constructor for class org.jgroups.protocols.relay.SiteMaster
-
- SiteMaster(String) - Constructor for class org.jgroups.protocols.relay.SiteMaster
-
- SiteMaster(byte[]) - Constructor for class org.jgroups.protocols.relay.SiteMaster
-
- siteMasterPicker(SiteMasterPicker) - Method in class org.jgroups.protocols.relay.RELAY2
-
- SiteMasterPicker - Interface in org.jgroups.protocols.relay
-
Allows an implementation to pick a
SiteMaster
from a list of site master (if multiple site masters are
enabled).
- siteNames() - Method in class org.jgroups.protocols.relay.RELAY2
-
- SITES - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
-
- sites - Variable in class org.jgroups.protocols.relay.RELAY2
-
A map containing site names (e.g.
- sitesDown(String...) - Method in interface org.jgroups.protocols.relay.RouteStatusListener
-
The sites went down
- sitesUp(String...) - Method in interface org.jgroups.protocols.relay.RouteStatusListener
-
The sites just came up
- siteUnreachable(String) - Method in class org.jgroups.blocks.GroupRequest
-
- siteUnreachable(String) - Method in class org.jgroups.blocks.Request
-
- siteUnreachable(String) - Method in class org.jgroups.blocks.UnicastRequest
-
- SiteUUID - Class in org.jgroups.protocols.relay
-
Implementation of SiteAddress
- SiteUUID() - Constructor for class org.jgroups.protocols.relay.SiteUUID
-
- SiteUUID(long, long, String, String) - Constructor for class org.jgroups.protocols.relay.SiteUUID
-
- SiteUUID(long, long, byte[], byte[]) - Constructor for class org.jgroups.protocols.relay.SiteUUID
-
- SiteUUID(UUID, String, String) - Constructor for class org.jgroups.protocols.relay.SiteUUID
-
- size() - Method in interface org.jgroups.Address
-
Returns serialized size of this address
- size() - Method in class org.jgroups.AnycastAddress
-
- size() - Method in class org.jgroups.auth.AuthToken
-
The size of the marshalled AuthToken
- size() - Method in class org.jgroups.auth.DemoToken.DemoHeader
-
- size() - Method in class org.jgroups.auth.DemoToken
-
- size() - Method in class org.jgroups.auth.FixedMembershipToken
-
- size() - Method in class org.jgroups.auth.Krb5Token
-
- size() - Method in class org.jgroups.auth.MD5Token
-
- size() - Method in class org.jgroups.auth.RegexMembership
-
- size() - Method in class org.jgroups.auth.SimpleToken
-
- size() - Method in class org.jgroups.auth.X509Token
-
- size() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- size() - Method in class org.jgroups.blocks.mux.MuxHeader
-
- size() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- size() - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- size() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
- size - Variable in class org.jgroups.demos.ExecutionServiceDemo
-
- size() - Method in class org.jgroups.Header
-
To be implemented by subclasses.
- size() - Method in class org.jgroups.Membership
-
Returns the number of addresses in this membership
- size() - Method in class org.jgroups.Message
-
Returns the exact size of the marshalled message.
- size() - Method in class org.jgroups.nio.Buffers
-
Returns the number of elements that have not yet been read or written
- size() - Method in class org.jgroups.protocols.ABP.ABPHeader
-
- size() - Method in class org.jgroups.protocols.AuthHeader
-
- size() - Method in class org.jgroups.protocols.BaseBundler
-
- size() - Method in interface org.jgroups.protocols.Bundler
-
The number of unsent messages in the bundler
- size() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
-
- size() - Method in class org.jgroups.protocols.COUNTER.CounterHeader
-
- size() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- size() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- size() - Method in class org.jgroups.protocols.EncryptHeader
-
- size() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
-
- size() - Method in class org.jgroups.protocols.Executing.ExecutorHeader
-
- size() - Method in class org.jgroups.protocols.FcHeader
-
- size() - Method in class org.jgroups.protocols.FD.FdHeader
-
- size() - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
-
- size() - Method in class org.jgroups.protocols.FD_ALL2.HeartbeatHeader
-
- size() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- size() - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- size() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- size() - Method in class org.jgroups.protocols.FragHeader
-
- size() - Method in class org.jgroups.protocols.Locking.LockingHeader
-
- size() - Method in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- size() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- size() - Method in class org.jgroups.protocols.NoBundler
-
- size() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- size() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- size() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- size() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- size() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- size() - Method in class org.jgroups.protocols.PERF.PerfHeader
-
- size() - Method in class org.jgroups.protocols.PingData
-
- size() - Method in class org.jgroups.protocols.PingHeader
-
- size() - Method in class org.jgroups.protocols.PrioHeader
-
- size() - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- size() - Method in class org.jgroups.protocols.RELAY.RelayHeader
-
- size() - Method in class org.jgroups.protocols.RingBufferBundler
-
- size - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- size() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- size() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- size() - Method in class org.jgroups.protocols.RSVP.Entry
-
- size() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
-
- size() - Method in class org.jgroups.protocols.SaslHeader
-
- size() - Method in class org.jgroups.protocols.SCOPE.MessageQueue
-
Deprecated.
- size() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- size() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- size() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- size() - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
-
- SIZE - Class in org.jgroups.protocols
-
Protocol which prints out the real size of a message.
- SIZE() - Constructor for class org.jgroups.protocols.SIZE
-
- size() - Method in class org.jgroups.protocols.STOMP.StompHeader
-
- size() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- size() - Method in class org.jgroups.protocols.TpHeader
-
- size() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- size() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- size() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- size() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- size() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
-
- size() - Method in class org.jgroups.stack.DefaultRetransmitter
-
- size() - Method in class org.jgroups.stack.GossipData
-
- size() - Method in class org.jgroups.stack.IpAddress
-
- size() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- size() - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
- size() - Method in class org.jgroups.stack.Retransmitter
-
Deprecated.
- size() - Method in class org.jgroups.util.AckCollector
-
- size() - Method in class org.jgroups.util.AgeOutCache
-
- size(int) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded int
- size(long) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded long.
- size(long, long) - Static method in class org.jgroups.util.Bits
-
- size(float) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded float
- size(double) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded double
- size(String) - Static method in class org.jgroups.util.Bits
-
- size(AsciiString) - Static method in class org.jgroups.util.Bits
-
Measures the number of bytes required to encode an AsciiSring.
- size() - Method in class org.jgroups.util.BlockingInputStream
-
- size() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- size() - Method in class org.jgroups.util.DefaultTimeScheduler
-
Answers the number of tasks currently in the queue.
- size() - Method in class org.jgroups.util.ExpiryCache
-
- size() - Method in class org.jgroups.util.ExtendedUUID
-
The number of bytes required to serialize this instance
- size - Variable in class org.jgroups.util.FixedSizeBitSet
-
- size() - Method in class org.jgroups.util.FixedSizeBitSet
-
- size() - Method in class org.jgroups.util.ForwardQueue
-
- size() - Method in class org.jgroups.util.HashedTimingWheel
-
Returns the number of tasks currently in the timer
- size(Header[]) - Static method in class org.jgroups.util.Headers
-
- size(Header[], short...) - Static method in class org.jgroups.util.Headers
-
- size() - Method in class org.jgroups.util.LazyThreadFactory
-
- size() - Method in class org.jgroups.util.MergeId
-
- size() - Method in class org.jgroups.util.MessageBatch
-
Returns the number of non-null messages
- size() - Method in class org.jgroups.util.MockTimeScheduler
-
- size() - Method in class org.jgroups.util.MyReceiver
-
- size() - Method in class org.jgroups.util.ProcessingQueue
-
- size() - Method in class org.jgroups.util.Queue
-
returns the number of objects that are currently in the queue
- size() - Method in class org.jgroups.util.RequestTable
-
Returns the number of non-null elements in range [low ..
- size() - Method in class org.jgroups.util.ResponseCollector
-
- size() - Method in class org.jgroups.util.Responses
-
- size - Variable in class org.jgroups.util.RetransmitTable
-
Deprecated.
- size() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Returns the numbers of messages in the table
- size() - Method in class org.jgroups.util.RingBuffer
-
- size() - Method in class org.jgroups.util.RingBufferSeqno
-
- size() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- size() - Method in class org.jgroups.util.RspList
-
- size() - Method in class org.jgroups.util.Seqno
-
- size() - Method in class org.jgroups.util.SeqnoList
-
- size() - Method in class org.jgroups.util.SeqnoRange
-
- size() - Method in class org.jgroups.util.SingletonAddress
-
- size() - Method in interface org.jgroups.util.SizeStreamable
-
Returns the size (in bytes) of the marshalled object
- size() - Method in class org.jgroups.util.SuppressCache
-
Returns the total count of all values
- size - Variable in class org.jgroups.util.Table
-
- size() - Method in class org.jgroups.util.Table
-
Returns the numbers of elements in the table
- size() - Method in interface org.jgroups.util.TimeScheduler
-
Returns the number of tasks currently in the queue.
- size() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
Returns the number of tasks currently in the timer
- size() - Method in class org.jgroups.util.TimeScheduler3
-
- size(Address) - Static method in class org.jgroups.util.Util
-
- size(View) - Static method in class org.jgroups.util.Util
-
- size(ViewId) - Static method in class org.jgroups.util.Util
-
- size(String) - Static method in class org.jgroups.util.Util
-
- size(byte[]) - Static method in class org.jgroups.util.Util
-
- size(Collection<? extends Address>) - Static method in class org.jgroups.util.Util
-
Returns the marshalled size of a Collection of Addresses.
- size(Address[]) - Static method in class org.jgroups.util.Util
-
- SIZE - Static variable in class org.jgroups.util.UUID
-
- size() - Method in class org.jgroups.util.UUID
-
- size() - Method in class org.jgroups.View
-
Returns the number of members in this view
- sizeOf(AuthToken) - Static method in class org.jgroups.protocols.AuthHeader
-
- sizeOfAllMessages(Table<Message>, boolean) - Static method in class org.jgroups.protocols.pbcast.NAKACK2
-
- sizeOfAllMessages(boolean) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Returns the number of bytes taken up by all of the messages in the RetransmitTable
- sizeOfAllMessages(boolean) - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
Computes the size of all messages currently in the table.
- sizeofHashMap() - Method in class org.jgroups.util.ExtendedUUID
-
- SizeStreamable - Interface in org.jgroups.util
-
Interface implementing Streamable and returning the size of the marshalled object.
- sizeUTF(String) - Static method in class org.jgroups.util.Bits
-
Measures the number of bytes required to encode a string, taking multibyte characters into account.
- skip(long) - Method in class org.jgroups.blocks.GridInputStream
-
- skip(Message) - Static method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Checks if a message needs to be encrypted/decrypted.
- skip(long) - Method in class org.jgroups.util.BlockingInputStream
-
- skip(long) - Method in class org.jgroups.util.InputStreamAdapter
-
- skip_bucket_existence_check - Variable in class org.jgroups.protocols.S3_PING
-
- skip_next_resend - Variable in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
-
- skipBytes(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- skipBytes(int) - Method in class org.jgroups.util.ByteBufferInputStream
-
- skipNext() - Method in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
-
- sleep(long) - Static method in class org.jgroups.util.Util
-
Sleep for timeout msecs.
- sleep(long, int) - Static method in class org.jgroups.util.Util
-
- sleep_interval - Variable in class org.jgroups.protocols.FILE_PING.InfoWriter
-
- sleep_interval - Variable in class org.jgroups.protocols.JDBC_PING.InfoWriter
-
- sleep_time - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- SLEEP_TIME - Static variable in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- sleepRandom(long, long) - Static method in class org.jgroups.util.Util
-
Sleeps between floor and ceiling milliseconds, chosen randomly
- sleepTime(long) - Method in class org.jgroups.protocols.MAKE_BATCH
-
- sock - Variable in class org.jgroups.blocks.cs.TcpConnection
-
- sock - Variable in class org.jgroups.client.StompConnection
-
- sock - Variable in class org.jgroups.protocols.BPING
-
- sock - Variable in class org.jgroups.protocols.STOMP.Connection
-
- sock - Variable in class org.jgroups.protocols.TUNNEL
-
- sock - Variable in class org.jgroups.protocols.UDP
-
Socket used for
sending unicast and multicast packets and
receiving unicast packets
The address of this socket will be our local address (local_addr)
- sock_addr - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- sock_conn_timeout - Variable in class org.jgroups.blocks.cs.BaseServer
-
- sock_conn_timeout - Variable in class org.jgroups.protocols.BasicTCP
-
- sock_conn_timeout - Variable in class org.jgroups.protocols.FD_SOCK
-
- sock_conn_timeout - Variable in class org.jgroups.stack.RouterStub
-
- sock_creation_lock - Variable in class org.jgroups.blocks.cs.BaseServer
-
- sock_read_timeout - Variable in class org.jgroups.stack.GossipRouter
-
- socket() - Method in class org.jgroups.nio.MockSocketChannel
-
- socket_factory - Variable in class org.jgroups.blocks.BasicConnectionTable
-
- socket_factory - Variable in class org.jgroups.blocks.cs.TcpBaseServer
-
- socket_factory - Variable in class org.jgroups.Channel
-
- socket_factory - Variable in class org.jgroups.client.StompConnection
-
- socket_factory - Variable in class org.jgroups.protocols.TP.ProtocolAdapter
-
- socket_factory - Variable in class org.jgroups.protocols.TP
-
- socket_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- socket_timeout - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- socketConnectionTimeout() - Method in class org.jgroups.blocks.cs.BaseServer
-
- socketConnectionTimeout(int) - Method in class org.jgroups.blocks.cs.BaseServer
-
- socketConnectionTimeout() - Method in class org.jgroups.stack.RouterStub
-
- socketConnectionTimeout(int) - Method in class org.jgroups.stack.RouterStub
-
- socketFactory() - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- socketFactory(SocketFactory) - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- SocketFactory - Interface in org.jgroups.util
-
Factory to create various types of sockets.
- socketReadTimeout() - Method in class org.jgroups.stack.GossipRouter
-
- socketReadTimeout(long) - Method in class org.jgroups.stack.GossipRouter
-
- sort() - Method in class org.jgroups.Membership
-
- SortingByteCallable() - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
-
- SortingByteCallable(byte[], int, int) - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingByteCallable
-
- SortingTwoByteCallable() - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
-
- SortingTwoByteCallable(ExecutionServiceDemo.ByteBufferStreamable, ExecutionServiceDemo.ByteBufferStreamable) - Constructor for class org.jgroups.demos.ExecutionServiceDemo.SortingTwoByteCallable
-
- spaceAvailable(int) - Method in class org.jgroups.nio.Buffers
-
- spaceUsed() - Method in class org.jgroups.util.RingBufferSeqno
-
- spaceUsed() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- spawner - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
-
Runnable that listens for state requests and spawns threads to serve those requests if socket transport is used
- SPIN - Static variable in class org.jgroups.protocols.RingBufferBundler
-
- SPIN_PARK - Static variable in class org.jgroups.protocols.RingBufferBundler
-
- SPIN_YIELD - Static variable in class org.jgroups.protocols.RingBufferBundler
-
- src() - Method in class org.jgroups.Message
-
- src(Address) - Method in class org.jgroups.Message
-
- src_addr - Variable in class org.jgroups.Message
-
- srv_sock - Variable in class org.jgroups.blocks.cs.TcpServer
-
- srv_sock - Variable in class org.jgroups.protocols.FD_SOCK
-
- srv_sock - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- srv_sock - Variable in class org.jgroups.protocols.STOMP
-
- srv_sock_addr - Variable in class org.jgroups.protocols.FD_SOCK
-
- srv_sock_handler - Variable in class org.jgroups.protocols.FD_SOCK
-
- srv_sock_handler - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- srv_sock_sent - Variable in class org.jgroups.protocols.FD_SOCK
-
- SSL_KEY_EXCHANGE - Class in org.jgroups.protocols
-
Key exchange based on SSL sockets.
- SSL_KEY_EXCHANGE() - Constructor for class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- SSL_KEY_EXCHANGE.SessionVerifier - Interface in org.jgroups.protocols
-
- SSL_KEY_EXCHANGE.Type - Enum in org.jgroups.protocols
-
- STABILITY - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- stability_delay - Variable in class org.jgroups.protocols.pbcast.STABLE
-
delay before we send STABILITY msg (give others a change to send first).
- stability_digest - Variable in class org.jgroups.protocols.pbcast.STABLE.StabilitySendTask
-
- stability_lock - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Keeps the last 10 stability messages
- stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Keeps the last N stability messages
- stability_task_future - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- StabilitySendTask(Digest, ViewId) - Constructor for class org.jgroups.protocols.pbcast.STABLE.StabilitySendTask
-
- STABLE - Static variable in class org.jgroups.Event
-
- stable(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Garbage collect messages that have been seen by all members.
- STABLE - Class in org.jgroups.protocols.pbcast
-
Computes the broadcast messages that are stable; i.e., have been delivered by all members.
- STABLE() - Constructor for class org.jgroups.protocols.pbcast.STABLE
-
- stable(Address, short, long, long) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
Purge all messages in window for local_addr, which are <= low.
- STABLE - Static variable in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- stable(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
Delete all messages <= seqno (they are stable, that is, have been delivered by all members).
- stable(long) - Method in class org.jgroups.util.RingBufferSeqno
-
Nulls elements between low and seqno and forwards low
- stable(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Nulls elements between low and seqno and forwards low
- STABLE.ResumeTask - Class in org.jgroups.protocols.pbcast
-
- STABLE.StabilitySendTask - Class in org.jgroups.protocols.pbcast
-
Multicasts a STABILITY message
- STABLE.StableHeader - Class in org.jgroups.protocols.pbcast
-
- STABLE.StableTask - Class in org.jgroups.protocols.pbcast
-
Mcast periodic STABLE message.
- STABLE_GOSSIP - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- stable_interval - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stable_task_future - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- stable_task_future - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stable_task_lock - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- StableHeader() - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- StableHeader(byte, ViewId) - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- StableTask() - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableTask
-
- stack - Variable in class org.jgroups.stack.Protocol
-
- STACK_DEPENDENT - Static variable in class org.jgroups.Global
-
- STACK_INDEPENDENT - Static variable in class org.jgroups.Global
-
- StackType - Enum in org.jgroups.util
-
- stagger_timeout - Variable in class org.jgroups.protocols.Discovery
-
- staggerTimeout() - Method in class org.jgroups.protocols.Discovery
-
- staggerTimeout(long) - Method in class org.jgroups.protocols.Discovery
-
- start() - Method in class org.jgroups.auth.AuthToken
-
- start() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- start() - Method in class org.jgroups.blocks.Cache
-
- start() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
- start() - Method in class org.jgroups.blocks.cs.BaseServer.Reaper
-
- start() - Method in class org.jgroups.blocks.cs.BaseServer
-
Starts accepting connections.
- start() - Method in class org.jgroups.blocks.cs.Connection
-
- start() - Method in class org.jgroups.blocks.cs.NioClient
-
- start() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- start() - Method in class org.jgroups.blocks.cs.NioConnection
-
- start() - Method in class org.jgroups.blocks.cs.NioServer
-
- start() - Method in class org.jgroups.blocks.cs.TcpClient
-
- start() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- start() - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- start() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- start() - Method in class org.jgroups.blocks.cs.TcpServer
-
- start() - Method in class org.jgroups.blocks.MemcachedConnector
-
- start() - Method in class org.jgroups.blocks.MessageDispatcher
-
- start() - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- start() - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- start() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- start() - Method in class org.jgroups.blocks.ReplCache
-
- start(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Fetches the state
- start() - Method in class org.jgroups.blocks.ReplicatedTree
-
- start() - Method in class org.jgroups.blocks.RequestCorrelator
-
- start() - Method in class org.jgroups.demos.applets.DrawApplet
-
- start(JChannel) - Method in class org.jgroups.demos.Chat
-
Method called from other app, injecting channel
- start(JChannel) - Method in class org.jgroups.demos.CounterServiceDemo
-
- start() - Method in class org.jgroups.demos.ExecutionServiceDemo
-
- start() - Method in class org.jgroups.demos.LockServiceDemo
-
- start(JChannel) - Method in class org.jgroups.demos.LockServiceDemo
-
- start(InetAddress, int, boolean) - Method in class org.jgroups.demos.PubClient
-
- start(InetAddress, int, boolean) - Method in class org.jgroups.demos.PubServer
-
- start() - Method in class org.jgroups.demos.QuoteClient
-
- start() - Method in class org.jgroups.demos.QuoteServer
-
- start(String, String) - Method in class org.jgroups.demos.RelayDemoRpc
-
- start(JChannel) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- start() - Method in class org.jgroups.demos.StompChat
-
- start() - Method in class org.jgroups.demos.Topology
-
- start(String) - Method in class org.jgroups.demos.ViewDemo
-
- start(String) - Method in class org.jgroups.demos.wb.GraphPanel
-
- start() - Method in class org.jgroups.protocols.AUTH
-
- start() - Method in class org.jgroups.protocols.BaseBundler
-
- start() - Method in class org.jgroups.protocols.BPING
-
- start() - Method in interface org.jgroups.protocols.Bundler
-
- start() - Method in class org.jgroups.protocols.DAISYCHAIN
-
- start() - Method in class org.jgroups.protocols.DISCARD
-
- start() - Method in class org.jgroups.protocols.Discovery
-
- start() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- start() - Method in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
- start() - Method in class org.jgroups.protocols.FD_SOCK
-
- start() - Method in class org.jgroups.protocols.FlowControl
-
- start() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- start() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- start() - Method in class org.jgroups.protocols.MPING
-
- start() - Method in class org.jgroups.protocols.NoBundler
-
- start() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- start() - Method in class org.jgroups.protocols.pbcast.GMS
-
- start() - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- start(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- start() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- start() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- start() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- start - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- start() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- start() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- start() - Method in class org.jgroups.protocols.PRIO
-
- start() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- start() - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
- start(List<RelayConfig.BridgeConfig>, String, String) - Method in class org.jgroups.protocols.relay.Relayer
-
Creates all bridges from site_config and connects them (joining the bridge clusters)
- start() - Method in class org.jgroups.protocols.RingBufferBundler
-
- start() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- start() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- start() - Method in class org.jgroups.protocols.RSVP
-
- start() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- start() - Method in class org.jgroups.protocols.SEQUENCER
-
- start() - Method in class org.jgroups.protocols.SEQUENCER2
-
- start() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- start() - Method in class org.jgroups.protocols.STOMP
-
- start() - Method in class org.jgroups.protocols.TCP
-
- start() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- start() - Method in class org.jgroups.protocols.TCP_NIO2
-
- start() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- start(DeliveryManager) - Method in class org.jgroups.protocols.tom.DeliveryThread
-
- start() - Method in class org.jgroups.protocols.tom.DeliveryThread
-
- start() - Method in class org.jgroups.protocols.tom.TOA
-
- start() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- 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.TransferQueueBundler
-
- start() - Method in class org.jgroups.protocols.UDP.PacketReceiver
-
- 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.UNICAST
-
Deprecated.
- start() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- start() - Method in class org.jgroups.protocols.UNICAST3
-
- start() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- start() - Method in class org.jgroups.stack.GossipRouter
-
Lifecycle operation.
- start() - Method in class org.jgroups.stack.Protocol
-
- start() - Method in class org.jgroups.util.ForwardQueue
-
- start(TimeScheduler, long, long) - Method in class org.jgroups.util.ResponseCollectorTask
-
- start() - Method in class org.jgroups.util.Runner
-
- start() - Method in class org.jgroups.util.TimeScheduler3
-
- start() - Method in class org.jgroups.util.TimeService
-
- START_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- start_port - Variable in class org.jgroups.protocols.FD_SOCK
-
- start_time - Variable in class org.jgroups.blocks.Request
-
- start_time - Variable in class org.jgroups.protocols.PERF.PerfHeader
-
- startBatcher() - Method in class org.jgroups.protocols.MAKE_BATCH
-
- startBroadcastTask(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
-
Starts a new task, or - if already running - adds the argument to the running task.
- startCacheDissemination(List<Address>, List<Address>, List<Address>) - Method in class org.jgroups.protocols.Discovery
-
- startConnectionReaper() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- startConnectionReaper() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- startDiagnostics() - Method in class org.jgroups.protocols.TP
-
- started - Variable in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- started - Variable in class org.jgroups.blocks.RequestCorrelator
-
- startExpiryTask() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- startFailureDetection() - Method in class org.jgroups.protocols.FD
-
- startFailureDetection() - Method in class org.jgroups.protocols.FD_ALL
-
- startFailureDetection() - Method in class org.jgroups.protocols.FD_ALL2
-
- startFlush(List<Address>, boolean) - Method in class org.jgroups.Channel
-
Performs the flush of the cluster but only for the specified flush participants.
- startFlush(boolean) - Method in class org.jgroups.Channel
-
Performs the flush of the cluster, ie.
- startFlush(List<Address>, boolean) - Method in class org.jgroups.fork.ForkChannel
-
- startFlush(boolean) - Method in class org.jgroups.fork.ForkChannel
-
- startFlush(boolean) - Method in class org.jgroups.JChannel
-
- startFlush(List<Address>, boolean) - Method in class org.jgroups.JChannel
-
- startFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- startFlush(Channel, List<Address>, int, long, long) - Static method in class org.jgroups.util.Util
-
Performs the flush of the given channel for the specified flush participants and the given
number of attempts along with random sleep time after each such attempt.
- startFlush(Channel, List<Address>) - Static method in class org.jgroups.util.Util
-
Performs the flush of the given channel and the specified flush participants
- startFlush(Channel, int, long, long) - Static method in class org.jgroups.util.Util
-
Performs the flush of the given channel within the specfied number of attempts along with random
sleep time after each such attempt.
- startFlush(Channel) - Static method in class org.jgroups.util.Util
-
Performs the flush of the given channel
- startFlusher(Address) - Method in class org.jgroups.protocols.SEQUENCER
-
- startFlusher(Address) - Method in class org.jgroups.util.ForwardQueue
-
- startGui() - Method in class org.jgroups.protocols.DISCARD
-
- startHeartbeatSender() - Method in class org.jgroups.protocols.FD_ALL
-
- startHeartbeatSender() - Method in class org.jgroups.protocols.FD_ALL2
-
- startInfoSender() - Method in class org.jgroups.protocols.MERGE3
-
- startInfoWriter() - Method in class org.jgroups.protocols.FILE_PING
-
- startInfoWriter() - Method in class org.jgroups.protocols.JDBC_PING
-
- startMergeKiller() - Method in class org.jgroups.protocols.pbcast.Merger
-
- startMergeTask() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- startMonitor() - Method in class org.jgroups.protocols.FD
-
Requires lock to held by caller
- startNodeCrashMonitor() - Method in class org.jgroups.protocols.FD_SOCK
-
- startPingerTask() - Method in class org.jgroups.protocols.FD_HOST
-
- startPingerThread() - Method in class org.jgroups.protocols.FD_SOCK
-
Does *not* need to be synchronized on pinger_mutex because the caller (down()) already has the mutex acquired
- startQueueing() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- startReconciliationTask() - Method in class org.jgroups.protocols.COUNTER
-
- startReconnectingClient() - Method in class org.jgroups.client.StompConnection
-
- startReconnector() - Method in class org.jgroups.stack.RouterStubManager
-
- startRelayer(Relayer, String) - Method in class org.jgroups.protocols.relay.RELAY2
-
- startRemoteViewFetcher() - Method in class org.jgroups.protocols.RELAY
-
- startResendTask() - Method in class org.jgroups.protocols.RSVP
-
- startResumeTask(long) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- startRetransmitTask() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST3
-
- startRunner() - Method in class org.jgroups.client.StompConnection
-
- startRunner() - Method in class org.jgroups.util.HashedTimingWheel
-
- startRunner() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- startRunner() - Method in class org.jgroups.util.TimeScheduler3
-
- startServerSocket() - Method in class org.jgroups.protocols.FD_SOCK
-
- startStabilityTask(Digest, ViewId, long) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- startStableTask() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- startStableTask() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- startStack(String, Address) - Method in class org.jgroups.fork.ForkProtocolStack
-
- startStack(String) - Method in class org.jgroups.JChannel
-
- startStack(String, Address) - Method in class org.jgroups.stack.ProtocolStack
-
Start all layers.
- startTask() - Method in class org.jgroups.protocols.ABP.Entry
-
- startTask() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- startTask() - Method in class org.jgroups.protocols.SHUFFLE
-
- startTask() - Method in class org.jgroups.util.TimeService
-
- startTimeoutChecker() - Method in class org.jgroups.protocols.FD_ALL
-
- startTimeoutChecker() - Method in class org.jgroups.protocols.FD_ALL2
-
- startTimer() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- startViewConsistencyChecker() - Method in class org.jgroups.protocols.MERGE3
-
- state - Variable in class org.jgroups.blocks.cs.NioConnection.Reader
-
- state(NioConnection.State) - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- state - Variable in class org.jgroups.Channel
-
The current state of the channel
- state - Variable in class org.jgroups.demos.Draw.DrawPanel
-
- STATE - Class in org.jgroups.protocols.pbcast
-
STATE streams the state (written to an OutputStream) to the state requester in chunks (defined by
chunk_size).
- STATE() - Constructor for class org.jgroups.protocols.pbcast.STATE
-
- state - Variable in class org.jgroups.protocols.UNICAST3.Entry
-
- state - Variable in class org.jgroups.stack.StateTransferInfo
-
- STATE.StateOutputStream - Class in org.jgroups.protocols.pbcast
-
- STATE_EOF - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- STATE_EX - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_EX - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- STATE_PART - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- state_promise - Variable in class org.jgroups.JChannel
-
- state_provider - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- state_requesters - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
List of members requesting state
- state_requesters - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
List of members requesting state.
- STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- STATE_SOCK - Class in org.jgroups.protocols.pbcast
-
STATE_SOCK
has the state provider create a server socket to which the state
requester connects and from which the latter reads the state.
- STATE_SOCK() - Constructor for class org.jgroups.protocols.pbcast.STATE_SOCK
-
- STATE_SOCK.StateProviderAcceptor - Class in org.jgroups.protocols.pbcast
-
- STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
-
STATE_TRANSFER protocol based on byte array transfer.
- 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_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_supported - Variable in class org.jgroups.JChannel
-
True if a state transfer protocol is available, false otherwise (set by CONFIG event from STATE_TRANSFER protocol)
- StateGetter(Address, OutputStream) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
-
- StateHeader() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- StateHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- StateHeader(byte, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- StateHeader() - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- StateHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- StateHeader(byte, Digest) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- StateHeader(byte, IpAddress, Digest) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- StateOutputStream(Address) - Constructor for class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- StateProviderAcceptor(ExecutorService, ServerSocket) - Constructor for class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- stateRequester - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
-
- StateTransferException - Exception in org.jgroups
-
StateTransferException
is thrown to indicate a failure of a 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, long, byte[]) - Constructor for class org.jgroups.stack.StateTransferInfo
-
- StateTransferResult - Class in org.jgroups.util
-
Encapsulates the result of a state transfer.
- StateTransferResult() - Constructor for class org.jgroups.util.StateTransferResult
-
- StateTransferResult(byte[]) - Constructor for class org.jgroups.util.StateTransferResult
-
- StateTransferResult(Throwable) - Constructor for class org.jgroups.util.StateTransferResult
-
- StaticInterval - Class in org.jgroups.stack
-
Manages retransmission timeouts.
- StaticInterval(int...) - Constructor for class org.jgroups.stack.StaticInterval
-
- stats - Variable in class org.jgroups.JChannel
-
Collect statistics
- stats - Variable in class org.jgroups.protocols.relay.Relayer
-
- stats - Variable in class org.jgroups.protocols.relay.Route
-
- stats() - Method in class org.jgroups.protocols.relay.Route
-
- stats(boolean) - Method in class org.jgroups.protocols.relay.Route
-
- 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
-
- stats - Variable in class org.jgroups.util.RpcStats
-
- StatsCollector - Class in org.jgroups.protocols.tom
-
This collects the stats and some profiling information
- StatsCollector() - Constructor for class org.jgroups.protocols.tom.StatsCollector
-
- statsEnabled() - Method in class org.jgroups.JChannel
-
- statsEnabled() - Method in class org.jgroups.stack.Protocol
-
- status() - Method in class org.jgroups.blocks.cs.Connection
-
- status() - Method in class org.jgroups.blocks.cs.NioConnection
-
- status() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- STOMP - Class in org.jgroups.protocols
-
Protocol which provides STOMP (http://stomp.codehaus.org/) support.
- STOMP() - Constructor for class org.jgroups.protocols.STOMP
-
- STOMP.ClientVerb - Enum in org.jgroups.protocols
-
- STOMP.Connection - Class in org.jgroups.protocols
-
Class which handles a connection to a client
- STOMP.Frame - Class in org.jgroups.protocols
-
- STOMP.ServerVerb - Enum in org.jgroups.protocols
-
- STOMP.StompHeader - Class in org.jgroups.protocols
-
- STOMP.StompHeader.Type - Enum in org.jgroups.protocols
-
- STOMP_BIND_ADDR - Static variable in class org.jgroups.Global
-
- stomp_client - Variable in class org.jgroups.demos.StompChat
-
- stomp_client - Variable in class org.jgroups.demos.StompDraw
-
- STOMP_ENDPOINT_ADDR - Static variable in class org.jgroups.Global
-
- StompChat - Class in org.jgroups.demos
-
Chat client using STOMP to talk to other clients
- StompChat(String, int, String) - Constructor for class org.jgroups.demos.StompChat
-
- StompConnection - Class in org.jgroups.client
-
STOMP client to access the STOMP [1] protocol.
- StompConnection(String) - Constructor for class org.jgroups.client.StompConnection
-
- StompConnection(String, boolean, boolean) - Constructor for class org.jgroups.client.StompConnection
-
- StompConnection(String, boolean, SSLContext) - Constructor for class org.jgroups.client.StompConnection
-
- StompConnection(String, String, String, boolean, boolean) - Constructor for class org.jgroups.client.StompConnection
-
- StompConnection(String, String, String, boolean, SSLContext) - Constructor for class org.jgroups.client.StompConnection
-
- StompConnection.ConnectionCallback - Interface in org.jgroups.client
-
- StompConnection.Listener - Interface in org.jgroups.client
-
- StompDraw - Class in org.jgroups.demos
-
Simple STOMP demo client.
- StompDraw(String, String) - Constructor for class org.jgroups.demos.StompDraw
-
- StompHeader() - Constructor for class org.jgroups.protocols.STOMP.StompHeader
-
- stop() - Method in class org.jgroups.auth.AuthToken
-
- stop() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- stop() - Method in class org.jgroups.blocks.Cache
-
- 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.cs.BaseServer.Reaper
-
- stop() - Method in class org.jgroups.blocks.cs.BaseServer
-
Stops listening for connections and handling traffic.
- stop() - Method in class org.jgroups.blocks.cs.NioClient
-
- stop() - Method in class org.jgroups.blocks.cs.NioConnection.Reader
-
- stop() - Method in class org.jgroups.blocks.cs.NioServer
-
- stop() - Method in class org.jgroups.blocks.cs.TcpClient
-
- stop() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
-
- stop() - Method in class org.jgroups.blocks.cs.TcpConnection.Sender
-
- stop() - Method in class org.jgroups.blocks.cs.TcpServer
-
- stop() - Method in class org.jgroups.blocks.MemcachedConnector
-
- stop() - Method in class org.jgroups.blocks.MessageDispatcher
-
- stop() - Method in class org.jgroups.blocks.mux.MuxMessageDispatcher
-
- stop() - Method in class org.jgroups.blocks.mux.MuxRpcDispatcher
-
- stop() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- stop() - Method in class org.jgroups.blocks.ReplCache
-
- 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() - Method in class org.jgroups.demos.Draw
-
- stop() - Method in class org.jgroups.demos.StompDraw
-
- stop() - Method in class org.jgroups.demos.wb.GraphPanel
-
- stop() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- stop() - Method in class org.jgroups.protocols.AUTH
-
- stop() - Method in class org.jgroups.protocols.BARRIER
-
- stop() - Method in class org.jgroups.protocols.BaseBundler
-
- stop() - Method in class org.jgroups.protocols.BPING
-
- stop() - Method in interface org.jgroups.protocols.Bundler
-
- stop() - Method in class org.jgroups.protocols.DAISYCHAIN
-
- stop() - Method in class org.jgroups.protocols.DISCARD
-
- stop() - Method in class org.jgroups.protocols.Discovery
-
- stop() - Method in class org.jgroups.protocols.FC
-
Deprecated.
- 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_ALL2
-
- stop() - Method in class org.jgroups.protocols.FD_HOST
-
- stop(boolean) - Method in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
-
- stop() - Method in class org.jgroups.protocols.FD_SOCK
-
- stop() - Method in class org.jgroups.protocols.FlowControl
-
- stop() - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- stop() - Method in class org.jgroups.protocols.JDBC_PING
-
- stop() - Method in class org.jgroups.protocols.MERGE2.FindSubgroupsTask
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.MERGE3
-
- stop() - Method in class org.jgroups.protocols.MFC
-
- stop() - Method in class org.jgroups.protocols.MPING
-
- stop() - Method in class org.jgroups.protocols.NoBundler
-
- 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.Merger.MergeTask
-
- stop() - Method in class org.jgroups.protocols.pbcast.Merger
-
- stop() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- stop() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- stop() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
-
- stop() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
-
- stop - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- stop() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- stop() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- stop() - Method in class org.jgroups.protocols.PRIO
-
- stop() - Method in class org.jgroups.protocols.RATE_LIMITER
-
- stop() - Method in class org.jgroups.protocols.relay.RELAY2
-
- stop() - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
- stop() - Method in class org.jgroups.protocols.relay.Relayer
-
Disconnects and destroys all bridges
- stop() - Method in class org.jgroups.protocols.RELAY
-
- stop() - Method in class org.jgroups.protocols.RingBufferBundler
-
- stop() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- stop() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- stop() - Method in class org.jgroups.protocols.RSVP
-
- stop() - Method in class org.jgroups.protocols.SASL
-
- stop() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.SEQUENCER
-
- stop() - Method in class org.jgroups.protocols.SEQUENCER2
-
- stop() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- stop() - Method in class org.jgroups.protocols.SHUFFLE
-
- stop() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- stop() - Method in class org.jgroups.protocols.STOMP.Connection
-
- stop() - Method in class org.jgroups.protocols.STOMP
-
- stop() - Method in class org.jgroups.protocols.TCP
-
- stop() - Method in class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.TCP_NIO2
-
- stop() - Method in class org.jgroups.protocols.TCPGOSSIP
-
- stop() - Method in class org.jgroups.protocols.tom.TOA
-
- stop() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- stop() - Method in class org.jgroups.protocols.TP
-
- stop() - Method in class org.jgroups.protocols.TransferQueueBundler
-
- stop() - Method in class org.jgroups.protocols.UDP.PacketReceiver
-
- stop() - Method in class org.jgroups.protocols.UDP
-
- stop() - Method in class org.jgroups.protocols.UFC
-
- stop() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stop() - Method in class org.jgroups.protocols.UNICAST3
-
- stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- stop() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- stop() - Method in class org.jgroups.stack.GossipRouter
-
Always called before destroy().
- stop() - Method in class org.jgroups.stack.Protocol
-
- stop() - Method in class org.jgroups.util.DefaultTimeScheduler
-
Stop the scheduler if it's running.
- stop() - Method in class org.jgroups.util.ForwardQueue
-
- stop() - Method in class org.jgroups.util.HashedTimingWheel
-
Stops the timer, cancelling all tasks
- stop() - Method in class org.jgroups.util.MockTimeScheduler
-
- stop() - Method in class org.jgroups.util.ResponseCollectorTask
-
- stop() - Method in class org.jgroups.util.Runner
-
- stop() - Method in interface org.jgroups.util.TimeScheduler
-
Stops the scheduler if running, cancelling all pending tasks
- stop() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
Stops the timer, cancelling all tasks
- stop() - Method in class org.jgroups.util.TimeScheduler3
-
Stops the timer, cancelling all tasks
- stop() - Method in class org.jgroups.util.TimeService
-
- STOP_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- stop_function - Variable in class org.jgroups.protocols.RingBufferBundler
-
- stop_function - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- stop_function - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- stop_function - Variable in class org.jgroups.util.Runner
-
- stopBatcher() - Method in class org.jgroups.protocols.MAKE_BATCH
-
- stopBroadcastTask() - Method in class org.jgroups.protocols.FD.Broadcaster
-
- stopConnectionReaper() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- stopConnectionReaper() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stopDiagnostics() - Method in class org.jgroups.protocols.TP
-
- stopExpiryTask() - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- stopFailureDetection() - Method in class org.jgroups.protocols.FD
-
- stopFailureDetection() - Method in class org.jgroups.protocols.FD_ALL
-
- stopFailureDetection() - Method in class org.jgroups.protocols.FD_ALL2
-
- stopFlush() - Method in class org.jgroups.Channel
-
Stops the current flush of the cluster.
- stopFlush(List<Address>) - Method in class org.jgroups.Channel
-
Stops the current flush of the cluster for the specified flush participants.
- stopFlush() - Method in class org.jgroups.fork.ForkChannel
-
- stopFlush(List<Address>) - Method in class org.jgroups.fork.ForkChannel
-
- stopFlush() - Method in class org.jgroups.JChannel
-
- stopFlush(List<Address>) - Method in class org.jgroups.JChannel
-
- stopFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- stopFlusher() - Method in class org.jgroups.protocols.SEQUENCER
-
- stopFlusher() - Method in class org.jgroups.util.ForwardQueue
-
- stopGui() - Method in class org.jgroups.protocols.DISCARD
-
- stopHeartbeatSender() - Method in class org.jgroups.protocols.FD_ALL
-
- stopHeartbeatSender() - Method in class org.jgroups.protocols.FD_ALL2
-
- stopInfoSender() - Method in class org.jgroups.protocols.MERGE3
-
- stopInfoWriter() - Method in class org.jgroups.protocols.FILE_PING
-
- stopInfoWriter() - Method in class org.jgroups.protocols.JDBC_PING
-
- stopKeyserver() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- stopMergeKiller() - Method in class org.jgroups.protocols.pbcast.Merger
-
- stopMergeTask() - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- stopMonitor() - Method in class org.jgroups.protocols.FD
-
Requires lock to be held by caller
- stopped - Variable in class org.jgroups.stack.ProtocolStack
-
- stopPingerTask() - Method in class org.jgroups.protocols.FD_HOST
-
- stopPingerThread() - Method in class org.jgroups.protocols.FD_SOCK
-
- stopQueueing() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- stopReconciliationTask() - Method in class org.jgroups.protocols.COUNTER
-
- stopReconnector() - Method in class org.jgroups.stack.RouterStubManager
-
- stopRemoteViewFetcher() - Method in class org.jgroups.protocols.RELAY
-
- stopResendTask() - Method in class org.jgroups.protocols.RSVP
-
- stopResumeTask() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- stopRetransmitTask() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST3
-
- stopRunner() - Method in class org.jgroups.util.HashedTimingWheel
-
- stopRunner() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- stopRunner() - Method in class org.jgroups.util.TimeScheduler3
-
- stopServerSocket(boolean) - Method in class org.jgroups.protocols.FD_SOCK
-
- stopStabilityTask() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- stopStableTask() - Method in class org.jgroups.protocols.pbcast.STABLE
-
- stopStableTask() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- stopStack(String) - Method in class org.jgroups.fork.ForkProtocolStack
-
- 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
- stopTask() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- stopTask() - Method in class org.jgroups.protocols.SHUFFLE
-
- stopTask() - Method in class org.jgroups.util.TimeService
-
- stopThread(boolean) - Method in class org.jgroups.protocols.FD_SOCK.ClientConnectionHandler
-
- stopTimeoutChecker() - Method in class org.jgroups.protocols.FD_ALL
-
- stopTimeoutChecker() - Method in class org.jgroups.protocols.FD_ALL2
-
- stopViewConsistencyChecker() - Method in class org.jgroups.protocols.MERGE3
-
- store_password - Variable in class org.jgroups.protocols.SYM_ENCRYPT
-
- storePassword() - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
- storePassword(String) - Method in class org.jgroups.protocols.SYM_ENCRYPT
-
- Streamable - Interface in org.jgroups.util
-
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly
serialization
- StreamableCallable() - Constructor for class org.jgroups.blocks.executor.Executions.StreamableCallable
-
- StreamableCallable(Class<? extends Callable<?>>, byte, Object...) - Constructor for class org.jgroups.blocks.executor.Executions.StreamableCallable
-
- streamableFromBuffer(byte[], int, int) - Static method in class org.jgroups.protocols.COUNTER
-
- streamableFromBuffer(Class<T>, byte[], int, int) - Static method in class org.jgroups.util.Util
-
- streamableFromByteBuffer(Class<? extends Streamable>, byte[]) - Static method in class org.jgroups.util.Util
-
- streamableFromByteBuffer(Class<? extends Streamable>, byte[], int, int) - Static method in class org.jgroups.util.Util
-
- streamableToBuffer(byte, byte, Streamable) - Static method in class org.jgroups.protocols.COUNTER
-
- streamableToBuffer(Streamable) - Static method in class org.jgroups.util.Util
-
- streamableToByteBuffer(Streamable) - Static method in class org.jgroups.util.Util
-
- StreamingStateTransfer - Class in org.jgroups.protocols.pbcast
-
Base class for state transfer protocols which use streaming (or chunking) to transfer state between two members.
- StreamingStateTransfer() - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- StreamingStateTransfer.StateGetter - Class in org.jgroups.protocols.pbcast
-
- StreamingStateTransfer.StateHeader - Class in org.jgroups.protocols.pbcast
-
- string_version - Static variable in class org.jgroups.Version
-
- StringProperties() - Constructor for class org.jgroups.conf.PropertyConverters.StringProperties
-
- stringToBytes(String) - Static method in class org.jgroups.util.Util
-
- strToLevel(String) - Static method in class org.jgroups.logging.JDKLogImpl
-
- stub - Variable in class org.jgroups.util.ResponseCollectorTask
-
- stubManager - Variable in class org.jgroups.protocols.TCPGOSSIP
-
- stubManager - Variable in class org.jgroups.protocols.TUNNEL
-
- stubs - Variable in class org.jgroups.stack.RouterStubManager
-
- subgroups - Variable in class org.jgroups.MergeView
-
- submit(Callable<V>) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
- submit(Runnable, V) - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
- submit(Runnable, T) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- submit(Callable<T>) - Method in class org.jgroups.blocks.executor.ExecutionService
-
- submitToPool(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
-
- subscribe(String) - Method in class org.jgroups.client.StompConnection
-
- subscriptions - Variable in class org.jgroups.client.StompConnection
-
- subscriptions - Variable in class org.jgroups.protocols.STOMP
-
- 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)
- substituteVariables() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- subviews - Variable in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- SUFFIX - Static variable in class org.jgroups.protocols.FILE_PING
-
- SUFFIX - Static variable in class org.jgroups.protocols.PDC
-
- sum() - Method in class org.jgroups.util.PaddedAtomicBoolean
-
- sum() - Method in class org.jgroups.util.PaddedAtomicInteger
-
- sum() - Method in class org.jgroups.util.PaddedAtomicLong
-
- supervisor(SUPERVISOR) - Method in class org.jgroups.protocols.rules.Rule
-
- SUPERVISOR - Class in org.jgroups.protocols.rules
-
Protocol which supervises other protocols.
- SUPERVISOR() - Constructor for class org.jgroups.protocols.rules.SUPERVISOR
-
- supportedKeys() - Method in class org.jgroups.blocks.RequestCorrelator.MyProbeHandler
-
- supportedKeys() - Method in class org.jgroups.protocols.pbcast.GMS
-
- supportedKeys() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- supportedKeys() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- supportedKeys() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- supportedKeys() - Method in class org.jgroups.protocols.TP
-
- supportedKeys() - Method in interface org.jgroups.stack.DiagnosticsHandler.ProbeHandler
-
Returns a list of supported keys
- supportedOptions() - Method in class org.jgroups.nio.MockSocketChannel
-
- supportsMulticasting() - Method in class org.jgroups.protocols.BasicTCP
-
- supportsMulticasting() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- supportsMulticasting() - Method in class org.jgroups.protocols.TP
-
Whether or not hardware multicasting is supported
- supportsMulticasting() - Method in class org.jgroups.protocols.TUNNEL
-
We can simply send a message with dest == null and the GossipRouter will take care of routing it to all
members in the cluster
- supportsMulticasting() - Method in class org.jgroups.protocols.UDP
-
- suppress_format - Variable in class org.jgroups.util.SuppressLog
-
- suppress_log_different_cluster - Variable in class org.jgroups.protocols.TP
-
Log to suppress identical warnings for messages from members in different clusters
- suppress_log_different_version - Variable in class org.jgroups.protocols.TP
-
Log to suppress identical warnings for messages from members with different (incompatible) versions
- suppress_log_non_member - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Log to suppress identical warnings for messages from non-members
- suppress_log_non_member - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Log to suppress identical warnings for messages from non-members
- suppress_log_out_of_buffer_space - Variable in class org.jgroups.protocols.UDP
-
- suppress_time_different_cluster_warnings - Variable in class org.jgroups.protocols.TP
-
- suppress_time_different_version_warnings - Variable in class org.jgroups.protocols.TP
-
- suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
- suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- suppress_time_out_of_buffer_space - Variable in class org.jgroups.protocols.UDP
-
- SUPPRESS_VIEW_SIZE - Static variable in class org.jgroups.Global
-
- suppress_view_size - Static variable in class org.jgroups.View
-
- SuppressCache<T> - Class in org.jgroups.util
-
Cache which keeps a timestamp and counter for every key.
- SuppressCache() - Constructor for class org.jgroups.util.SuppressCache
-
- SuppressCache.Value - Class in org.jgroups.util
-
- SuppressLog<T> - Class in org.jgroups.util
-
Log (using
SuppressCache
) which suppresses (certain) messages from the same member for a given time
- SuppressLog(Log, String, String) - Constructor for class org.jgroups.util.SuppressLog
-
- SuppressLog.Level - Enum in org.jgroups.util
-
- suspect(Address) - Method in class org.jgroups.blocks.GroupRequest
-
Callback (called by RequestCorrelator or Transport).
- suspect(Address) - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
-
- suspect(Address) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- suspect(Address) - Method in class org.jgroups.blocks.ReplCache
-
- suspect(Address) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Called when a member is suspected
- suspect(Address) - Method in class org.jgroups.blocks.Request
-
- suspect(Address) - Method in class org.jgroups.blocks.UnicastRequest
-
Callback (called by RequestCorrelator or Transport).
- suspect(Address) - Method in class org.jgroups.demos.QuoteClient
-
- 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 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(List<Address>) - Method in class org.jgroups.protocols.FD_ALL
-
- suspect(List<Address>) - Method in class org.jgroups.protocols.FD_ALL2
-
- suspect(InetAddress) - Method in class org.jgroups.protocols.FD_HOST
-
Called by ping task; will result in all members of host getting suspected
- suspect(List<Address>) - Method in class org.jgroups.protocols.FD_HOST
-
- SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- suspect(Set<Address>) - Method in class org.jgroups.protocols.FD_SOCK
-
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
- suspect(String) - Method in class org.jgroups.protocols.pbcast.GMS
-
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
- suspect - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- suspect(Address) - Method in class org.jgroups.ReceiverAdapter
-
Called whenever a member is suspected of having crashed, but has not yet been excluded.
- suspect(Address) - Method in class org.jgroups.util.AckCollector
-
- suspect(Address) - Method in class org.jgroups.util.ResponseCollector
-
- suspect_history - Variable in class org.jgroups.protocols.FD
-
- suspect_history - Variable in class org.jgroups.protocols.FD_ALL
-
- suspect_history - Variable in class org.jgroups.protocols.FD_ALL2
-
- suspect_history - Variable in class org.jgroups.protocols.FD_HOST
-
- suspect_history - Variable in class org.jgroups.protocols.FD_SOCK
-
- suspect_msg_interval - Variable in class org.jgroups.protocols.FD_SOCK
-
- SUSPECTED - Static variable in class org.jgroups.util.Rsp
-
Flag that represents whether the sender of the response was suspected
- suspected_mbrs - Variable in class org.jgroups.protocols.FD.Broadcaster
-
- suspected_mbrs - Variable in class org.jgroups.protocols.FD_ALL
-
- suspected_mbrs - Variable in class org.jgroups.protocols.FD_ALL2
-
- suspected_mbrs - Variable in class org.jgroups.protocols.FD_HOST
-
- suspected_mbrs - Variable in class org.jgroups.protocols.FD_SOCK
-
- suspected_mbrs - Variable in class org.jgroups.util.AckCollector
-
- suspected_members - Variable in class org.jgroups.protocols.FD.BroadcastTask
-
- 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
-
- suspects - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
- SUSPEND - Static variable in class org.jgroups.Event
-
- suspend(long) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- SUSPEND_BUT_FAIL - Static variable in class org.jgroups.Event
-
- SUSPEND_STABLE - Static variable in class org.jgroups.Event
-
- suspended - Variable in class org.jgroups.protocols.pbcast.STABLE
-
When true, don't take part in garbage collection: neither send STABLE messages nor handle STABILITY messages
- suspendEncoding() - Method in class org.jgroups.util.Base64.OutputStream
-
Suspends encoding of the stream.
- suspendViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
-
- sv - Variable in class org.jgroups.protocols.rules.Rule
-
- SWIFT_PING - Class in org.jgroups.protocols
-
Discovery protocol based on Openstack Swift (object storage).
- SWIFT_PING() - Constructor for class org.jgroups.protocols.SWIFT_PING
-
- SWIFT_PING.SwiftClient - Class in org.jgroups.protocols
-
A thread safe Swift client
- swiftClient - Variable in class org.jgroups.protocols.SWIFT_PING
-
- SwiftClient(SWIFT_PING.Authenticator) - Constructor for class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Constructor
- sym_algorithm - Variable in class org.jgroups.protocols.EncryptBase
-
- SYM_ENCRYPT - Class in org.jgroups.protocols
-
Encrypts and decrypts communication in JGroups by using a secret key shared by all cluster members.
- SYM_ENCRYPT() - Constructor for class org.jgroups.protocols.SYM_ENCRYPT
-
- sym_keylength - Variable in class org.jgroups.protocols.EncryptBase
-
- sym_version - Variable in class org.jgroups.protocols.EncryptBase
-
- symAlgorithm() - Method in class org.jgroups.protocols.EncryptBase
-
- symAlgorithm(String) - Method in class org.jgroups.protocols.EncryptBase
-
- symKeylength() - Method in class org.jgroups.protocols.EncryptBase
-
- symKeylength(int) - Method in class org.jgroups.protocols.EncryptBase
-
- symVersion - Variable in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- symVersion() - Method in class org.jgroups.protocols.EncryptBase
-
- symVersion(byte[]) - Method in class org.jgroups.protocols.EncryptBase
-
- sync - Variable in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
Synchronization control for FutureTask
- Sync(ExecutionService.DistributedFuture<V>, Callable<V>) - Constructor for class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
- SYNC() - Static method in class org.jgroups.blocks.RequestOptions
-
- sync - Variable in class org.jgroups.util.RpcStats.Result
-
- sync() - Method in class org.jgroups.util.RpcStats.Result
-
- sync_anycasts - Variable in class org.jgroups.util.RpcStats
-
- sync_min_interval - Variable in class org.jgroups.protocols.UNICAST3
-
- sync_multicasts - Variable in class org.jgroups.util.RpcStats
-
- sync_unicasts - Variable in class org.jgroups.util.RpcStats
-
- synchronizedMap(ReplicatedMap<K, V>) - Static method in class org.jgroups.blocks.ReplicatedHashMap
-
Creates a synchronized facade for a ReplicatedMap.
- table - Variable in class org.jgroups.protocols.Locking.ClientLockTable
-
- Table<T> - Class in org.jgroups.util
-
A store for elements (typically messages) to be retransmitted or delivered.
- Table() - Constructor for class org.jgroups.util.Table
-
- Table(long) - Constructor for class org.jgroups.util.Table
-
- Table(int, int, long) - Constructor for class org.jgroups.util.Table
-
- Table(int, int, long, double) - Constructor for class org.jgroups.util.Table
-
- Table(int, int, long, double, long) - Constructor for class org.jgroups.util.Table
-
Creates a new table
- Table.Counter - Class in org.jgroups.util
-
- Table.Dump - Class in org.jgroups.util
-
- Table.Getter - Class in org.jgroups.util
-
- Table.HighestDeliverable - Class in org.jgroups.util
-
- Table.Missing - Class in org.jgroups.util
-
- Table.Remover - Class in org.jgroups.util
-
- Table.RemoverOnAdd - Class in org.jgroups.util
-
- Table.Visitor<T> - Interface in org.jgroups.util
-
- take() - Method in class org.jgroups.blocks.executor.ExecutionCompletionService
- take() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
- take() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
- take() - Method in class org.jgroups.util.RingBuffer
-
- target - Variable in class org.jgroups.blocks.UnicastRequest
-
- target - Variable in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- target - Variable in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- target - Variable in class org.jgroups.protocols.RSVP.Entry
-
- Target(IpAddress, IpAddress, RouterStub.StubReceiver) - Constructor for class org.jgroups.stack.RouterStubManager.Target
-
- target - Variable in class org.jgroups.stack.StateTransferInfo
-
- target_time - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- task - Variable in class org.jgroups.blocks.executor.ExecutionService.RunnableAdapter
-
- task - Variable in class org.jgroups.protocols.FD.Broadcaster
-
- task - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- task - Variable in class org.jgroups.protocols.SHUFFLE
-
- Task(Interval, Retransmitter.RetransmitCommand, Address) - Constructor for class org.jgroups.stack.Retransmitter.Task
-
Deprecated.
- task - Variable in class org.jgroups.util.HashedTimingWheel.MyTask
-
- task - Variable in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- Task(Runnable) - Constructor for class org.jgroups.util.TimeScheduler3.Task
-
- Task(Runnable, long, TimeUnit) - Constructor for class org.jgroups.util.TimeScheduler3.Task
-
- task - Variable in class org.jgroups.util.TimeService
-
- TASK_CANCEL - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
-
- TASK_COMPLETE - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
-
- TASK_SUBMIT - Static variable in class org.jgroups.blocks.executor.ExecutorEvent
-
- taskReady(long) - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
Signals that a task with a lower execution time than next_execution_time is ready
- TaskWrapper(TimeScheduler.Task) - Constructor for class org.jgroups.util.DefaultTimeScheduler.TaskWrapper
-
- TCP - Class in org.jgroups.protocols
-
TCP based protocol.
- TCP() - Constructor for class org.jgroups.protocols.TCP
-
- TCP_CLIENT_BIND_ADDR - Static variable in class org.jgroups.Global
-
- TCP_NIO - Class in org.jgroups.protocols
-
Deprecated.
- TCP_NIO() - Constructor for class org.jgroups.protocols.TCP_NIO
-
Deprecated.
- TCP_NIO2 - Class in org.jgroups.protocols
-
Protocol using TCP/IP to send and receive messages.
- TCP_NIO2() - Constructor for class org.jgroups.protocols.TCP_NIO2
-
- tcp_nodelay - Variable in class org.jgroups.blocks.cs.BaseServer
-
- tcp_nodelay - Variable in class org.jgroups.protocols.BasicTCP
-
- tcp_nodelay - Variable in class org.jgroups.protocols.TUNNEL
-
- tcp_nodelay - Variable in class org.jgroups.stack.RouterStub
-
- TcpBaseServer - Class in org.jgroups.blocks.cs
-
Common base class for TCP based clients and servers
- TcpBaseServer(ThreadFactory) - Constructor for class org.jgroups.blocks.cs.TcpBaseServer
-
- TcpClient - Class in org.jgroups.blocks.cs
-
- TcpClient(IpAddress, IpAddress) - Constructor for class org.jgroups.blocks.cs.TcpClient
-
Creates an instance of an
TcpClient
that acts as a
client: no server socket is created and
no acceptor is started to listen for incoming connections.
- TcpClient(InetAddress, int, InetAddress, int) - Constructor for class org.jgroups.blocks.cs.TcpClient
-
Creates an instance of an
TcpClient
that acts as a
client: no server socket is created and
no acceptor is started to listen for incoming connections.
- TcpClient(ThreadFactory, SocketFactory) - Constructor for class org.jgroups.blocks.cs.TcpClient
-
- TcpConnection - Class in org.jgroups.blocks.cs
-
Blocking IO (BIO) connection.
- TcpConnection(Address, TcpBaseServer) - Constructor for class org.jgroups.blocks.cs.TcpConnection
-
- TcpConnection(Socket, TcpServer) - Constructor for class org.jgroups.blocks.cs.TcpConnection
-
- TcpConnection.Receiver - Class in org.jgroups.blocks.cs
-
- TcpConnection.Sender - Class in org.jgroups.blocks.cs
-
- TCPGOSSIP - Class in org.jgroups.protocols
-
The TCPGOSSIP protocol layer retrieves the initial membership (used by the
GMS when started by sending event FIND_INITIAL_MBRS down the stack).
- TCPGOSSIP() - Constructor for class org.jgroups.protocols.TCPGOSSIP
-
- tcpNodelay() - Method in class org.jgroups.blocks.cs.BaseServer
-
- tcpNodelay(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
-
- tcpNoDelay() - Method in class org.jgroups.stack.RouterStub
-
- tcpNoDelay(boolean) - Method in class org.jgroups.stack.RouterStub
-
- TCPPING - Class in org.jgroups.protocols
-
The TCPPING protocol defines a static cluster membership.
- TCPPING() - Constructor for class org.jgroups.protocols.TCPPING
-
- TCPPING_INITIAL_HOSTS - Static variable in class org.jgroups.Global
-
- TcpServer - Class in org.jgroups.blocks.cs
-
Class that manages allows to send and receive messages via TCP sockets.
- TcpServer(InetAddress, int) - Constructor for class org.jgroups.blocks.cs.TcpServer
-
Creates an instance of
TcpServer
that creates a server socket and listens for connections.
- TcpServer(IpAddress) - Constructor for class org.jgroups.blocks.cs.TcpServer
-
Creates an instance of TcpServer.
- TcpServer(ThreadFactory, SocketFactory, InetAddress, int, int, InetAddress, int) - Constructor for class org.jgroups.blocks.cs.TcpServer
-
Creates an instance of
TcpServer
that creates a server socket and listens for connections
Needs to be started next.
- TcpServer(ThreadFactory, SocketFactory) - Constructor for class org.jgroups.blocks.cs.TcpServer
-
- TcpServer.Acceptor - Class in org.jgroups.blocks.cs
-
- teardownPingSocket() - Method in class org.jgroups.protocols.FD_SOCK
-
- tenant - Variable in class org.jgroups.protocols.SWIFT_PING
-
- termination - Static variable in class org.jgroups.blocks.cs.TcpConnection
-
- thread - Variable in class org.jgroups.blocks.cs.NioConnection.Reader
-
- thread - Variable in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
- thread - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- thread - Variable in class org.jgroups.util.Runner
-
- thread_factory - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- thread_factory - Variable in class org.jgroups.stack.GossipRouter
-
- thread_id - Variable in class org.jgroups.util.Owner
-
- THREAD_NAME - Static variable in class org.jgroups.protocols.RingBufferBundler
-
- THREAD_NAME - Static variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- THREAD_NAME - Static variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- THREAD_NAME - Static variable in class org.jgroups.protocols.TransferQueueBundler
-
- THREAD_NAME - Static variable in class org.jgroups.stack.DiagnosticsHandler
-
- thread_name - Variable in class org.jgroups.util.Runner
-
- thread_naming_pattern - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_naming_pattern - Variable in class org.jgroups.protocols.TP
-
- thread_pool - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- thread_pool - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_pool - Variable in class org.jgroups.protocols.TP
-
The thread pool which handles unmarshalling, version checks and dispatching of regular messages
- thread_pool_enabled - Variable in class org.jgroups.protocols.TP
-
Deprecated.
- thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_pool_keep_alive_time - Variable in class org.jgroups.protocols.TP
-
- thread_pool_max_threads - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_pool_max_threads - Variable in class org.jgroups.protocols.TP
-
- thread_pool_min_threads - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- thread_pool_min_threads - Variable in class org.jgroups.protocols.TP
-
- thread_pool_queue - Variable in class org.jgroups.protocols.TP
-
Used if thread_pool is a ThreadPoolExecutor and thread_pool_queue_enabled is true
- thread_pool_queue_enabled - Variable in class org.jgroups.protocols.TP
-
- thread_pool_queue_max_size - Variable in class org.jgroups.protocols.TP
-
- thread_pool_rejection_policy - Variable in class org.jgroups.protocols.TP
-
- THREAD_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
-
- ThreadFactory - Interface in org.jgroups.util
-
- threadId - Variable in class org.jgroups.protocols.Executing.RequestWithThread
-
- THREADPOOL_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
-
- threadPoolFactory() - Method in class org.jgroups.stack.GossipRouter
-
- threadPoolFactory(ThreadFactory) - Method in class org.jgroups.stack.GossipRouter
-
- threshold - Variable in class org.jgroups.protocols.SEQUENCER
-
- throw_exception_on_timeout - Variable in class org.jgroups.protocols.RSVP
-
- throwableEncountered(Throwable) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- throwableEncountered(Throwable) - Method in interface org.jgroups.blocks.executor.ExecutorNotification
-
- tick_time - Variable in class org.jgroups.protocols.TP
-
- tick_time - Variable in class org.jgroups.util.HashedTimingWheel
-
- time_period - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- time_period_ns - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- TIME_SENSITIVE - Static variable in class org.jgroups.Global
-
- time_service - Variable in class org.jgroups.blocks.cs.BaseServer
-
- time_service - Variable in class org.jgroups.protocols.FD_ALL
-
- time_service - Variable in class org.jgroups.protocols.FD_HOST
-
- time_service - Variable in class org.jgroups.protocols.TP
-
- time_service - Variable in class org.jgroups.protocols.UNICAST3
-
- time_service_interval - Variable in class org.jgroups.protocols.TP
-
- time_unit - Variable in class org.jgroups.blocks.locking.LockInfo
-
- timeout - Variable in class org.jgroups.blocks.locking.LockInfo
-
- timeout - Variable in class org.jgroups.blocks.RequestOptions
-
The max time (in ms) for a blocking call.
- timeout - Variable in class org.jgroups.protocols.COUNTER
-
- timeout - Variable in class org.jgroups.protocols.Discovery
-
Deprecated.
- timeout() - Method in class org.jgroups.protocols.Discovery
-
- timeout(long) - Method in class org.jgroups.protocols.Discovery
-
- timeout - Variable in class org.jgroups.protocols.FD
-
- timeout - Variable in class org.jgroups.protocols.FD_ALL
-
- timeout - Variable in class org.jgroups.protocols.FD_ALL2
-
- timeout - Variable in class org.jgroups.protocols.FD_HOST
-
- timeout - Variable in class org.jgroups.protocols.Locking.ClientLock
-
- timeout - Variable in class org.jgroups.protocols.Locking.Request
-
- timeout - Variable in class org.jgroups.protocols.RSVP
-
- timeout - Variable in class org.jgroups.protocols.SASL
-
- timeout - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- timeout - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- timeout - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
- timeout - Variable in class org.jgroups.stack.StateTransferInfo
-
- timeout - Variable in class org.jgroups.util.ExpiryCache
-
- timeout_check_interval - Variable in class org.jgroups.protocols.FD_ALL
-
- timeout_check_interval - Variable in class org.jgroups.protocols.FD_ALL2
-
- timeout_checker_future - Variable in class org.jgroups.protocols.FD_ALL
-
- timeout_checker_future - Variable in class org.jgroups.protocols.FD_ALL2
-
- TimeoutException - Exception in org.jgroups
-
Thrown if members fail to respond in time.
- TimeoutException() - Constructor for exception org.jgroups.TimeoutException
-
- TimeoutException(String) - Constructor for exception org.jgroups.TimeoutException
-
- timer - Variable in class org.jgroups.protocols.ABP
-
- timer - Variable in class org.jgroups.protocols.BARRIER
-
- timer - Variable in class org.jgroups.protocols.Discovery
-
- timer - Variable in class org.jgroups.protocols.FD
-
- timer - Variable in class org.jgroups.protocols.FD_ALL
-
- timer - Variable in class org.jgroups.protocols.FD_ALL2
-
- timer - Variable in class org.jgroups.protocols.FD_HOST
-
Timer used to run the ping task on
- timer - Variable in class org.jgroups.protocols.FD_SOCK
-
- timer - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- timer - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- timer - Variable in class org.jgroups.protocols.MERGE3
-
- timer - Variable in class org.jgroups.protocols.pbcast.GMS
-
- timer - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- timer - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- timer - Variable in class org.jgroups.protocols.relay.RELAY2
-
- timer - Variable in class org.jgroups.protocols.RELAY
-
- timer - Variable in class org.jgroups.protocols.RSVP
-
- timer - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- timer - Variable in class org.jgroups.protocols.SCOPE
-
Deprecated.
- timer - Variable in class org.jgroups.protocols.SHUFFLE
-
- timer - Variable in class org.jgroups.protocols.TP
-
- timer - Variable in class org.jgroups.protocols.UNICAST
-
Deprecated.
- timer - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- timer - Variable in class org.jgroups.protocols.UNICAST3
-
- timer - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
- timer - Variable in class org.jgroups.stack.GossipRouter
-
- timer - Variable in class org.jgroups.stack.Retransmitter
-
Deprecated.
- timer - Variable in class org.jgroups.stack.RouterStubManager
-
- timer - Variable in class org.jgroups.util.TimeService
-
- timer_keep_alive_time - Variable in class org.jgroups.protocols.TP
-
- timer_max_threads - Variable in class org.jgroups.protocols.TP
-
- timer_min_threads - Variable in class org.jgroups.protocols.TP
-
- TIMER_NUM_THREADS - Static variable in class org.jgroups.Global
-
- timer_queue_max_size - Variable in class org.jgroups.protocols.TP
-
- timer_rejection_policy - Variable in class org.jgroups.protocols.TP
-
- timer_thread_factory - Variable in class org.jgroups.protocols.TP
-
- timer_thread_factory - Variable in class org.jgroups.util.HashedTimingWheel
-
- timer_thread_factory - Variable in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- timer_thread_factory - Variable in class org.jgroups.util.TimeScheduler3
-
- timer_type - Variable in class org.jgroups.protocols.TP
-
- TimeScheduler - Interface in org.jgroups.util
-
Timer-like interface which allows for execution of tasks.
- TimeScheduler.Task - Interface in org.jgroups.util
-
- TimeScheduler2 - Class in org.jgroups.util
-
- TimeScheduler2() - Constructor for class org.jgroups.util.TimeScheduler2
-
Deprecated.
Create a scheduler that executes tasks in dynamically adjustable intervals
- TimeScheduler2(ThreadFactory, int, int, long, int, String) - Constructor for class org.jgroups.util.TimeScheduler2
-
Deprecated.
- TimeScheduler2(int) - Constructor for class org.jgroups.util.TimeScheduler2
-
Deprecated.
- TimeScheduler2.MyTask - Class in org.jgroups.util
-
Deprecated.
Simple task wrapper, always executed by at most 1 thread.
- TimeScheduler3 - Class in org.jgroups.util
-
- TimeScheduler3() - Constructor for class org.jgroups.util.TimeScheduler3
-
Create a scheduler that executes tasks in dynamically adjustable intervals
- TimeScheduler3(ThreadFactory, int, int, long, int, String) - Constructor for class org.jgroups.util.TimeScheduler3
-
- TimeScheduler3.RecurringTask - Class in org.jgroups.util
-
Tasks which runs more than once, either dynamic, fixed-rate or fixed-delay, until cancelled
- TimeScheduler3.Task - Class in org.jgroups.util
-
- TimeScheduler3.TaskType - Enum in org.jgroups.util
-
- timeService() - Method in class org.jgroups.blocks.cs.BaseServer
-
- timeService(TimeService) - Method in class org.jgroups.blocks.cs.BaseServer
-
- TimeService - Class in org.jgroups.util
-
Provides a coarse grained time service.
- TimeService(TimeScheduler) - Constructor for class org.jgroups.util.TimeService
-
- TimeService(TimeScheduler, long) - Constructor for class org.jgroups.util.TimeService
-
- timestamp - Variable in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- timestamp - Variable in class org.jgroups.protocols.RSVP.Entry
-
- timestamp - Variable in class org.jgroups.protocols.UNICAST.ReceiverEntry
-
Deprecated.
- timestamp - Variable in class org.jgroups.protocols.UNICAST.SenderEntry
-
Deprecated.
- timestamp - Variable in class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- timestamp - Variable in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- timestamp - Variable in class org.jgroups.protocols.UNICAST3.Entry
-
- timestamp() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- timestamp(long) - Method in class org.jgroups.protocols.UNICAST3.Header
-
- timestamp - Variable in class org.jgroups.util.SuppressCache.Value
-
- timestamp - Variable in class org.jgroups.util.TimeService
-
- timestamp() - Method in class org.jgroups.util.TimeService
-
Returns the timestamp (ns)
- timestamper - Variable in class org.jgroups.protocols.UNICAST3
-
- timestamps - Variable in class org.jgroups.protocols.FD_ALL
-
- timestamps - Variable in class org.jgroups.protocols.FD_ALL2
-
- timestamps - Variable in class org.jgroups.protocols.FD_HOST
-
- tmp_members - Variable in class org.jgroups.protocols.pbcast.GMS
-
- TMP_VIEW - Static variable in class org.jgroups.Event
-
- tmp_write_index - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- to - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- TOA - Class in org.jgroups.protocols.tom
-
Total Order Anycast with three communication steps (based on Skeen's Algorithm).
- TOA() - Constructor for class org.jgroups.protocols.tom.TOA
-
- ToaHeader - Class in org.jgroups.protocols.tom
-
The header for the Total Order Anycast (TOA) protocol
- ToaHeader() - Constructor for class org.jgroups.protocols.tom.ToaHeader
-
- token - Variable in class org.jgroups.protocols.AuthHeader
-
- token(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
-
- token() - Method in class org.jgroups.protocols.AuthHeader
-
- token() - Method in class org.jgroups.protocols.SaslHeader
-
- TOKEN_ATTR - Static variable in class org.jgroups.auth.X509Token
-
- toList() - Method in class org.jgroups.util.Responses
-
- toLowerCase(String) - Static method in class org.jgroups.jmx.ResourceDMBean
-
Returns a string with the first letter being lowercase
- top_prot - Variable in class org.jgroups.stack.ProtocolStack
-
- Topology - Class in org.jgroups.demos
-
Demonstrates the membership service.
- Topology(String, String) - Constructor for class org.jgroups.demos.Topology
-
- TopologyUUID - Class in org.jgroups.util
-
- TopologyUUID() - Constructor for class org.jgroups.util.TopologyUUID
-
Deprecated.
- TopologyUUID(byte[], String, String, String) - Constructor for class org.jgroups.util.TopologyUUID
-
Deprecated.
- TopologyUUID(long, long, String, String, String) - Constructor for class org.jgroups.util.TopologyUUID
-
Deprecated.
- toPositiveUnsignedShort(int) - Static method in class org.jgroups.nio.Buffers
-
- topProtocol(Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
- tos - Variable in class org.jgroups.protocols.UDP
-
Traffic class for sending unicast and multicast datagrams.
- tossWeightedCoin(double) - Static method in class org.jgroups.util.Util
-
Tosses a coin weighted with probability and returns true or false.
- toString() - Method in class org.jgroups.AnycastAddress
-
- toString() - Method in class org.jgroups.auth.DemoToken.DemoHeader
-
- toString() - Method in class org.jgroups.auth.SimpleToken
-
- toString() - Method in class org.jgroups.blocks.BasicConnectionTable
-
- toString() - Method in class org.jgroups.blocks.Cache
-
- toString() - Method in class org.jgroups.blocks.cs.BaseServer
-
- toString() - Method in class org.jgroups.blocks.cs.NioClient
-
- toString() - Method in class org.jgroups.blocks.cs.NioConnection
-
- toString() - Method in class org.jgroups.blocks.cs.TcpClient
-
- toString() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- toString() - Method in class org.jgroups.blocks.executor.Executions.StreamableCallable
-
- toString() - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture
-
- toString() - Method in class org.jgroups.blocks.GridFile.Metadata
-
- toString() - Method in class org.jgroups.blocks.GroupRequest
-
- toString() - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- toString() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- toString() - Method in class org.jgroups.blocks.locking.AwaitInfo
-
- toString() - Method in class org.jgroups.blocks.locking.LockInfo
-
- toString() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
-
- toString() - Method in class org.jgroups.blocks.MemcachedConnector.Request
-
- toString() - Method in class org.jgroups.blocks.MethodCall
-
- toString() - Method in class org.jgroups.blocks.mux.MuxHeader
-
- toString() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- toString() - Method in class org.jgroups.blocks.ReplCache
-
- toString() - Method in class org.jgroups.blocks.ReplCache.Value
-
- toString() - Method in class org.jgroups.blocks.ReplicatedTree.Node
-
- toString() - Method in class org.jgroups.blocks.ReplicatedTree
-
- toString() - Method in class org.jgroups.blocks.Request
-
- toString() - Method in class org.jgroups.blocks.RequestCorrelator.Header
-
- toString() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
-
- toString() - Method in class org.jgroups.blocks.RequestOptions
-
- toString() - Method in class org.jgroups.blocks.UnicastRequest
-
- toString() - Method in class org.jgroups.conf.ClassConfigurator
-
- toString(Object) - Method in interface org.jgroups.conf.PropertyConverter
-
Converts the value to a string.
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.BindInterface
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.Default
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.FlushInvoker
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.IntegerArray
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.LongArray
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
-
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.StringProperties
-
- toString() - Method in class org.jgroups.conf.ProtocolConfiguration
-
- toString() - Method in class org.jgroups.demos.DrawCommand
-
- toString() - Method in class org.jgroups.demos.JmxDemo.MyNotification
-
- toString() - Method in class org.jgroups.demos.wb.Node
-
- toString() - Method in class org.jgroups.Event
-
- toString() - Method in class org.jgroups.Header
-
- toString(boolean) - Method in class org.jgroups.JChannel
-
- toString() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
- toString() - Method in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
-
- toString() - Method in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
-
- toString() - Method in class org.jgroups.jmx.ResourceDMBean.NoopAccessor
-
- toString() - Method in class org.jgroups.Membership
-
- toString() - Method in class org.jgroups.MergeView
-
- toString() - Method in class org.jgroups.Message
-
- toString() - Method in class org.jgroups.nio.Buffers
-
- toString() - Method in class org.jgroups.protocols.ABP.ABPHeader
-
- toString() - Method in class org.jgroups.protocols.AuthHeader
-
- toString() - Method in class org.jgroups.protocols.COUNTER.AddAndGetRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.BooleanResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
-
- toString() - Method in class org.jgroups.protocols.COUNTER.DeleteRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.GetOrCreateResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
-
- toString() - Method in class org.jgroups.protocols.COUNTER.SetRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.SimpleResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
-
- toString() - Method in class org.jgroups.protocols.COUNTER.ValueResponse
-
- toString() - Method in class org.jgroups.protocols.COUNTER.VersionedValue
-
- toString() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
-
- toString() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.EncryptHeader
-
- toString() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
-
- toString() - Method in class org.jgroups.protocols.Executing.Owner
-
- toString() - Method in class org.jgroups.protocols.Executing.Request
-
- toString() - Method in class org.jgroups.protocols.Executing.RequestWithThread
-
- toString() - Method in class org.jgroups.protocols.FcHeader
-
- toString() - Method in class org.jgroups.protocols.FD.BroadcastTask
-
- toString() - Method in class org.jgroups.protocols.FD.FdHeader
-
- toString() - Method in class org.jgroups.protocols.FD.Monitor
-
- toString() - Method in class org.jgroups.protocols.FD_ALL.HeartbeatHeader
-
- toString() - Method in class org.jgroups.protocols.FD_ALL2.HeartbeatHeader
-
- toString() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
- toString() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- toString() - Method in class org.jgroups.protocols.FlowControl.Credit
-
- toString() - Method in class org.jgroups.protocols.FORK.ForkHeader
-
- toString() - Method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- toString() - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
- toString() - Method in class org.jgroups.protocols.FragHeader
-
- toString() - Method in class org.jgroups.protocols.Locking.ClientLock
-
- toString() - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- toString() - Method in class org.jgroups.protocols.Locking.Request
-
- toString() - Method in class org.jgroups.protocols.Locking.ServerLock
-
- toString() - Method in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.MERGE3.InfoSender
-
- toString() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
-
- toString() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
-
- toString() - Method in class org.jgroups.protocols.pbcast.DeltaView
-
- toString() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- toString() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- toString() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
-
- toString() - Method in class org.jgroups.protocols.pbcast.JoinRsp
-
- toString() - Method in class org.jgroups.protocols.pbcast.MergeData
-
- toString() - Method in class org.jgroups.protocols.pbcast.Merger.MergeKiller
-
- toString() - Method in class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
-
- toString() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- toString() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- toString() - Method in class org.jgroups.protocols.pbcast.STABLE.ResumeTask
-
- toString() - Method in class org.jgroups.protocols.pbcast.STABLE.StabilitySendTask
-
- toString() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- toString() - Method in class org.jgroups.protocols.pbcast.STABLE.StableTask
-
- toString() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- toString() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- toString() - Method in class org.jgroups.protocols.PDC.Mapping
-
- toString() - Method in class org.jgroups.protocols.PingData
-
- toString() - Method in class org.jgroups.protocols.PingHeader
-
- toString() - Method in class org.jgroups.protocols.PrioHeader
-
- toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
-
- toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
-
- toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ProgrammaticBridgeConfig
-
- toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.PropertiesBridgeConfig
-
- toString() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
-
- toString() - Method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- toString() - Method in class org.jgroups.protocols.RELAY.RelayHeader
-
- toString() - Method in class org.jgroups.protocols.relay.Route
-
- toString() - Method in class org.jgroups.protocols.relay.SiteMaster
-
- toString() - Method in class org.jgroups.protocols.relay.SiteUUID
-
- toString() - Method in class org.jgroups.protocols.RELAY.ViewData
-
- toString() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
-
- toString() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- toString() - Method in class org.jgroups.protocols.RSVP.Entry
-
- toString() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
-
- toString() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- toString() - Method in class org.jgroups.protocols.SaslHeader
-
- toString() - Method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.SenderSendsWithTimerBundler
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- toString() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- toString() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- toString() - Method in class org.jgroups.protocols.STOMP.Frame
-
- toString() - Method in class org.jgroups.protocols.STOMP.StompHeader
-
- toString() - Method in class org.jgroups.protocols.tom.MessageID
-
- toString() - Method in class org.jgroups.protocols.tom.ToaHeader
-
- toString() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- toString() - Method in class org.jgroups.protocols.TP
-
- toString() - Method in class org.jgroups.protocols.TpHeader
-
- toString() - Method in class org.jgroups.protocols.TRACE
-
- toString() - Method in class org.jgroups.protocols.TUNNEL
-
- toString() - Method in class org.jgroups.protocols.UDP.PacketReceiver
-
- toString() - Method in class org.jgroups.protocols.UNICAST.ConnectionReaper
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST.ReceiverEntry
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST.RetransmitTask
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST.SenderEntry
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST2.ConnectionReaper
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST2.ReceiverEntry
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST2.RetransmitTask
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- toString() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- toString() - Method in class org.jgroups.protocols.UNICAST3.ReceiverEntry
-
- toString() - Method in class org.jgroups.protocols.UNICAST3.RetransmitTask
-
- toString() - Method in class org.jgroups.protocols.UNICAST3.SenderEntry
-
- toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
-
- toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
-
- toString() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
-
- toString() - Method in class org.jgroups.stack.DefaultRetransmitter.SeqnoTask
-
- toString() - Method in class org.jgroups.stack.DefaultRetransmitter
-
- toString() - Method in class org.jgroups.stack.ExponentialInterval
-
- toString() - Method in class org.jgroups.stack.GossipData
-
- toString() - Method in class org.jgroups.stack.GossipRouter.Entry
-
- toString() - Method in class org.jgroups.stack.IpAddress
-
- toString() - Method in class org.jgroups.stack.NakReceiverWindow
-
Deprecated.
- toString() - Method in class org.jgroups.stack.ProtocolStack.RefCounter
-
- toString() - Method in class org.jgroups.stack.RangeBasedRetransmitter.RangeTask
-
- toString() - Method in class org.jgroups.stack.RangeBasedRetransmitter
-
- toString() - Method in class org.jgroups.stack.RouterStub
-
- toString() - Method in class org.jgroups.stack.RouterStubManager.Target
-
- toString() - Method in class org.jgroups.stack.StateTransferInfo
-
- toString() - Method in exception org.jgroups.SuspectedException
-
- toString() - Method in exception org.jgroups.TimeoutException
-
- toString() - Method in exception org.jgroups.UnreachableException
-
- toString() - Method in class org.jgroups.util.AckCollector
-
- toString() - Method in class org.jgroups.util.AgeOutCache
-
- toString() - Method in class org.jgroups.util.AsciiString
-
- toString() - Method in class org.jgroups.util.Average
-
- toString() - Method in class org.jgroups.util.AverageMinMax
-
- toString() - Method in class org.jgroups.util.BlockingInputStream
-
- toString() - Method in class org.jgroups.util.Buffer
-
- toString() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
- toString() - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
- toString() - Method in class org.jgroups.util.ByteBufferInputStream
-
- toString() - Method in class org.jgroups.util.ByteBufferOutputStream
-
- toString() - Method in class org.jgroups.util.CreditMap
-
- toString() - Method in class org.jgroups.util.DefaultTimeScheduler.RobustRunnable
-
- toString() - Method in class org.jgroups.util.DefaultTimeScheduler
-
- toString() - Method in class org.jgroups.util.Digest.Entry
-
- toString() - Method in class org.jgroups.util.Digest
-
- toString(Digest) - Method in class org.jgroups.util.Digest
-
- toString(Address[], boolean) - Method in class org.jgroups.util.Digest
-
- toString() - Method in class org.jgroups.util.ExpiryCache
-
- toString() - Method in class org.jgroups.util.ExtendedUUID
-
- toString() - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns a string representation of this bit set.
- toString() - Method in class org.jgroups.util.HashedTimingWheel.MyTask
-
- toString() - Method in class org.jgroups.util.HashedTimingWheel
-
- toString() - Method in class org.jgroups.util.MergeId
-
- toString() - Method in class org.jgroups.util.MessageBatch
-
- toString() - Method in class org.jgroups.util.Owner
-
- toString() - Method in class org.jgroups.util.Pool.Element
-
- toString() - Method in class org.jgroups.util.Pool
-
- toString() - Method in class org.jgroups.util.ProcessingQueue
-
- toString() - Method in class org.jgroups.util.Promise
-
- toString() - Method in class org.jgroups.util.Queue
-
prints the size of the queue
- toString() - Method in exception org.jgroups.util.QueueClosedException
-
- toString() - Method in class org.jgroups.util.Range
-
- toString() - Method in class org.jgroups.util.RequestTable
-
- toString() - Method in class org.jgroups.util.ResponseCollector
-
- toString() - Method in class org.jgroups.util.Responses
-
- toString() - Method in class org.jgroups.util.RetransmitTable
-
Deprecated.
- toString() - Method in class org.jgroups.util.RingBuffer
-
- toString() - Method in class org.jgroups.util.RingBufferSeqno
-
- toString() - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
- toString() - Method in class org.jgroups.util.RpcStats.Result
-
- toString() - Method in class org.jgroups.util.RpcStats
-
- toString() - Method in class org.jgroups.util.Rsp
-
- toString() - Method in class org.jgroups.util.RspList
-
- toString() - Method in class org.jgroups.util.Seqno
-
- toString() - Method in class org.jgroups.util.SeqnoList
-
- toString() - Method in class org.jgroups.util.SeqnoRange
-
- toString() - Method in class org.jgroups.util.SingletonAddress
-
- toString() - Method in class org.jgroups.util.StateTransferResult
-
- toString() - Method in class org.jgroups.util.SuppressCache
-
- toString() - Method in class org.jgroups.util.SuppressCache.Value
-
- toString() - Method in class org.jgroups.util.Table
-
- toString() - Method in class org.jgroups.util.TimeScheduler2.MyTask
-
Deprecated.
- toString() - Method in class org.jgroups.util.TimeScheduler2
-
Deprecated.
- toString() - Method in class org.jgroups.util.TimeScheduler3.Task
-
- toString() - Method in class org.jgroups.util.TimeScheduler3
-
- toString() - Method in class org.jgroups.util.TimeService
-
- toString() - Method in class org.jgroups.util.Triple
-
- toString() - Method in class org.jgroups.util.Tuple
-
- toString() - Method in class org.jgroups.util.UUID
-
- toString() - Method in class org.jgroups.View
-
- toString() - Method in class org.jgroups.ViewId
-
- toStringDetails() - Method in class org.jgroups.blocks.MethodCall
-
- toStringLong() - Method in class org.jgroups.util.UUID
-
Returns a String
object representing this UUID
.
- toStringShort() - Method in class org.jgroups.protocols.Locking.Request
-
- total_block_time - Variable in class org.jgroups.protocols.RATE_LIMITER
-
- TotalOrder - Class in org.jgroups.demos
-
Originally written to be a demo for TOTAL order (code to be written by a student).
- TotalOrder(String, long, int, int, String, int) - Constructor for class org.jgroups.demos.TotalOrder
-
- totalSize() - Method in class org.jgroups.util.MessageBatch
-
Returns the size of the message batch (by calling
Message.size()
on all messages)
- TP - Class in org.jgroups.protocols
-
Generic transport - specific implementations should extend this abstract class.
- TP() - Constructor for class org.jgroups.protocols.TP
-
Creates the TP protocol, and initializes the state variables, does
however not start any sockets or threads.
- TP.BatchHandler - Class in org.jgroups.protocols
-
- TP.ProtocolAdapter - Class in org.jgroups.protocols
-
Used when the transport is shared (singleton_name != null).
- TP.SingleMessageHandler - Class in org.jgroups.protocols
-
- TP.SingleMessageHandlerWithClusterName - Class in org.jgroups.protocols
-
- TpHeader - Class in org.jgroups.protocols
-
Generic transport header, used by TP.
- TpHeader() - Constructor for class org.jgroups.protocols.TpHeader
-
- TpHeader(String) - Constructor for class org.jgroups.protocols.TpHeader
-
- TpHeader(AsciiString) - Constructor for class org.jgroups.protocols.TpHeader
-
- TpHeader(byte[]) - Constructor for class org.jgroups.protocols.TpHeader
-
- trace(String) - Method in class org.jgroups.logging.JDKLogImpl
-
- trace(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
-
- trace(Object) - Method in class org.jgroups.logging.JDKLogImpl
-
- trace(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
-
- trace(Object) - Method in interface org.jgroups.logging.Log
-
- trace(String) - Method in interface org.jgroups.logging.Log
-
- trace(String, Object...) - Method in interface org.jgroups.logging.Log
-
- trace(String, Throwable) - Method in interface org.jgroups.logging.Log
-
- trace(Object) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- trace(String) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- trace(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- trace(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
-
- TRACE - Class in org.jgroups.protocols
-
- TRACE() - Constructor for class org.jgroups.protocols.TRACE
-
- TransferQueueBundler - Class in org.jgroups.protocols
-
This bundler adds all (unicast or multicast) messages to a queue until max size has been exceeded, but does send
messages immediately when no other messages are available.
- TransferQueueBundler() - Constructor for class org.jgroups.protocols.TransferQueueBundler
-
- TransferQueueBundler(BlockingQueue<Message>) - Constructor for class org.jgroups.protocols.TransferQueueBundler
-
- TransferQueueBundler(int) - Constructor for class org.jgroups.protocols.TransferQueueBundler
-
- transient_flags - Variable in class org.jgroups.blocks.RequestOptions
-
- transient_flags - Variable in class org.jgroups.Message
-
- transientFlagsToString(short) - Static method in class org.jgroups.Message
-
- transport - Variable in class org.jgroups.blocks.RequestCorrelator
-
The protocol layer to use to pass up/down messages.
- transport - Variable in class org.jgroups.protocols.BARRIER
-
- transport - Variable in class org.jgroups.protocols.BaseBundler
-
- transport - Variable in class org.jgroups.protocols.NoBundler
-
- transport - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- transport() - Method in class org.jgroups.stack.DiagnosticsHandler
-
- transport(TP) - Method in class org.jgroups.stack.DiagnosticsHandler
-
- transport_supports_multicasting - Variable in class org.jgroups.protocols.Discovery
-
- transport_supports_multicasting - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- transport_supports_multicasting - Variable in class org.jgroups.protocols.MERGE3
-
- transportClosed() - Method in class org.jgroups.blocks.GroupRequest
-
Marks all responses with an exception (unless a response was already marked as done)
- transportClosed() - Method in class org.jgroups.blocks.Request
-
- transportClosed() - Method in class org.jgroups.blocks.UnicastRequest
-
- trigger() - Method in class org.jgroups.protocols.rules.CheckFDMonitor
-
- trigger() - Method in class org.jgroups.protocols.rules.Rule
-
The action of the rule.
- trigger() - Method in class org.jgroups.protocols.rules.SampleRule
-
- triggerXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- triggerXmit() - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- triggerXmit() - Method in class org.jgroups.protocols.UNICAST3
-
- trim(String) - Static method in class org.jgroups.blocks.GridFile
-
- Triple<V1,V2,V3> - Class in org.jgroups.util
-
Holds 3 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate
holder object for the values, and don't want to pass the values as a list or array.
- Triple(V1, V2, V3) - Constructor for class org.jgroups.util.Triple
-
- tryAcquireShared(int) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
Implements AQS base acquire to succeed if ran or cancelled
- tryLock() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
-
If the thread is interrupted at entry or during the call, no InterruptedException will be thrown, but the
thread's status will be set to interrupted upon return.
- tryLock(long, TimeUnit) - Method in class org.jgroups.blocks.locking.LockService.LockImpl
-
* If the thread is interrupted at entry, the call will throw an InterruptedException immediately and the lock
won't be acquired.
- tryLock() - Method in class org.jgroups.protocols.Locking.ClientLock
-
- tryLock(long, TimeUnit) - Method in class org.jgroups.protocols.Locking.ClientLock
-
- tryReleaseShared(int) - Method in class org.jgroups.blocks.executor.ExecutionService.DistributedFuture.Sync
-
Implements AQS base release to always signal after setting
final done status by nulling runner thread.
- ttl - Variable in class org.jgroups.stack.DiagnosticsHandler
-
- TUNNEL - Class in org.jgroups.protocols
-
Replacement for UDP.
- TUNNEL() - Constructor for class org.jgroups.protocols.TUNNEL
-
- TUNNEL.TUNNELPolicy - Interface in org.jgroups.protocols
-
- tunnel_policy - Variable in class org.jgroups.protocols.TUNNEL
-
- Tuple<V1,V2> - Class in org.jgroups.util
-
Holds 2 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate
holder object for the values, and don't want to pass the values as a list or array.
- Tuple(V1, V2) - Constructor for class org.jgroups.util.Tuple
-
- type - Variable in class org.jgroups.auth.DemoToken.DemoHeader
-
- type - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
Type of header: request or reply
- type() - Method in class org.jgroups.Event
-
- type - Variable in class org.jgroups.protocols.ABP.ABPHeader
-
- type - Variable in class org.jgroups.protocols.EncryptHeader
-
- type() - Method in class org.jgroups.protocols.EncryptHeader
-
- type - Variable in class org.jgroups.protocols.Executing.Request
-
- type - Variable in class org.jgroups.protocols.FD.FdHeader
-
- type - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- type - Variable in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- type - Variable in class org.jgroups.protocols.Locking.Request
-
- type - Variable in class org.jgroups.protocols.Locking.Response
-
- type - Variable in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- type - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
-
- type - Variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- type - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- type - Variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- type - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
-
- type - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
-
- type - Variable in class org.jgroups.protocols.PingHeader
-
- type() - Method in class org.jgroups.protocols.PingHeader
-
- type - Variable in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- type - Variable in class org.jgroups.protocols.RELAY.RelayHeader
-
- type - Variable in class org.jgroups.protocols.RSVP.RsvpHeader
-
- type(SaslHeader.Type) - Method in class org.jgroups.protocols.SaslHeader
-
- type - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
-
- type - Variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
-
- type - Variable in class org.jgroups.protocols.STOMP.StompHeader
-
- type() - Method in class org.jgroups.protocols.UNICAST3.Header
-
- type - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
-
- type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
-
- type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
-
- type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST3.Header
-
- type2String(int) - Static method in class org.jgroups.Event
-
- type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- type2String(int) - Static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- type2String(byte) - Static method in class org.jgroups.protocols.tom.ToaHeader
-
- types - Variable in class org.jgroups.blocks.MethodCall
-
The class types, e.g., new Class[]{String.class, int.class}.
- TYPES - Static variable in class org.jgroups.blocks.MethodCall
-
Use class information.
- typeToString(byte) - Static method in class org.jgroups.protocols.EncryptHeader
-
- typeToString(byte) - Static method in class org.jgroups.protocols.FORWARD_TO_COORD.ForwardHeader
-
- typeToString(byte) - Static method in class org.jgroups.protocols.relay.RELAY2.Relay2Header
-
- typeToString() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
-
- typeToString(byte) - Static method in class org.jgroups.protocols.SCOPE.ScopeHeader
-
Deprecated.
- ucast_queue - Variable in class org.jgroups.protocols.BARRIER
-
- ucast_receiver - Variable in class org.jgroups.protocols.UDP
-
Runnable to receive unicast packets
- ucast_recv_buf_size - Variable in class org.jgroups.protocols.UDP
-
- ucast_send_buf_size - Variable in class org.jgroups.protocols.UDP
-
- UDP - Class in org.jgroups.protocols
-
IP multicast transport based on UDP.
- UDP() - Constructor for class org.jgroups.protocols.UDP
-
- UDP.PacketReceiver - Class in org.jgroups.protocols
-
- UDP_IP_TTL - Static variable in class org.jgroups.Global
-
- UDP_MCAST_ADDR - Static variable in class org.jgroups.Global
-
- UDP_MCAST_PORT - Static variable in class org.jgroups.Global
-
- UFC - Class in org.jgroups.protocols
-
Simple flow control protocol based on a credit system.
- UFC() - Constructor for class org.jgroups.protocols.UFC
-
- UFC_CREDIT_REQUEST_HDR - Static variable in class org.jgroups.protocols.UFC
-
- UFC_REPLENISH_HDR - Static variable in class org.jgroups.protocols.UFC
-
- unblock() - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
-
- unblock() - Method in class org.jgroups.blocks.PartitionedHashMap
-
- unblock() - Method in class org.jgroups.blocks.ReplCache
-
- unblock() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- unblock() - Method in class org.jgroups.demos.QuoteClient
-
- unblock() - Method in class org.jgroups.demos.wb.Whiteboard
-
- UNBLOCK - Static variable in class org.jgroups.Event
-
- unblock() - Method in interface org.jgroups.MembershipListener
-
Called after the FLUSH protocol has unblocked previously blocked senders, and
messages can be sent again.
- unblock(Thread) - Method in class org.jgroups.protocols.BARRIER
-
- unblock() - Method in class org.jgroups.protocols.FC
-
Deprecated.
Allows to unblock a blocked sender from an external program, e.g.
- unblock() - Method in class org.jgroups.protocols.FlowControl
-
Allows to unblock all blocked senders from an external program, e.g.
- unblock() - Method in class org.jgroups.protocols.MFC
-
Allows to unblock a blocked sender from an external program, e.g.
- unblock() - Method in class org.jgroups.protocols.UFC
-
- unblock() - Method in class org.jgroups.ReceiverAdapter
-
Called after the FLUSH protocol has unblocked previously blocked senders, and
messages can be sent again.
- unblockAll() - Method in class org.jgroups.protocols.SEQUENCER
-
- unblockAll() - Method in class org.jgroups.util.ForwardQueue
-
- uncompress(Message, int) - Method in class org.jgroups.protocols.COMPRESS
-
Returns a new message as a result of uncompressing msg, or null if msg couldn't be uncompressed
- unfragment(Message, FragHeader) - Method in class org.jgroups.protocols.FRAG2
-
1.
- UNICAST - Class in org.jgroups.protocols
-
- UNICAST() - Constructor for class org.jgroups.protocols.UNICAST
-
Deprecated.
- UNICAST.ConnectionReaper - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST.ReceiverEntry - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST.RetransmitTask - Class in org.jgroups.protocols
-
Deprecated.
Retransmitter task which periodically (every xmit_interval ms) looks at all the retransmit (send) tables and
re-sends messages for which we haven't received an ack yet
- UNICAST.SenderEntry - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST.UnicastHeader - Class in org.jgroups.protocols
-
Deprecated.
The following types and fields are serialized:
- UNICAST2 - Class in org.jgroups.protocols
-
- UNICAST2() - Constructor for class org.jgroups.protocols.UNICAST2
-
Deprecated.
- UNICAST2.ConnectionReaper - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST2.ReceiverEntry - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST2.RetransmitTask - Class in org.jgroups.protocols
-
Deprecated.
Retransmitter task which periodically (every xmit_interval ms) looks at all the retransmit tables and
sends retransmit request to all members from which we have missing messages
- UNICAST2.SenderEntry - Class in org.jgroups.protocols
-
Deprecated.
- UNICAST2.Unicast2Header - Class in org.jgroups.protocols
-
Deprecated.
The following types and fields are serialized:
- Unicast2Header() - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- Unicast2Header(byte) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- Unicast2Header(byte, long) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- Unicast2Header(byte, long, long, short, boolean) - Constructor for class org.jgroups.protocols.UNICAST2.Unicast2Header
-
Deprecated.
- UNICAST3 - Class in org.jgroups.protocols
-
Reliable unicast protocol using a combination of positive and negative acks.
- UNICAST3() - Constructor for class org.jgroups.protocols.UNICAST3
-
- UNICAST3.Entry - Class in org.jgroups.protocols
-
- UNICAST3.Header - Class in org.jgroups.protocols
-
The following types and fields are serialized:
- UNICAST3.ReceiverEntry - Class in org.jgroups.protocols
-
- UNICAST3.RetransmitTask - Class in org.jgroups.protocols
-
Retransmitter task which periodically (every xmit_interval ms):
If any of the receiver windows have the ack flag set, clears the flag and sends an ack for the
highest delivered seqno to the sender
Checks all receiver windows for missing messages and asks senders for retransmission
For all sender windows, checks if highest acked (HA) < highest sent (HS).
- UNICAST3.SenderEntry - Class in org.jgroups.protocols
-
- UNICAST3.State - Enum in org.jgroups.protocols
-
- UnicastHeader() - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- UnicastHeader(byte, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- UnicastHeader(byte, long, short, boolean) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
-
Deprecated.
- UnicastRequest<T> - Class in org.jgroups.blocks
-
Sends a request to a single target destination
- UnicastRequest(RequestCorrelator, Address, RequestOptions) - Constructor for class org.jgroups.blocks.UnicastRequest
-
- unicasts - Variable in class org.jgroups.protocols.MAKE_BATCH
-
- unicasts(boolean) - Method in class org.jgroups.protocols.MAKE_BATCH
-
- unicasts(boolean) - Method in class org.jgroups.util.RpcStats
-
- uninstallRule(String) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- unknownForkHandler - Variable in class org.jgroups.fork.ForkProtocolStack
-
- UnknownForkHandler - Interface in org.jgroups.fork
-
Allows a user of fork to define the handling of a message for which no fork stack or fork channel exists.
- unknownMember(Address, Object) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- unlock() - Method in class org.jgroups.blocks.locking.LockService.LockImpl
-
Releases a lock.
- UNLOCK - Static variable in class org.jgroups.Event
-
- unlock() - Method in class org.jgroups.protocols.ENCRYPT.Decrypter
-
Deprecated.
- unlock() - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
- unlock() - Method in class org.jgroups.protocols.Locking.ClientLock
-
- UNLOCK_ALL - Static variable in class org.jgroups.Event
-
- unlockAll() - Method in class org.jgroups.blocks.locking.LockService
-
- unlockAll() - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- unlockAll() - Method in class org.jgroups.protocols.Locking
-
- unlocked(String, Owner) - Method in interface org.jgroups.blocks.locking.LockNotification
-
- unlocked(String, Owner) - Method in class org.jgroups.demos.LockServiceDemo
-
- unlocked(String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- unmarshal(byte[], int, int) - Method in class org.jgroups.protocols.FD_SOCK
-
- unparkIfNeeded(long) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- unparking - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
-
- unparking - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
-
- UNREACHABLE - Static variable in class org.jgroups.util.Rsp
-
If true, the sender (below) could not be reached, e.g.
- UnreachableException - Exception in org.jgroups
-
Thrown if member in different site cannot be contacted; used by RELAY2
- UnreachableException(Address) - Constructor for exception org.jgroups.UnreachableException
-
- UnreachableException(String, Address) - Constructor for exception org.jgroups.UnreachableException
-
- unregister(Object, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- unregister(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Unregisters object_name and everything under it
- unregister(AUTH.UpHandler) - Method in class org.jgroups.protocols.AUTH
-
- unregister(EventHandler) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- unregister(AsciiString, Address) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
-
- unregisterChannel(MBeanServer, ObjectName) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- unregisterChannel(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- unregisterChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- unregisterChannel(JChannel, MBeanServer, String, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
- unregisterProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
-
- unregisterProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.protocols.TP
-
- unregisterProbeHandler(DiagnosticsHandler.ProbeHandler) - Method in class org.jgroups.stack.DiagnosticsHandler
-
- unregisterStub(IpAddress) - Method in class org.jgroups.stack.RouterStubManager
-
- unsetThreadNames() - Method in class org.jgroups.protocols.TP
-
- unsubscribe(String) - Method in class org.jgroups.client.StompConnection
-
- Unsupported - Annotation Type in org.jgroups.annotations
-
Elements annotated with this annotation are unsupported and may get removed from the distribution at any time
- UNSUSPECT - Static variable in class org.jgroups.Event
-
- UNSUSPECT - Static variable in class org.jgroups.protocols.FD.FdHeader
-
- unsuspect(Address) - Method in class org.jgroups.protocols.FD
-
- unsuspect(Address) - Method in class org.jgroups.protocols.FD_ALL
-
Removes mbr from suspected_mbrs and sends a UNSUSPECT event up and down the stack
- unsuspect(Address) - Method in class org.jgroups.protocols.FD_ALL2
-
Removes mbr from suspected_mbrs and sends a UNSUSPECT event up and down the stack
- unsuspect(Address) - Method in class org.jgroups.protocols.FD_HOST
-
- UNSUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
-
- unsuspect(Address) - Method in class org.jgroups.protocols.FD_SOCK
-
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
Removes previously suspected member from list of currently suspected members
- unsuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- unwrap(byte[], int, int) - Method in class org.jgroups.auth.sasl.SaslClientContext
-
- unwrap(byte[], int, int) - Method in interface org.jgroups.auth.sasl.SaslContext
-
- unwrap(byte[], int, int) - Method in class org.jgroups.auth.sasl.SaslServerContext
-
- unwrapAndDeliver(Message, boolean) - Method in class org.jgroups.protocols.SEQUENCER
-
Unmarshal the original message (in the payload) and then pass it up (unless already delivered)
- up(Event) - Method in class org.jgroups.blocks.mux.MuxUpHandler
-
Invoked for all channel events except connection management and state transfer.
- up(Event) - Method in class org.jgroups.fork.ForkProtocolStack
-
- up(MessageBatch) - Method in class org.jgroups.fork.ForkProtocolStack
-
- up(Event) - Method in class org.jgroups.JChannel
-
Callback method
Called by the ProtocolStack when a message is received.
- up(MessageBatch) - Method in class org.jgroups.JChannel
-
Callback invoked by the protocol stack to deliver a message batch
- up(Event) - Method in class org.jgroups.protocols.ABP
-
- up(Event) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- up(MessageBatch) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
- up(Event) - Method in class org.jgroups.protocols.AUTH
-
An event was received from the layer below.
- up(MessageBatch) - Method in class org.jgroups.protocols.AUTH
-
- up(Event) - Method in class org.jgroups.protocols.BARRIER
-
- up(MessageBatch) - Method in class org.jgroups.protocols.BARRIER
-
- up(Event) - Method in class org.jgroups.protocols.COMPRESS
-
If there is no header, we pass the message up.
- up(MessageBatch) - Method in class org.jgroups.protocols.COMPRESS
-
- up(Event) - Method in class org.jgroups.protocols.COUNTER
-
- up(Event) - Method in class org.jgroups.protocols.DAISYCHAIN
-
- up(MessageBatch) - Method in class org.jgroups.protocols.DAISYCHAIN
-
- up(Event) - Method in class org.jgroups.protocols.DELAY
-
- up(MessageBatch) - Method in class org.jgroups.protocols.DELAY
-
- up(Event) - Method in class org.jgroups.protocols.DELIVERY_TIME
-
- up(MessageBatch) - Method in class org.jgroups.protocols.DELIVERY_TIME
-
- up - Variable in class org.jgroups.protocols.DISCARD
-
- up(Event) - Method in class org.jgroups.protocols.DISCARD
-
- up(MessageBatch) - Method in class org.jgroups.protocols.DISCARD
-
- up(Event) - Method in class org.jgroups.protocols.Discovery
-
- up(Event) - Method in class org.jgroups.protocols.DUPL
-
- up(MessageBatch) - Method in class org.jgroups.protocols.DUPL
-
- up(Event) - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.ENCRYPT
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.EncryptBase
-
- up(MessageBatch) - Method in class org.jgroups.protocols.EncryptBase
-
- up(Event) - Method in class org.jgroups.protocols.EXAMPLE
-
- up(MessageBatch) - Method in class org.jgroups.protocols.EXAMPLE
-
- up(Event) - Method in class org.jgroups.protocols.Executing
-
- up(Event) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.FC
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.FD
-
- up(MessageBatch) - Method in class org.jgroups.protocols.FD
-
- up(Event) - Method in class org.jgroups.protocols.FD_ALL
-
- up(MessageBatch) - Method in class org.jgroups.protocols.FD_ALL
-
- up(Event) - Method in class org.jgroups.protocols.FD_ALL2
-
- up(MessageBatch) - Method in class org.jgroups.protocols.FD_ALL2
-
- up(Event) - Method in class org.jgroups.protocols.FD_SOCK
-
- up(Event) - Method in class org.jgroups.protocols.FlowControl
-
- up(MessageBatch) - Method in class org.jgroups.protocols.FlowControl
-
- up(Event) - Method in class org.jgroups.protocols.FORK
-
- up(MessageBatch) - Method in class org.jgroups.protocols.FORK
-
- up(Event) - Method in class org.jgroups.protocols.FORWARD_TO_COORD
-
- up(Event) - Method in class org.jgroups.protocols.FRAG
-
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
- up(MessageBatch) - Method in class org.jgroups.protocols.FRAG
-
- up(Event) - Method in class org.jgroups.protocols.FRAG2
-
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
- up(MessageBatch) - Method in class org.jgroups.protocols.FRAG2
-
- up(Event) - Method in class org.jgroups.protocols.HDRS
-
- up(MessageBatch) - Method in class org.jgroups.protocols.HDRS
-
- up(Event) - Method in class org.jgroups.protocols.Locking
-
- up(Event) - Method in class org.jgroups.protocols.MAKE_BATCH
-
- up(Event) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.MERGE2
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.MERGE3
-
- up(Event) - Method in class org.jgroups.protocols.MPING
-
- up(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.FLUSH
-
- up(Event) - Method in class org.jgroups.protocols.pbcast.GMS
-
- up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.
Callback.
- up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Callback.
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
- up(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
-
- up(MessageBatch) - 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.protocols.pbcast.StreamingStateTransfer
-
- up(Event) - Method in class org.jgroups.protocols.PERF
-
- up(MessageBatch) - Method in class org.jgroups.protocols.PERF
-
- up(Event) - Method in class org.jgroups.protocols.PRIO
-
An event was received from the layer below.
- up(MessageBatch) - Method in class org.jgroups.protocols.PRIO
-
- up(Event) - Method in class org.jgroups.protocols.relay.RELAY2
-
- up(MessageBatch) - Method in class org.jgroups.protocols.relay.RELAY2
-
- up(Event) - Method in class org.jgroups.protocols.RELAY
-
- up(MessageBatch) - Method in class org.jgroups.protocols.RELAY
-
- up(Event) - Method in class org.jgroups.protocols.RSVP
-
- up(MessageBatch) - Method in class org.jgroups.protocols.RSVP
-
- up(Event) - Method in interface org.jgroups.protocols.rules.EventHandler
-
Called when an up event is received
- up(Event) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- up(MessageBatch) - Method in class org.jgroups.protocols.rules.SUPERVISOR
-
- up(Event) - Method in class org.jgroups.protocols.SASL
-
- up(MessageBatch) - Method in class org.jgroups.protocols.SASL
-
- up(Event) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.SCOPE
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.SEQUENCER
-
- up(MessageBatch) - Method in class org.jgroups.protocols.SEQUENCER
-
- up(Event) - Method in class org.jgroups.protocols.SEQUENCER2
-
- up(MessageBatch) - Method in class org.jgroups.protocols.SEQUENCER2
-
- up - Variable in class org.jgroups.protocols.SHUFFLE
-
- up(Event) - Method in class org.jgroups.protocols.SHUFFLE
-
- up(MessageBatch) - Method in class org.jgroups.protocols.SHUFFLE
-
- up(Event) - Method in class org.jgroups.protocols.SIZE
-
- up(MessageBatch) - Method in class org.jgroups.protocols.SIZE
-
- up(Event) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- up(Event) - Method in class org.jgroups.protocols.STATS
-
- up(MessageBatch) - Method in class org.jgroups.protocols.STATS
-
- up(Event) - Method in class org.jgroups.protocols.STOMP
-
- up(MessageBatch) - Method in class org.jgroups.protocols.STOMP
-
- up(Event) - Method in class org.jgroups.protocols.tom.TOA
-
- up(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
-
- up(MessageBatch) - 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(MessageBatch) - Method in class org.jgroups.protocols.TRACE
-
- up(Event) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.UNICAST
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- up(MessageBatch) - Method in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- up(Event) - Method in class org.jgroups.protocols.UNICAST3
-
- up(MessageBatch) - Method in class org.jgroups.protocols.UNICAST3
-
- up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
- up(Event) - Method in class org.jgroups.stack.Protocol
-
An event was received from the layer below.
- up(MessageBatch) - Method in class org.jgroups.stack.Protocol
-
- up(Event) - Method in class org.jgroups.stack.ProtocolStack
-
- up(MessageBatch) - 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_handlers - Variable in class org.jgroups.protocols.AUTH
-
List of UpHandler which are called when an up event has been received.
- up_msgs - Variable in class org.jgroups.protocols.SHUFFLE
-
- up_prot - Variable in class org.jgroups.stack.Protocol
-
- up_prot - Variable in class org.jgroups.util.ForwardQueue
-
- up_prots - Variable in class org.jgroups.protocols.TP
-
If singleton_name is enabled, this map is used to de-multiplex incoming messages according to their cluster
names (attached to the message by the transport anyway).
- up_queue - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- update(Graphics) - Method in class org.jgroups.demos.wb.GraphPanel
-
- update - Variable in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
-
- update(Address) - Method in class org.jgroups.protocols.FD_ALL
-
- update(Address) - Method in class org.jgroups.protocols.FD_ALL2
-
- update(long) - Method in class org.jgroups.protocols.tom.SequenceNumberManager
-
updates the sequence number to the maximum between them
- update() - Method in class org.jgroups.protocols.UNICAST2.SenderEntry
-
Deprecated.
- update(UNICAST3.Entry, int) - Method in class org.jgroups.protocols.UNICAST3
-
- update(RpcStats.Type, boolean) - Method in class org.jgroups.util.RpcStats
-
- update() - Method in class org.jgroups.util.SuppressCache.Value
-
- updateAndGet(long) - Method in class org.jgroups.protocols.tom.SequenceNumberManager
-
updates the sequence number and returns the next, that will be used a propose sequence number
- updateBackups(Executing.Type, Executing.Owner) - Method in class org.jgroups.protocols.CENTRAL_EXECUTOR
-
- updateBackups(Locking.Type, String, Owner) - Method in class org.jgroups.protocols.CENTRAL_LOCK
-
- updateBackups(String, long, long) - Method in class org.jgroups.protocols.COUNTER
-
- updateIfBigger(long, long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
-
Sets the value only if the version argument is greater than the own version
- updateLastAccessed() - Method in class org.jgroups.blocks.cs.NioConnection
-
- updateLastAccessed() - Method in class org.jgroups.blocks.cs.TcpConnection
-
- updateLastTimestamp(long) - Method in class org.jgroups.protocols.UNICAST3.SenderEntry
-
Updates last_timestamp.
- updateLocalDigest(Digest, Address) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Update my own digest from a digest received by somebody else.
- UpdateRequest() - Constructor for class org.jgroups.protocols.COUNTER.UpdateRequest
-
- UpdateRequest(String, long, long) - Constructor for class org.jgroups.protocols.COUNTER.UpdateRequest
-
- updateSequenceNumber(long) - Method in class org.jgroups.protocols.tom.DeliveryManagerImpl
-
- updateTimestamp(Address) - Method in class org.jgroups.protocols.FD
-
- updateTimestampFor(InetAddress) - Method in class org.jgroups.protocols.FD_HOST
-
- UpHandler - Interface in org.jgroups
-
Provides a hook to hijack over all events received by a certain channel which has installed this
UpHandler.
- URL_SAFE - Static variable in class org.jgroups.util.Base64
-
- use_adler - Variable in class org.jgroups.protocols.EncryptBase
-
- use_anycast_addresses - Variable in class org.jgroups.blocks.RequestOptions
-
If use_anycasting is true: do we want to use an AnycastAddress [B,C] or a unicast to B and another unicast
to C to send an anycast to {B,C} ? Only used if use_anycasting is true
- use_anycasting - Variable in class org.jgroups.blocks.RequestOptions
-
Turns on anycasting; this results in multiple unicasts rather than a multicast for group calls
- use_delta_views - Variable in class org.jgroups.protocols.pbcast.GMS
-
- use_disk_cache - Variable in class org.jgroups.protocols.Discovery
-
- use_external_key_exchange - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
-
- USE_FLUSH - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- use_flush_if_present - Variable in class org.jgroups.protocols.pbcast.GMS
-
- use_gui - Variable in class org.jgroups.protocols.DISCARD
-
- use_icmp - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
- USE_JDK_LOGGER - Static variable in class org.jgroups.Global
-
- use_jdk_logger - Static variable in class org.jgroups.logging.LogFactory
-
- use_mcast_rsps - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
- use_mcast_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Retransmit messages using multicast rather than unicast.
- use_mcast_xmit_req - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Use a multicast to request retransmission of missing messages.
- use_nio - Variable in class org.jgroups.protocols.TCPGOSSIP
-
- use_nio - Variable in class org.jgroups.protocols.TUNNEL
-
- use_nio - Variable in class org.jgroups.stack.GossipRouter
-
- use_nio - Variable in class org.jgroups.stack.RouterStub
-
- use_nio - Variable in class org.jgroups.stack.RouterStubManager
-
- use_numbering - Variable in class org.jgroups.util.DefaultThreadFactory
-
- use_peer_connections - Variable in class org.jgroups.blocks.cs.BaseServer
-
- use_range_based_retransmitter - Variable in class org.jgroups.protocols.UNICAST2
-
Deprecated.
- use_send_queues - Variable in class org.jgroups.blocks.cs.TcpBaseServer
-
- use_send_queues - Variable in class org.jgroups.protocols.BasicTCP
-
Deprecated.
- use_ssl - Variable in class org.jgroups.protocols.S3_PING
-
- use_thread_id_for_lock_owner - Variable in class org.jgroups.protocols.CENTRAL_LOCK
-
- use_time_service - Variable in class org.jgroups.protocols.FD_ALL
-
- use_time_service - Variable in class org.jgroups.protocols.FD_HOST
-
- use_timeout - Variable in class org.jgroups.blocks.locking.LockInfo
-
- useAnycastAddresses() - Method in class org.jgroups.blocks.RequestOptions
-
- useAnycastAddresses(boolean) - Method in class org.jgroups.blocks.RequestOptions
-
- useAsyncStateDelivery() - Method in class org.jgroups.protocols.pbcast.STATE
-
- useAsyncStateDelivery() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
- useDiskCache() - Method in class org.jgroups.protocols.Discovery
-
- useDiskCache(boolean) - Method in class org.jgroups.protocols.Discovery
-
- useFlushIfPresent - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- useJdkLogger() - Static method in class org.jgroups.logging.LogFactory
-
- useJdkLogger(boolean) - Static method in class org.jgroups.logging.LogFactory
-
- useNio() - Method in class org.jgroups.stack.GossipRouter
-
- useNio(boolean) - Method in class org.jgroups.stack.GossipRouter
-
- useNio() - Method in class org.jgroups.stack.RouterStub
-
- useNio(boolean) - Method in class org.jgroups.stack.RouterStubManager
-
- usePeerConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
- usePeerConnections(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
-
- USER - Static variable in class org.jgroups.demos.StompChat
-
- USER_DEFINED - Static variable in class org.jgroups.Event
-
- USER_JOINED - Static variable in class org.jgroups.demos.StompChat
-
- USER_LEFT - Static variable in class org.jgroups.demos.StompChat
-
- userid - Variable in class org.jgroups.client.StompConnection
-
- UserInfoDialog - Class in org.jgroups.demos.wb
-
- UserInfoDialog(Frame) - Constructor for class org.jgroups.demos.wb.UserInfoDialog
-
- username - Variable in class org.jgroups.demos.StompChat
-
- username - Variable in class org.jgroups.protocols.RACKSPACE_PING
-
- username - Variable in class org.jgroups.protocols.SWIFT_PING
-
- users - Variable in class org.jgroups.demos.StompChat
-
- USERS - Static variable in class org.jgroups.demos.StompChat
-
- USERS_KW - Static variable in class org.jgroups.demos.StompChat
-
- usesDefaultConverter(Field) - Static method in class org.jgroups.conf.PropertyHelper
-
- useSendQueues() - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- useSendQueues(boolean) - Method in class org.jgroups.blocks.cs.TcpBaseServer
-
- usingPreSignedUrls() - Method in class org.jgroups.protocols.S3_PING
-
- 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
-
- Util.AddressScope - Enum in org.jgroups.util
-
- UUID - Class in org.jgroups.util
-
Logical address which is unique over space and time.
- UUID() - Constructor for class org.jgroups.util.UUID
-
- UUID(long, long) - Constructor for class org.jgroups.util.UUID
-
- UUID(byte[]) - Constructor for class org.jgroups.util.UUID
-
Private constructor which uses a byte array to construct the new UUID
- UUID_ADDR - Static variable in interface org.jgroups.Address
-
- UUID_CACHE_MAX_AGE - Static variable in class org.jgroups.Global
-
- UUID_CACHE_MAX_ELEMENTS - Static variable in class org.jgroups.Global
-
- uuids - Variable in class org.jgroups.protocols.RELAY.ViewData
-
- val - Variable in class org.jgroups.blocks.LazyRemovalCache.Entry
-
- val - Variable in class org.jgroups.util.AsciiString
-
- validate(long) - Static method in class org.jgroups.util.RingBufferSeqnoLockless
-
- validateArgs(Address, T) - Method in class org.jgroups.blocks.cs.BaseServer
-
- validateBindAddressFromInterface(InetAddress, String) - Static method in class org.jgroups.util.Util
-
Method used by PropertyConverters.BindInterface to check that a bind_address is
consistent with a specified interface
Idea:
1.
- validateProperties() - Method in class org.jgroups.protocols.S3_PING
-
- validateSecurityContext(Subject, byte[]) - Static method in class org.jgroups.auth.Krb5TokenUtils
-
- Value(V, long) - Constructor for class org.jgroups.blocks.Cache.Value
-
- Value() - Constructor for class org.jgroups.blocks.Cache.Value
-
- value - Variable in class org.jgroups.blocks.executor.ExecutionRunner.Holder
-
- Value(V, short) - Constructor for class org.jgroups.blocks.ReplCache.Value
-
- value() - Method in enum org.jgroups.Message.Flag
-
- value() - Method in enum org.jgroups.Message.TransientFlag
-
- value - Variable in class org.jgroups.protocols.COUNTER.SetRequest
-
- value - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
-
- value - Variable in class org.jgroups.protocols.COUNTER.VersionedValue
-
- value - Variable in class org.jgroups.util.Rsp
-
The value from the response (or the exception)
- Value() - Constructor for class org.jgroups.util.SuppressCache.Value
-
- valueOf(String) - Static method in enum org.jgroups.annotations.XmlInclude.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.blocks.cs.NioConnection.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.blocks.MemcachedConnector.Request.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.blocks.ResponseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.Channel.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.Message.Flag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.Message.TransientFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.ABP.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.COUNTER.RequestType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.COUNTER.ResponseType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.DUPL.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.Executing.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.Locking.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.MERGE3.MergeHeader.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.RELAY.RelayHeader.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.SaslHeader.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.SSL_KEY_EXCHANGE.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.ClientVerb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.ServerVerb
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.STOMP.StompHeader.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.UNICAST3.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.stack.GossipType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.MessageBatch.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.RpcStats.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.StackType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.SuppressLog.Level
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.TimeScheduler3.TaskType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.Util.AddressScope
-
Returns the enum constant of this type with the specified name.
- ValueResponse() - Constructor for class org.jgroups.protocols.COUNTER.ValueResponse
-
- ValueResponse(Owner, long, long) - Constructor for class org.jgroups.protocols.COUNTER.ValueResponse
-
- values() - Static method in enum org.jgroups.annotations.XmlInclude.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.blocks.cs.NioConnection.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- values() - Static method in enum org.jgroups.blocks.MemcachedConnector.Request.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- values() - Static method in enum org.jgroups.blocks.ResponseMode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.Channel.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.Message.Flag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.Message.TransientFlag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.ABP.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- values - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- values() - Static method in enum org.jgroups.protocols.COUNTER.RequestType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.COUNTER.ResponseType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.DUPL.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.Executing.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.jgroups.protocols.Locking.ClientLockTable
-
- values() - Static method in enum org.jgroups.protocols.Locking.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.MERGE3.MergeHeader.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.RELAY.RelayHeader.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.SaslHeader.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.SSL_KEY_EXCHANGE.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.STOMP.ClientVerb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.STOMP.ServerVerb
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.STOMP.StompHeader.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.protocols.UNICAST3.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.stack.GossipType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values - Variable in class org.jgroups.util.ExtendedUUID
-
- values() - Static method in enum org.jgroups.util.MessageBatch.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.jgroups.util.Queue
-
Returns all the elements of the queue
- values() - Static method in enum org.jgroups.util.RpcStats.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.jgroups.util.RspList
-
- values() - Static method in enum org.jgroups.util.StackType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.util.SuppressLog.Level
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.util.TimeScheduler3.TaskType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.jgroups.util.Util.AddressScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesIterator() - Method in class org.jgroups.blocks.LazyRemovalCache
-
- verbose - Variable in class org.jgroups.util.MyReceiver
-
- verbose(boolean) - Method in class org.jgroups.util.MyReceiver
-
- verify(SSLSession) - Method in class org.jgroups.protocols.CertficateCNMatcher
-
- verify(SSLSession) - Method in interface org.jgroups.protocols.SSL_KEY_EXCHANGE.SessionVerifier
-
Called to verify that the session is correct, e.g.
- VERIFY_SUSPECT - Class in org.jgroups.protocols
-
Catches SUSPECT events traveling up the stack.
- VERIFY_SUSPECT() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT
-
- VERIFY_SUSPECT.Entry - Class in org.jgroups.protocols
-
- VERIFY_SUSPECT.VerifyHeader - Class in org.jgroups.protocols
-
- verifyconfigurationParameters() - Method in class org.jgroups.protocols.JDBC_PING
-
- VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
-
- version - Variable in class org.jgroups.protocols.COUNTER.SimpleResponse
-
- version - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
-
- version - Variable in class org.jgroups.protocols.COUNTER.VersionedValue
-
- version - Variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
-
Deprecated.
- version() - Method in class org.jgroups.protocols.EncryptBase
-
- version - Variable in class org.jgroups.protocols.EncryptHeader
-
- version() - Method in class org.jgroups.protocols.EncryptHeader
-
- Version - Class in org.jgroups
-
We're using the scheme described at http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
for major, minor and micro version numbers.
- Version() - Constructor for class org.jgroups.Version
-
- version - Static variable in class org.jgroups.Version
-
- VERSION_FILE - Static variable in class org.jgroups.Version
-
- VERSION_PROPERTY - Static variable in class org.jgroups.Version
-
- VersionedValue(long) - Constructor for class org.jgroups.protocols.COUNTER.VersionedValue
-
- VersionedValue(long, long) - Constructor for class org.jgroups.protocols.COUNTER.VersionedValue
-
- versionMatch(short, Address) - Method in class org.jgroups.protocols.TP
-
- versions - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
-
- versions - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
-
- view - Variable in class org.jgroups.blocks.RequestCorrelator
-
- view - Variable in class org.jgroups.demos.RelayDemoRpc
-
- VIEW - Static variable in class org.jgroups.demos.StompChat
-
- view - Variable in class org.jgroups.protocols.COUNTER
-
- view - Variable in class org.jgroups.protocols.Discovery
-
- view - Variable in class org.jgroups.protocols.EncryptBase
-
- view - Variable in class org.jgroups.protocols.Executing
-
- view - Variable in class org.jgroups.protocols.Locking
-
- view - Variable in class org.jgroups.protocols.MERGE2.MergeHeader
-
Deprecated.
- view - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- view - Variable in class org.jgroups.protocols.MERGE3
-
- VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- view - Variable in class org.jgroups.protocols.pbcast.GMS
-
- view() - Method in class org.jgroups.protocols.pbcast.GMS
-
- view - Variable in class org.jgroups.protocols.pbcast.JoinRsp
-
- view - Variable in class org.jgroups.protocols.pbcast.MergeData
-
- view - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
- view - Variable in class org.jgroups.protocols.pbcast.STABLE
-
- view - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
- view - Variable in class org.jgroups.protocols.relay.Relayer.Bridge
-
- view - Variable in class org.jgroups.protocols.rules.SUPERVISOR
-
- view - Variable in class org.jgroups.protocols.SEQUENCER
-
- view - Variable in class org.jgroups.protocols.SEQUENCER2
-
- view - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
- view - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
-
- view - Variable in class org.jgroups.protocols.STOMP
-
- view - Variable in class org.jgroups.protocols.TP
-
- view() - Method in class org.jgroups.protocols.TP
-
- View - Class in org.jgroups
-
A view is a local representation of the current membership of a group.
- View() - Constructor for class org.jgroups.View
-
Creates an empty view, should not be used, only used by (de-)serialization
- View(ViewId, Collection<Address>) - Constructor for class org.jgroups.View
-
Creates a new view
- View(ViewId, Address[]) - Constructor for class org.jgroups.View
-
Creates a new view.
- View(Address, long, List<Address>) - Constructor for class org.jgroups.View
-
Creates a new view
- VIEW_ACK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
- view_ack_collection_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
-
- view_bundling - Variable in class org.jgroups.protocols.pbcast.GMS
-
Whether view bundling (http://jira.jboss.com/jira/browse/JGRP-144) should be enabled or not.
- VIEW_CHANGE - Static variable in class org.jgroups.Event
-
- view_consistency_checker - Variable in class org.jgroups.protocols.MERGE3
-
- view_handler - Variable in class org.jgroups.protocols.pbcast.GMS
-
Class to process JOIN, LEAVE and MERGE requests
- view_id - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
-
- view_id - Variable in class org.jgroups.protocols.pbcast.STABLE.StabilitySendTask
-
- view_id - Variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
-
- view_id - Variable in class org.jgroups.View
-
A view is uniquely identified by its ViewID.
- VIEW_PRESENT - Static variable in class org.jgroups.protocols.pbcast.GMS
-
- VIEW_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
-
only set if JOIN failed, e.g.
- view_rsps - Variable in class org.jgroups.protocols.MERGE3
-
- view_size - Variable in class org.jgroups.protocols.DAISYCHAIN
-
- viewAccepted(View) - Method in class org.jgroups.blocks.PartitionedHashMap.ConsistentHashFunction
-
- viewAccepted(View) - Method in class org.jgroups.blocks.PartitionedHashMap
-
- viewAccepted(View) - Method in class org.jgroups.blocks.ReplCache
-
- viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
- viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedTree
-
- viewAccepted(View) - Method in class org.jgroups.demos.Chat
-
- viewAccepted(View) - Method in class org.jgroups.demos.Draw
-
- viewAccepted(View) - Method in class org.jgroups.demos.QuoteClient
-
- viewAccepted(View) - Method in class org.jgroups.demos.QuoteServer
-
- viewAccepted(View) - Method in class org.jgroups.demos.RelayDemoRpc
-
- viewAccepted(View) - Method in class org.jgroups.demos.ViewDemo
-
- viewAccepted(View) - Method in class org.jgroups.demos.wb.Whiteboard
-
- viewAccepted(View) - Method in interface org.jgroups.MembershipListener
-
Called when a change in membership has occurred.
- viewAccepted(View) - Method in class org.jgroups.protocols.RELAY.Receiver
-
- viewAccepted(View) - Method in class org.jgroups.protocols.relay.Relayer.Bridge
-
The view contains a list of SiteUUIDs.
- viewAccepted(View) - Method in class org.jgroups.ReceiverAdapter
-
Called when a change in membership has occurred.
- viewChange(View) - Method in class org.jgroups.blocks.GroupRequest
-
Any member of 'membership' that is not in the new view is flagged as
SUSPECTED.
- viewChange(View, List<Address>, List<Address>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
-
- viewChange(View) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
-
- viewChange(View) - Method in class org.jgroups.blocks.Request
-
- viewChange(View) - Method in class org.jgroups.blocks.UnicastRequest
-
If the target address is not a member of the new view, we'll mark the response as not received and unblock
the caller of execute()
- viewChange(View, List<Address>, List<Address>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
-
- viewChange(View) - Method in class org.jgroups.protocols.BaseBundler
-
- viewChange(View) - Method in interface org.jgroups.protocols.Bundler
-
- viewChange(View) - Method in class org.jgroups.protocols.NoBundler
-
- ViewConsistencyChecker() - Constructor for class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
-
- ViewData() - Constructor for class org.jgroups.protocols.RELAY.ViewData
-
- ViewDemo - Class in org.jgroups.demos
-
Demos the reception of views using a PullPushAdapter.
- ViewDemo() - Constructor for class org.jgroups.demos.ViewDemo
-
- viewID - Variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
-
- ViewId - Class in org.jgroups
-
ViewIds are used for ordering views (each view has a ViewId and a list of members).
- ViewId() - Constructor for class org.jgroups.ViewId
-
- ViewId(Address) - Constructor for class org.jgroups.ViewId
-
Creates a ViewID with the coordinator address and a Lamport timestamp of 0.
- ViewId(Address, long) - Constructor for class org.jgroups.ViewId
-
Creates a ViewID with the coordinator address and the given Lamport timestamp.
- views - Variable in class org.jgroups.protocols.MERGE2
-
Deprecated.
- views - Variable in class org.jgroups.protocols.MERGE3
-
- visit(Message, MessageBatch) - Method in class org.jgroups.protocols.ENCRYPT.Decrypter
-
Deprecated.
- visit(Message, MessageBatch) - Method in class org.jgroups.protocols.EncryptBase.Decrypter
-
- visit(long, Message, int, int) - Method in class org.jgroups.protocols.pbcast.NAKACK2.Counter
-
- visit(Message, MessageBatch) - Method in interface org.jgroups.util.MessageBatch.Visitor
-
Called when iterating over the message batch
- visit(T) - Method in interface org.jgroups.util.RequestTable.Visitor
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Counter
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Dump
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Getter
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.HighestDeliverable
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Missing
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Remover
-
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.RemoverOnAdd
-
- visit(long, T, int, int) - Method in interface org.jgroups.util.Table.Visitor
-
- votes - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Keeps track of who we already heard from (STABLE_GOSSIP msgs).