A B C D E F G H I J K L M N O P Q R S T U V W X Y _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- A - org.jgroups.protocols.dns.DNSResolver.DNSRecordType
- ABNORMAL_TERMINATION - Static variable in class org.jgroups.protocols.FD_SOCK
- ABORT - org.jgroups.protocols.STOMP.ClientVerb
- ABOVE - org.jgroups.stack.ProtocolStack.Position
- 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. - acceptor - Variable in class org.jgroups.blocks.cs.NioBaseServer
- acceptor - Variable in class org.jgroups.blocks.cs.TcpServer
- acceptor - Variable in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
- acceptor - Variable in class org.jgroups.protocols.SimpleTCP
- acceptor - Variable in class org.jgroups.protocols.STOMP
- Acceptor() - Constructor for class org.jgroups.blocks.cs.NioBaseServer.Acceptor
- Acceptor() - Constructor for class org.jgroups.blocks.cs.TcpServer.Acceptor
- Acceptor(InetAddress, int) - Constructor for class org.jgroups.protocols.SimpleTCP.Acceptor
- acceptorDone() - Method in class org.jgroups.blocks.cs.NioBaseServer
- acceptorDone() - Method in class org.jgroups.blocks.cs.NioServer
- acceptorRunning() - Method in class org.jgroups.blocks.cs.NioBaseServer
- accumulate(ToIntFunction<Table<Message>>, Collection<? extends UNICAST3.Entry>...) - Static method in class org.jgroups.protocols.UNICAST3
- 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(Collection<Address>) - Method in class org.jgroups.util.AckCollector
- ack(Address) - Method in class org.jgroups.protocols.RSVP.Entry
- ack(Address) - Method in class org.jgroups.util.AckCollector
- ack(Address...) - Method in class org.jgroups.util.AckCollector
- ack(Address, long) - Method in class org.jgroups.util.AckTable
-
Adds an ACK from a sender to the map.
- ACK - org.jgroups.protocols.STOMP.ClientVerb
- ACK - Static variable in class org.jgroups.protocols.NakAckHeader
- ACK - Static variable in class org.jgroups.protocols.UnicastHeader3
- 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_table - Variable in class org.jgroups.protocols.NAKACK4
- 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
- ackOnDelivery() - Method in class org.jgroups.protocols.RSVP
- ackOnDelivery(boolean) - Method in class org.jgroups.protocols.RSVP
- acks - Variable in class org.jgroups.util.AckTable
- acks_received - Variable in class org.jgroups.protocols.NAKACK4
- AckTable - Class in org.jgroups.util
-
Manages ACKs from receivers in
NAKACK4
- AckTable() - Constructor for class org.jgroups.util.AckTable
- action - Variable in class org.jgroups.util.Delayer.Entry
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Draw
- 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.protocols.DISCARD.DiscardDialog
- add(boolean, long) - Method in class org.jgroups.util.RpcStats.Result
- add(byte, Class<?>) - Static method in class org.jgroups.util.Util
- add(int, int) - Static method in class org.jgroups.demos.JmxDemo
- add(long) - Method in class org.jgroups.util.Average
- add(long) - Method in class org.jgroups.util.AverageMinMax
- 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.Buffer
-
Adds an element if the element at the given index is null.
- add(long, T) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- add(long, T) - Method in class org.jgroups.util.RingBufferSeqnoOld
- 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, boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Adds a new element to the buffer
- add(long, T, boolean) - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Adds a new element to the buffer
- add(long, T, Predicate<T>) - Method in class org.jgroups.util.Table
-
Adds an element if the element at the given index is null.
- add(long, T, Predicate<T>, Buffer.Options) - Method in class org.jgroups.util.Buffer
-
Adds an element if the element at the given index is null.
- add(long, T, Predicate<T>, Buffer.Options) - Method in class org.jgroups.util.DynamicBuffer
-
Adds an element if the element at the given index is null.
- add(long, T, Predicate<T>, Buffer.Options) - Method in class org.jgroups.util.FixedBuffer
-
Adds a new element to the buffer
- 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(ByteBuffer) - Method in class org.jgroups.nio.Buffers
-
Adds a buffer.
- add(ByteBuffer...) - Method in class org.jgroups.nio.Buffers
-
Adds a number of buffers.
- add(Collection<Long>) - Method in class org.jgroups.util.SeqnoList
- add(Collection<Address>) - Method in class org.jgroups.Membership
-
Adds a list of members to this membership
- add(Collection<Message>) - Method in class org.jgroups.util.MessageBatch
- add(Collection<R>) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- add(Collection<T>) - Method in class org.jgroups.util.FastArray
- add(LongAdder, int, LongAdder, int) - Method in class org.jgroups.protocols.MsgStats
- add(List<Message>, Message, Lock, Consumer<Message>) - Method in class org.jgroups.protocols.SHUFFLE
- add(List<Message>, MessageBatch, Lock, Consumer<Message>) - Method in class org.jgroups.protocols.SHUFFLE
- add(List<LongTuple<T>>) - Method in class org.jgroups.util.Table
-
Adds elements from list to the table
- add(List<LongTuple<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<LongTuple<T>>, boolean, T) - Method in class org.jgroups.util.Table
-
Adds elements from the list to the table
- add(Map<Address, String>) - Static method in class org.jgroups.util.NameCache
- add(Set<String>, SiteStatus.Status) - Method in class org.jgroups.protocols.relay.SiteStatus
-
Adds a set of sites to the cache.
- add(K) - Method in class org.jgroups.util.AgeOutCache
- add(K, V) - Method in class org.jgroups.blocks.LazyRemovalCache
- add(K, V) - Method in class org.jgroups.util.BoundedHashMap
- add(K, V, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
- add(Address) - Method in class org.jgroups.Membership
-
Adds a new member to this membership.
- add(Address...) - Method in class org.jgroups.Membership
- add(Address, String) - Static method in class org.jgroups.util.NameCache
- add(Address, Message) - Method in class org.jgroups.util.MessageCache
- add(Address, T) - Method in class org.jgroups.util.ResponseCollector
- add(Address, T) - Method in class org.jgroups.util.ResponseCollectorTask
- add(Message) - Method in class org.jgroups.BatchMessage
-
Adds the message at the end of the array.
- add(Message) - Method in class org.jgroups.CompositeMessage
-
Adds the message at the end of the array.
- add(Message) - Method in class org.jgroups.util.MessageBatch
- add(Message...) - Method in class org.jgroups.BatchMessage
- add(Message...) - Method in class org.jgroups.CompositeMessage
- add(Message[], int) - Method in class org.jgroups.util.MessageBatch
-
Adds message to this batch from a message array
- add(Message, boolean) - Method in class org.jgroups.util.MessageBatch
-
Adds a message to the table
- add(COUNTER.ReconcileResponse, Address) - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
- add(PingData) - Method in class org.jgroups.util.Responses
- add(RTTHeader) - Method in class org.jgroups.util.RpcStats.RTTStat
- add(AverageMinMax, long) - Static method in class org.jgroups.protocols.TIME
- add(FastArray<T>) - Method in class org.jgroups.util.FastArray
- add(FastArray<T>, boolean) - Method in class org.jgroups.util.FastArray
- add(MessageBatch) - Method in class org.jgroups.util.MessageBatch
- add(MessageBatch, boolean) - Method in class org.jgroups.util.MessageBatch
-
Adds another batch to this one
- add(MessageBatch, Function<T, Long>) - Method in class org.jgroups.util.Table
- add(MessageBatch, Function<T, Long>, boolean, T) - Method in class org.jgroups.util.Buffer
- add(MessageBatch, Function<T, Long>, boolean, T) - Method in class org.jgroups.util.DynamicBuffer
-
Adds all messages from the given batch to the table
- add(MessageBatch, Function<T, Long>, boolean, T) - Method in class org.jgroups.util.FixedBuffer
- add(MessageBatch, Function<T, Long>, boolean, T) - Method in class org.jgroups.util.Table
-
Adds all messages from the given batch to the table
- add(Responses, Address) - Method in class org.jgroups.util.Responses
- add(RpcStats.Type, Address, boolean, long) - Method in class org.jgroups.util.RpcStats
- add(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
- add(R) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- add(R...) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- add(T) - Method in class org.jgroups.util.BoundedList
-
Adds an element at the tail.
- add(T) - Method in class org.jgroups.util.FastArray
- add(T) - Method in class org.jgroups.util.ProcessingQueue
- add(T) - Method in class org.jgroups.util.RequestTable
-
Adds a new element and returns the sequence number at which it was inserted.
- add(T...) - Method in class org.jgroups.util.FastArray
- add(T[], int) - Method in class org.jgroups.util.FastArray
-
Adds elements from an array els to this array
- add(T, boolean) - Method in class org.jgroups.util.FastArray
- add(T, int) - Method in class org.jgroups.util.SizeBoundedQueue
- add(T, Predicate<T>, Consumer<Boolean>) - Method in class org.jgroups.util.Delayer
- ADD_AND_GET - org.jgroups.protocols.COUNTER.RequestType
- ADD_PHYSICAL_ADDRESS - Static variable in class org.jgroups.Event
- addAddressGenerator(AddressGenerator) - Method in class org.jgroups.fork.ForkChannel
- addAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
-
Sets the new
AddressGenerator
. - addAddressMapping(Address, String, Address, PhysicalAddress, String) - Method in class org.jgroups.stack.GossipRouter
- addAddressToLocalCache(Address, PhysicalAddress) - Method in class org.jgroups.protocols.LOCAL_PING
- addAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
- addAll(Collection<Address>, Collection<Address>) - Method in class org.jgroups.util.AckCollector
- addAll(Collection<Address>, Address...) - Method in class org.jgroups.util.AckCollector
- addAll(Map<K, V>) - Method in class org.jgroups.blocks.LazyRemovalCache
- addAll(Map<K, V>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
- addAll(Address...) - Method in class org.jgroups.util.AckCollector
- addAllIfAbsent(Map<K, V>) - Method in class org.jgroups.blocks.LazyRemovalCache
- addAndGet(long) - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically adds the given value to the current value.
- addAndGet(long) - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
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
- addAndSendIfSizeExceeded(Message) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- addAndSendIfSizeExceeded(Message) - Method in class org.jgroups.protocols.TransferQueueBundler
- addAndSendIfSizeExceeded(Message) - Method in class org.jgroups.protocols.TransferQueueBundler2
- addAnycast(boolean, long, Collection<Address>) - Method in class org.jgroups.util.RpcStats
- addAttribute(String, String) - Method in class org.jgroups.conf.XmlNode
- 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.JChannel
-
Adds a ChannelListener that will be notified when a connect, disconnect or close occurs
- addChild(XmlNode) - Method in class org.jgroups.conf.XmlNode
- addConnection(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- addConnectionListener(ConnectionListener) - Method in class org.jgroups.blocks.cs.BaseServer
- addContents(T) - Method in class org.jgroups.util.ExtendedUUID
- addContents(T) - Method in class org.jgroups.util.FlagsUUID
- addDiscoveryResponseToCaches(Address, String, PhysicalAddress) - Method in class org.jgroups.protocols.Discovery
- addDownFilter(Predicate<Message>) - Method in class org.jgroups.protocols.DROP
- addEntry(Request<T>, RequestCorrelator.Header, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- adders - Variable in class org.jgroups.util.Buffer
- adders - Variable in class org.jgroups.util.Table
- addFlag(boolean, String) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- addFlag(boolean, Message.Flag) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- addForward(RelayConfig.ForwardConfig) - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- addIfAbsent(short, Class<?>) - Static method in class org.jgroups.conf.ClassConfigurator
- addIfAbsent(K, V) - Method in class org.jgroups.blocks.LazyRemovalCache
- addIfAbsent(T) - Method in class org.jgroups.util.BoundedList
- addIfAbsentOrExpired(K) - Method in class org.jgroups.util.ExpiryCache
- addIgnoredMembers(Address...) - Method in class org.jgroups.protocols.DISCARD
- 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
- addKeysToMessage(Message, boolean, boolean, Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Adds the public and/or encrypted shared keys to the payload of msg.
- addListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
- addMessage(Message) - Method in class org.jgroups.protocols.BATCH.Buffer
- addMessage(Message) - Method in class org.jgroups.protocols.BATCH2.Buffer
- addMessage(Message) - Method in class org.jgroups.protocols.BatchBundler.Buffer
- addMessage(Message, int) - Method in class org.jgroups.protocols.AlternatingBundler
- addMessage(Message, int) - Method in class org.jgroups.protocols.BaseBundler
- addMessage(Message, int) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- addMessage(Message, int) - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- addMessage(UNICAST3.ReceiverEntry, Address, long, Message) - Method in class org.jgroups.protocols.UNICAST3
- addMetadata(Message, boolean, Address, boolean) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- addNode(Address) - Method in class org.jgroups.demos.Topology
- addNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
- addPhysicalAddressToCache(Address, PhysicalAddress) - Method in class org.jgroups.protocols.SimpleTCP
- addPhysicalAddressToCache(Address, PhysicalAddress) - Method in class org.jgroups.protocols.TP
- addPhysicalAddressToCache(Address, PhysicalAddress, boolean) - Method in class org.jgroups.protocols.TP
- addPingData(PingData) - Method in class org.jgroups.stack.GossipData
- addPolicy(Policy) - Method in class org.jgroups.stack.Protocol
- 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(List<Protocol>) - Method in class org.jgroups.stack.ProtocolStack
-
Adds a list of protocols
- addProtocols(Protocol...) - Method in class org.jgroups.stack.ProtocolStack
-
Adds a list of protocols
- addQueuedMessages(Address, UNICAST3.ReceiverEntry, Collection<Message>) - Method in class org.jgroups.protocols.UNICAST3
- addr() - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- addr() - Method in class org.jgroups.stack.Protocol
- addr(Address) - Method in class org.jgroups.stack.Protocol
- addr_getter - Variable in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- addr_supplier - Variable in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- addr_table - Variable in class org.jgroups.protocols.SimpleTCP
- addReceiver(Receiver) - Method in class org.jgroups.blocks.ReplCache
- 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
- addResponse(Responses) - Method in class org.jgroups.protocols.Discovery
- 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 - Variable in class org.jgroups.util.ThreadPool
- address() - Method in class org.jgroups.JChannel
- Address - Interface in org.jgroups
-
Address identifies cluster member.
- 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
- AddressedDNSResolver - Class in org.jgroups.protocols.dns
- AddressedDNSResolver(String, String) - Constructor for class org.jgroups.protocols.dns.AddressedDNSResolver
- AddressedDNSResolver(DirContext) - Constructor for class org.jgroups.protocols.dns.AddressedDNSResolver
- addressFromString(String) - Static method in class org.jgroups.util.Util
- AddressGenerator - Interface in org.jgroups.stack
-
Callback to provide custom addresses.
- addressSupplier(Supplier<Address>) - Method in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- addressToFilename(Address) - Static method in class org.jgroups.protocols.FILE_PING
- addressToString(Address) - Static method in class org.jgroups.util.Util
- addRoutes(String, List<Route>) - Method in class org.jgroups.protocols.relay.Relayer
- addRsp(Address, T) - Method in class org.jgroups.util.RspList
- addRTTStats(Address, RTTHeader) - Method in class org.jgroups.util.RpcStats
- addSite(String, RelayConfig.SiteConfig) - Method in class org.jgroups.protocols.relay.RELAY
- addSubtree(XmlNode) - Method in class org.jgroups.conf.ProtocolConfiguration
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
-
Adds a suspected member.
- addSuspects(Collection<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
Adds suspected members to the suspect list.
- addSuspects(Collection<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
-
Adds suspected members to the suspect list.
- addSuspects(List<Address>) - Method in class org.jgroups.protocols.FD_SOCK2.BroadcastTask
- addToCache(String) - Method in class org.jgroups.protocols.Discovery
- addToQueue(Message, int) - Method in class org.jgroups.util.NonBlockingCredit
- addToQueue(Message, int) - Method in class org.jgroups.util.NonBlockingCreditMap
- addToRelayedTime(long) - Method in class org.jgroups.protocols.relay.RELAY
- addToResults(Address, boolean, long) - Method in class org.jgroups.util.RpcStats
- addToSites(String...) - Method in class org.jgroups.protocols.relay.RelayHeader
- addToSites(Collection<String>) - Method in class org.jgroups.protocols.relay.RelayHeader
- addToVisitedSites(String) - Method in class org.jgroups.protocols.relay.RelayHeader
- addToVisitedSites(Collection<String>) - Method in class org.jgroups.protocols.relay.RelayHeader
- addUpFilter(Predicate<Message>) - Method in class org.jgroups.protocols.DROP
- 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.
- adjust(List<Address>) - Method in class org.jgroups.util.AckTable
-
Removes left members from and adds new members to the map
- adjustCredit(Map<Address, Credit>, Address, int) - Method in class org.jgroups.protocols.FlowControl
-
Check whether sender has enough credits left.
- adjustPosition(boolean) - Method in class org.jgroups.nio.Buffers
- adjustReceivers(List<Address>) - Method in class org.jgroups.protocols.NAKACK4
- 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).
- adjustReceivers(List<Address>) - Method in class org.jgroups.protocols.ReliableMulticast
-
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
- adjustSuspects(List<Address>) - Method in class org.jgroups.protocols.FD_SOCK2.BroadcastTask
-
Removes all elements from suspects that are not in the new membership
- advance() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
-
Advances the index (mod length) and sets the bits[index] to 0
- advance(int) - Method in class org.jgroups.protocols.RingBufferBundler
- advance(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
Advances the current position without reading any bytes.
- 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.conf.ProtocolStackConfigurator
-
Invoked after each
Protocol
is instantiated and beforeProtocol.init()
is invoked. - 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.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 annotation type org.jgroups.annotations.XmlInclude
- alias() - Method in class org.jgroups.protocols.SYM_ENCRYPT
- alias(String) - Method in class org.jgroups.protocols.SYM_ENCRYPT
- ALL - org.jgroups.protocols.relay.SiteAddress.Type
- ALL - org.jgroups.stack.GossipRouter.DumpMessages
- all_acks_received - Variable in class org.jgroups.util.AckCollector
- all_clients_retry_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
- ALL_SMS - Static variable in class org.jgroups.protocols.relay.SiteMaster
- 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
- allowedToSubmitToThreadPool(Message) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
-
Either allows access to submit a task to the thread pool for delivery to the application, or queues the message
- allowedToSubmitToThreadPool(MessageBatch) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- 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
- alreadyInMagicMap(short, String) - Static method in class org.jgroups.conf.ClassConfigurator
- alreadyInProtocolsMap(short, String) - Static method in class org.jgroups.conf.ClassConfigurator
- AlternatingBundler - Class in org.jgroups.protocols
-
Bundler implementation which sends message batches (or single messages) as soon as the target destination changes (or max_bundler_size would be exceeded).
Messages are removed from the main queue one by one and processed as follows:
A B B C C A causes the following sends: A -> {CC} -> {BB} -> A
Note that null is also a valid destination (send-to-all).
JIRA: https://issues.redhat.com/browse/JGRP-2171 - AlternatingBundler() - Constructor for class org.jgroups.protocols.AlternatingBundler
- ANYCAST - org.jgroups.util.RpcStats.Type
- anycasting() - Method in class org.jgroups.blocks.RequestOptions
- anycasting(boolean) - Method in class org.jgroups.blocks.RequestOptions
- anycasts(boolean) - Method in class org.jgroups.util.RpcStats
- anyMatch(Predicate<Message>) - Method in class org.jgroups.util.MessageBatch
- anyMatch(Predicate<T>) - Method in class org.jgroups.util.FastArray
- apiKey - Variable in class org.jgroups.protocols.RACKSPACE_PING
- apply(String, COUNTER.VersionedValue) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
- arg() - Method in class org.jgroups.Event
- args - Variable in class org.jgroups.blocks.MethodCall
- around(Supplier<T>) - Method in class org.jgroups.blocks.UnicastRequest
- array - Variable in class org.jgroups.BytesMessage
-
The payload
- 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(byte[]) - Constructor for class org.jgroups.util.AsciiString
- AsciiString(int) - 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
- assembleMessage() - Method in class org.jgroups.protocols.FRAG3.FragEntry
-
Assembles all the fragments into one buffer.
- assembleMessage(Message[], boolean, FragHeader) - Method in class org.jgroups.protocols.FRAG2
-
Assembles all the message fragments into one message.
- assembleMessage(Message[], boolean, FragHeader) - Method in class org.jgroups.protocols.FRAG4
- assertAllChannelsHaveSameView(JChannel...) - Static method in class org.jgroups.util.Util
- assertNonNull(String...) - Static method in class org.jgroups.protocols.JDBC_PING
- assertNonNull(String...) - Static method in class org.jgroups.protocols.JDBC_PING2
- assertNonNullSites() - Method in class org.jgroups.protocols.relay.RelayHeader
- assertNotNegative(short) - Static method in class org.jgroups.blocks.MethodCall
- 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.TransferQueueBundler2
- assertPositive(int, String) - Static method in class org.jgroups.util.Util
- assertPositiveUnsignedShort(int) - Static method in class org.jgroups.nio.Buffers
- asym_algorithm - Variable in class org.jgroups.protocols.Encrypt
- 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_ENCRYPT.Processing - Enum in org.jgroups.protocols
- asym_keylength - Variable in class org.jgroups.protocols.Encrypt
- asymAlgorithm() - Method in class org.jgroups.protocols.Encrypt
- asymAlgorithm(String) - Method in class org.jgroups.protocols.Encrypt
- asymCipher() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- asymKeylength() - Method in class org.jgroups.protocols.Encrypt
- asymKeylength(int) - Method in class org.jgroups.protocols.Encrypt
- async - Variable in class org.jgroups.util.RpcStats.Result
- async() - Method in interface org.jgroups.blocks.atomic.AsyncCounter
- async() - Method in interface org.jgroups.blocks.atomic.BaseCounter
-
Returns an
AsyncCounter
wrapper for this instance. - async() - Method in interface org.jgroups.blocks.atomic.Counter
-
Deprecated.
- async() - Method in class org.jgroups.util.RpcStats.Result
- ASYNC() - Static method in class org.jgroups.blocks.RequestOptions
- async_anycasts - Variable in class org.jgroups.util.RpcStats
- async_discovery - Variable in class org.jgroups.protocols.Discovery
- ASYNC_DISCOVERY_EVENT - Variable in class org.jgroups.protocols.MERGE3
- 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_executor - Variable in class org.jgroups.protocols.TP
- async_multicasts - Variable in class org.jgroups.util.RpcStats
- async_relay_creation - Variable in class org.jgroups.protocols.relay.RELAY
- async_rsp_handling - Variable in class org.jgroups.blocks.MessageDispatcher
-
When enabled, responses are handled by the common ForkJoinPool (https://issues.redhat.com/browse/JGRP-2644)
- async_rsp_handling - Variable in class org.jgroups.blocks.RequestCorrelator
-
When enabled, responses are handled by the common ForkJoinPool (https://issues.redhat.com/browse/JGRP-2644)
- async_unicasts - Variable in class org.jgroups.util.RpcStats
- AsyncCounter - Interface in org.jgroups.blocks.atomic
-
An asynchronous counter interface.
- asyncDispatching() - Method in class org.jgroups.blocks.MessageDispatcher
- asyncDispatching() - Method in class org.jgroups.blocks.RequestCorrelator
- asyncDispatching(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- asyncDispatching(boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- AsyncExecutor<T> - Class in org.jgroups.util
-
Used to execute asynchronous tasks, e.g.
- AsyncExecutor() - Constructor for class org.jgroups.util.AsyncExecutor
- AsyncExecutor(ThreadPool) - Constructor for class org.jgroups.util.AsyncExecutor
- AsyncExecutor.Task<T> - Class in org.jgroups.util
- AsyncNoBundler - Class in org.jgroups.protocols
-
Simple and stupid async version of NoBundler.
- AsyncNoBundler() - Constructor for class org.jgroups.protocols.AsyncNoBundler
- asyncRelayCreation() - Method in class org.jgroups.protocols.relay.RELAY
- asyncRelayCreation(boolean) - Method in class org.jgroups.protocols.relay.RELAY
- asyncRspHandling() - Method in class org.jgroups.blocks.MessageDispatcher
- asyncRspHandling() - Method in class org.jgroups.blocks.RequestCorrelator
- asyncRspHandling(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- asyncRspHandling(boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- asyncWaitUntilTrue(long, long, BooleanSupplier, Supplier<T>, Supplier<T>) - Static method in class org.jgroups.util.Util
-
In a separate thread (common ForkJoinPool): waits for the given timeout / interval until a condition is true.
- attemptSchemaInitialization() - Method in class org.jgroups.protocols.JDBC_PING
- AttributeEntry(AccessibleObject, String, MBeanAttributeInfo) - Constructor for class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- AttributeEntry(AccessibleObject, String, MBeanAttributeInfo, ResourceDMBean.Accessor, ResourceDMBean.Accessor) - Constructor for class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- attributeNameToMethodName(String) - Static method in class org.jgroups.util.Util
- attributes - Variable in class org.jgroups.conf.XmlNode
- AttributeType - Enum in org.jgroups.conf
-
Defines the type of an attribute exposed by
ManagedAttribute
orProperty
. - attrInfo - Variable in class org.jgroups.jmx.ResourceDMBean
- attrs - Variable in class org.jgroups.stack.NonReflectiveProbeHandler
- attrs() - Method in annotation type org.jgroups.annotations.XmlAttribute
- 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_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() - Method in class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
Authenticate
- authenticate() - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Authenticate
- 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.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.RegexMembership
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.X509Token
- 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
- available() - Method in class org.jgroups.blocks.GridInputStream
- available() - Method in class org.jgroups.util.BlockingInputStream
- available() - Method in class org.jgroups.util.InputStreamAdapter
- available(InputStream) - Static method in class org.jgroups.util.Util
- average() - Method in class org.jgroups.util.Average
- Average - Class in org.jgroups.util
-
Maintains an approximation of an average of values.
- Average() - Constructor for 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.Profiler
- 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.AlternatingBundler
- avg_batch_size - Variable in class org.jgroups.protocols.MsgStats
-
The average number of messages in a received
MessageBatch
- avg_batch_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
The average number of messages in a received
MessageBatch
- avg_batch_size - Variable in class org.jgroups.protocols.ReliableMulticast
-
The average number of messages in a received
MessageBatch
- avg_batch_size - Variable in class org.jgroups.protocols.RemoveQueueBundler
- avg_block_time - Variable in class org.jgroups.protocols.RATE_LIMITER2
- avg_block_time - Variable in class org.jgroups.util.CreditMap
- avg_blockings - Variable in class org.jgroups.util.Credit
- avg_delivery_batch_size - Variable in class org.jgroups.protocols.UNICAST3
- avg_down - Variable in class org.jgroups.protocols.THREAD_COUNT
- avg_fill_count - Variable in class org.jgroups.protocols.TransferQueueBundler
- avg_fill_count - Variable in class org.jgroups.protocols.TransferQueueBundler2
- avg_queue_size - Variable in class org.jgroups.protocols.RED
- avg_req_delivery - Variable in class org.jgroups.blocks.RequestCorrelator
- avg_rsp_delivery - Variable in class org.jgroups.blocks.RequestCorrelator
- avg_send_time - Variable in class org.jgroups.protocols.BaseBundler
- avg_size - Variable in class org.jgroups.protocols.PERF
- avg_size_down - Variable in class org.jgroups.protocols.FRAG2
- avg_size_down - Variable in class org.jgroups.protocols.FRAG3
- avg_size_up - Variable in class org.jgroups.protocols.FRAG2
- avg_size_up - Variable in class org.jgroups.protocols.FRAG3
- avg_state_size - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- avg_state_size - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- avg_time_blocked - Variable in class org.jgroups.util.FixedBuffer
- avg_up - Variable in class org.jgroups.protocols.THREAD_COUNT
- avg_up_batch_size - Variable in class org.jgroups.protocols.TIME
- avgBatchSize() - Method in class org.jgroups.protocols.BATCH
- avgBatchSize() - Method in class org.jgroups.protocols.BATCH2
- avgBatchSize() - Method in class org.jgroups.protocols.BatchBundler
- avgBatchSize() - Method in class org.jgroups.protocols.PerDestinationBundler
- avgBatchSize() - Method in class org.jgroups.protocols.RemoveQueueBundler
- avgTimeBlocked() - Method in class org.jgroups.util.FixedBuffer
- avgTimePerMessageIncludingDelay(int, long) - Static method in class org.jgroups.protocols.TIME
B
- backup_coords - Variable in class org.jgroups.protocols.COUNTER
-
Backup coordinators.
- BARRIER - Class in org.jgroups.protocols
-
All messages up the stack have to go through a barrier (read lock, RL).
- BARRIER() - Constructor for class org.jgroups.protocols.BARRIER
- barrier_closed - Variable in class org.jgroups.protocols.BARRIER
- barrier_opener_future - Variable in class org.jgroups.protocols.BARRIER
- Base64 - Class in org.jgroups.util
-
Encodes and decodes to and from Base64 notation.
- Base64.InputStream - Class in org.jgroups.util
-
A
Base64.InputStream
will read data from another java.io.InputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly. - Base64.OutputStream - Class in org.jgroups.util
-
A
Base64.OutputStream
will write data to another java.io.OutputStream, given in the constructor, and encode/decode to/from Base64 notation on the fly. - BaseBundler - Class in org.jgroups.protocols
-
Implements storing of messages in a hashmap and sending of single messages and message batches.
- BaseBundler() - Constructor for class org.jgroups.protocols.BaseBundler
- BaseCounter - Interface in org.jgroups.blocks.atomic
-
Base interface for all counters
- BaseDataOutputStream - Class in org.jgroups.util
-
Implements
DataOutput
in a generic manner, so that subclasses can implement specific behavior. - BaseDataOutputStream() - Constructor for class org.jgroups.util.BaseDataOutputStream
- BaseMessage - Class in org.jgroups
-
A common superclass for all
Message
implementations. - BaseMessage() - Constructor for class org.jgroups.BaseMessage
- BaseMessage(Address) - Constructor for class org.jgroups.BaseMessage
-
Constructs a message given a destination address
- baseName - Variable in class org.jgroups.util.DefaultThreadFactory
- BaseServer - Class in org.jgroups.blocks.cs
-
Abstract class for a server handling sending, receiving and connection management.
- BaseServer(ThreadFactory, SocketFactory, int) - Constructor for class org.jgroups.blocks.cs.BaseServer
- BaseServer.Reaper - Class in org.jgroups.blocks.cs
- BasicTCP - Class in org.jgroups.protocols
-
Shared base class for TCP protocols
- BasicTCP() - Constructor for class org.jgroups.protocols.BasicTCP
- batch - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- batch - Variable in class org.jgroups.util.SubmitToThreadPool.BatchHandler
- BATCH - Class in org.jgroups.protocols
-
Batches messages near the top of the stack.
- BATCH() - Constructor for class org.jgroups.protocols.BATCH
- BATCH_ACCUMULATOR - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
- BATCH_ACCUMULATOR - Static variable in class org.jgroups.protocols.ReliableMulticast
- BATCH_ACCUMULATOR - Static variable in class org.jgroups.protocols.SEQUENCER2
- BATCH_ACCUMULATOR - Static variable in class org.jgroups.protocols.UNICAST3
- BATCH.BatchHeader - Class in org.jgroups.protocols
- BATCH.Buffer - Class in org.jgroups.protocols
- BATCH.FlushTask - Class in org.jgroups.protocols
- BATCH2 - Class in org.jgroups.protocols
-
Batches messages near the top of the stack.
- BATCH2() - Constructor for class org.jgroups.protocols.BATCH2
- BATCH2.Batch2Header - Class in org.jgroups.protocols
- BATCH2.Buffer - Class in org.jgroups.protocols
- Batch2Header() - Constructor for class org.jgroups.protocols.BATCH2.Batch2Header
- BatchBundler - Class in org.jgroups.protocols
-
Bundler based on
BATCH
. - BatchBundler() - Constructor for class org.jgroups.protocols.BatchBundler
- BatchBundler.Buffer - Class in org.jgroups.protocols
- BatchBundler.FlushTask - Class in org.jgroups.protocols
- batcher - Variable in class org.jgroups.protocols.MAKE_BATCH
- Batcher() - Constructor for class org.jgroups.protocols.MAKE_BATCH.Batcher
- batches - Variable in class org.jgroups.protocols.ReliableMulticast
- BatchHandler(MessageBatch) - Constructor for class org.jgroups.util.SubmitToThreadPool.BatchHandler
- BatchHandlerLoop(MessageBatch, MaxOneThreadPerSender.Entry, boolean) - Constructor for class org.jgroups.util.MaxOneThreadPerSender.BatchHandlerLoop
- BatchHeader() - Constructor for class org.jgroups.protocols.BATCH.BatchHeader
- BatchMessage - Class in org.jgroups
-
A message that contains a batch of messages.
- BatchMessage() - Constructor for class org.jgroups.BatchMessage
- BatchMessage(Address, int) - Constructor for class org.jgroups.BatchMessage
- BatchMessage(Address, Address, Message[], int) - Constructor for class org.jgroups.BatchMessage
- BatchMessage.BatchMessageIterator - Class in org.jgroups
- BatchMessageIterator() - Constructor for class org.jgroups.BatchMessage.BatchMessageIterator
- BCAST - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- BCAST - Static variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- bcast_msgs - Variable in class org.jgroups.protocols.SEQUENCER
- bcast_task - Variable in class org.jgroups.protocols.FD_SOCK
- bcast_task - Variable in class org.jgroups.protocols.FD_SOCK2
- bcasts_delivered - Variable in class org.jgroups.protocols.SEQUENCER2
- bcasts_received - Variable in class org.jgroups.protocols.SEQUENCER2
- bcasts_sent - Variable in class org.jgroups.protocols.SEQUENCER2
- BECOME_SERVER - Static variable in class org.jgroups.Event
- become_server_queue - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- become_server_queue - Variable in class org.jgroups.protocols.ReliableMulticast
- become_server_queue_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- become_server_queue_size - Variable in class org.jgroups.protocols.ReliableMulticast
- becomeClient() - Method in class org.jgroups.protocols.pbcast.GMS
- becomeCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
- becomeKeyserver() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- becomeParticipant() - Method in class org.jgroups.protocols.pbcast.GMS
- BEGIN - org.jgroups.protocols.STOMP.ClientVerb
- BELOW - org.jgroups.stack.ProtocolStack.Position
- bind - Variable in class org.jgroups.protocols.SimpleTCP.Acceptor
- bind(ServerSocket, InetAddress, int, int) - Static method in class org.jgroups.util.Util
- bind(SocketAddress) - Method in class org.jgroups.nio.MockSocketChannel
- bind(Socket, InetAddress, int, int) - Static method in class org.jgroups.util.Util
- bind_addr - Variable in class org.jgroups.protocols.FD_SOCK
- bind_addr - Variable in class org.jgroups.protocols.FD_SOCK2
- bind_addr - Variable in class org.jgroups.protocols.MPING
- bind_addr - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- bind_addr - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- bind_addr - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- bind_addr - Variable in class org.jgroups.protocols.STOMP
- bind_addr - Variable in class org.jgroups.protocols.TP
- bind_addr - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- bind_addr - Variable in class org.jgroups.stack.DiagnosticsHandler
- bind_addr - Variable in class org.jgroups.stack.GossipRouter
- BIND_ADDR - Static variable in class org.jgroups.Global
- bind_interface_str - Variable in class org.jgroups.protocols.MPING
- bind_interface_str - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- bind_interfaces - Variable in class org.jgroups.stack.DiagnosticsHandler
- bind_port - Variable in class org.jgroups.protocols.BPING
- bind_port - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- bind_port - Variable in class org.jgroups.protocols.TP
-
The port to which the transport binds.
- BIND_PORT - Static variable in class org.jgroups.Global
- bindAddress() - Method in class org.jgroups.stack.GossipRouter
- bindAddress(InetAddress) - Method in class org.jgroups.stack.GossipRouter
- BindInterface() - Constructor for class org.jgroups.conf.PropertyConverters.BindInterface
- bindToInterfaces(List<NetworkInterface>, MulticastSocket) - Method in class org.jgroups.stack.DiagnosticsHandler
- bindToInterfaces(List<NetworkInterface>, MulticastSocket, InetAddress) - Method in class org.jgroups.protocols.MPING
- Bitmap(int) - Constructor for class org.jgroups.protocols.FD_ALL3.Bitmap
- bits - Variable in class org.jgroups.protocols.FD_ALL3.Bitmap
- Bits - Class in org.jgroups.util
-
Class (similar to (and partly copied from) java.nio.Bits) containing helper methods to encode variables (e.g.
- BITS_PER_WORD - Static variable in class org.jgroups.util.FixedSizeBitSet
- block - Variable in class org.jgroups.util.Buffer.Options
- block() - Method in class org.jgroups.protocols.SEQUENCER
- block() - Method in class org.jgroups.util.Buffer.Options
- block(boolean) - Method in class org.jgroups.util.Buffer.Options
- block(long) - Method in class org.jgroups.protocols.RSVP.Entry
- block(long) - Method in class org.jgroups.util.FixedBuffer
- block(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- block(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
- block_time - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- BlockingInputStream - Class in org.jgroups.util
-
Bounded input stream.
- BlockingInputStream() - Constructor for class org.jgroups.util.BlockingInputStream
- BlockingInputStream(int) - Constructor for class org.jgroups.util.BlockingInputStream
- blocks - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- BLOCKS_START_ID - Static variable in class org.jgroups.Global
-
First ID assigned for building blocks (defined in jg-protocols.xml)
- bold(String) - Static method in class org.jgroups.util.Util
- bottom_prot - Variable in class org.jgroups.stack.ProtocolStack
- bottomProtocol(Protocol) - Method in class org.jgroups.stack.ProtocolStack
- BoundedHashMap<K,V> - Class in org.jgroups.util
-
Bounded linked hashmap; used by SEQUENCER
- BoundedHashMap(int) - Constructor for class org.jgroups.util.BoundedHashMap
- BoundedList<T> - Class in org.jgroups.util
-
A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.
- BoundedList() - Constructor for class org.jgroups.util.BoundedList
- BoundedList(int) - Constructor for class org.jgroups.util.BoundedList
- BPING - Class in org.jgroups.protocols
-
Broadcast PING.
- BPING() - Constructor for class org.jgroups.protocols.BPING
- break_on_coord_rsp - Variable in class org.jgroups.protocols.Discovery
- break_on_coord_rsp - Variable in class org.jgroups.util.Responses
- breakOnCoordResponse() - Method in class org.jgroups.protocols.Discovery
- breakOnCoordResponse(boolean) - Method in class org.jgroups.protocols.Discovery
- bridge - Variable in class org.jgroups.protocols.relay.Route
- bridge() - Method in class org.jgroups.protocols.relay.Route
- Bridge - Class in org.jgroups.protocols.relay
-
Class which joins the bridge cluster and send and receives messages to/from other sites.
- Bridge(JChannel, String, String, AddressGenerator) - Constructor for class org.jgroups.protocols.relay.Relayer2.Bridge
- Bridge(JChannel, Relayer3, String, String, AddressGenerator) - Constructor for class org.jgroups.protocols.relay.Bridge
- BRIDGE - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- BridgeConfig(String) - Constructor for class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
- bridges - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- bridges - Variable in class org.jgroups.protocols.relay.Relayer2
-
The bridges which are used to connect to different sites
- bridges - Variable in class org.jgroups.protocols.relay.Relayer3
-
The bridges which are used to connect to different sites
- BRIDGES - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- broadcast(Message, boolean, Address, long, boolean) - Method in class org.jgroups.protocols.SEQUENCER
- broadcast(Message, long) - Method in class org.jgroups.protocols.SEQUENCER2
- broadcast_route_notifications - Variable in class org.jgroups.protocols.relay.RELAY
- broadcastEndpoint() - Method in class org.jgroups.protocols.STOMP
- broadcastRouteNotifications() - Method in class org.jgroups.protocols.relay.RELAY
- broadcastRouteNotifications(boolean) - Method in class org.jgroups.protocols.relay.RELAY
- broadcastSuspectMessage(List<Address>) - Method in class org.jgroups.protocols.FD_SOCK2
-
Sends a SUSPECT message to all group members.
- broadcastSuspectMessage(Address) - Method in class org.jgroups.protocols.FD_SOCK
-
Sends a SUSPECT message to all group members.
- BroadcastTask() - Constructor for class org.jgroups.protocols.FD_SOCK.BroadcastTask
- BroadcastTask() - Constructor for class org.jgroups.protocols.FD_SOCK2.BroadcastTask
- broadcastUnuspectMessage(Address) - Method in class org.jgroups.protocols.FD_SOCK
- broadcastUnuspectMessage(Address) - Method in class org.jgroups.protocols.FD_SOCK2
- buf - Variable in class org.jgroups.NioMessage
-
The payload
- buf - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- buf - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- buf - Variable in class org.jgroups.util.BlockingInputStream
-
The transfer buffer
- buf - Variable in class org.jgroups.util.ByteArrayDataInputStream
- buf - Variable in class org.jgroups.util.ByteArrayDataOutputStream
- buf - Variable in class org.jgroups.util.ByteBufferInputStream
- buf - Variable in class org.jgroups.util.ByteBufferOutputStream
- buf - Variable in class org.jgroups.util.FixedBuffer
-
Holds the elements
- buf - Variable in class org.jgroups.util.RingBuffer
- buf - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
Atomic ref array so that elements can be checked for null and set atomically.
- buf - Variable in class org.jgroups.util.RingBufferSeqnoOld
-
Atomic ref array so that elements can be checked for null and set atomically.
- buf() - Method in class org.jgroups.protocols.RingBufferBundler
- buf() - Method in class org.jgroups.util.ByteBufferInputStream
- buf() - Method in class org.jgroups.util.RingBuffer
- buffer - Variable in class org.jgroups.blocks.cs.TcpConnection.Receiver
- buffer - Variable in class org.jgroups.protocols.FRAG3.FragEntry
- buffer - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- buffer - Variable in class org.jgroups.util.FixedBuffer.FixedBufferIterator
- buffer - Variable in class org.jgroups.util.RequestTable
- buffer - Variable in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
- buffer - Variable in class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- buffer - Variable in class org.jgroups.util.StateTransferResult
- buffer() - Method in class org.jgroups.util.ByteArrayDataInputStream
- buffer() - Method in class org.jgroups.util.ByteArrayDataOutputStream
- Buffer<T> - Class in org.jgroups.util
-
Base class for message buffers.
- Buffer() - Constructor for class org.jgroups.util.Buffer
- Buffer(Address) - Constructor for class org.jgroups.protocols.BATCH.Buffer
- Buffer(Address) - Constructor for class org.jgroups.protocols.BATCH2.Buffer
- Buffer(Address) - Constructor for class org.jgroups.protocols.BatchBundler.Buffer
- buffer_full - Variable in class org.jgroups.util.FixedBuffer
- buffer_full - Variable in class org.jgroups.util.RingBufferSeqnoLockless
- buffer_full - Variable in class org.jgroups.util.RingBufferSeqnoOld
- buffer_size - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- Buffer.HighestDeliverable - Class in org.jgroups.util
- Buffer.Missing - Class in org.jgroups.util
- Buffer.NumDeliverable - Class in org.jgroups.util
- Buffer.Options - Class in org.jgroups.util
- Buffer.Remover<R> - Class in org.jgroups.util
- Buffer.Visitor<T> - Interface in org.jgroups.util
- buffered_input_stream_size - Variable in class org.jgroups.protocols.SimpleTCP
- buffered_input_stream_size - Variable in class org.jgroups.protocols.TCP
- buffered_inputstream_size - Variable in class org.jgroups.blocks.cs.TcpBaseServer
- buffered_output_stream_size - Variable in class org.jgroups.protocols.SimpleTCP
- buffered_output_stream_size - Variable in class org.jgroups.protocols.TCP
- buffered_outputstream_size - Variable in class org.jgroups.blocks.cs.TcpBaseServer
- Buffers - Class in org.jgroups.nio
-
Class to do scattering reads or gathering writes on a sequence of
ByteBuffer
instances. - Buffers(int) - Constructor for class org.jgroups.nio.Buffers
-
Creates a new instance with an array of capacity buffers
- Buffers(ByteBuffer...) - Constructor for class org.jgroups.nio.Buffers
- Buffers.BuffersIterator - Class in org.jgroups.nio
-
Iterates over the non-null buffers
- BuffersIterator() - Constructor for class org.jgroups.nio.Buffers.BuffersIterator
- bufferToArray(ByteBuffer) - Static method in class org.jgroups.util.Util
-
Returns a copy of the byte array between position and limit; requires a non-null buffer
- bufferToArray(Address, ByteBuffer, Receiver) - Static method in class org.jgroups.util.Util
- bufs - Variable in class org.jgroups.nio.Buffers
- build() - Method in class org.jgroups.util.SslContextFactory
- buildSocket(String, int) - Method in class org.jgroups.client.StompConnection
- bundler - Variable in class org.jgroups.protocols.RED
- bundler - Variable in class org.jgroups.protocols.TP
- bundler(String) - Method in class org.jgroups.protocols.TP
- Bundler - Interface in org.jgroups.protocols
-
Pluggable way to collect messages and send them as batches
- bundler_thread - Variable in class org.jgroups.protocols.RingBufferBundler
- bundler_thread - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- bundler_thread - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- bundler_thread - Variable in class org.jgroups.protocols.TransferQueueBundler
- bundler_thread - Variable in class org.jgroups.protocols.TransferQueueBundler2
- bundler_type - Variable in class org.jgroups.protocols.TP
- bypass_bundling - Variable in class org.jgroups.protocols.COUNTER
- BYTE_SIZE - Static variable in class org.jgroups.Global
- ByteArray - Class in org.jgroups.util
-
Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use ! - ByteArray(byte[]) - Constructor for class org.jgroups.util.ByteArray
- ByteArray(byte[], int, int) - Constructor for class org.jgroups.util.ByteArray
- ByteArrayDataInputStream - Class in org.jgroups.util
-
Implements
DataInput
over a byte[] buffer. - ByteArrayDataInputStream(byte[]) - Constructor for class org.jgroups.util.ByteArrayDataInputStream
- ByteArrayDataInputStream(byte[], int, int) - Constructor for class org.jgroups.util.ByteArrayDataInputStream
- ByteArrayDataInputStream(ByteBuffer) - Constructor for class org.jgroups.util.ByteArrayDataInputStream
- ByteArrayDataInputStream(ByteArray) - Constructor for class org.jgroups.util.ByteArrayDataInputStream
- ByteArrayDataOutputStream - Class in org.jgroups.util
-
Implements
DataOutput
over a byte[] buffer. - ByteArrayDataOutputStream() - Constructor for class org.jgroups.util.ByteArrayDataOutputStream
- ByteArrayDataOutputStream(int) - Constructor for class org.jgroups.util.ByteArrayDataOutputStream
- ByteArrayDataOutputStream(int, boolean) - Constructor for class org.jgroups.util.ByteArrayDataOutputStream
- byteArrayToHexString(byte[]) - Static method in class org.jgroups.util.Util
- byteArrayToHexString(byte[], int, int) - Static method in class org.jgroups.util.Util
- byteBuffer() - Method in class org.jgroups.util.ByteArrayDataInputStream
- byteBuffer() - Method in class org.jgroups.util.ByteArrayDataOutputStream
- ByteBufferInputStream - Class in org.jgroups.util
-
Class using
ByteBuffer
and implementingDataInput
. - ByteBufferInputStream(ByteBuffer) - Constructor for class org.jgroups.util.ByteBufferInputStream
- ByteBufferOutputStream - Class in org.jgroups.util
-
Class using
ByteBuffer
and implementingDataOutput
. - ByteBufferOutputStream(ByteBuffer) - Constructor for class org.jgroups.util.ByteBufferOutputStream
- BYTEMAN - Static variable in class org.jgroups.Global
- BYTES - org.jgroups.conf.AttributeType
- bytes_left - Variable in class org.jgroups.protocols.RATE_LIMITER2
- BYTES_MSG - Static variable in interface org.jgroups.Message
- bytes_to_read - Variable in class org.jgroups.nio.MockSocketChannel
- bytes_to_write - Variable in class org.jgroups.nio.MockSocketChannel
- BytesMessage - Class in org.jgroups
-
A
Message
containing a byte array as payload. - BytesMessage() - Constructor for class org.jgroups.BytesMessage
- BytesMessage(Address) - Constructor for class org.jgroups.BytesMessage
-
Constructs a message given a destination address
- BytesMessage(Address, byte[]) - Constructor for class org.jgroups.BytesMessage
-
Constructs a message given a destination and source address and the payload byte array
- BytesMessage(Address, byte[], int, int) - Constructor for class org.jgroups.BytesMessage
-
Constructs a message.
- BytesMessage(Address, Object) - Constructor for class org.jgroups.BytesMessage
-
Constructs a message given a destination and source address and the payload object
- BytesMessage(Address, ByteArray) - Constructor for class org.jgroups.BytesMessage
- bytesRequiredFor(int) - Static method in class org.jgroups.util.Bits
- bytesRequiredFor(long) - Static method in class org.jgroups.util.Bits
- bytesToRead() - Method in class org.jgroups.nio.MockSocketChannel
- bytesToRead(byte[]) - Method in class org.jgroups.nio.MockSocketChannel
- bytesToRead(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
- bytesToString(byte[]) - Static method in class org.jgroups.util.Util
- bytesToWrite(int) - Method in class org.jgroups.nio.MockSocketChannel
- bytesWrittenCounter - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
C
- 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.relay.Topology
- cache - Variable in class org.jgroups.protocols.UNICAST3
- cache - Static variable in class org.jgroups.util.NameCache
-
Keeps track of associations between addresses and logical names
- cache - Variable in class org.jgroups.util.SuppressLog
- cache() - Method in class org.jgroups.protocols.relay.Topology
- Cache<K,V> - Class in org.jgroups.blocks
-
Simple cache which maintains keys and value.
- Cache() - Constructor for class org.jgroups.blocks.Cache
- 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
- Cache.ChangeListener - Interface in org.jgroups.blocks
- Cache.Value<V> - Class in org.jgroups.blocks
- cacheGroupKey(byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Cache the current shared key to decrypt messages encrypted with the old shared group key
- cacheServerAddress(Address) - Static method in class org.jgroups.protocols.ASYM_ENCRYPT
- call_insert_sp - Variable in class org.jgroups.protocols.JDBC_PING2
- call_options - Variable in class org.jgroups.blocks.ReplicatedHashMap
- callAfterCreationHook(Protocol, String) - Static method in class org.jgroups.stack.ProtocolStack
- callbacks - Variable in class org.jgroups.client.StompConnection
- callFindMembersInAllDiscoveryProtocols(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.Discovery
-
Calls
Discovery.findMembers(List, boolean, Responses)
in this protocol and all discovery protocols below - callInsertStoredProcedure(Connection, PingData, String) - Method in class org.jgroups.protocols.JDBC_PING2
- 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) - 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) - Method in class org.jgroups.blocks.RpcDispatcher
-
Invokes a method in a cluster member and - if blocking - returns the result
- can_become_site_master - Variable in class org.jgroups.protocols.relay.RELAY
- can_become_site_master_flag - Static variable in class org.jgroups.protocols.relay.RELAY
- can_bind_to_mcast_addr - Static variable in class org.jgroups.util.Util
- can_block - Variable in class org.jgroups.util.TimeScheduler3.Task
- can_forward_local_cluster - Variable in class org.jgroups.protocols.relay.RELAY2
- canBecomeSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY
- canBecomeSiteMaster(boolean) - Method in class org.jgroups.protocols.relay.RELAY
- canBeProcessedTogether(GmsImpl.Request) - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
-
Specifies whether this request can be processed with other request simultaneously
- canBlock() - Method in class org.jgroups.util.TimeScheduler3.Task
- cancel() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
- cancel(boolean) - Method in class org.jgroups.blocks.Request
- 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 - 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
- canDeliver(Address, long) - Method in class org.jgroups.protocols.SEQUENCER
-
Checks if seqno has already been received from sender.
- canForwardLocalCluster() - Method in class org.jgroups.protocols.relay.RELAY2
- canForwardLocalCluster(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
- canRun() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
- capacity - Variable in class org.jgroups.protocols.BaseBundler
- capacity - Variable in class org.jgroups.protocols.NAKACK4
- capacity - Variable in class org.jgroups.protocols.TransferQueueBundler2
- capacity - Variable in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- capacity() - Method in class org.jgroups.protocols.NAKACK4
- capacity() - Method in class org.jgroups.util.BlockingInputStream
- capacity() - Method in class org.jgroups.util.Buffer
-
Returns the current capacity in the buffer.
- capacity() - Method in class org.jgroups.util.ByteArrayDataInputStream
- capacity() - Method in class org.jgroups.util.ByteArrayDataOutputStream
- capacity() - Method in class org.jgroups.util.Digest
- capacity() - Method in class org.jgroups.util.DynamicBuffer
-
Returns the total capacity in the matrix
- capacity() - Method in class org.jgroups.util.FastArray
- capacity() - Method in class org.jgroups.util.FixedBuffer
- capacity() - Method in class org.jgroups.util.MessageBatch
- capacity() - Method in class org.jgroups.util.RequestTable
- capacity() - Method in class org.jgroups.util.RingBuffer
- capacity() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- capacity() - Method in class org.jgroups.util.RingBufferSeqnoOld
- capacity() - Method in class org.jgroups.util.Table
-
Returns the total capacity in the matrix
- capacity(int) - Method in class org.jgroups.protocols.NAKACK4
- car(List<E>) - Static method in class org.jgroups.util.Util
- 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) - Method in class org.jgroups.blocks.MessageDispatcher
- 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) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a message to all members and expects responses from members in dests (if non-null).
- castViewChangeAndSendJoinRsps(View, Digest, Collection<Address>, Collection<Address>, JoinRsp) - Method in class org.jgroups.protocols.pbcast.GMS
-
Broadcasts the new view and digest as VIEW messages, possibly sends JOIN-RSP messages to joiners and then waits for acks from expected_acks
- 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
- cdr(List<E>) - Static method in class org.jgroups.util.Util
- cert_alias - Variable in class org.jgroups.auth.X509Token
- CertficateCNMatcher - Class in org.jgroups.protocols
-
Sample implementation of
SSL_KEY_EXCHANGE.SessionVerifier
- CertficateCNMatcher() - Constructor for class org.jgroups.protocols.CertficateCNMatcher
- cf - Variable in class org.jgroups.util.AsyncExecutor.Task
- ch - Variable in class org.jgroups.demos.CounterServiceDemo
- ch - Static variable in class org.jgroups.demos.ProgrammaticChat
- ch - Variable in class org.jgroups.demos.RelayDemo
- ch - Variable in class org.jgroups.demos.RelayDemoRpc
- ch - Variable in class org.jgroups.JChannelProbeHandler
- ch - Variable in class org.jgroups.util.Metrics
- change_key_on_coord_leave - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- 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
- changeInterval(long) - Method in class org.jgroups.protocols.RATE_LIMITER2
- 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 - Variable in class org.jgroups.demos.Chat
- channel - Variable in class org.jgroups.protocols.relay.Bridge
- channel - Variable in class org.jgroups.protocols.relay.Relayer2.Bridge
- channel - Variable in class org.jgroups.stack.ProtocolStack
- channel_listeners - Variable in class org.jgroups.JChannel
- channelClosed(JChannel) - Method in class org.jgroups.blocks.MessageDispatcher
- channelClosed(JChannel) - Method in interface org.jgroups.ChannelListener
-
Channel has been closed notification callback
- channelClosed(JChannel) - Method in class org.jgroups.fork.ForkChannel
- channelConnected(JChannel) - Method in interface org.jgroups.ChannelListener
-
Channel has been connected notification callback
- channelConnected(JChannel) - Method in class org.jgroups.demos.Draw
- channelConnected(JChannel) - Method in class org.jgroups.fork.ForkChannel
- channelDisconnected(JChannel) - Method in class org.jgroups.blocks.MessageDispatcher
- channelDisconnected(JChannel) - Method in interface org.jgroups.ChannelListener
-
Channel has been disconnected notification callback
- channelDisconnected(JChannel) - Method in class org.jgroups.demos.Draw
- channelDisconnected(JChannel) - 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(Protocol) - Method in class org.jgroups.stack.CheckCallerRunsPolicy
- check(Protocol) - Method in class org.jgroups.stack.CheckForAbsenceOfRED
- check(Protocol) - Method in interface org.jgroups.stack.Policy
-
Checks that a condition is met in a given protocol
- check_interval - Variable in class org.jgroups.protocols.MERGE3
- check_timeout - Variable in class org.jgroups.protocols.FD_HOST
- check_timeouts - Variable in class org.jgroups.stack.RouterStubManager
- checkBounds(int) - Method in class org.jgroups.util.BaseDataOutputStream
- checkBounds(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
- checkBounds(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
- CheckCallerRunsPolicy - Class in org.jgroups.stack
- CheckCallerRunsPolicy() - Constructor for class org.jgroups.stack.CheckCallerRunsPolicy
- checkCapacity(int) - Method in class org.jgroups.util.IntHashMap
- checkClientTrusted(X509Certificate[], String) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkClosed() - Method in class org.jgroups.JChannel
- checkClosedOrNotConnected() - Method in class org.jgroups.JChannel
- CheckForAbsenceOfRED - Class in org.jgroups.stack
- CheckForAbsenceOfRED() - Constructor for class org.jgroups.stack.CheckForAbsenceOfRED
- 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
- 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
- checkLocalAddress(Address) - Method in class org.jgroups.protocols.relay.RELAY3
- checkOrder(Collection<E>, List<E>...) - Static method in class org.jgroups.util.Util
- 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
- checkRange(double, double, double, String) - Static method in class org.jgroups.protocols.RED
- checkSameId(Header, short) - Static method in class org.jgroups.conf.ClassConfigurator
- checkServerTrusted(X509Certificate[], String) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class org.jgroups.util.ReloadingX509TrustManager
- checkTimeouts() - Method in class org.jgroups.stack.RouterStubManager
- children - Variable in class org.jgroups.conf.XmlNode
- chooseClientAlias(String[], Principal[], Socket) - Method in class org.jgroups.util.ReloadingX509KeyManager
- chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class org.jgroups.util.ReloadingX509KeyManager
- chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class org.jgroups.util.ReloadingX509KeyManager
- chooseServerAlias(String, Principal[], Socket) - Method in class org.jgroups.util.ReloadingX509KeyManager
- cipher_pool_size - Variable in class org.jgroups.protocols.Encrypt
- cipher_suites - Variable in class org.jgroups.util.TLS
- cipher_type - Variable in class org.jgroups.auth.X509Token
- CLASS - Static variable in class org.jgroups.conf.ClassConfigurator
- ClassConfigurator - Class in org.jgroups.conf
-
Maintains a mapping between magic IDs and classes (defined in jg-magic-map.xml), and between protocol IDs and protocol classes (defined in jg-protocol-ids.xml).
- ClassConfigurator() - Constructor for class org.jgroups.conf.ClassConfigurator
- classLoader(ClassLoader) - Method in class org.jgroups.util.SslContextFactory
- cleanup() - Method in class org.jgroups.JChannel
- 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.FD_SOCK2.BroadcastTask
- clear() - Static method in class org.jgroups.protocols.LOCAL_PING
- clear() - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- clear() - Method in class org.jgroups.protocols.relay.SiteStatus
- clear() - Method in class org.jgroups.util.AckTable
- 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.Delayer
- clear() - Method in class org.jgroups.util.ExpiryCache
- clear() - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- clear() - Method in class org.jgroups.util.MessageBatch
- clear() - Method in class org.jgroups.util.MessageCache
- clear() - Method in class org.jgroups.util.NonBlockingCreditMap
- clear() - Method in class org.jgroups.util.RequestTable
-
Removes all elements, compacts the buffer and sets low=high=0
- clear() - Method in class org.jgroups.util.Responses
- clear() - Method in class org.jgroups.util.RingBuffer
- clear() - Method in class org.jgroups.util.SuppressCache
- clear(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
- clear(boolean) - Method in class org.jgroups.util.FastArray
- clear(boolean) - Method in class org.jgroups.util.SizeBoundedQueue
- 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 specifiedto
(inclusive) tofalse
. - clear(long) - Method in class org.jgroups.util.RequestTable
- CLEAR_FLAGS - Class in org.jgroups.protocols
-
Protocol which clears a set of flags in the down or up direction for all messages
- CLEAR_FLAGS() - Constructor for class org.jgroups.protocols.CLEAR_FLAGS
- clear_sql - Variable in class org.jgroups.protocols.JDBC_PING
- clear_sql - Variable in class org.jgroups.protocols.JDBC_PING2
- clearAllFilters() - Method in class org.jgroups.protocols.DROP
- clearAllFragments() - Method in class org.jgroups.protocols.FRAG2
- clearAllFragments() - Method in class org.jgroups.protocols.FRAG3
- clearChannelListeners() - Method in class org.jgroups.JChannel
- clearConnections() - Method in class org.jgroups.blocks.cs.BaseServer
-
Used only for testing !
- clearConnections() - Method in class org.jgroups.protocols.TCP_NIO2
- clearConnections() - Method in class org.jgroups.protocols.TCP
- clearDifferentClusterCache() - Method in class org.jgroups.protocols.TP
- clearDifferentVersionCache() - Method in class org.jgroups.protocols.TP
- clearDownFilters() - Method in class org.jgroups.protocols.DROP
- clearDroppedMessagesCache() - Method in class org.jgroups.protocols.UDP
- clearDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
- clearFlag(short) - Method in class org.jgroups.util.FlagsUUID
- clearFlag(Message.Flag...) - Method in class org.jgroups.BaseMessage
-
Clears a number of flags in a message
- clearFlag(Message.Flag...) - Method in interface org.jgroups.Message
-
Removes a number of flags from the message.
- clearFlag(Message.TransientFlag...) - Method in class org.jgroups.BaseMessage
- clearFlag(Message.TransientFlag...) - Method in interface org.jgroups.Message
-
Removes a number of transient flags from the message.
- clearFlags(byte, byte) - Static method in class org.jgroups.util.Util
- clearFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
- clearFragmentsFor(Address) - Method in class org.jgroups.protocols.FRAG2
- clearFragmentsFor(Address) - Method in class org.jgroups.protocols.FRAG3
- clearHeaders() - Method in class org.jgroups.BaseMessage
-
Removes all headers: use carefully!
- clearHeaders() - Method in interface org.jgroups.Message
-
Removes all headers: use carefully!
- clearLogicalAddressCache() - Method in class org.jgroups.protocols.TP
-
Clears the cache.
- clearNonMemberCache() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- clearNonMemberCache() - Method in class org.jgroups.protocols.ReliableMulticast
- clearNoRouteCache() - Method in class org.jgroups.protocols.relay.RELAY
- clearPanel() - Method in class org.jgroups.demos.Draw
- clearPanel() - Method in class org.jgroups.demos.StompDraw
- clearRequestFutures() - Method in class org.jgroups.protocols.Discovery
- clearSelectionKey(int) - Method in class org.jgroups.blocks.cs.NioConnection
- clearSuspects() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- clearTable(String) - Method in class org.jgroups.protocols.JDBC_PING
- clearTable(String) - Method in class org.jgroups.protocols.JDBC_PING2
- clearTransientFlags(Message.TransientFlag...) - Method in class org.jgroups.blocks.RequestOptions
- clearUpFilters() - Method in class org.jgroups.protocols.DROP
- clearViews() - Method in class org.jgroups.protocols.MERGE3
- client - Variable in class org.jgroups.demos.PubClient
- client - Variable in class org.jgroups.stack.RouterStub
- Client - Interface in org.jgroups.blocks.cs
-
Defines common operations for clients (TCP or NIO)
- CLIENT - Static variable in class org.jgroups.demos.StompChat
- CLIENT - Static variable in class org.jgroups.protocols.pbcast.GMS
- client_addr - Variable in class org.jgroups.stack.GossipRouter.Entry
- client_auth - Variable in class org.jgroups.util.TLS
- 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_bind_port - Variable in class org.jgroups.protocols.FD_SOCK2
- CLIENT_JOINED - Static variable in class org.jgroups.demos.StompChat
- CLIENT_LEFT - Static variable in class org.jgroups.demos.StompChat
- client_password - Variable in class org.jgroups.auth.Krb5Token
- CLIENT_PASSWORD - Static variable in class org.jgroups.auth.Krb5Token
- client_principal_name - Variable in class org.jgroups.auth.Krb5Token
- CLIENT_PRINCIPAL_NAME - Static variable in class org.jgroups.auth.Krb5Token
- client_sock - Variable in class org.jgroups.demos.EchoServer.ConnectionHandler
- client_ssl_ctx - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- client_ssl_ctx_reloader - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- client_state - Variable in class org.jgroups.protocols.FD_SOCK2.PingDest
- 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
- 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
- clients - Variable in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
- CLIENTS - Static variable in class org.jgroups.demos.StompChat
- clients_dest - Static variable in class org.jgroups.demos.StompDraw
- CLIENTS_KW - Static variable in class org.jgroups.demos.StompChat
- clientState() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- clientState(FD_SOCK2.State) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- clone() - Method in class org.jgroups.blocks.ReplicatedTree.Node
- 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.TcpConnection
- close() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- 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.fork.ForkChannel
-
Closes the fork-channel, essentially setting its state to CLOSED.
- close() - Method in class org.jgroups.JChannel
-
Destroys the channel and its associated resources (e.g.
- close() - Method in class org.jgroups.protocols.BATCH.Buffer
- close() - Method in class org.jgroups.protocols.BATCH2.Buffer
- close() - Method in class org.jgroups.protocols.BatchBundler.Buffer
- close() - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- close() - Method in interface org.jgroups.protocols.dns.DNSResolver
- close() - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- close() - Method in class org.jgroups.protocols.SimpleTCP.Connection
- close() - Method in class org.jgroups.protocols.UDP.PacketReceiver
- close() - Method in class org.jgroups.stack.DiagnosticsHandler
- 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() - Method in class org.jgroups.util.FileWatcher
- close() - Method in class org.jgroups.util.FixedBuffer
- close() - Method in class org.jgroups.util.InputStreamAdapter
- close() - Method in class org.jgroups.util.MyReceiver
- close() - Method in class org.jgroups.util.OutputStreamAdapter
- close() - Method in class org.jgroups.util.ReloadingX509KeyManager
- close() - Method in class org.jgroups.util.ReloadingX509TrustManager
- close() - Method in class org.jgroups.util.Runner
- close(Closeable) - Static method in class org.jgroups.util.Util
- close(Closeable...) - Static method in class org.jgroups.util.Util
- close(Object) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- close(Object) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- close(DatagramSocket) - Method in class org.jgroups.util.DefaultSocketFactory
- close(DatagramSocket) - Method in interface org.jgroups.util.SocketFactory
- close(ServerSocket) - Method in class org.jgroups.util.DefaultSocketFactory
- close(ServerSocket) - Method in interface org.jgroups.util.SocketFactory
- close(Socket) - Method in class org.jgroups.util.DefaultSocketFactory
- close(Socket) - Method in interface org.jgroups.util.SocketFactory
- close(ServerSocketChannel) - Method in interface org.jgroups.util.SocketFactory
- close(SocketChannel) - Method in interface org.jgroups.util.SocketFactory
- CLOSE - Static variable in class org.jgroups.protocols.UnicastHeader3
- 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
- closeConnection(Connection) - Method in class org.jgroups.protocols.JDBC_PING
- closeConnection(Address) - Method in class org.jgroups.blocks.cs.BaseServer
- closeConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Removes and resets from connection table (which is already locked).
- closeConnection(Address, boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- closeConnection(Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- closeConnection(Connection, boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- closeConnections() - Method in class org.jgroups.client.StompConnection
- closeConnectionToPingDest() - Method in class org.jgroups.protocols.FD_SOCK2
- CloseConnectionToPingDest - org.jgroups.protocols.FD_SOCK2.Request.Type
- closed - Variable in class org.jgroups.nio.MockSocketChannel
- closed - Variable in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- closed - Variable in class org.jgroups.util.BlockingInputStream
-
Set to true when
BlockingInputStream.close()
is called - closed(RouterStub) - Method in interface org.jgroups.stack.RouterStub.CloseListener
- closed(RouterStub) - Method in class org.jgroups.stack.RouterStubManager
- CLOSED - org.jgroups.JChannel.State
- CLOSED - org.jgroups.protocols.UNICAST3.State
- closeFast(JChannel...) - Static method in class org.jgroups.util.Util
-
Closes all non-coordinators first, in parallel, then closes the coord.
- 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
- closeReverse(Closeable...) - Static method in class org.jgroups.util.Util
- closeSendConnection(Address) - Method in class org.jgroups.protocols.UNICAST3
- closeUnicastSocket() - Method in class org.jgroups.protocols.UDP
- CLOSING - org.jgroups.protocols.UNICAST3.State
- cluster - Variable in class org.jgroups.protocols.FD_SOCK2
- cluster - Variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- cluster - Variable in class org.jgroups.util.SubmitToThreadPool.SingleMessageHandlerWithClusterName
- cluster(String) - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- cluster(AsciiString) - Method in class org.jgroups.util.MessageBatch
- CLUSTER - Static variable in class org.jgroups.demos.Chat
- 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.MERGE3
- cluster_name - Variable in class org.jgroups.protocols.PingHeader
- cluster_name - Variable in class org.jgroups.protocols.relay.Bridge
- cluster_name - Variable in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
- cluster_name - Variable in class org.jgroups.protocols.relay.Relayer2.Bridge
- 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.MaxOneThreadPerSender.Entry
- 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
- clusterName - Variable in class org.jgroups.util.DefaultThreadFactory
- clusterName() - Method in class org.jgroups.JChannel
- clusterName() - Method in class org.jgroups.protocols.TpHeader
- clusterName() - Method in class org.jgroups.util.MessageBatch
- clusterName(String) - Method in class org.jgroups.protocols.PingHeader
- 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.protocols.SOS
- cn_name - Variable in class org.jgroups.protocols.CertficateCNMatcher
- cnt - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
- code(byte[], int, int, byte[], boolean) - Method in class org.jgroups.protocols.Encrypt
- CODENAME - Static variable in class org.jgroups.Version
- collapse - Variable in class org.jgroups.CompositeMessage
- collapse() - Method in class org.jgroups.CompositeMessage
- collapse(boolean) - Method in class org.jgroups.CompositeMessage
- collectionToByteBuffer(Collection<Address>) - Static method in class org.jgroups.util.Util
- column - Variable in class org.jgroups.util.DynamicBuffer.TableIterator
- column - Variable in class org.jgroups.util.Table.TableIterator
- combine(E[]...) - Static method in class org.jgroups.util.Util
- combine(Class<?>, E...) - Static method in class org.jgroups.util.Util
- combine(List<E>, List<E>) - Static method in class org.jgroups.util.Util
- CommandExecutor2() - Constructor for class org.jgroups.protocols.FD_HOST.CommandExecutor2
- comment() - Method in annotation type org.jgroups.annotations.Experimental
- comment() - Method in annotation type org.jgroups.annotations.Unsupported
- COMMENT - org.jgroups.conf.XmlConfigurator.ElementType
- COMMIT - org.jgroups.protocols.STOMP.ClientVerb
- common_pool - Variable in class org.jgroups.blocks.RequestCorrelator
- compact() - Method in class org.jgroups.protocols.NAKACK3
- compact() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- 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.DynamicBuffer
- 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.Table
- compare(byte[], byte[]) - Static method in class org.jgroups.util.Util
-
Compares 2 byte arrays, elements are treated as unigned
- compare(int, int) - Static method in class org.jgroups.protocols.UNICAST3
-
Compares 2 timestamps, handles numeric overflow
- COMPARE_AND_SET - org.jgroups.protocols.COUNTER.RequestType
- compareAndSet(long, long) - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically updates the counter using a compare-and-set operation.
- compareAndSet(long, long) - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Atomically updates the counter using a CAS operation
- CompareAndSetRequest() - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- CompareAndSetRequest(Owner, String, long, long) - Constructor for class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- compareAndSwap(long, long) - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically updates the counter using a compare-and-swap operation.
- compareAndSwap(long, long) - Method in interface org.jgroups.blocks.atomic.Counter
-
Deprecated.
- compareAndSwap(long, long) - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Atomically updates the counter using a compare-and-swap operation.
- compareAndSwap(long, long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
- compareAndSwap(long, long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
- compareTo(Delayed) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
- compareTo(Delayed) - Method in class org.jgroups.util.TimeScheduler3.Task
- compareTo(Address) - Method in class org.jgroups.NullAddress
- compareTo(Address) - Method in class org.jgroups.protocols.relay.SiteMaster
- compareTo(Address) - Method in class org.jgroups.protocols.relay.SiteUUID
- compareTo(Address) - Method in class org.jgroups.stack.IpAddress
-
implements the java.lang.Comparable interface
- compareTo(Address) - Method in class org.jgroups.util.UUID
-
Compares this UUID with the specified UUID.
- compareTo(ForwardingRoute) - Method in class org.jgroups.protocols.relay.ForwardingRoute
- compareTo(Route) - Method in class org.jgroups.protocols.relay.Route
- compareTo(VERIFY_SUSPECT2.Entry) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- 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(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.
- CompletableFutures - Enum in org.jgroups.util
-
Utility class with
CompletableFuture
andCompletionStage
useful methods. - COMPLETE - org.jgroups.conf.XmlConfigurator.ElementType
- completedFalse() - Static method in enum org.jgroups.util.CompletableFutures
- completedNull() - Static method in enum org.jgroups.util.CompletableFutures
-
A
null
completedCompletableFuture
. - completedTrue() - Static method in enum org.jgroups.util.CompletableFutures
- completeExceptionally(Throwable) - Method in class org.jgroups.util.AsyncExecutor.Task
- Component - Annotation Type in org.jgroups.annotations
-
Tags components inside of protocols.
- components - Variable in class org.jgroups.jmx.ResourceDMBean
- components(String, String) - Static method in class org.jgroups.util.Util
- COMPOSITE_MSG - Static variable in interface org.jgroups.Message
- CompositeMessage - Class in org.jgroups
-
A message composed of multiple messages.
- CompositeMessage() - Constructor for class org.jgroups.CompositeMessage
- CompositeMessage(Address) - Constructor for class org.jgroups.CompositeMessage
- CompositeMessage(Address, Message...) - Constructor for class org.jgroups.CompositeMessage
- CompositeMessage.CompositeMessageIterator - Class in org.jgroups
- CompositeMessageIterator() - Constructor for class org.jgroups.CompositeMessage.CompositeMessageIterator
- 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
- computeAverage(double, int) - Method in class org.jgroups.protocols.RED
- computeBindPorts(int) - Method in class org.jgroups.protocols.FD_SOCK2
- computeBits() - Method in class org.jgroups.protocols.FD_ALL3
- computeCheckInterval() - Method in class org.jgroups.protocols.MERGE3
- computeDropProbability(double) - Method in class org.jgroups.protocols.RED
-
Computes a probability P with which the message should get dropped.
- computeFragOffsets(byte[], int) - Static method in class org.jgroups.util.Util
- 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.
- computeIndex(long) - Method in class org.jgroups.util.DynamicBuffer
-
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
- computeLowestCredit() - Method in class org.jgroups.util.CreditMap
-
Needs to be called with lock held
- computeLowestCreditWithAccumulated() - Method in class org.jgroups.util.CreditMap
- computeMin() - Method in class org.jgroups.util.AckTable
- computeNewMembership(Collection<Collection<Address>>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes a merge membership
- computeNewMembership(List<Address>, Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes the regular membership
- computeRow(long) - Method in class org.jgroups.util.DynamicBuffer
-
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.Buffer
-
Iterates from hd to high and adds 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.protocols.RATE_LIMITER2
- cond - Variable in class org.jgroups.util.CondVar
- cond - Variable in class org.jgroups.util.Promise
- cond - Variable in class org.jgroups.util.Responses
- condGet(Function<ThreadPoolExecutor, T>, T) - Method in class org.jgroups.util.TimeScheduler3
- condSet(Consumer<ThreadPoolExecutor>) - Method in class org.jgroups.util.TimeScheduler3
- 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 - 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.RELAY
- config - Variable in class org.jgroups.protocols.SOS
- config() - Method in class org.jgroups.protocols.relay.RELAY
- config(String) - Method in class org.jgroups.protocols.relay.RELAY
- CONFIG - Static variable in class org.jgroups.Event
- 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.RELAY
- configure() - Method in class org.jgroups.protocols.relay.RELAY2
- configure() - Method in class org.jgroups.protocols.relay.RELAY3
- conn - Variable in class org.jgroups.blocks.cs.NioClient
- conn - Variable in class org.jgroups.blocks.cs.TcpClient
- 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.UNICAST3
- conn_id - Variable in class org.jgroups.protocols.UNICAST3.Entry
- conn_listeners - Variable in class org.jgroups.blocks.cs.BaseServer
- connect() - Method in class org.jgroups.client.StompConnection
- connect() - Method in class org.jgroups.demos.StompChat
- connect() - Method in class org.jgroups.stack.RouterStub
- connect(String) - Method in class org.jgroups.fork.ForkChannel
-
Connects the fork-channel, which will be operational after this.
- connect(String) - Method in class org.jgroups.JChannel
-
Joins the cluster.
- connect(String, Address, long) - Method in class org.jgroups.fork.ForkChannel
- connect(String, Address, long) - Method in class org.jgroups.JChannel
-
Joins the cluster and gets the state from a specified state provider. This method invokes
connect
and
getState
methods.
- 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(SocketAddress) - Method in class org.jgroups.nio.MockSocketChannel
- 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(Address) - Method in class org.jgroups.blocks.cs.Connection
- connect(Address) - 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.NioConnection
- connect(Address, boolean, boolean) - Method in class org.jgroups.blocks.cs.TcpConnection
- CONNECT - org.jgroups.protocols.STOMP.ClientVerb
- CONNECT - Static variable in class org.jgroups.Event
- CONNECT - Static variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- connect_promise - Variable in class org.jgroups.protocols.FD_SOCK2.PingDest
- CONNECT_RSP - Static variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- connect_timeout - Variable in class org.jgroups.protocols.FD_SOCK2
- CONNECT_WITH_STATE_TRANSFER - Static variable in class org.jgroups.Event
- connected - Variable in class org.jgroups.blocks.cs.TcpConnection
- connected() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- connected(Connection) - Static method in class org.jgroups.blocks.cs.BaseServer
- CONNECTED - org.jgroups.JChannel.State
- CONNECTED - org.jgroups.protocols.FD_SOCK2.State
- CONNECTED - org.jgroups.protocols.STOMP.ServerVerb
- connectedStubs() - Method in class org.jgroups.stack.RouterStubManager
- CONNECTING - org.jgroups.JChannel.State
- 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.SimpleTCP.Connection
- Connection(Socket) - Constructor for class org.jgroups.protocols.STOMP.Connection
- connection_driver - Variable in class org.jgroups.protocols.JDBC_PING
- connection_driver - Variable in class org.jgroups.protocols.JDBC_PING2
- connection_password - Variable in class org.jgroups.protocols.JDBC_PING
- connection_password - Variable in class org.jgroups.protocols.JDBC_PING2
- connection_url - Variable in class org.jgroups.protocols.JDBC_PING
- connection_url - Variable in class org.jgroups.protocols.JDBC_PING2
- connection_username - Variable in class org.jgroups.protocols.JDBC_PING
- connection_username - Variable in class org.jgroups.protocols.JDBC_PING2
- connectionClosed(Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- connectionClosed(Connection) - Method in interface org.jgroups.blocks.cs.ConnectionListener
- connectionClosed(Connection) - Method in class org.jgroups.blocks.cs.TcpClient
- connectionClosed(Connection) - Method in class org.jgroups.demos.PubClient
- connectionClosed(Connection) - Method in class org.jgroups.protocols.FD_SOCK2
- connectionClosed(Connection) - Method in class org.jgroups.stack.GossipRouter
- connectionClosed(Connection) - 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.demos.PubClient
- connectionEstablished(Connection) - Method in class org.jgroups.protocols.FD_SOCK2
- 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
- ConnectionHandler(Socket) - Constructor for class org.jgroups.demos.EchoServer.ConnectionHandler
- connectionListener() - Method in class org.jgroups.stack.RouterStub
- connectionListener(RouterStub.CloseListener) - Method in class org.jgroups.stack.RouterStub
- ConnectionListener - Interface in org.jgroups.blocks.cs
- connections - Variable in class org.jgroups.protocols.SimpleTCP
- connections - Variable in class org.jgroups.protocols.STOMP
- 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
- connectTo(Address, Membership) - Method in class org.jgroups.protocols.FD_SOCK2
- connectTo(IpAddress, Address) - Method in class org.jgroups.protocols.FD_SOCK2
- connectToDestination(String) - Method in class org.jgroups.client.StompConnection
- connectToNextPingDest(Address) - Method in class org.jgroups.protocols.FD_SOCK2
- ConnectToNextPingDest - org.jgroups.protocols.FD_SOCK2.Request.Type
- connectToSingleDestination(String) - Method in class org.jgroups.client.StompConnection
- 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.UnicastHeader3
- conns - Variable in class org.jgroups.blocks.cs.BaseServer
- 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
- Constructable<T> - Interface in org.jgroups
-
Interface returning a supplier which can be called to create an instance
- consumer_lock - Variable in class org.jgroups.util.ProcessingQueue
- container - Variable in class org.jgroups.protocols.RACKSPACE_PING
- container - Variable in class org.jgroups.protocols.SWIFT_PING
- contains(String, Address) - Method in class org.jgroups.protocols.JDBC_PING
- contains(List<Route>, Address) - Static method in class org.jgroups.protocols.relay.Bridge
- contains(List<Route>, Address) - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
- contains(K) - Method in class org.jgroups.util.AgeOutCache
- contains(K) - Method in class org.jgroups.util.ExpiryCache
- contains(Address) - Method in class org.jgroups.Membership
-
Returns true if the provided member belongs to this membership
- contains(Address) - Method in class org.jgroups.util.Digest
- 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(int) - Method in class org.jgroups.util.IntHashMap
- containsKey(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- containsKey(K) - Method in class org.jgroups.blocks.LazyRemovalCache
- 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
- 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<Object, Object>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- contentsSet(Map<K, V>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- Context(SSLContext, KeyManager, TrustManager) - Constructor for class org.jgroups.util.SslContextFactory.Context
- contiguousSpaceAvailable() - Method in class org.jgroups.util.RequestTable
-
Checks if there is at least buffer.length/2 contiguous space in range [low+1 ..
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in interface org.jgroups.conf.PropertyConverter
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.BindInterface
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.Default
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.PolicyConverter
- convert(Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.util.TLS.SniMatcherConverter
- convert(String, Class<?>, TimeUnit) - Static method in class org.jgroups.util.Util
- convert(Map<String, Map<String, Object>>, Map<String, String>) - Static method in class org.jgroups.JChannelProbeHandler
- convert(Map<String, Map<String, Object>>, Map<String, String>) - Static method in class org.jgroups.jmx.ReflectUtils
- convert(Map<String, Map<String, Metrics.Entry<Object>>>) - Static method in class org.jgroups.util.Metrics
- convert(Property, Object, Class<?>, String, String, boolean, StackType) - Method in interface org.jgroups.conf.PropertyConverter
- convert(Property, Object, Class<?>, String, String, boolean, StackType) - Method in class org.jgroups.conf.PropertyConverters.Default
- converter() - Method in annotation type org.jgroups.annotations.Property
- convertProtocol(Map<String, Metrics.Entry<Object>>) - Static method in class org.jgroups.util.Metrics
- 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.COUNTER
-
The address of the cluster coordinator.
- coord - Variable in class org.jgroups.protocols.SEQUENCER
- coord - Variable in class org.jgroups.protocols.SEQUENCER2
- coord(boolean) - Method in class org.jgroups.protocols.PingData
- coord(boolean) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- COORD - Static variable in class org.jgroups.protocols.pbcast.GMS
- COORD_LEAVE - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- coordChanged(Address) - Method in class org.jgroups.protocols.pbcast.Leaver
-
Callback to notify Leaver that the coord changed.
- coordChanged(Address, Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- coordChanged(Address, Address) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- 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.nio.Buffers
-
Copies the data that has not yet been written and moves last_copied.
- copy() - Method in class org.jgroups.protocols.NakAckHeader
- copy() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- copy() - Method in class org.jgroups.protocols.relay.RelayHeader
- 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.UnicastHeader3
- copy() - Method in class org.jgroups.stack.IpAddress
- copy() - Method in class org.jgroups.stack.StateTransferInfo
- copy() - Method in class org.jgroups.util.ByteArray
- copy() - Method in class org.jgroups.util.Digest
- copy() - Method in class org.jgroups.util.UUID
- copy() - Method in class org.jgroups.ViewId
- copy(boolean, boolean) - Method in class org.jgroups.BaseMessage
-
Copies the source- and destination addresses, flags and headers (if copy_headers is true).
If copy_payload is set, then methodBaseMessage.copyPayload(Message)
of the subclass will be called, which is responsible for copying the payload specific to that message type.
Note that for headers, only the arrays holding references to the headers are copied, not the headers themselves ! The consequence is that the headers array of the copy hold the *same* references as the original, so do *not* modify the headers ! If you want to change a header, copy it and callMessage.putHeader(short,Header)
again. - copy(boolean, boolean) - Method in class org.jgroups.BatchMessage
-
Create a shallow copy of this
BatchMessage
. - copy(boolean, boolean) - Method in class org.jgroups.CompositeMessage
-
Create a copy of this
CompositeMessage
. - copy(boolean, boolean) - Method in interface org.jgroups.Message
-
Copies a message
- copy(boolean, boolean) - Method in class org.jgroups.NioMessage
-
Create a copy of the message.
Note that for headers, only the arrays holding references to the headers are copied, not the headers themselves ! The consequence is that the headers array of the copy hold the *same* references as the original, so do *not* modify the headers ! If you want to change a header, copy it and callBaseMessage.putHeader(short,Header)
again. - copy(Reader, Writer) - Static method in class org.jgroups.util.PropertiesToAsciidoc
- copy(Header[]) - Static method in class org.jgroups.util.Headers
- copy(Message) - Method in class org.jgroups.protocols.relay.RELAY
-
Copies the message, but only the headers above the current protocol (RELAY) (or RpcDispatcher related headers)
- copy(Message, boolean, short, short...) - Static method in class org.jgroups.util.Util
-
Copies a message.
- 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
- copyOnPartialWrite() - Method in class org.jgroups.blocks.cs.NioBaseServer
- copyOnPartialWrite() - Method in class org.jgroups.blocks.cs.NioConnection
- copyOnPartialWrite() - Method in class org.jgroups.protocols.TCP_NIO2
- copyOnPartialWrite(boolean) - Method in class org.jgroups.blocks.cs.NioBaseServer
- copyOnPartialWrite(boolean) - Method in class org.jgroups.blocks.cs.NioConnection
- copyOnPartialWrite(boolean) - Method in class org.jgroups.protocols.TCP_NIO2
- copyPayload(Message) - Method in class org.jgroups.BaseMessage
-
Copies the payload
- copyPayload(Message) - Method in class org.jgroups.BytesMessage
-
Copies the byte array.
- copyPayload(Message) - Method in class org.jgroups.FragmentedMessage
- copyPayload(Message) - Method in class org.jgroups.LongMessage
- copyPayload(Message) - Method in class org.jgroups.NioMessage
- copyPayload(Message) - Method in class org.jgroups.ObjectMessage
- 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
- 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.protocols.DETECT_LOOPBACKS
- count - Variable 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 - Variable in class org.jgroups.util.SizeBoundedQueue
- count - Variable in class org.jgroups.util.SuppressCache.Value
- count() - Method in class org.jgroups.util.Average
- count() - Method in class org.jgroups.util.FastArray
-
Returns the number of non-null elements, should have the same result as size().
- count() - Method in class org.jgroups.util.SuppressCache.Value
- count(boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- count(boolean) - Method in class org.jgroups.util.RingBufferSeqnoOld
- counter - Variable in class org.jgroups.util.DefaultThreadFactory
- Counter - Interface in org.jgroups.blocks.atomic
-
Deprecated.Since 5.2 and to be removed in a future version. Use
SyncCounter
instead. - 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_prot - Variable in class org.jgroups.blocks.atomic.CounterService
- COUNTER.AddAndGetRequest - 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.ReconcileRequest - Class in org.jgroups.protocols
- COUNTER.ReconcileResponse - Class in org.jgroups.protocols
- COUNTER.ReconciliationTask - Class in org.jgroups.protocols
- COUNTER.Request - Interface in org.jgroups.protocols
- COUNTER.RequestType - Enum in org.jgroups.protocols
- COUNTER.ResendPendingRequests - 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.UpdateRequest - Class in org.jgroups.protocols
- COUNTER.ValueResponse - Class in org.jgroups.protocols
- COUNTER.VersionedValue - Class in org.jgroups.protocols
- CounterFunction<T extends Streamable> - Interface in org.jgroups.blocks.atomic
-
A function to update
AsyncCounter
orSyncCounter
. - 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(JChannel) - Constructor for class org.jgroups.blocks.atomic.CounterService
- CounterServiceDemo - Class in org.jgroups.demos
- CounterServiceDemo() - Constructor for class org.jgroups.demos.CounterServiceDemo
- CounterView - Interface in org.jgroups.blocks.atomic
-
A view representing the counter's state.
- countLockLockless() - Method in class org.jgroups.util.RingBuffer
- countNonSetMembers() - Method in class org.jgroups.util.MutableDigest
- cpu_time - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- create() - Method in class org.jgroups.BatchMessage
- create() - Method in class org.jgroups.blocks.MethodCall
- create() - Method in interface org.jgroups.blocks.ReplCache.HashFunctionFactory
- create() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- create() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
- create() - Method in class org.jgroups.BytesMessage
- create() - Method in class org.jgroups.CompositeMessage
- create() - Method in interface org.jgroups.Constructable
-
Creates an instance of the class implementing this interface
- create() - Method in class org.jgroups.EmptyMessage
- create() - Method in class org.jgroups.FragmentedMessage
- create() - Method in class org.jgroups.LongMessage
- create() - Method in class org.jgroups.MergeView
- create() - Method in class org.jgroups.NioMessage
- create() - Method in class org.jgroups.ObjectMessage
- create() - Method in class org.jgroups.protocols.AuthHeader
- create() - Method in class org.jgroups.protocols.BATCH.BatchHeader
- create() - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- create() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- create() - Method in class org.jgroups.protocols.COUNTER.CounterHeader
- create() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- create() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- create() - Method in class org.jgroups.protocols.EncryptHeader
- create() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
- create() - Method in class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- create() - Method in class org.jgroups.protocols.FcHeader
- create() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- create() - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- create() - Method in class org.jgroups.protocols.FORK.ForkHeader
- create() - Method in class org.jgroups.protocols.Frag3Header
- create() - Method in class org.jgroups.protocols.FragHeader
- create() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
- create() - Method in class org.jgroups.protocols.NakAckHeader
- create() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- create() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- create() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- create() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- create() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- create() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- create() - Method in class org.jgroups.protocols.PERF.PerfHeader
- create() - Method in class org.jgroups.protocols.PingData
- create() - Method in class org.jgroups.protocols.PingHeader
- create() - Method in class org.jgroups.protocols.ProtPerfHeader
- create() - Method in class org.jgroups.protocols.relay.RelayHeader
- create() - Method in class org.jgroups.protocols.relay.SiteMaster
- create() - Method in class org.jgroups.protocols.relay.SiteUUID
- create() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- create() - Method in class org.jgroups.protocols.RTTHeader
- create() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- create() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- create() - Method in class org.jgroups.protocols.STOMP.StompHeader
- create() - Method in class org.jgroups.protocols.TpHeader
- create() - Method in class org.jgroups.protocols.UnicastHeader3
- create() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- create() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- create() - Method in class org.jgroups.stack.IpAddress
- create() - Method in class org.jgroups.util.Digest
- create() - Method in class org.jgroups.util.ExtendedUUID
- create() - Method in class org.jgroups.util.FlagsUUID
- create() - Method in class org.jgroups.util.MutableDigest
- create() - Method in class org.jgroups.util.SeqnoList
- create() - Method in class org.jgroups.util.UUID
- create() - Method in class org.jgroups.View
- create() - Method in class org.jgroups.ViewId
- create(short) - Static method in class org.jgroups.conf.ClassConfigurator
- create(short) - Method in class org.jgroups.DefaultMessageFactory
- create(short) - Method in interface org.jgroups.MessageFactory
-
Creates a message based on the given ID
- create(Address) - Static method in class org.jgroups.util.MergeId
- create(Address, long, Collection<Address>) - Static method in class org.jgroups.View
- create(Address, long, Address...) - Static method in class org.jgroups.View
- createAcceptor() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- createAckHeader(long) - Static method in class org.jgroups.protocols.NakAckHeader
- createAckHeader(long, short, int) - Static method in class org.jgroups.protocols.UnicastHeader3
- createAndRegisterStub(InetSocketAddress, InetSocketAddress) - Method in class org.jgroups.stack.RouterStubManager
- createAndRegisterStub(InetSocketAddress, InetSocketAddress, int) - 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
- createBuffer(byte[], int, int) - Method in class org.jgroups.NioMessage
- createBufferedInputStream(InputStream) - Method in class org.jgroups.protocols.SimpleTCP.Connection
- createBufferedOutputStream(OutputStream) - Method in class org.jgroups.protocols.SimpleTCP.Connection
- createBundler(String, Class<?>) - Static 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
- createCipher(String) - Method in class org.jgroups.protocols.Encrypt
- createClient(SocketFactory) - Method in class org.jgroups.stack.RouterStub
- createCloseHeader(short) - Static method in class org.jgroups.protocols.UnicastHeader3
- createConcurrentMap() - Static method in class org.jgroups.util.Util
- createConcurrentMap(int) - Static method in class org.jgroups.util.Util
- createConcurrentMap(int, float, int) - 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
- createContainer(String) - Method in class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
Create a container, which is equivalent to a bucket
- createContainer(String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Create a container, which is equivalent to a bucket
- createContext() - Method in class org.jgroups.util.TLS
- createCredit(int) - Method in class org.jgroups.protocols.UFC_NB
- createCredit(int) - Method in class org.jgroups.protocols.UFC
- createCreditMap(long) - Method in class org.jgroups.protocols.MFC_NB
- createCreditMap(long) - Method in class org.jgroups.protocols.MFC
- createDaemons - Variable in class org.jgroups.util.DefaultThreadFactory
- createDatagramSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
- createDatagramSocket(String) - Method in interface org.jgroups.util.SocketFactory
- createDatagramSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createDatagramSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
- createDatagramSocket(String, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
- createDatagramSocket(String, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
- createDatagramSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
- createDatagramSocket(String, SocketAddress) - 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.UnicastHeader3
- createDataInputStream(InputStream) - Method in class org.jgroups.blocks.cs.TcpConnection
- createDataOutputStream(OutputStream) - Method in class org.jgroups.blocks.cs.TcpConnection
- createDeltaView(View, View) - Static method in class org.jgroups.protocols.pbcast.GMS
- createDiagnosticsHandler() - Method in class org.jgroups.protocols.TP
- createDigest(String, long, double) - Static method in class org.jgroups.util.Util
- createDiskCacheFile() - Method in class org.jgroups.protocols.PDC
- createEmptyArray(int) - Static method in class org.jgroups.util.MutableDigest
- createEnum(String, Type) - Static method in class org.jgroups.util.Util
-
Creates an enum from a string
- 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.BaseMessage
- createHighestSeqnoHeader(long) - Static method in class org.jgroups.protocols.NakAckHeader
- 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
- createInsertStoredProcedure() - Method in class org.jgroups.protocols.JDBC_PING2
- createLayer(ProtocolStack, ProtocolConfiguration) - Static method in class org.jgroups.stack.Configurator
- createLocalAddress() - Method in class org.jgroups.protocols.UDP
- createMessage() - Method in class org.jgroups.BytesMessage
- createMessage() - Method in class org.jgroups.FragmentedMessage
- createMessage(Address, Address, Address, Message, Collection<String>) - Method in class org.jgroups.protocols.relay.Route
- createMessageHeader(long) - Static method in class org.jgroups.protocols.NakAckHeader
- createMessageHeader(long) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
- createMulticastSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
- createMulticastSocket(String) - Method in interface org.jgroups.util.SocketFactory
- createMulticastSocket(String, int) - Method in class org.jgroups.protocols.MPING
- createMulticastSocket(String, int) - Method in class org.jgroups.protocols.UDP
- createMulticastSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createMulticastSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
- createMulticastSocket(String, SocketAddress) - Method in class org.jgroups.util.DefaultSocketFactory
- 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(String) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- createObject(String, String, byte[]) - Method in class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
Create an object (=file)
- createObject(String, String, byte[]) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Create an object (=file)
- createProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
- createProtocol(String, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
- createProtocol(String, ProtocolStack, boolean) - Static method in class org.jgroups.stack.Configurator
-
Creates a new protocol given the protocol specification.
- createProtocols(List<ProtocolConfiguration>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
Takes a list of configurations, creates a protocol for each and returns all protocols in a list.
- createProtocolsAndInitializeAttrs(List<ProtocolConfiguration>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
- 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, Address) - Method in class org.jgroups.protocols.UNICAST3
- createReceivers(int, DatagramSocket, String) - Method in class org.jgroups.protocols.UDP
- createRequestCorrelator(Protocol, RequestHandler, Address) - Static method in class org.jgroups.blocks.MessageDispatcher
- createRootDir() - Method in class org.jgroups.protocols.FILE_PING
- createRootDir() - Method in class org.jgroups.protocols.JDBC_PING
- createRootDir() - Method in class org.jgroups.protocols.JDBC_PING2
- createRootDir() - Method in class org.jgroups.protocols.RACKSPACE_PING
- createRootDir() - Method in class org.jgroups.protocols.SWIFT_PING
- createSchema() - Method in class org.jgroups.protocols.JDBC_PING2
- createSecretKey() - 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
- createSecretKey(String, int) - Static method in class org.jgroups.demos.KeyStoreGenerator
- createSecretKeyRequest(byte[]) - Static method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- createSecretKeyResponse(byte[], byte[], byte[]) - Static method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- createSendFirstSeqnoHeader(int) - Static method in class org.jgroups.protocols.UnicastHeader3
- createServer(int[]) - Method in class org.jgroups.protocols.FD_SOCK2
- createServerSocket() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- createServerSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
- createServerSocket(String) - Method in interface org.jgroups.util.SocketFactory
- createServerSocket(String, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createServerSocket(String, int) - Method in interface org.jgroups.util.SocketFactory
- createServerSocket(String, int, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createServerSocket(String, int, int) - Method in interface org.jgroups.util.SocketFactory
- createServerSocket(String, int, int, InetAddress) - Method in class org.jgroups.util.DefaultSocketFactory
- createServerSocket(String, int, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
- createServerSocket(SocketFactory, String, InetAddress, int, int, int) - Static method in class org.jgroups.util.Util
- createServerSocketChannel(String) - Method in interface org.jgroups.util.SocketFactory
- createServerSocketChannel(String, int) - Method in interface org.jgroups.util.SocketFactory
- createServerSocketChannel(String, int, int) - Method in interface org.jgroups.util.SocketFactory
- createServerSocketChannel(String, int, int, InetAddress) - Method in interface org.jgroups.util.SocketFactory
- createServerSocketChannel(SocketFactory, String, InetAddress, int, int, int) - Static method in class org.jgroups.util.Util
- createSocket(String) - Method in class org.jgroups.util.DefaultSocketFactory
- createSocket(String) - Method in interface org.jgroups.util.SocketFactory
- createSocket(String, String, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createSocket(String, String, int) - Method in interface org.jgroups.util.SocketFactory
- createSocket(String, String, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createSocket(String, String, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
- createSocket(String, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createSocket(String, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
- createSocket(String, InetAddress, int, InetAddress, int) - Method in class org.jgroups.util.DefaultSocketFactory
- createSocket(String, InetAddress, int, InetAddress, int) - Method in interface org.jgroups.util.SocketFactory
- createSocketChannel(String) - Method in interface org.jgroups.util.SocketFactory
- createSocketChannel(String, SocketAddress) - Method in interface org.jgroups.util.SocketFactory
- createSocketFactory() - Method in class org.jgroups.util.TLS
- createSocketFactory(SSLContext) - Method in class org.jgroups.util.TLS
- 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
- createSocketTo(IpAddress, SSLSocketFactory) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- createStreamToProvider(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.STATE
- 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
- createTable(long) - Method in class org.jgroups.protocols.UNICAST3
- createThread(Runnable, String, boolean, boolean) - Static method in class org.jgroups.util.ThreadCreator
- createThreadPool() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- createThreadPool(int, int, long, boolean, Log) - Static method in class org.jgroups.util.ThreadCreator
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) - Static method in class org.jgroups.util.ThreadPool
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory, boolean, Log) - Static method in class org.jgroups.util.ThreadCreator
- createTimeoutChecker() - Method in class org.jgroups.protocols.FailureDetection
- 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.UnicastHeader3
- createXmitRequestHeader(Address) - Static method in class org.jgroups.protocols.NakAckHeader
- createXmitRequestHeader(Address) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
- createXmitResponseHeader() - Static method in class org.jgroups.protocols.NakAckHeader
- createXmitResponseHeader() - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
- createXmitWindow(long) - Method in class org.jgroups.protocols.NAKACK3
- createXmitWindow(long) - Method in class org.jgroups.protocols.NAKACK4
- createXmitWindow(long) - Method in class org.jgroups.protocols.ReliableMulticast
- creation_time - Variable in class org.jgroups.util.TimeScheduler3.Task
- creator - Variable in class org.jgroups.ViewId
- creators - Variable in class org.jgroups.DefaultMessageFactory
- Credit - Class in org.jgroups.util
-
Maintains credits for a unicast destination.
- Credit(long) - Constructor for class org.jgroups.util.Credit
- Credit(long, Lock) - Constructor for class org.jgroups.util.Credit
- CREDIT_REQUEST - Static variable in class org.jgroups.protocols.FcHeader
- credit_send_task - Variable in class org.jgroups.protocols.MFC_NB
- credit_send_task - Variable in class org.jgroups.protocols.UFC_NB
- 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
- CreditMap(long, Lock) - 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.Credit
- credits_available - Variable in class org.jgroups.util.CreditMap
- credits_left - Variable in class org.jgroups.util.Credit
- ctor_class - Static variable in class org.jgroups.logging.LogFactory
- curr - Variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- curr_id - Variable in class org.jgroups.protocols.FRAG
- curr_id - Variable in class org.jgroups.protocols.FRAG2
-
Used to assign fragmentation-specific sequence IDs (monotonically increasing)
- curr_id - Variable in class org.jgroups.protocols.FRAG3
- curr_mbrs - Variable in class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
- curr_view - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
- current - Variable in class org.jgroups.util.FixedBuffer.FixedBufferIterator
- current - Variable in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
- current - Variable in class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- current_coord - Variable in class org.jgroups.protocols.Discovery
- current_id - Variable in class org.jgroups.protocols.RSVP
-
ID to be used to identify messages.
- current_index - Variable in class org.jgroups.BatchMessage.BatchMessageIterator
- current_index - Variable in class org.jgroups.CompositeMessage.CompositeMessageIterator
- current_index - Variable in class org.jgroups.util.FastArray.FastIterator
- current_period_start - Variable in class org.jgroups.protocols.RATE_LIMITER
- current_receive_rate - Variable in class org.jgroups.protocols.RATE
- current_row - Variable in class org.jgroups.util.DynamicBuffer.TableIterator
- current_row - Variable in class org.jgroups.util.Table.TableIterator
- current_send_rate - Variable in class org.jgroups.protocols.RATE
- currentIndex() - Method in class org.jgroups.util.FastArray.FastIterator
- currentReceiveRate() - Method in class org.jgroups.protocols.RATE
- currentSendRate() - Method in class org.jgroups.protocols.RATE
- 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
- d - Variable in class org.jgroups.demos.Draw.DrawPanel
- daemon - Variable in class org.jgroups.util.Runner
- daemon() - Method in class org.jgroups.util.Runner
- daemon(boolean) - Method in class org.jgroups.util.Runner
- 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(Address) - Constructor for class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- data - Variable in class org.jgroups.blocks.GridFilesystem
- data - Variable in class org.jgroups.util.Responses.PingDataIterator
- DATA - Static variable in class org.jgroups.protocols.relay.RelayHeader
- DATA - Static variable in class org.jgroups.protocols.UnicastHeader3
- dataSource - Variable in class org.jgroups.protocols.JDBC_PING
- dataSource - Variable in class org.jgroups.protocols.JDBC_PING2
- datasource_injecter_class - Variable in class org.jgroups.protocols.JDBC_PING
- datasource_injecter_class - Variable in class org.jgroups.protocols.JDBC_PING2
- datasource_jndi_name - Variable in class org.jgroups.protocols.JDBC_PING
- datasource_jndi_name - Variable in class org.jgroups.protocols.JDBC_PING2
- debug(String) - Method in class org.jgroups.logging.JDKLogImpl
- debug(String) - Method in interface org.jgroups.logging.Log
- debug(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- debug(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- debug(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- debug(String, Object...) - Method in interface org.jgroups.logging.Log
- debug(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- debug(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- debug(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
- debug(String, Throwable) - Method in interface org.jgroups.logging.Log
- debug(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
- debug(String, Throwable) - Method in class org.jgroups.logging.Slf4jLogImpl
- 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(short) - Static method in class org.jgroups.Version
- 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 - Static variable in class org.jgroups.util.Base64
-
Specify decoding in first bit.
- 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
- 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
- decrCount() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- decrement(long) - Method in class org.jgroups.util.Credit
- decrement(long) - Method in class org.jgroups.util.CreditMap
- decrement(Message, int, long) - Method in class org.jgroups.util.CreditMap
-
Decrements credits bytes from all.
- decrement(Message, int, long) - Method in class org.jgroups.util.NonBlockingCreditMap
- decrementAndAdd(Address, long) - Method in class org.jgroups.util.CreditMap
-
Decrements credits bytes from all elements and adds new_credits to member (if non null).
- decrementAndGet() - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically decrements the counter and returns the new value
- decrementAndGet() - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Atomically decrements the counter and returns the new value
- decrementAndGet(long, long, long) - Method in class org.jgroups.util.Credit
- decrementIfEnoughCredits(Message, int, long) - Method in class org.jgroups.util.Credit
- decrementIfEnoughCredits(Message, int, long) - Method in class org.jgroups.util.NonBlockingCredit
-
Decrements the sender's credits by the size of the message.
- decrypt(Cipher, Message) - Method in class org.jgroups.protocols.Encrypt
-
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 - Static variable in class org.jgroups.util.Buffer.Options
- DEFAULT() - Static method in class org.jgroups.util.Buffer.Options
- default_chunk_size - Variable in class org.jgroups.blocks.GridFilesystem
- DEFAULT_DIAG_ADDR - Static variable in class org.jgroups.Global
- DEFAULT_DIAG_ADDR_IPv6 - Static variable in class org.jgroups.Global
- 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.DynamicBuffer
- DEFAULT_MAX_COMPACTION_TIME - Static variable in class org.jgroups.util.Table
- DEFAULT_PROTOCOL_STACK - Static variable in class org.jgroups.Global
- default_repl_count - Variable in class org.jgroups.blocks.GridFilesystem
- DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.DynamicBuffer
- DEFAULT_RESIZE_FACTOR - Static variable in class org.jgroups.util.Table
- DEFAULT_SSL_PROTOCOL - Static variable in class org.jgroups.util.SslContextFactory
- DEFAULT_SYM_ALGO - Static variable in class org.jgroups.protocols.Encrypt
- DEFAULT_XMIT_INTERVAL - Static variable in class org.jgroups.protocols.UNICAST3
- DefaultDNSResolver - Class in org.jgroups.protocols.dns
- DefaultDNSResolver(String, String) - Constructor for class org.jgroups.protocols.dns.DefaultDNSResolver
- DefaultDNSResolver(DirContext) - Constructor for class org.jgroups.protocols.dns.DefaultDNSResolver
- defaultHeaders(boolean) - Method in class org.jgroups.protocols.TP
- DefaultMembershipPolicy() - Constructor for class org.jgroups.protocols.pbcast.GMS.DefaultMembershipPolicy
- DefaultMessageFactory - Class in org.jgroups
-
Default implementation of
MessageFactory
. - DefaultMessageFactory() - Constructor for class org.jgroups.DefaultMessageFactory
- DefaultRouteStatusListener - Class in org.jgroups.protocols.relay
-
The default implementation of
RouteStatusListener
- DefaultRouteStatusListener(Supplier<Address>) - Constructor for class org.jgroups.protocols.relay.DefaultRouteStatusListener
- DefaultSocketFactory - Class in org.jgroups.util
-
Default implementation, ignores service names
- DefaultSocketFactory() - Constructor for class org.jgroups.util.DefaultSocketFactory
- DefaultSocketFactory(SocketFactory, ServerSocketFactory) - Constructor for class org.jgroups.util.DefaultSocketFactory
- DefaultSocketFactory(SSLContext) - 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
- defaultValueIPv4() - Method in annotation type org.jgroups.annotations.Property
-
Global.NON_LOOPBACK_ADDRESS means pick any valid non-loopback IPv4 address
- defaultValueIPv6() - Method in annotation type org.jgroups.annotations.Property
-
Global.NON_LOOPBACK_ADDRESS means pick any valid non-loopback IPv6 address
- defer_client_bind_addr - Variable in class org.jgroups.protocols.BasicTCP
- defer_client_binding - Variable in class org.jgroups.blocks.cs.BaseServer
- deferClientBindAddr() - Method in class org.jgroups.protocols.BasicTCP
- deferClientBindAddr(boolean) - Method in class org.jgroups.protocols.BasicTCP
- 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 - Variable in class org.jgroups.util.TimeScheduler3.Task
- 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_site_unreachable_events - Variable in class org.jgroups.protocols.relay.RELAY3
- delay_sites_down - Variable in class org.jgroups.protocols.relay.RELAY
- delayed_message_handler - Variable in class org.jgroups.protocols.DELAY
- delayed_messages - Variable in class org.jgroups.protocols.DELAY
- Delayer<T> - Class in org.jgroups.util
-
Collects actions by key and executes them - if a predicate is true - every N ms.
- Delayer(long) - Constructor for class org.jgroups.util.Delayer
- Delayer.Entry - Class in org.jgroups.util
- delaySitesDown() - Method in class org.jgroups.protocols.relay.RELAY
- delaySitesDown(boolean) - Method in class org.jgroups.protocols.relay.RELAY
- delaySiteUnreachableEvents() - Method in class org.jgroups.protocols.relay.RELAY3
- delaySiteUnreachableEvents(long) - Method in class org.jgroups.protocols.relay.RELAY3
- delete() - Method in class org.jgroups.blocks.GridFile
- delete(boolean) - Method in class org.jgroups.blocks.GridFile
- delete(String, String) - Method in class org.jgroups.protocols.JDBC_PING
- delete(String, Address) - Method in class org.jgroups.protocols.JDBC_PING2
- delete(Connection, String, String) - Method in class org.jgroups.protocols.JDBC_PING
- delete(Connection, String, Address) - Method in class org.jgroups.protocols.JDBC_PING2
- DELETE - org.jgroups.protocols.COUNTER.RequestType
- delete_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
- delete_single_sql - Variable in class org.jgroups.protocols.JDBC_PING2
- 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.RACKSPACE_PING.RackspaceClient
-
Delete a object (=file) from the storage
- 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
- deliver(Address, Address, Message) - Method in class org.jgroups.protocols.relay.RELAY2
- deliver(Address, Message, boolean) - Method in class org.jgroups.protocols.relay.RELAY3
-
Sends the message to a local destination.
- deliver(Address, Message, boolean, boolean, boolean) - Method in class org.jgroups.protocols.relay.RELAY3
- deliver(Message, Address, long, String) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- deliver(Message, Address, long, Buffer<Message>, String) - Method in class org.jgroups.protocols.ReliableMulticast
- deliver(Message, SEQUENCER.SequencerHeader) - Method in class org.jgroups.protocols.SEQUENCER
- deliver(Message, SEQUENCER2.SequencerHeader) - Method in class org.jgroups.protocols.SEQUENCER2
- 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
- deliverBatch(MessageBatch, Buffer<Message>) - Method in class org.jgroups.protocols.ReliableMulticast
- delivered_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
- deliverLocally(SiteAddress, SiteAddress, Message) - Method in class org.jgroups.protocols.relay.RELAY2
- deliverMessage(Message, Address, long) - Method in class org.jgroups.protocols.UNICAST3
- delivery_table - Variable in class org.jgroups.protocols.SEQUENCER
- delivery_table_max_size - Variable in class org.jgroups.protocols.SEQUENCER
- delta - Variable in class org.jgroups.util.ThreadPool
- 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
- dependsUpon() - Method in annotation type org.jgroups.annotations.Property
- deprecatedMessage() - Method in annotation type org.jgroups.annotations.Component
- deprecatedMessage() - Method in annotation type org.jgroups.annotations.Property
- description - Variable in class org.jgroups.util.Metrics.Entry
- description - Static variable in class org.jgroups.Version
- description() - Method in annotation type org.jgroups.annotations.Component
- description() - Method in annotation type org.jgroups.annotations.ManagedAttribute
- description() - Method in annotation type org.jgroups.annotations.ManagedOperation
- description() - Method in annotation type org.jgroups.annotations.MBean
- description() - Method in annotation type org.jgroups.annotations.Property
- description() - Method in class org.jgroups.util.Metrics.Entry
- deserialize(byte[], int, int) - Static method in class org.jgroups.protocols.Discovery
- deserialize(long) - Method in class org.jgroups.protocols.RTTHeader
-
Sets either
RTTHeader.deserialize_req
orRTTHeader.deserialize_rsp
; same logic asRTTHeader.serialize(long)
. - deserialize(Address, byte[], int, int) - Method in class org.jgroups.protocols.SERIALIZE
- deserialize_req - Variable in class org.jgroups.protocols.RTTHeader
- deserialize_rsp - Variable in class org.jgroups.protocols.RTTHeader
- desired_avg_gossip - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Sends a STABLE gossip every 20 seconds on average.
- dest - Variable in class org.jgroups.BaseMessage
- dest - Variable in class org.jgroups.protocols.BPING
- dest - Variable in class org.jgroups.protocols.FD_SOCK2.PingDest
- dest - Variable in class org.jgroups.util.MessageBatch
-
The destination address.
- dest() - Method in interface org.jgroups.Message
- dest() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- dest() - Method in class org.jgroups.util.MessageBatch
- dest(Address) - Method in interface org.jgroups.Message
- dest(Address) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- dest(Address) - Method in class org.jgroups.util.MessageBatch
- dest_addr - Variable in class org.jgroups.protocols.BPING
- dest_physical - Variable in class org.jgroups.protocols.FD_SOCK2.PingDest
- destChanged(Address) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- DESTINATION - Static variable in class org.jgroups.demos.StompChat
- destPhysical() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- destPhysical(IpAddress) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- destroy() - Method in class org.jgroups.auth.AuthToken
- destroy() - Method in class org.jgroups.fork.ForkProtocolStack
- destroy() - Method in interface org.jgroups.Lifecycle
-
Called after an instance has been stopped.
- 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.dns.DNS_PING
- destroy() - Method in interface org.jgroups.protocols.LocalTransport
- destroy() - Method in class org.jgroups.protocols.NAKACK4
- destroy() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- destroy() - Method in class org.jgroups.protocols.relay.RELAY3
- destroy() - Method in class org.jgroups.protocols.RSVP.Entry
- destroy() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- destroy() - Method in class org.jgroups.protocols.SHUFFLE
- destroy() - Method in class org.jgroups.protocols.SimpleTCP
- 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.VERIFY_SUSPECT2
- destroy() - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
Called before the transport is stopped
- destroy() - Method in class org.jgroups.stack.Protocol
-
This method is called on a
JChannel.close()
. - 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.MaxOneThreadPerSender
- destroy() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- destroy() - Method in class org.jgroups.util.RingBufferSeqnoOld
- destroy() - Method in class org.jgroups.util.ThreadPool
- destroySockets() - Method in class org.jgroups.protocols.UDP
- destroyStubs() - Method in class org.jgroups.stack.RouterStubManager
- dests - Variable in class org.jgroups.protocols.PerDestinationBundler
- details() - Method in class org.jgroups.util.Profiler
- details(boolean) - Method in class org.jgroups.util.Profiler
- DETECT_LOOPBACKS - Class in org.jgroups.protocols
-
Detects unicast loopbacks: messages where dest == local address
- DETECT_LOOPBACKS() - Constructor for class org.jgroups.protocols.DETECT_LOOPBACKS
- detectDifferentViews(Map<Address, View>) - Static method in class org.jgroups.protocols.MERGE3
- determineActualMergeCoords(Map<Address, View>) - Static method in class org.jgroups.util.Util
-
Similar to
Util.determineMergeCoords(java.util.Map)
but only actual coordinators are counted: an actual coord is when the sender of a view is the first member of that view - determineCoordinator() - Method in class org.jgroups.JChannel
- 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() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- determineFlags(View, Digest) - Static method in class org.jgroups.protocols.pbcast.GMS
- 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
-
This is the same or a subset of
Util.determineMergeParticipants(java.util.Map)
and contains only members which are currently sub-partition coordinators. - 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
- determineMode(Message) - Method in class org.jgroups.util.MessageBatch
- determineNextCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
-
Returns the second-in-line
- determinePingDest() - Method in class org.jgroups.protocols.FD_SOCK
- determineSiteMasters(View, int) - Static method in class org.jgroups.protocols.relay.RELAY
-
Iterates over the list of members and adds every member if the member's rank is below max_site_masters.
- dh_key - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
-
The public key used for the Diffie-Hellman key exchange to obtain the session key (used to encrypt the keyserver's secret key)
- dh_key - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- DH_KEY_EXCHANGE - Class in org.jgroups.protocols
-
Key exchange based on Diffie-Hellman-Merkle (https://en.wikipedia.org/wiki/Diffie%E2%80%93Hellman_key_exchange).
Diffie-Hellman is used between a member and a key server (the coordinator) to obtain a session key (only known to the key server and the joiner) which is used by the key server to encrypt the shared secret symmetric (group) key and by the requester to decrypt the group key it gets in the response of the key server. - DH_KEY_EXCHANGE() - Constructor for class org.jgroups.protocols.DH_KEY_EXCHANGE
- DH_KEY_EXCHANGE.DhHeader - Class in org.jgroups.protocols
- DH_KEY_EXCHANGE.Type - Enum in org.jgroups.protocols
- dh_key_factory - Static variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
- DhHeader() - Constructor for class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- dhKey() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- diag - Variable in class org.jgroups.stack.GossipRouter
- diag_handler - Variable in class org.jgroups.protocols.TP
- diagHandler() - Method in class org.jgroups.stack.GossipRouter
- DiagnosticsHandler - Class in org.jgroups.stack
- DiagnosticsHandler() - Constructor for class org.jgroups.stack.DiagnosticsHandler
-
Constructor used for standalone apps (without a JGroups stack)
- DiagnosticsHandler(Log, SocketFactory, ThreadFactory) - 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(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[]) - Constructor for class org.jgroups.util.Digest
-
Only used internally, don't use !
- Digest(Address[], long[]) - Constructor for class org.jgroups.util.Digest
- Digest(Address, long, long) - Constructor for class org.jgroups.util.Digest
- Digest(Digest) - Constructor for class org.jgroups.util.Digest
-
Only used for testing
- 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.NAKACK2
-
Keeps a bounded list of the last N digest sets
- digest_history - Variable in class org.jgroups.protocols.ReliableMulticast
-
Keeps a bounded list of the last N digest sets
- DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.GMS
- DIGEST_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
- 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
- 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
- disableLoopback() - Method in class org.jgroups.protocols.UDP
- disableLoopback(boolean) - Method in class org.jgroups.protocols.UDP
- 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_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_delivered_msgs - Variable in class org.jgroups.protocols.ReliableMulticast
-
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_own_messages - Variable in class org.jgroups.JChannel
- 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
- DISCARD.DiscardDialog - Class in org.jgroups.protocols
- discardAll() - Method in class org.jgroups.protocols.DISCARD
- discardAll(boolean) - Method in class org.jgroups.protocols.DISCARD
- discardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- discardDeliveredMsgs() - Method in class org.jgroups.protocols.ReliableMulticast
- discardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- discardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- DiscardDialog() - Constructor for class org.jgroups.protocols.DISCARD.DiscardDialog
- disconnect() - Method in class org.jgroups.client.StompConnection
- 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
-
Leaves the cluster (disconnects the channel if it is connected).
- disconnect(String, Address) - Method in class org.jgroups.stack.RouterStub
- DISCONNECT - org.jgroups.protocols.STOMP.ClientVerb
- DISCONNECT - Static variable in class org.jgroups.Event
- DISCONNECTED - org.jgroups.protocols.FD_SOCK2.State
- disconnectedStubs() - Method in class org.jgroups.stack.RouterStubManager
- disconnectStubs() - Method in class org.jgroups.stack.RouterStubManager
- discoverSecurityProviders(ClassLoader) - Static method in class org.jgroups.util.SslContextFactory
- discovery - Static variable in class org.jgroups.protocols.LOCAL_PING
-
Map of cluster names and address-protocol mappings.
- 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_req_futures - Variable in class org.jgroups.protocols.Discovery
- discovery_rsp_callback - Variable in class org.jgroups.protocols.Discovery
- discovery_rsp_cb - Variable in class org.jgroups.protocols.MERGE3
- discovery_rsp_expiry_time - Variable in class org.jgroups.protocols.Discovery
- Discovery.DiscoveryCacheDisseminationTask - Class in org.jgroups.protocols
- 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
- dispatch(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
- disseminateDiscoveryInformation(List<Address>, List<Address>, List<Address>) - Method in class org.jgroups.protocols.Discovery
-
Disseminates cache information (UUID/IP adddress/port/name) to the given members
- dns_address - Variable in class org.jgroups.protocols.dns.DNS_PING
- dns_context_factory - Variable in class org.jgroups.protocols.dns.DNS_PING
- DNS_PING - Class in org.jgroups.protocols.dns
- DNS_PING() - Constructor for class org.jgroups.protocols.dns.DNS_PING
- dns_query - Variable in class org.jgroups.protocols.dns.DNS_PING
- dns_record_type - Variable in class org.jgroups.protocols.dns.DNS_PING
- dns_resolver - Variable in class org.jgroups.protocols.dns.DNS_PING
- DNSResolver - Interface in org.jgroups.protocols.dns
- DNSResolver.DNSRecordType - Enum in org.jgroups.protocols.dns
- DO_BREAK_LINES - Static variable in class org.jgroups.util.Base64
-
Do break lines when encoding.
- doAndComplete(Callable<RspList<T>>) - Method in class org.jgroups.blocks.GroupRequest
- doClose() - Method in class org.jgroups.nio.MockSocketChannel
- doExecute(Runnable) - Method in class org.jgroups.util.ThreadPool
- done - Variable in class org.jgroups.protocols.relay.Relayer
-
Flag set when stop() is called.
- done - Variable in class org.jgroups.util.Credit
- done - Variable in class org.jgroups.util.CreditMap
- done - Variable in class org.jgroups.util.Responses
- done - Variable in class org.jgroups.util.SizeBoundedQueue
- done - Variable in class org.jgroups.util.TimeScheduler3.Task
- done() - Method in class org.jgroups.protocols.relay.Relayer
- done() - Method in class org.jgroups.util.Delayer
- done() - Method in class org.jgroups.util.Delayer.Entry
- done() - Method in class org.jgroups.util.Responses
- 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
- DONT_BLOCK - org.jgroups.Message.TransientFlag
- DONT_BUNDLE - org.jgroups.Message.Flag
- DONT_GUNZIP - Static variable in class org.jgroups.util.Base64
-
Specify that gzipped data should not be automatically gunzipped.
- DONT_LOOPBACK - org.jgroups.Message.TransientFlag
- dont_loopback_filter - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
- dont_loopback_filter - Static variable in class org.jgroups.protocols.UNICAST3
- 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) - Method in class org.jgroups.blocks.cs.TcpConnection
- doSend(byte[], int, int, boolean) - Method in class org.jgroups.blocks.cs.TcpConnection
- doSend(byte[], int, int, Address) - Method in class org.jgroups.protocols.TP
- doStart() - Method in class org.jgroups.blocks.cs.NioClient
- doStart() - Method in class org.jgroups.blocks.cs.TcpClient
- DOUBLE_SIZE - Static variable in class org.jgroups.Global
- down - org.jgroups.protocols.relay.SiteStatus.Status
- down - Variable in class org.jgroups.protocols.DISCARD
- down - Variable in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- down - Variable in class org.jgroups.protocols.SHUFFLE
- down - Variable in class org.jgroups.protocols.SNIFF
- down() - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- down(Event) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- 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.ASYM_ENCRYPT
- down(Event) - Method in class org.jgroups.protocols.BARRIER
- down(Event) - Method in class org.jgroups.protocols.BasicTCP
- down(Event) - Method in class org.jgroups.protocols.BATCH
- down(Event) - Method in class org.jgroups.protocols.BATCH2
- 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.DISCARD
- down(Event) - Method in class org.jgroups.protocols.Discovery
- down(Event) - Method in class org.jgroups.protocols.Encrypt
- down(Event) - Method in class org.jgroups.protocols.EXAMPLE
- down(Event) - Method in class org.jgroups.protocols.FailureDetection
- 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.FD_SOCK2
- 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.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.FRAG3
-
Fragment a packet if larger than frag_size (add a header).
- down(Event) - Method in class org.jgroups.protocols.KeyExchange
- down(Event) - Method in class org.jgroups.protocols.LOCAL_PING
- down(Event) - Method in class org.jgroups.protocols.MAKE_BATCH
- down(Event) - Method in class org.jgroups.protocols.MERGE3
- down(Event) - Method in class org.jgroups.protocols.pbcast.GMS
- 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.RATE_LIMITER
- down(Event) - Method in class org.jgroups.protocols.relay.RELAY
- down(Event) - Method in class org.jgroups.protocols.ReliableMulticast
-
Callback.
- down(Event) - Method in class org.jgroups.protocols.RSVP
- 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(Event) - Method in class org.jgroups.protocols.SimpleTCP
- 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.TP
- down(Event) - Method in class org.jgroups.protocols.TRACE
- down(Event) - Method in class org.jgroups.protocols.TUNNEL
- down(Event) - Method in class org.jgroups.protocols.UDP
- 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.protocols.VERIFY_SUSPECT2
- 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(Message) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- down(Message) - Method in class org.jgroups.fork.ForkChannel
- down(Message) - Method in class org.jgroups.fork.ForkProtocol
- down(Message) - Method in class org.jgroups.fork.ForkProtocolStack
- down(Message) - Method in class org.jgroups.JChannel
- down(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- down(Message) - Method in class org.jgroups.protocols.AUTH
- down(Message) - Method in class org.jgroups.protocols.BATCH
- down(Message) - Method in class org.jgroups.protocols.BATCH2
- down(Message) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- down(Message) - Method in class org.jgroups.protocols.COMPRESS
-
We compress the payload if it is larger than
min_size
. - down(Message) - Method in class org.jgroups.protocols.DAISYCHAIN
- down(Message) - Method in class org.jgroups.protocols.DELAY
- down(Message) - Method in class org.jgroups.protocols.DETECT_LOOPBACKS
- down(Message) - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
- down(Message) - Method in class org.jgroups.protocols.DISCARD
- down(Message) - Method in class org.jgroups.protocols.DROP
- down(Message) - Method in class org.jgroups.protocols.DUPL
- down(Message) - Method in class org.jgroups.protocols.Encrypt
- down(Message) - Method in class org.jgroups.protocols.EXAMPLE
- down(Message) - Method in class org.jgroups.protocols.FailureDetection
- down(Message) - Method in class org.jgroups.protocols.FlowControl
- down(Message) - Method in class org.jgroups.protocols.FRAG
- down(Message) - Method in class org.jgroups.protocols.FRAG2
- down(Message) - Method in class org.jgroups.protocols.FRAG3
- down(Message) - Method in class org.jgroups.protocols.HDRS
- down(Message) - Method in class org.jgroups.protocols.NON_BLOCKING_SENDS
- down(Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- down(Message) - Method in class org.jgroups.protocols.pbcast.STABLE
- down(Message) - Method in class org.jgroups.protocols.PERF
- down(Message) - Method in class org.jgroups.protocols.RATE_LIMITER
- down(Message) - Method in class org.jgroups.protocols.RATE_LIMITER2
- down(Message) - Method in class org.jgroups.protocols.RATE
- down(Message) - Method in class org.jgroups.protocols.RED
- down(Message) - Method in class org.jgroups.protocols.relay.RELAY2
- down(Message) - Method in class org.jgroups.protocols.relay.RELAY3
- down(Message) - Method in class org.jgroups.protocols.ReliableMulticast
- down(Message) - Method in class org.jgroups.protocols.RSVP
- down(Message) - Method in class org.jgroups.protocols.SEQUENCER
- down(Message) - Method in class org.jgroups.protocols.SEQUENCER2
- down(Message) - Method in class org.jgroups.protocols.SERIALIZE
- down(Message) - Method in class org.jgroups.protocols.SHUFFLE
- down(Message) - Method in class org.jgroups.protocols.SimpleTCP
- down(Message) - Method in class org.jgroups.protocols.SIZE
- down(Message) - Method in class org.jgroups.protocols.SNIFF
- down(Message) - Method in class org.jgroups.protocols.STATS
- down(Message) - Method in class org.jgroups.protocols.THREAD_COUNT
- down(Message) - Method in class org.jgroups.protocols.TIME
- down(Message) - Method in class org.jgroups.protocols.TP
-
A message needs to be sent to a single member or all members
- down(Message) - Method in class org.jgroups.protocols.TRACE
- down(Message) - Method in class org.jgroups.protocols.UNICAST3
- down(Message) - Method in class org.jgroups.stack.Protocol
-
A message is sent down the stack.
- down(Message) - Method in class org.jgroups.stack.ProtocolStack
- down(Message, boolean) - Method in class org.jgroups.JChannel
-
Sends a message down asynchronously.
- down(Message, boolean) - Method in class org.jgroups.stack.Protocol
-
Passes a message down asynchronously.
- down(Message, boolean) - Method in class org.jgroups.stack.ProtocolStack
- DOWN - org.jgroups.protocols.DUPL.Direction
- down_count - Variable in class org.jgroups.protocols.THREAD_COUNT
- down_delivery - Variable in class org.jgroups.protocols.TIME
- down_filters - Variable in class org.jgroups.protocols.DROP
- down_flags - Variable in class org.jgroups.protocols.CLEAR_FLAGS
- down_lock - Variable in class org.jgroups.protocols.SHUFFLE
- down_msgs - Variable in class org.jgroups.protocols.SHUFFLE
- down_msgs - Variable in class org.jgroups.protocols.TIME
- down_prot - Variable in class org.jgroups.blocks.RequestCorrelator
-
The protocol layer to use to pass up/down messages.
- down_prot - Variable in class org.jgroups.stack.Protocol
- down_queue - Variable in class org.jgroups.protocols.BATCH2
- down_req_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- down_threads - Variable in class org.jgroups.protocols.THREAD_COUNT
- downFlags() - Method in class org.jgroups.protocols.CLEAR_FLAGS
- downRequest() - Method in class org.jgroups.protocols.RTTHeader
-
Time to send a request down, from sending until just before serialization
- drain() - Method in class org.jgroups.protocols.TransferQueueBundler
-
Takes all messages from the queue, adds them to the hashmap and then sends all bundled messages
- drain() - Method in class org.jgroups.protocols.TransferQueueBundler2
-
Takes all messages from the queue, adds them to the hashmap and then sends all bundled messages
- drain(Address) - Method in class org.jgroups.util.MessageCache
- drainTo(Collection<? super T>) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- drainTo(Collection<? super T>) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- drainTo(Collection<? super T>) - Method in class org.jgroups.util.RingBuffer
-
Removes as many messages as possible and adds them to c.
- drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- drainTo(Collection<? super T>, int) - Method in class org.jgroups.util.RingBuffer
-
Removes a number of messages and adds them to c.
- drainTo(Collection<T>, int) - Method in class org.jgroups.util.SizeBoundedQueue
-
Removes and adds to collection c as many elements as possible (including waiters) but not exceeding max_bytes.
- drainTo(T[]) - Method in class org.jgroups.util.RingBuffer
-
Removes messages and adds them to c.
- drainToBlocking(Collection<? super T>) - Method in class org.jgroups.util.RingBuffer
-
Removes as many messages as possible and adds them to c.
- drainToBlocking(Collection<? super T>, int) - Method in class org.jgroups.util.RingBuffer
-
Removes a number of messages and adds them to c.
- drainToBlocking(T[]) - Method in class org.jgroups.util.RingBuffer
-
Removes messages and adds them to c.
- 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_dest - Static variable in class org.jgroups.demos.StompDraw
- Draw.DrawPanel - Class in org.jgroups.demos
- 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(double) - Method in class org.jgroups.protocols.RED
- DROP - Class in org.jgroups.protocols
-
Protocol which drops up or down messages according to user-defined filters
- DROP - org.jgroups.protocols.ASYM_ENCRYPT.Processing
- DROP() - Constructor for class org.jgroups.protocols.DROP
- drop_dont_block_msgs - Variable in class org.jgroups.protocols.RATE_LIMITER2
- 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
- drop_when_full - Variable in class org.jgroups.protocols.TransferQueueBundler
- dropDontBlockMessages() - Method in class org.jgroups.protocols.RATE_LIMITER2
- dropDontBlockMessages(boolean) - Method in class org.jgroups.protocols.RATE_LIMITER2
- dropDownMulticasts() - Method in class org.jgroups.protocols.DISCARD
- dropDownMulticasts(int) - Method in class org.jgroups.protocols.DISCARD
- dropDownUnicasts(int) - Method in class org.jgroups.protocols.DISCARD
-
Drop the next N unicasts down the stack
- dropMulticastMessageFromNonMember(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- dropped(Message, boolean) - Method in class org.jgroups.protocols.DROP
- dropped_msgs - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- dropped_msgs - Variable in class org.jgroups.protocols.RED
- droppedMessages() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- dropWhenFull() - Method in class org.jgroups.protocols.TransferQueueBundler
- dropWhenFull(boolean) - Method in class org.jgroups.protocols.TransferQueueBundler
- Dual - org.jgroups.util.StackType
- DUMMY_OOB_MSG - Static variable in class org.jgroups.protocols.pbcast.NAKACK2
- DUMMY_OOB_MSG - Static variable in class org.jgroups.protocols.ReliableMulticast
- 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.ReplCache
- dump() - Method in class org.jgroups.protocols.TransferQueueBundler2
- dump() - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- dump() - Method in class org.jgroups.util.Buffer
-
Dumps all non-null messages (used for testing)
- dump() - Method in class org.jgroups.util.MaxOneThreadPerSender
- dump() - Method in class org.jgroups.util.Table
-
Dumps the seqnos in the table as a list
- dump(String) - Method in class org.jgroups.protocols.JDBC_PING2
- dump(String[], long[], long[]) - Static method in class org.jgroups.protocols.COUNTER
- dump(String, Message) - Static method in class org.jgroups.protocols.SNIFF
- dump(GossipData) - Static method in class org.jgroups.stack.GossipRouter
- dump_msgs - Variable in class org.jgroups.stack.GossipRouter
- dumpAddressMappings() - Method in class org.jgroups.stack.GossipRouter
- dumpAttrsAllProtocols() - Method in class org.jgroups.JChannelProbeHandler
-
Dumps the attributes and their values of _all_ protocols in a stack
- dumpAttrsAllProtocols() - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- dumpAttrsSelectedProtocol(String, List<String>) - Method in class org.jgroups.JChannelProbeHandler
-
Dumps attributes and their values of a given protocol.
- dumpAttrsSelectedProtocol(String, List<String>) - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- dumpCache(String) - Method in class org.jgroups.protocols.Discovery
- dumpContents() - Method in class org.jgroups.util.RequestTable
- DumperTask() - Constructor for class org.jgroups.protocols.SOS.DumperTask
- dumpHistory() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- dumpMessages() - Method in class org.jgroups.stack.GossipRouter
- dumpMessages(boolean) - Method in class org.jgroups.stack.GossipRouter
- dumpMessages(GossipRouter.DumpMessages) - Method in class org.jgroups.stack.GossipRouter
- dumpPendingRequests() - Method in class org.jgroups.blocks.atomic.CounterService
- dumpPendingRequests() - Method in class org.jgroups.protocols.COUNTER
- dumpQueue() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- dumpRoutingTable() - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
- dumpRoutingTable() - Method in class org.jgroups.stack.GossipRouter
- dumpSelectedAttributes(Object, List<String>) - Static method in class org.jgroups.jmx.ReflectUtils
-
Reads all attributes and values of the given target (annotated with
ManagedAttribute
and filters them if a non-null list of attributes is given - dumpSite(String) - Method in class org.jgroups.protocols.relay.Topology
- dumpSocketInfo() - Method in class org.jgroups.protocols.UDP
- dumpStats() - Method in class org.jgroups.JChannel
-
Returns a map of statistics of the various protocols and of the channel itself
- dumpStats() - Method in class org.jgroups.stack.ProtocolStack
- dumpStats(Object, String, Map<String, Object>) - Static method in class org.jgroups.jmx.ResourceDMBean
- dumpStats(Object, Map<String, Object>) - Static method in class org.jgroups.jmx.ReflectUtils
- dumpStats(Object, Map<String, Object>) - Static method in class org.jgroups.jmx.ResourceDMBean
- dumpStats(String) - Method in class org.jgroups.JChannel
- dumpStats(String, List<String>) - Method in class org.jgroups.JChannel
- 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
- dumpTimerTasks() - Method in class org.jgroups.protocols.TP
- dumpTimerTasks() - Method in interface org.jgroups.util.TimeScheduler
-
Returns a list of tasks currently waiting for execution.
- 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.NAKACK3
- 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
- dynamic - org.jgroups.util.TimeScheduler3.TaskType
- dynamic_hosts - Variable in class org.jgroups.protocols.TCPPING
-
https://issues.redhat.com/browse/JGRP-989
- DynamicBuffer<T> - Class in org.jgroups.util
-
Copy of
Table
. - DynamicBuffer() - Constructor for class org.jgroups.util.DynamicBuffer
- DynamicBuffer(int, int, long) - Constructor for class org.jgroups.util.DynamicBuffer
- DynamicBuffer(int, int, long, double) - Constructor for class org.jgroups.util.DynamicBuffer
- DynamicBuffer(int, int, long, double, long) - Constructor for class org.jgroups.util.DynamicBuffer
-
Creates a new table
- DynamicBuffer(long) - Constructor for class org.jgroups.util.DynamicBuffer
- DynamicBuffer.TableIterator - Class in org.jgroups.util
-
Iterates through all elements of the matrix.
E
- EAP_EXCLUDED - Static variable in class org.jgroups.Global
- EARLYBATCH_MSG - Static variable in interface org.jgroups.Message
- EchoServer - Class in org.jgroups.demos
-
Simple TCP server replying back to client with connection information (peer address etc)
- EchoServer() - Constructor for class org.jgroups.demos.EchoServer
- EchoServer.ConnectionHandler - Class in org.jgroups.demos
- el - Variable in class org.jgroups.util.SizeBoundedQueue.El
- El(T, int) - Constructor for class org.jgroups.util.SizeBoundedQueue.El
- elementAt(int) - Method in class org.jgroups.Membership
-
Returns the component at the specified index
- elements - Variable in class org.jgroups.util.ArrayIterator
- elements - Variable in class org.jgroups.util.FastArray
- elements_per_row - Variable in class org.jgroups.util.DynamicBuffer
-
Must be a power of 2 for efficient modular arithmetic
- elements_per_row - Variable in class org.jgroups.util.Table
-
Must be a power of 2 for efficient modular arithmetic
- EMBED - org.jgroups.annotations.XmlInclude.Type
- embeddedSchemas - Static variable in class org.jgroups.util.XMLSchemaGenerator
- 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
- EMPTY - Static variable in class org.jgroups.util.ByteArrayDataInputStream
- empty_group_request - Static variable in class org.jgroups.blocks.MessageDispatcher
- EMPTY_MSG - Static variable in interface org.jgroups.Message
- empty_rsplist - Static variable in class org.jgroups.blocks.MessageDispatcher
- emptyGossipClientStubManager(Log, TimeScheduler) - Static method in class org.jgroups.stack.RouterStubManager
- EmptyMessage - Class in org.jgroups
-
A
Message
without a payload; optimized for sending only headers (e.g. - EmptyMessage() - Constructor for class org.jgroups.EmptyMessage
- EmptyMessage(Address) - Constructor for class org.jgroups.EmptyMessage
- enable(boolean) - Method in class org.jgroups.protocols.MsgStats
- enable(boolean) - Method in class org.jgroups.protocols.UNBATCH
- enable(boolean) - Method in class org.jgroups.util.AsyncExecutor
- enable(int, boolean) - Static method in class org.jgroups.JChannelProbeHandler
- enable_address_tagging - Variable in class org.jgroups.protocols.relay.RELAY2
- enable_tcp - Variable in class org.jgroups.stack.DiagnosticsHandler
- enable_udp - Variable in class org.jgroups.stack.DiagnosticsHandler
- enableAddressTagging() - Method in class org.jgroups.protocols.relay.RELAY2
- enableAddressTagging(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
- enableBlockingTimerTasks(boolean) - Method in class org.jgroups.protocols.TP
- enabled - Variable in class org.jgroups.protocols.MsgStats
- enabled - Variable in class org.jgroups.protocols.RED
- enabled - Variable in class org.jgroups.protocols.UNBATCH
- enabled - Variable in class org.jgroups.stack.DiagnosticsHandler
- enabled - Variable in class org.jgroups.util.AsyncExecutor
- enabled - Variable in class org.jgroups.util.ThreadPool
- enabled - Variable in class org.jgroups.util.TLS
- enabled() - Method in class org.jgroups.protocols.MsgStats
- enabled() - Method in class org.jgroups.protocols.UNBATCH
- enabled() - Method in class org.jgroups.util.AsyncExecutor
- enabled() - Method in class org.jgroups.util.TLS
- enabled(boolean) - Method in class org.jgroups.util.TLS
- 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.protocols.TP
- enableStats(boolean) - Method in class org.jgroups.stack.Protocol
- enableTcp(boolean) - Method in class org.jgroups.stack.DiagnosticsHandler
- enableUdp(boolean) - Method in class org.jgroups.stack.DiagnosticsHandler
- 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
- encode(ByteBuffer, ByteBuffer) - Static method in class org.jgroups.util.Base64
-
Performs Base64 encoding on the
raw
ByteBuffer, writing it to theencoded
ByteBuffer. - encode(ByteBuffer, CharBuffer) - Static method in class org.jgroups.util.Base64
-
Performs Base64 encoding on the
raw
ByteBuffer, writing it to theencoded
CharBuffer. - ENCODE - Static variable in class org.jgroups.util.Base64
-
Specify encoding in first bit.
- 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
-
Similar to
Base64.encodeBytes(byte[])
but returns a byte array instead of instantiating a String. - encodeBytesToBytes(byte[], int, int, int) - Static method in class org.jgroups.util.Base64
-
Similar to
Base64.encodeBytes(byte[], int, int, int)
but returns a byte array instead of instantiating a String. - 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
- encrypt(Message) - Method in class org.jgroups.protocols.Encrypt
- Encrypt<E extends java.security.KeyStore.Entry> - Class in org.jgroups.protocols
-
Super class of symmetric (
SYM_ENCRYPT
) and asymmetric (ASYM_ENCRYPT
) encryption protocols. - Encrypt() - Constructor for class org.jgroups.protocols.Encrypt
- ENCRYPT - Static variable in class org.jgroups.Global
- encrypted_secret_key - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- encryptedSecret() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- encryptedToken(byte[]) - Method in class org.jgroups.auth.X509Token
-
To be used for testing only
- EncryptHeader - Class in org.jgroups.protocols
- EncryptHeader() - Constructor for class org.jgroups.protocols.EncryptHeader
- EncryptHeader(byte[]) - Constructor for class org.jgroups.protocols.EncryptHeader
- EncryptHeader(byte, byte[]) - Constructor for class org.jgroups.protocols.EncryptHeader
- EncryptHeader(byte, 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 - Variable in class org.jgroups.util.PartialOutputStream
- END - org.jgroups.conf.XmlConfigurator.ElementType
- end_index - Variable in class org.jgroups.util.Responses.PingDataIterator
- endpoint - Variable in class org.jgroups.protocols.STOMP
- ENDPOINT - org.jgroups.protocols.STOMP.StompHeader.Type
- endpoint_addr - Variable in class org.jgroups.protocols.STOMP
- endpoints - Variable in class org.jgroups.protocols.STOMP
- ENDPOINTS - Static variable in class org.jgroups.demos.StompChat
- ensureCapacity(int) - Method in class org.jgroups.BatchMessage
- ensureCapacity(int) - Method in class org.jgroups.CompositeMessage
- ensureCapacity(int) - Method in class org.jgroups.util.BaseDataOutputStream
-
Makes sure that bytes can be written to the output stream (e.g.
- ensureCapacity(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
-
Grows the buffer; whether it grow linearly or exponentially depends on grow_exponentially
- ensureCapacity(int) - Method in class org.jgroups.util.PartialOutputStream
- ensurePositive(int) - Static method in class org.jgroups.util.FastArray
- ensureSameDest(Message) - Method in class org.jgroups.BatchMessage
- ensureSameDest(Message) - Method in class org.jgroups.CompositeMessage
- 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 - Variable in class org.jgroups.util.MaxOneThreadPerSender.BatchHandlerLoop
- Entry(short, Table<Message>) - Constructor for class org.jgroups.protocols.UNICAST3.Entry
- Entry(AccessibleObject, String, Supplier<T>) - Constructor for class org.jgroups.util.Metrics.Entry
- Entry(Collection<Address>) - Constructor for class org.jgroups.protocols.RSVP.Entry
-
Multicast entry
- Entry(Address) - Constructor for class org.jgroups.protocols.RSVP.Entry
-
Unicast entry
- Entry(Address, boolean, AsciiString) - Constructor for class org.jgroups.util.MaxOneThreadPerSender.Entry
- Entry(Address, long) - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.Entry
- Entry(Address, long) - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- Entry(Address, long, long) - Constructor for class org.jgroups.util.Digest.Entry
- Entry(Address, PhysicalAddress, String) - Constructor for class org.jgroups.stack.GossipRouter.Entry
- Entry(T, Predicate<T>, Consumer<Boolean>) - Constructor for class org.jgroups.util.Delayer.Entry
- Entry(V) - Constructor for class org.jgroups.blocks.LazyRemovalCache.Entry
- entryRemoved(Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- entryRemoved(K) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- 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(Object, Object) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- entrySet(K, V) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- enumerate(T[], int, int) - Static method in class org.jgroups.util.Util
- enumerate(T[], int, int, Function<T, R>) - Static method in class org.jgroups.util.Util
- equals(byte[]) - Method in class org.jgroups.util.AsciiString
- equals(Object) - Method in class org.jgroups.NullAddress
- equals(Object) - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
- equals(Object) - Method in class org.jgroups.protocols.PingData
- equals(Object) - Method in class org.jgroups.protocols.relay.ForwardingRoute
- 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.relay.SiteUUID
- equals(Object) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- 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.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.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 - org.jgroups.util.SuppressLog.Level
- error(String) - Method in class org.jgroups.logging.JDKLogImpl
- error(String) - Method in interface org.jgroups.logging.Log
- error(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- error(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- error(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- error(String, Object...) - Method in interface org.jgroups.logging.Log
- error(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- error(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- error(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
- error(String, Throwable) - Method in interface org.jgroups.logging.Log
- error(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
- error(String, Throwable) - Method in class org.jgroups.logging.Slf4jLogImpl
- ERROR - org.jgroups.protocols.STOMP.ServerVerb
- error_message - Variable in class org.jgroups.protocols.COUNTER.ExceptionResponse
- 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
- eventLoop() - Method in class org.jgroups.demos.PubClient
- eventLoop(JChannel) - Method in class org.jgroups.demos.RelayDemo
- 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.util.StateTransferResult
- EXCEPTION - org.jgroups.protocols.COUNTER.ResponseType
- exceptionFromBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
- exceptionFromStream(DataInput) - Static method in class org.jgroups.util.Util
- exceptionFromStream(DataInput, int) - Static method in class org.jgroups.util.Util
- ExceptionResponse() - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
- ExceptionResponse(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.ExceptionResponse
- exceptionToBuffer(Throwable) - Static method in class org.jgroups.util.Util
- exceptionToStream(Throwable, DataOutput) - Static method in class org.jgroups.util.Util
-
Poor man's serialization of an exception.
- exceptionToStream(Set<Throwable>, Throwable, DataOutput) - Static method in class org.jgroups.util.Util
- excludeItself - Variable in class org.jgroups.protocols.DISCARD
- excludeItself() - Method in class org.jgroups.protocols.DISCARD
- excludeItself(boolean) - Method 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
- exclusionList(Address...) - Method in class org.jgroups.blocks.RequestOptions
- exec() - Method in class org.jgroups.protocols.SOS
- exec() - Method in class org.jgroups.util.AsyncExecutor
- execute() - Method in class org.jgroups.protocols.ReliableMulticast.LastSeqnoResender
- 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.ThreadPool
- execute(Runnable) - Method in interface org.jgroups.util.TimeScheduler
-
Executes command with zero required delay.
- execute(Runnable, boolean) - Method in interface org.jgroups.util.TimeScheduler
- execute(Runnable, boolean) - Method in class org.jgroups.util.TimeScheduler3
- execute(String) - Static method in class org.jgroups.protocols.FD_HOST.CommandExecutor2
- execute(Supplier<T>, boolean) - Method in class org.jgroups.util.AsyncExecutor
- execute(Message, boolean) - Method in class org.jgroups.blocks.Request
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.AddAndGetRequest
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.DeleteRequest
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
- execute(COUNTER, Address) - Method in interface org.jgroups.protocols.COUNTER.Request
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.SetRequest
- execute(COUNTER, Address) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
- executor - Variable in class org.jgroups.util.AsyncExecutor
- 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
- 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
- expired(K) - Method in interface org.jgroups.util.AgeOutCache.Handler
- expired(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Called by AgeOutCache, to removed expired connections
- expiry() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- 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
- 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
- expose_all - Variable in class org.jgroups.jmx.ResourceDMBean
- exposeAll() - Method in annotation type org.jgroups.annotations.MBean
- exposeAsManagedAttribute() - Method in annotation type org.jgroups.annotations.Property
-
Expose this property also as a managed attribute
- exposeManagedAttribute(Method, Object, String) - Method in class org.jgroups.jmx.ResourceDMBean
- 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(T) - Constructor for class org.jgroups.util.ExtendedUUID
- EXTERNAL - Static variable in class org.jgroups.conf.ClassConfigurator
- external_addr - Variable in class org.jgroups.protocols.FD_SOCK
- external_addr - Variable in class org.jgroups.protocols.FD_SOCK2
- external_addr - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- external_addr - Variable in class org.jgroups.protocols.TP
- EXTERNAL_ADDR - 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.FD_SOCK2
- external_port - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- external_port - Variable in class org.jgroups.protocols.TP
- EXTERNAL_PORT - Static variable in class org.jgroups.Global
- ExternalPingCommand(String) - Constructor for class org.jgroups.protocols.FD_HOST.ExternalPingCommand
- extract(JChannel) - Static method in class org.jgroups.util.Metrics
- extract(JChannel, Predicate<AccessibleObject>) - Static method in class org.jgroups.util.Metrics
- extract(Protocol) - Static method in class org.jgroups.util.Metrics
- extract(Protocol, Predicate<AccessibleObject>) - Static method in class org.jgroups.util.Metrics
- extract(View) - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
-
Returns a map containing the site keys and addresses as values
F
- f - Variable in class org.jgroups.protocols.RATE_LIMITER2
- f - Variable in class org.jgroups.protocols.RATE
- f - Variable in class org.jgroups.util.Delayer.Entry
- factorial(int) - Static method in class org.jgroups.util.Util
- factory - Variable in class org.jgroups.blocks.cs.BaseServer
- factory - Variable in class org.jgroups.util.Runner
- FAIL - Static variable in class org.jgroups.blocks.cs.BaseServer
- fail_reason - Variable in class org.jgroups.protocols.pbcast.JoinRsp
- FAIL_REASON_PRESENT - Static variable in class org.jgroups.protocols.pbcast.JoinRsp
- FailureDetection - Class in org.jgroups.protocols
- FailureDetection() - Constructor for class org.jgroups.protocols.FailureDetection
- FailureDetection.HeartbeatHeader - Class in org.jgroups.protocols
- FastArray<T> - Class in org.jgroups.util
-
Simple
- FastArray(int) - Constructor for class org.jgroups.util.FastArray
- FastArray.FastIterator - Class in org.jgroups.util
- FastIterator(Predicate<T>) - Constructor for class org.jgroups.util.FastArray.FastIterator
- fatal(String) - Method in class org.jgroups.logging.JDKLogImpl
- fatal(String) - Method in interface org.jgroups.logging.Log
- fatal(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- fatal(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- fatal(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- fatal(String, Object...) - Method in interface org.jgroups.logging.Log
- fatal(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- fatal(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- fatal(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
- fatal(String, Throwable) - Method in interface org.jgroups.logging.Log
- fatal(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
- fatal(String, Throwable) - Method in class org.jgroups.logging.Slf4jLogImpl
- 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_ALL - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD_ALL() - Constructor for class org.jgroups.protocols.FD_ALL
- 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_ALL3 - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD_ALL3() - Constructor for class org.jgroups.protocols.FD_ALL3
- FD_ALL3.Bitmap - 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.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_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.
- FD_SOCK2 - Class in org.jgroups.protocols
-
Failure detection protocol based on TCP connections, successor to
FD_SOCK
. - FD_SOCK2() - Constructor for class org.jgroups.protocols.FD_SOCK2
- FD_SOCK2.BroadcastTask - Class in org.jgroups.protocols
-
Task which periodically broadcasts a list of suspected members.
- FD_SOCK2.FdHeader - Class in org.jgroups.protocols
- FD_SOCK2.PingDest - Class in org.jgroups.protocols
- FD_SOCK2.Request - Class in org.jgroups.protocols
- FD_SOCK2.Request.Type - Enum in org.jgroups.protocols
- FD_SOCK2.State - Enum in org.jgroups.protocols
- FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK2.FdHeader
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK2.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
- FETCH_SHARED_KEY - Static variable in class org.jgroups.protocols.EncryptHeader
- fetchAndSetKeyExchange() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- 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.
- fetchFromDns() - Method in class org.jgroups.protocols.dns.DNS_PING
- 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.DH_KEY_EXCHANGE
- 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.
- fetchTopoFromSiteMaster(Address) - Method in class org.jgroups.protocols.relay.RELAY2
- fibersAvailable() - Static method in class org.jgroups.util.Util
-
Deprecated.
- field - Variable in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
- FieldAccessor(Field, Object) - Constructor for class org.jgroups.jmx.ResourceDMBean.FieldAccessor
- file - Variable in class org.jgroups.blocks.GridInputStream
- file - Variable in class org.jgroups.blocks.GridOutputStream
- FILE - Static variable in class org.jgroups.blocks.GridFile.Metadata
- 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.
- filename - Variable in class org.jgroups.protocols.SOS
- filename(String) - Static method in class org.jgroups.blocks.GridFile
- FileWatcher - Class in org.jgroups.util
- FileWatcher() - Constructor for class org.jgroups.util.FileWatcher
- filter - Static variable in class org.jgroups.protocols.FILE_PING
- filter - Variable in class org.jgroups.protocols.HDRS
- filter - Variable in class org.jgroups.protocols.PDC
- filter - Variable in class org.jgroups.protocols.REVERSE
- filter - Variable in class org.jgroups.util.Buffer.Remover
- filter - Variable in class org.jgroups.util.FastArray.FastIterator
- filter - Variable in class org.jgroups.util.Table.Remover
- filter() - Method in class org.jgroups.protocols.REVERSE
- filter(Predicate<Message>) - Method in class org.jgroups.protocols.HDRS
- filter(Predicate<Message>) - Method in class org.jgroups.protocols.REVERSE
- FILTER - Static variable in class org.jgroups.jmx.ResourceDMBean
- FILTER - Static variable in class org.jgroups.stack.NonReflectiveProbeHandler
- final_dest - Variable in class org.jgroups.protocols.relay.RelayHeader
- finalizer_task - Variable in class org.jgroups.util.ResponseCollectorTask
- find(char, String, InputStream, StringBuilder, boolean) - Static method in class org.jgroups.conf.XmlConfigurator
- 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_MBRS - Static variable in class org.jgroups.Event
- FIND_MBRS_ASYNC - Static variable in class org.jgroups.Event
- findClassesAnnotatedWith(String, Class<? extends Annotation>) - Static method in class org.jgroups.util.Util
- findClassesAssignableFrom(String, Class<?>, ClassLoader) - Static method in class org.jgroups.util.Util
- findClassesAssignableFromPath(String, Class<?>, ClassLoader) - Static method in class org.jgroups.util.Util
- findConstructor(String, Class<?>) - Static method in class org.jgroups.logging.LogFactory
- findDownProtocol(Class<? extends Protocol>) - Method in class org.jgroups.protocols.RSVP
- findField(Object, List<String>) - Static method in class org.jgroups.util.Util
- findFields(Object, Predicate<AccessibleObject>, String) - 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<LongTuple<T>>) - Method in class org.jgroups.util.DynamicBuffer
- findHighestSeqno(List<LongTuple<T>>) - Method in class org.jgroups.util.Table
- findHighestSeqno(MessageBatch, Function<T, Long>) - Static method in class org.jgroups.util.DynamicBuffer
- findHighestSeqno(MessageBatch, Function<T, Long>) - Static method in class org.jgroups.util.Table
- findImplementations(List<Class<?>>, Class<?>) - Static method in class org.jgroups.util.XMLSchemaGenerator
- findInitialMembersAsString() - Method in class org.jgroups.protocols.Discovery
- findMembers(List<Address>, boolean, boolean, long) - Method in class org.jgroups.protocols.Discovery
- findMembers(List<Address>, boolean, boolean, long) - Method in class org.jgroups.protocols.LOCAL_PING
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.Discovery
-
Fetches information (e.g.
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.dns.DNS_PING
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.FILE_PING
- findMembers(List<Address>, boolean, Responses) - Method in class org.jgroups.protocols.LOCAL_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(short) - Method in interface org.jgroups.blocks.MethodLookup
- findMethod(Class<?>, String, Class<?>...) - Static method in class org.jgroups.protocols.UDP
- findMethod(Class<?>, String, Class<?>...) - Static method in class org.jgroups.util.Util
- findMethod(Class<?>, String, Object[]) - Static method in class org.jgroups.util.Util
-
Called by the ProbeHandler impl.
- findMethod(Class<?>, List<String>, Class<?>...) - Static method in class org.jgroups.util.Util
- findMethod(Object, List<String>, Class<?>...) - Static method in class org.jgroups.util.Util
- findMethod(Protocol, String, String[]) - Method in class org.jgroups.JChannelProbeHandler
- findMethod(Protocol, String, String[]) - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- findMethods(Object, Predicate<AccessibleObject>, String) - Method in class org.jgroups.jmx.ResourceDMBean
- findProtocol(Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
- findProtocol(Class<? extends Protocol>...) - Method in class org.jgroups.stack.ProtocolStack
-
Finds the first protocol of a list and returns it.
- findProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Returns a given protocol or null if not found
- findProtocol(Protocol, boolean, Class<? extends Protocol>) - Static method in class org.jgroups.stack.ProtocolStack
- findProtocolAbove(Class<? extends Protocol>) - Method in class org.jgroups.protocols.KeyExchange
- findProtocols(String) - Method in class org.jgroups.stack.ProtocolStack
- findProvider(String, String, String) - Static method in class org.jgroups.util.SslContextFactory
- findRandomConnectedStub() - Method in class org.jgroups.stack.RouterStubManager
- 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.
- findTopmostDiscoveryProtocol() - Method in class org.jgroups.protocols.Discovery
-
Finds the top-most discovery protocol, starting from this.
- finishConnect() - Method in class org.jgroups.nio.MockSocketChannel
- first - Variable in class org.jgroups.util.OneTimeAddressGenerator
- first() - Method in class org.jgroups.protocols.UnicastHeader3
- first() - Method in class org.jgroups.util.MessageBatch
- first_view_sent - Variable in class org.jgroups.protocols.pbcast.GMS
- firstNibble(byte) - Static method in class org.jgroups.util.Bits
- firstOfAllClients(Address, Responses) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
Handles the case where no coord responses were received.
- fix - Variable in class org.jgroups.protocols.NON_BLOCKING_SENDS
- 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_delay - org.jgroups.util.TimeScheduler3.TaskType
- fixed_rate - org.jgroups.util.TimeScheduler3.TaskType
- FixedBuffer<T> - Class in org.jgroups.util
-
Ring buffer of fixed capacity.
- FixedBuffer() - Constructor for class org.jgroups.util.FixedBuffer
- FixedBuffer(int, long) - Constructor for class org.jgroups.util.FixedBuffer
-
Creates a RingBuffer
- FixedBuffer(long) - Constructor for class org.jgroups.util.FixedBuffer
- FixedBuffer.FixedBufferIterator - Class in org.jgroups.util
- FixedBufferIterator(T[]) - Constructor for class org.jgroups.util.FixedBuffer.FixedBufferIterator
- 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
throughsize-1
. - fixFields(Object) - Method in class org.jgroups.jmx.ResourceDMBean
-
Provides field-based getter and/or setters for all attributes in attrs if not present
- flag - Variable in class org.jgroups.protocols.TpHeader
- flag() - Method in class org.jgroups.protocols.TpHeader
- flags - Variable in class org.jgroups.BaseMessage
- 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.protocols.PingData
- flags - Variable in class org.jgroups.util.FlagsUUID
- flags - Variable in class org.jgroups.util.Rsp
- flags() - Method in class org.jgroups.blocks.RequestOptions
- flags() - Method in class org.jgroups.protocols.CLEAR_FLAGS
- flags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
- flagSet(Message.Flag) - Method in class org.jgroups.blocks.RequestOptions
- flagsToString(short) - Static method in class org.jgroups.util.Util
- FlagsUUID - Class in org.jgroups.util
-
Subclass of
UUID
accommodating additional data such as a flag. - FlagsUUID() - Constructor for class org.jgroups.util.FlagsUUID
- FlagsUUID(byte[]) - Constructor for class org.jgroups.util.FlagsUUID
- FlagsUUID(long, long) - Constructor for class org.jgroups.util.FlagsUUID
- FlagsUUID(T) - Constructor for class org.jgroups.util.FlagsUUID
- 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
- flush() - Method in class org.jgroups.blocks.cs.Connection
- flush() - Method in class org.jgroups.blocks.cs.NioConnection
- flush() - Method in class org.jgroups.blocks.cs.TcpConnection
- flush() - Method in class org.jgroups.blocks.GridOutputStream
- flush() - Method in class org.jgroups.protocols.BATCH
- flush() - Method in class org.jgroups.protocols.BatchBundler
- flush() - Method in class org.jgroups.protocols.REVERSE
- flush() - Method in class org.jgroups.util.OutputStreamAdapter
- flush(boolean) - Method in class org.jgroups.protocols.SHUFFLE
- flush(Address) - Method in class org.jgroups.blocks.cs.BaseServer
- flush(Address) - Method in class org.jgroups.protocols.SEQUENCER
- FLUSH - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- flush_ack - Variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- flush_forward_table - Variable in class org.jgroups.protocols.SEQUENCER
- flush_interval - Variable in class org.jgroups.protocols.BATCH
- flush_interval - Variable in class org.jgroups.protocols.BATCH2
- flush_interval - Variable in class org.jgroups.protocols.BatchBundler
- flush_task - Variable in class org.jgroups.protocols.BATCH
- flush_task - Variable in class org.jgroups.protocols.BatchBundler
- flush_timeout - Variable in class org.jgroups.protocols.BARRIER
- flushAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
- flushAll() - Method in class org.jgroups.blocks.cs.BaseServer
- flushBase64() - Method in class org.jgroups.util.Base64.OutputStream
-
Method added by PHIL.
- flushBecomeServerQueue() - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Flushes the queue.
- flushBecomeServerQueue() - Method in class org.jgroups.protocols.ReliableMulticast
-
Flushes the queue.
- flusher - Variable in class org.jgroups.protocols.SEQUENCER
- Flusher(Address) - Constructor for class org.jgroups.protocols.SEQUENCER.Flusher
- flushing - Variable in class org.jgroups.protocols.SEQUENCER
-
Set when we block all sending threads to resend all messages from forward_table
- flushMessagesInForwardTable() - Method in class org.jgroups.protocols.SEQUENCER
-
Sends all messages currently in forward_table to the new coordinator (changing the dest field).
- flushQueue(Map<Address, Message>) - Method in class org.jgroups.protocols.BARRIER
- FlushTask() - Constructor for class org.jgroups.protocols.BATCH.FlushTask
- FlushTask() - Constructor for class org.jgroups.protocols.BatchBundler.FlushTask
- foo() - Method in class org.jgroups.demos.JmxDemo
- foobar() - Method in class org.jgroups.demos.JmxDemo
- forAllAttributes(BiConsumer<String, ResourceDMBean.AttributeEntry>) - Method in class org.jgroups.jmx.ResourceDMBean
- forAllComponents(Object, BiConsumer<Object, String>) - Static method in class org.jgroups.util.Util
-
Applies a function to all fields annotated with @Component
- forAllComponentTypes(Class<?>, BiConsumer<Class<?>, String>) - Static method in class org.jgroups.util.Util
- forAllConnections(BiConsumer<Address, Connection>) - Method in class org.jgroups.blocks.cs.BaseServer
- forAllFieldsAndMethods(Object, Predicate<? super AccessibleObject>, BiConsumer<Field, Object>, BiConsumer<Method, Object>) - Static method in class org.jgroups.util.Util
-
Applies a function against all fields and methods of a given target object which satisfy a given predicate.
- forAny(Consumer<RouterStub>) - Method in class org.jgroups.stack.RouterStubManager
-
Applies action to a randomly picked RouterStub that's connected
- forceCancelMerge() - Method in class org.jgroups.protocols.pbcast.Merger
- forEach(long, long, Buffer.Visitor<T>, boolean) - Method in class org.jgroups.util.Buffer
- forEach(long, long, Buffer.Visitor<T>, boolean) - Method in class org.jgroups.util.DynamicBuffer
-
Iterates over the matrix with range [from ..
- forEach(long, long, Buffer.Visitor<T>, boolean) - Method in class org.jgroups.util.FixedBuffer
- forEach(long, long, Buffer.Visitor<T>, boolean, boolean) - Method in class org.jgroups.util.FixedBuffer
- forEach(long, long, Table.Visitor<T>) - Method in class org.jgroups.util.Table
-
Iterates over the matrix with range [from ..
- forEach(Consumer<RouterStub>) - Method in class org.jgroups.stack.RouterStubManager
-
Applies action to all connected RouterStubs
- forEach(Buffer.Visitor<T>, boolean) - Method in class org.jgroups.util.Buffer
- forEach(RequestTable.Visitor<T>) - Method in class org.jgroups.util.RequestTable
- forEachNonBlocking(RequestTable.Visitor<T>) - Method in class org.jgroups.util.RequestTable
-
Non-blocking alternative to
RequestTable.forEach(Visitor)
: iteration is performed on the array that exists at the time of this call. - FORK - Class in org.jgroups.protocols
-
The FORK protocol; multiplexes messages to different forks in a stack (https://issues.redhat.com/browse/JGRP-1613).
- FORK() - Constructor for class org.jgroups.protocols.FORK
- 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 - Variable in class org.jgroups.protocols.FORK
- FORK_STACKS - Static variable in class org.jgroups.fork.ForkConfig
- FORK.ForkHeader - Class in org.jgroups.protocols
- ForkChannel - Class in org.jgroups.fork
-
Implementation of a ForkChannel, which is a light-weight channel.
- ForkChannel(JChannel, String, String, boolean, ProtocolStack.Position, Class<? extends Protocol>, Protocol...) - Constructor for class org.jgroups.fork.ForkChannel
-
Creates a new fork-channel from a main-channel.
- ForkChannel(JChannel, 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 protocol 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(double, String) - Static method in class org.jgroups.util.Util
- format(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- forward(Message, long, boolean) - Method in class org.jgroups.protocols.SEQUENCER
- FORWARD - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- FORWARD - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- forward_non_client_generated_msgs - Variable in class org.jgroups.protocols.STOMP
- forward_routes - Variable in class org.jgroups.protocols.relay.Relayer
- forward_sm_time - Variable in class org.jgroups.protocols.relay.RELAY
- forward_table - Variable in class org.jgroups.protocols.SEQUENCER
-
Maintains messages forwarded to the coord which which no ack has been received yet.
- forward_to_local_mbr - Variable in class org.jgroups.protocols.relay.RELAY
-
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.RELAY
- forward_to_site_master - Variable in class org.jgroups.protocols.relay.RELAY
-
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
- ForwardingRoute - Class in org.jgroups.protocols.relay
-
Route which forwards all messages to a given site via a given route.
Example: if site HF is reachable via NET1, and NET2 is not directly connected to HF, it needs to have a ForwardConfig with to="HF" and gateway="NET1". - ForwardingRoute(String, String) - Constructor for class org.jgroups.protocols.relay.ForwardingRoute
- forwards - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- FORWARDS - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- forwardTo(Address, SiteAddress, Address, Message, boolean) - Method in class org.jgroups.protocols.relay.RELAY2
- 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
- frag_id - Variable in class org.jgroups.protocols.Frag3Header
- frag_id - Variable in class org.jgroups.protocols.FragHeader
- FRAG_MSG - Static variable in interface org.jgroups.Message
- frag_size - Variable in class org.jgroups.protocols.FlowControl
- frag_size - Variable in class org.jgroups.protocols.Fragmentation
- frag_size - Variable in class org.jgroups.protocols.RATE_LIMITER
- 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.
- FRAG3 - Class in org.jgroups.protocols
-
Fragmentation protocol which uses less memory to store fragments than
FRAG2
.
When a message is fragmented, all fragments carry the size of the original message, their offset and length with respect to the original message and a fragment ID (to identify the fragment).
When the first fragment is received, the full message is created and each fragment copies its data into the full message at its offset and length. - FRAG3() - Constructor for class org.jgroups.protocols.FRAG3
- FRAG3.FragEntry - Class in org.jgroups.protocols
-
Entry for a full message, received fragments are copied into buffer and set in the bitset of expected frags.
- Frag3Header - Class in org.jgroups.protocols
- Frag3Header() - Constructor for class org.jgroups.protocols.Frag3Header
- Frag3Header(int, int, int) - Constructor for class org.jgroups.protocols.Frag3Header
- Frag3Header(int, int, int, int, int) - Constructor for class org.jgroups.protocols.Frag3Header
- FRAG4 - Class in org.jgroups.protocols
-
Fragmentation layer.
- FRAG4() - Constructor for class org.jgroups.protocols.FRAG4
- FragEntry(int, boolean) - Constructor for class org.jgroups.protocols.FRAG3.FragEntry
-
Creates a new entry
- FragEntry(int, boolean, MessageFactory) - 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(Message) - Method in class org.jgroups.protocols.FRAG3
-
Send all fragments as separate messages (with same ID !).
- fragment(Message) - Method in class org.jgroups.protocols.FRAG4
- fragment_list - Variable in class org.jgroups.protocols.FRAG
-
Contains a frag table per sender, this way it becomes easier to clean up if a sender leaves or crashes
- fragment_list - Variable in class org.jgroups.protocols.FRAG2
- fragment_list - Variable in class org.jgroups.protocols.FRAG3
- Fragmentation - Class in org.jgroups.protocols
-
Base class for all fragmentation protocols.
- Fragmentation() - Constructor for class org.jgroups.protocols.Fragmentation
- fragmentBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
-
Fragments a byte buffer into smaller fragments of (max.) frag_size.
- FragmentedMessage - Class in org.jgroups
-
A message which refers to another message, but only marshals (
Streamable.writeTo(DataOutput)
) a part of the original message, starting at a givenBytesMessage.offset
and marshalling onlyBytesMessage.length
bytes. - FragmentedMessage() - Constructor for class org.jgroups.FragmentedMessage
- FragmentedMessage(Message, int, int) - Constructor for class org.jgroups.FragmentedMessage
- fragments - Variable in class org.jgroups.protocols.FRAG2.FragEntry
- Frame(String, Map<String, String>, byte[]) - Constructor for class org.jgroups.protocols.STOMP.Frame
- from - Variable in class org.jgroups.util.DynamicBuffer.TableIterator
- from - Variable in class org.jgroups.util.Table.TableIterator
- fromString(String) - Static method in class org.jgroups.util.UUID
-
Creates a
UUID
from the string standard representation as described in theUUID.toString()
method. - FUNC - Static variable in class org.jgroups.protocols.LOCAL_PING
- FUNC - Static variable in class org.jgroups.protocols.SHARED_LOOPBACK
- function - Variable in class org.jgroups.util.Runner
- FUNCTIONAL - Static variable in class org.jgroups.Global
- future - Variable in class org.jgroups.protocols.FD_SOCK.BroadcastTask
- future - Variable in class org.jgroups.protocols.FD_SOCK2.BroadcastTask
- fwd_queue - Variable in class org.jgroups.protocols.SEQUENCER2
G
- gateway - Variable in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
- gateway - Variable in class org.jgroups.protocols.relay.ForwardingRoute
- gateway() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
- gateway() - Method in class org.jgroups.protocols.relay.ForwardingRoute
- gateway(String) - Method in class org.jgroups.protocols.relay.ForwardingRoute
- gc() - Method in class org.jgroups.protocols.pbcast.STABLE
- generate(String, String) - Method in class org.jgroups.util.GenerateProfilingScript
- generateAddress() - Method in interface org.jgroups.stack.AddressGenerator
-
Deprecated.
- generateAddress() - Method in class org.jgroups.util.OneTimeAddressGenerator
- generateAddress(String) - Method in class org.jgroups.JChannel
- generateAddress(String) - Method in interface org.jgroups.stack.AddressGenerator
- generateArray(int) - Static method in class org.jgroups.util.Util
- GenerateGettersAndSetters - Class in org.jgroups.util
-
Given a class, generates code for getters and setters for all attributes and writes it to stdout
- GenerateGettersAndSetters() - Constructor for class org.jgroups.util.GenerateGettersAndSetters
- generateLocalName() - Static method in class org.jgroups.util.Util
- GenerateProfilingScript - Class in org.jgroups.util
-
Takes a list of methods to profile and generates the Byteman script from them.
- GenerateProfilingScript() - Constructor for class org.jgroups.util.GenerateProfilingScript
- generateProtocolSchema(Document, Element, String...) - Static method in class org.jgroups.util.XMLSchemaGenerator
- generateRandomBytes() - Static method in class org.jgroups.util.UUID
-
Generate random bytes and adjusts them for a type-4 UUID
- generateRule(String, OutputStream) - Method in class org.jgroups.util.GenerateProfilingScript
- generateSecuritySubject(String, String, String) - Static method in class org.jgroups.auth.Krb5TokenUtils
- get() - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Gets the current value of the counter.
- get() - Method in interface org.jgroups.blocks.atomic.CounterView
- get() - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Gets the current value of the counter
- get() - Method in class org.jgroups.blocks.GroupRequest
- get() - Method in class org.jgroups.blocks.UnicastRequest
- get() - Method in class org.jgroups.util.Credit
- get() - Method in class org.jgroups.util.Ref
- get() - Method in class org.jgroups.util.TimeScheduler3.Task
- get(byte[]) - Method in class org.jgroups.util.ExtendedUUID
- get(int) - Method in class org.jgroups.BatchMessage
- get(int) - Method in class org.jgroups.CompositeMessage
- get(int) - Method in class org.jgroups.MergeView
- get(int) - Method in class org.jgroups.nio.Buffers
- get(int) - Method in class org.jgroups.util.FastArray
- get(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the value of the bit with the specified index.
- get(int) - Method in class org.jgroups.util.IntHashMap
- get(long) - Method in class org.jgroups.util.Buffer
- get(long) - Method in class org.jgroups.util.DynamicBuffer
-
Returns an element at seqno
- get(long) - Method in class org.jgroups.util.FixedBuffer
- get(long) - Method in class org.jgroups.util.RequestTable
- get(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- get(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
- get(long) - Method in class org.jgroups.util.Table
-
Returns an element at seqno
- get(long, long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Returns a list of messages in the range [from ..
- get(long, long) - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Returns a list of messages in the range [from ..
- get(long, TimeUnit) - Method in class org.jgroups.blocks.GroupRequest
- get(long, TimeUnit) - Method in class org.jgroups.blocks.UnicastRequest
- get(long, TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
- get(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- get(String) - Static method in class org.jgroups.conf.ClassConfigurator
- get(String) - Method in class org.jgroups.fork.ForkProtocolStack
- get(String) - Method in class org.jgroups.protocols.FORK
- get(String) - Method in class org.jgroups.protocols.relay.SiteStatus
- get(String) - Method in class org.jgroups.util.ExtendedUUID
- get(String, ClassLoader) - Static method in class org.jgroups.conf.ClassConfigurator
-
Loads and returns the class from the class name
- 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(K) - Method in class org.jgroups.blocks.Cache
- get(K) - Method in class org.jgroups.blocks.LazyRemovalCache
- get(K) - Method in class org.jgroups.blocks.ReplCache
-
Returns the value associated with key
- get(Address) - Method in class org.jgroups.MergeView
- get(Address) - Method in class org.jgroups.util.CreditMap
- get(Address) - Method in class org.jgroups.util.Digest
-
Returns the highest delivered and received seqnos associated with a member.
- get(Address) - Static method in class org.jgroups.util.NameCache
- get(Address, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- GET_ALL - org.jgroups.blocks.ResponseMode
-
return all responses
- 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_FIRST - org.jgroups.blocks.ResponseMode
-
Returns the first response received
- GET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
- GET_LOGICAL_PHYSICAL_MAPPINGS - Static variable in class org.jgroups.Event
- GET_MBRS - org.jgroups.stack.GossipType
- GET_MBRS_REQ - Static variable in class org.jgroups.protocols.PingHeader
- GET_MBRS_RSP - org.jgroups.stack.GossipType
- GET_MBRS_RSP - Static variable in class org.jgroups.protocols.PingHeader
- get_members_map - Variable in class org.jgroups.stack.RouterStub
- GET_NONE - org.jgroups.blocks.ResponseMode
-
return no response (async call)
- GET_OR_CREATE - org.jgroups.protocols.COUNTER.RequestType
- 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
- getAcceptedIssuers() - Method in class org.jgroups.util.ReloadingX509TrustManager
- getAccountNumber() - Method in class org.jgroups.demos.JmxDemo
- getAccumulatedCredits() - Method in class org.jgroups.util.CreditMap
- getAckThreshold() - Method in class org.jgroups.protocols.UNICAST3
- getActualBindPort() - Method in class org.jgroups.protocols.FD_SOCK2
- getAdders() - Method in class org.jgroups.util.Buffer
- getAdders() - Method in class org.jgroups.util.Table
- getAddress() - Method in class org.jgroups.JChannel
- getAddress() - Method in class org.jgroups.protocols.PingData
- getAddress() - Method in class org.jgroups.stack.GossipData
- getAddress() - Method in class org.jgroups.stack.Protocol
- getAddress() - Method in class org.jgroups.util.Owner
- getAddress() - Method in class org.jgroups.util.ThreadPool
- getAddress(String, StackType) - Static method in class org.jgroups.util.Util
- getAddress(NetworkInterface, Util.AddressScope, StackType) - Static method in class org.jgroups.util.Util
-
Returns the first address on the given interface on the current host, which satisfies scope
- getAddress(Util.AddressScope, StackType) - Static method in class org.jgroups.util.Util
-
Returns the first address on any interface which satisfies scope and ip_version.
- getAddressAsString() - Method in class org.jgroups.JChannel
- getAddressAsUUID() - Method in class org.jgroups.JChannel
- getAddressByCustomCode(String) - Static method in class org.jgroups.util.Util
- getAddressByPatternMatch(String, StackType) - Static method in class org.jgroups.util.Util
-
Returns a valid interface address based on a pattern.
- getAddresses(Map<String, Map<String, Configurator.InetAddressInfo>>) - Static method in class org.jgroups.stack.Configurator
-
Returns all inet addresses found
- 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.UNICAST3
- getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST3
- getAlgorithm(String) - Static method in class org.jgroups.protocols.Encrypt
- getAllAvailableAddresses(Predicate<InetAddress>) - Static method in class org.jgroups.util.Util
-
Returns all addresses of all interfaces (that are up) that satisfy a given filter (ignored if null)
- getAllAvailableInterfaces() - 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
- getAllMethods(Class<?>) - Static method in class org.jgroups.util.Util
-
The method walks up the class hierarchy and returns all methods of this class and those inherited from superclasses and superinterfaces.
- getAllPhysicalAddressesFromCache() - Method in class org.jgroups.protocols.TP
- getAnnotation(Class<?>, Class<A>) - Static method in class org.jgroups.util.Util
- getAnycasting() - Method in class org.jgroups.blocks.RequestOptions
- getArg() - Method in class org.jgroups.Event
- getArgs() - Method in class org.jgroups.blocks.MethodCall
- getArray() - Method in class org.jgroups.BatchMessage
- getArray() - Method in class org.jgroups.BytesMessage
-
Returns a reference to the payload (byte array).
- getArray() - Method in class org.jgroups.CompositeMessage
- getArray() - Method in class org.jgroups.EmptyMessage
- getArray() - Method in class org.jgroups.LongMessage
- getArray() - Method in interface org.jgroups.Message
-
Returns a reference to the payload (byte array).
- getArray() - Method in class org.jgroups.NioMessage
- getArray() - Method in class org.jgroups.ObjectMessage
- getArray() - Method in class org.jgroups.util.ByteArray
- getAsLong() - Method in class org.jgroups.util.LongSizeStreamable
- getAsyncDispatching() - Method in class org.jgroups.blocks.MessageDispatcher
- getAsyncExecutor() - Method in class org.jgroups.protocols.TP
- getAttribute(String) - Method in class org.jgroups.jmx.ResourceDMBean
- getAttributes() - Method in class org.jgroups.conf.XmlNode
- getAttributes(String[]) - Method in class org.jgroups.jmx.ResourceDMBean
- getAuthClass() - Method in class org.jgroups.protocols.AUTH
- getAuthToken() - Method in class org.jgroups.protocols.AUTH
- getAverage() - Method in class org.jgroups.util.Average
- getAverageBatchSize() - Method in class org.jgroups.protocols.AlternatingBundler
- getAverageBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
- getAverageBlockTime() - Method in class org.jgroups.util.Credit
- getAverageBlockTime() - Method in class org.jgroups.util.CreditMap
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
Deprecated.
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.FlowControl
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.MFC
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.UFC
- getAvgBatchSize() - Method in class org.jgroups.protocols.MsgStats
- getAvgMsgsForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY
- getAvgMsgsForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY
- getAvgMsgsRelaying() - Method in class org.jgroups.protocols.relay.RELAY
- getAvgSizeDown() - Method in class org.jgroups.protocols.FRAG2
- getAvgSizeDown() - Method in class org.jgroups.protocols.FRAG3
- getAvgSizeUp() - Method in class org.jgroups.protocols.FRAG2
- getAvgSizeUp() - Method in class org.jgroups.protocols.FRAG3
- getAvgTimeBlocked() - Method in class org.jgroups.protocols.NAKACK4
- getBackupCoords() - Method in class org.jgroups.protocols.COUNTER
- getBatch() - Method in class org.jgroups.util.SubmitToThreadPool.BatchHandler
- getBecomeServerQueueSize() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getBecomeServerQueueSize() - Method in class org.jgroups.protocols.ReliableMulticast
- getBecomeServerQueueSizeActual() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getBecomeServerQueueSizeActual() - Method in class org.jgroups.protocols.ReliableMulticast
- getBindAddr() - Method in class org.jgroups.protocols.MPING
- getBindAddr() - Method in class org.jgroups.protocols.TP
- getBindAddress() - Method in class org.jgroups.protocols.FD_SOCK
- getBindAddress() - Method in class org.jgroups.protocols.FD_SOCK2
- getBindAddress() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getBindAddress() - Method in class org.jgroups.protocols.TP
- getBindAddress() - Method in class org.jgroups.stack.DiagnosticsHandler
- getBindInterfaces() - Method in class org.jgroups.stack.DiagnosticsHandler
- getBindPort() - Method in class org.jgroups.protocols.BPING
- getBindPort() - Method in class org.jgroups.protocols.TP
- 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.RELAY
-
Returns the bridge channel to a given site
- getBridges() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.RELAY
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.Relayer
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.Relayer2
- getBridgeView(String) - Method in class org.jgroups.protocols.relay.Relayer3
- getBuf() - Method in class org.jgroups.NioMessage
-
Returns the byte buffer.
- getBuffer() - Method in class org.jgroups.stack.GossipData
- getBuffer() - Method in class org.jgroups.util.ByteArrayDataInputStream
- getBuffer() - Method in class org.jgroups.util.ByteArrayDataOutputStream
- getBuffer() - Method in class org.jgroups.util.ByteBufferOutputStream
- getBuffer() - Method in class org.jgroups.util.StateTransferResult
- getBuffer(ByteBuffer) - Static method in class org.jgroups.blocks.cs.NioConnection
- getBufferAsBuffer() - Method in class org.jgroups.util.ByteBufferOutputStream
- getBufferedInputStreamSize() - Method in class org.jgroups.blocks.cs.TcpBaseServer
- getBufferedInputStreamSize() - Method in class org.jgroups.protocols.TCP
- getBufferedOutputStreamSize() - Method in class org.jgroups.blocks.cs.TcpBaseServer
- getBufferedOutputStreamSize() - Method in class org.jgroups.protocols.TCP
- getBufferSize(DatagramSocket, boolean) - Static method in class org.jgroups.protocols.UDP
- getBundler() - Method in class org.jgroups.protocols.TP
- getBundlerClass() - Method in class org.jgroups.protocols.TP
- getBundlerType() - Method in class org.jgroups.protocols.TP
- getByName(String) - Static method in class org.jgroups.util.Util
-
Finds a network interface or sub-interface with the given name
- getByName(String, StackType) - Static method in class org.jgroups.util.Util
-
Finds an address given a symbolic name.
- getBypassBundling() - Method in class org.jgroups.protocols.COUNTER
- getByteAt(long, int) - Static method in class org.jgroups.util.Bits
- getBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
- getBytes() - Method in class org.jgroups.util.ByteArray
- getByValue(V) - Method in class org.jgroups.blocks.LazyRemovalCache
- getCache() - Method in class org.jgroups.util.SuppressLog
- getCachedServerAddress() - Static method in class org.jgroups.protocols.ASYM_ENCRYPT
- getCacheFromCoordinator() - Method in class org.jgroups.protocols.FD_SOCK
-
Determines coordinator C.
- getCacheMaxAge() - Method in class org.jgroups.protocols.FD_SOCK
- getCacheMaxElements() - Method in class org.jgroups.protocols.FD_SOCK
- getCachingTime() - Method in class org.jgroups.blocks.ReplCache
- getCallInsertSp() - Method in class org.jgroups.protocols.JDBC_PING2
- getCallTimeout() - Method in class org.jgroups.blocks.ReplCache
- getCapacity() - Method in class org.jgroups.protocols.BaseBundler
- getCapacity() - Method in class org.jgroups.protocols.BatchBundler
- getCapacity() - Method in interface org.jgroups.protocols.Bundler
-
If the bundler implementation supports a capacity (e.g.
- getCapacity() - Method in class org.jgroups.protocols.TransferQueueBundler2
- getCapacity() - Method in class org.jgroups.util.IntHashMap
- getCertificateChain(String) - Method in class org.jgroups.util.ReloadingX509KeyManager
- getChangeKeyOnCoordLeave() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- getChangeKeyOnLeave() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- getChannel() - Method in class org.jgroups.blocks.cs.NioServer
- 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
- getCheckInterval() - Method in class org.jgroups.protocols.MERGE3
- getChild(Element, String) - Static method in class org.jgroups.util.Util
- getChildren() - Method in class org.jgroups.conf.XmlNode
- 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
- getCipherSuites() - Method in class org.jgroups.util.TLS
- getClasses(Class<?>, String) - Static method in class org.jgroups.util.XMLSchemaGenerator
- getClassesFromPackages(Class<?>, String...) - Static method in class org.jgroups.util.XMLSchemaGenerator
- getClassForName(String) - Static method in class org.jgroups.jmx.ResourceDMBean
- getClassLoader() - Method in class org.jgroups.conf.ProtocolConfiguration
- getClearSql() - Method in class org.jgroups.protocols.JDBC_PING
- getClearSql() - Method in class org.jgroups.protocols.JDBC_PING2
- getClientAliases(String, Principal[]) - Method in class org.jgroups.util.ReloadingX509KeyManager
- getClientAuth() - Method in class org.jgroups.util.TLS
- getClientBindAddr() - Method in class org.jgroups.protocols.BasicTCP
- getClientBindPort() - Method in class org.jgroups.protocols.BasicTCP
- getClientBindPort() - Method in class org.jgroups.protocols.FD_SOCK
- getClientBindPort() - Method in class org.jgroups.protocols.FD_SOCK2
- getClientBindPortActual() - Method in class org.jgroups.protocols.FD_SOCK
- getClientSSLContext() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getClientState() - Method in class org.jgroups.protocols.FD_SOCK2
- getClusterName() - Method in class org.jgroups.blocks.ReplCache
- getClusterName() - Method in class org.jgroups.blocks.ReplicatedHashMap
- getClusterName() - Method in class org.jgroups.demos.Draw
- getClusterName() - Method in class org.jgroups.JChannel
- getClusterName() - Method in class org.jgroups.protocols.Discovery
- getClusterName() - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
- getClusterName() - Method in class org.jgroups.protocols.TP
- getClusterName() - Method in class org.jgroups.protocols.TpHeader
- getClusterName() - Method in class org.jgroups.util.MessageBatch
- getClusterName() - Method in class org.jgroups.util.SubmitToThreadPool.SingleMessageHandler
- getClusterName() - Method in class org.jgroups.util.SubmitToThreadPool.SingleMessageHandlerWithClusterName
- getClusterNameAscii() - Method in class org.jgroups.protocols.TP
- getClusterSize() - Method in class org.jgroups.blocks.ReplCache
- getComponents() - 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 component objects which need to be configured.
- getComponents(Class<?>) - Static method in class org.jgroups.util.Util
- getComponents(Object) - Static method in class org.jgroups.util.Util
-
Returns the non-null values of all fields of target annotated with @Component
- getConfig() - Method in class org.jgroups.protocols.FORK
- getConfig() - Method in class org.jgroups.protocols.relay.RELAY
- getConfigStream(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
- getConfigStream(Object) - 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.
- getConnCloseTimeout() - Method in class org.jgroups.protocols.UNICAST3
- getConnection() - Method in class org.jgroups.protocols.JDBC_PING
- getConnection() - Method in class org.jgroups.protocols.JDBC_PING2
- getConnection(SocketAddress) - Method in class org.jgroups.protocols.SimpleTCP
- getConnection(Address) - Method in class org.jgroups.blocks.cs.BaseServer
-
Creates a new connection to dest, or returns an existing one
- getConnection(Address, boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- getConnectionDriver() - Method in class org.jgroups.protocols.JDBC_PING
- getConnectionDriver() - Method in class org.jgroups.protocols.JDBC_PING2
- getConnectionPassword() - Method in class org.jgroups.protocols.JDBC_PING
- getConnectionPassword() - Method in class org.jgroups.protocols.JDBC_PING2
- getConnectionUrl() - Method in class org.jgroups.protocols.JDBC_PING
- getConnectionUrl() - Method in class org.jgroups.protocols.JDBC_PING2
- getConnectionUsername() - Method in class org.jgroups.protocols.JDBC_PING
- getConnectionUsername() - Method in class org.jgroups.protocols.JDBC_PING2
- getConnects() - Method in class org.jgroups.fork.ForkProtocolStack
- getConnExpireTime() - Method in class org.jgroups.protocols.BasicTCP
- getConnExpiryTimeout() - Method in class org.jgroups.protocols.UNICAST3
- getContainsSql() - Method in class org.jgroups.protocols.JDBC_PING
- getContents() - Static method in class org.jgroups.util.NameCache
-
Returns a copy of the cache's contents
- getConvertedValue(Object, Field, String, boolean, StackType) - Static method in class org.jgroups.conf.PropertyHelper
- getConvertedValue(Object, Field, Map<String, String>, String, boolean, StackType) - Static method in class org.jgroups.conf.PropertyHelper
- getConvertedValue(Object, Method, Map<String, String>, String, boolean, StackType) - Static method in class org.jgroups.conf.PropertyHelper
- getCoord() - Method in class org.jgroups.protocols.pbcast.GMS
- getCoord() - Method in class org.jgroups.View
- getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
- getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER2
- getCorrelator() - Method in class org.jgroups.blocks.MessageDispatcher
- getCount() - Method in class org.jgroups.util.Average
- getCounter(String) - Method in class org.jgroups.protocols.COUNTER
- getCounterName() - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
- getCounterName() - Method in interface org.jgroups.protocols.COUNTER.Request
- getCounterName() - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
- getCounterName() - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
- getCounterName() - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
- getCreateVThreadHandle() - Static method in class org.jgroups.util.ThreadCreator
- 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
- getCurrentSeqno() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getCurrentSeqno() - Method in class org.jgroups.protocols.ReliableMulticast
- getCurrentSites() - Method in class org.jgroups.protocols.relay.RELAY
- 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.TimeScheduler3
- getCustomLogFactory() - Static method in class org.jgroups.logging.LogFactory
- getDataSource() - Method in class org.jgroups.protocols.JDBC_PING
- getDataSource() - Method in class org.jgroups.protocols.JDBC_PING2
- getDataSourceFromJNDI(String) - Method in class org.jgroups.protocols.JDBC_PING
- getDataSourceFromJNDI(String) - Method in class org.jgroups.protocols.JDBC_PING2
- getDatasourceInjecterClass() - Method in class org.jgroups.protocols.JDBC_PING
- getDatasourceInjecterClass() - Method in class org.jgroups.protocols.JDBC_PING2
- getDatasourceJndiName() - Method in class org.jgroups.protocols.JDBC_PING
- getDatasourceJndiName() - Method in class org.jgroups.protocols.JDBC_PING2
- getDefaultReplicationCount() - Method in class org.jgroups.blocks.ReplCache
- getDelay(TimeUnit) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
- getDelay(TimeUnit) - Method in class org.jgroups.util.TimeScheduler3.Task
- getDeleteSingleSql() - Method in class org.jgroups.protocols.JDBC_PING
- getDeleteSingleSql() - Method in class org.jgroups.protocols.JDBC_PING2
- getDelta() - Method in class org.jgroups.util.ThreadPool
- getDescriptions(Class<?>, Map<String, String>, String, boolean) - Static method in class org.jgroups.util.PropertiesToAsciidoc
- getDesiredAverageGossip() - Method in class org.jgroups.protocols.pbcast.STABLE
- getDest() - Method in class org.jgroups.BaseMessage
- getDest() - Method in interface org.jgroups.Message
-
Returns the destination address to send the message to.
- getDest() - Method in class org.jgroups.util.MessageBatch
- getDiagnosticsHandler() - Method in class org.jgroups.protocols.TP
- 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.NAKACK2
-
Returns a message digest: for each member P the highest delivered and received seqno is added
- 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.protocols.ReliableMulticast
-
Returns a message digest: for each member P the highest delivered and received seqno is added
- getDigest() - Method in class org.jgroups.util.Buffer
- getDigest() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- getDigest() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getDigest() - Method in class org.jgroups.util.Table
- getDigest(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getDigest(Address) - Method in class org.jgroups.protocols.ReliableMulticast
- getDiscardOwnMessages() - Method in class org.jgroups.JChannel
- getDiscoveryCacheSize() - Static method in class org.jgroups.protocols.LOCAL_PING
- getDiscoveryResponsesFor(String) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
- getDNSAddress() - Method in class org.jgroups.protocols.dns.DNS_PING
- getDnsContext() - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- getDNSContextFactory() - Method in class org.jgroups.protocols.dns.DNS_PING
- getDownDiscardRate() - Method in class org.jgroups.protocols.DISCARD
- getDownMessages() - Method in class org.jgroups.protocols.SHUFFLE
- 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
- getDropDownUnicasts() - Method in class org.jgroups.protocols.DISCARD
- getDroppedMessages() - Method in class org.jgroups.protocols.RED
-
Deprecated.
- getDroppedMessages() - Method in class org.jgroups.protocols.UDP
- getDropRate() - Method in class org.jgroups.protocols.RED
- getDynamicHostList() - Method in class org.jgroups.protocols.TCPPING
- getElements() - Method in class org.jgroups.util.SizeBoundedQueue
-
Returns the number of elements in the queue
- getElementsPerRow() - Method in class org.jgroups.util.DynamicBuffer
- getElementsPerRow() - Method in class org.jgroups.util.Table
- getEndpoints() - Method in class org.jgroups.protocols.STOMP
- getEnqueuedMessages() - Method in class org.jgroups.util.NonBlockingCredit
- getEnqueuedMessages() - Method in class org.jgroups.util.NonBlockingCreditMap
- getEntry(K) - Method in class org.jgroups.blocks.Cache
- getException() - Method in class org.jgroups.util.Rsp
- getException() - Method in class org.jgroups.util.StateTransferResult
- getExclusionList() - Method in class org.jgroups.blocks.RequestOptions
- getExternalAddr() - Method in class org.jgroups.protocols.TP
- getExternalAddress() - Method in class org.jgroups.protocols.FD_SOCK
- getExternalAddress() - Method in class org.jgroups.protocols.FD_SOCK2
- getExternalPort() - Method in class org.jgroups.protocols.FD_SOCK
- getExternalPort() - Method in class org.jgroups.protocols.FD_SOCK2
- getExternalPort() - Method in class org.jgroups.protocols.TP
- 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(Class<?>, String, boolean) - Static method in class org.jgroups.util.Util
- getField(Field, Object) - Static method in class org.jgroups.util.Util
- getFile(File, String) - Method in class org.jgroups.blocks.GridFilesystem
- getFile(File, String, int) - Method in class org.jgroups.blocks.GridFilesystem
- 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
- getFilename() - Method in class org.jgroups.protocols.SOS
- getFinalDest() - Method in class org.jgroups.protocols.relay.RelayHeader
- getFirst() - Method in class org.jgroups.Membership
- getFirst() - Method in class org.jgroups.util.RspList
-
Returns the first value in the response set.
- getFirst() - Method in class org.jgroups.util.SeqnoList
-
Returns the first seqno, this is also the lowest seqno in the list as we add seqnos in order
- getFlags() - Method in class org.jgroups.blocks.RequestOptions
- getFlags() - Method in interface org.jgroups.Message
- getFlags(boolean) - Method in class org.jgroups.BaseMessage
-
Returns the internal representation of flags.
- getFlags(boolean) - Method in interface org.jgroups.Message
-
Returns the flags as an or-ed short
- getFlushTimeout() - Method in class org.jgroups.protocols.BARRIER
- getFORK(JChannel, ProtocolStack.Position, 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
- getForwardingRouteMatching(String, Address) - Method in class org.jgroups.protocols.relay.Relayer
-
Returns a Route matching any of the ForwardingRoutes, or null if none matches
- getForwards() - Method in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- getForwardTableSize() - Method in class org.jgroups.protocols.SEQUENCER
- getFragId() - Method in class org.jgroups.protocols.Frag3Header
- getFragSize() - Method in class org.jgroups.protocols.Fragmentation
- getFwdQueueSize() - Method in class org.jgroups.protocols.SEQUENCER2
- getGetCacheTimeout() - Method in class org.jgroups.protocols.FD_SOCK
- 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.ReplCache
- getHashFunctionFactory() - Method in class org.jgroups.blocks.ReplCache
- getHeader(short) - Method in class org.jgroups.BaseMessage
- getHeader(short) - Method in interface org.jgroups.Message
-
Gets a header from the message
- getHeader(Header[], short) - Static method in class org.jgroups.util.Headers
-
Returns the header associated with an ID
- getHeader(Header[], short...) - Static method in class org.jgroups.util.Headers
-
Returns the header associated with a set of IDs
- getHeaders() - Method in class org.jgroups.BaseMessage
- getHeaders() - Method in interface org.jgroups.Message
-
Returns a hashmap of all header IDs and their associated headers
- 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.FailureDetection
- getHeartbeatsSent() - Method in class org.jgroups.protocols.FailureDetection
- getHighest() - Method in class org.jgroups.util.Digest.Entry
- getHighestDeliverable() - Method in class org.jgroups.util.Buffer
-
Returns the highest deliverable (= removable) seqno.
- getHighestDeliverable() - Method in class org.jgroups.util.Table
-
Returns the highest deliverable (= removable) seqno.
- getHighestDelivered() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- getHighestDelivered() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getHighestDelivered() - Method in class org.jgroups.util.Table
- getHighestDeliveredSeqno() - Method in class org.jgroups.util.Digest.Entry
- getHighestReceived() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- getHighestReceived() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getHighestReceived() - Method in class org.jgroups.util.Table
- getHighestReceivedSeqno() - Method in class org.jgroups.util.Digest.Entry
- getHoles() - Method in class org.jgroups.protocols.BARRIER
- getHostFor(Address) - Method in class org.jgroups.protocols.FD_HOST
- 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
- getIncreaseMaxSizeDynamically() - Method in class org.jgroups.util.ThreadPool
- getInDelay() - Method in class org.jgroups.protocols.DELAY
- getInDelayNanos() - Method in class org.jgroups.protocols.DELAY
- getIndex() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
- getInetAddresses() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
- getInetAddresses(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
- getInetAddresses2(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Returns a map of protocol.attr/InetAddress tuples
- 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.SimpleTCP
- getInfo() - Method in class org.jgroups.protocols.TP
- getInfo() - Method in class org.jgroups.protocols.TUNNEL
- getInfo() - Method in class org.jgroups.protocols.UDP
- getInfoWriterMaxWritesAfterView() - Method in class org.jgroups.protocols.FILE_PING
- getInfoWriterSleepTime() - Method in class org.jgroups.protocols.FILE_PING
- 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.
- getInitializeSql() - Method in class org.jgroups.protocols.JDBC_PING
- getInitializeSql() - Method in class org.jgroups.protocols.JDBC_PING2
- getInits() - Method in class org.jgroups.fork.ForkProtocolStack
- getInput(File) - Method in class org.jgroups.blocks.GridFilesystem
- getInput(String) - Method in class org.jgroups.blocks.GridFilesystem
- getInput(String) - Method in class org.jgroups.protocols.SOS
- getInsertionTime() - Method in class org.jgroups.blocks.Cache.Value
- getInsertSingleSql() - Method in class org.jgroups.protocols.JDBC_PING
- getInsertSingleSql() - Method in class org.jgroups.protocols.JDBC_PING2
- getInsertSp() - Method in class org.jgroups.protocols.JDBC_PING2
- getInstance(InputStream) - 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
- getInterval() - Method in class org.jgroups.protocols.FailureDetection
- getInterval() - Method in class org.jgroups.protocols.SOS
- getIpAddress() - Method in class org.jgroups.stack.IpAddress
- getIpStackType() - Static method in class org.jgroups.util.Util
- getIpTTL() - Method in class org.jgroups.protocols.UDP
- getIv(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- getJoinResponse(Message) - Static method in class org.jgroups.protocols.AUTH
- getJoinTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
- getJoinTimeout() - Method in class org.jgroups.util.Runner
- getKeepAliveTime() - Method in class org.jgroups.util.ThreadPool
- 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.TimeScheduler3
- getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Gets the keys of the
data
map. - getKeyServerAddress() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- getKeystore() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getKeystoreAlias() - Method in class org.jgroups.util.TLS
- getKeystoreName() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getKeystorePassword() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getKeystorePassword() - Method in class org.jgroups.util.TLS
- getKeystorePath() - Method in class org.jgroups.util.TLS
- getKeyStoreSource() - Method in class org.jgroups.protocols.SYM_ENCRYPT
- getKeystoreType() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getKeystoreType() - Method in class org.jgroups.util.TLS
- getL1Cache() - Method in class org.jgroups.blocks.ReplCache
- getL2Cache() - Method in class org.jgroups.blocks.ReplCache
- getLargestSize() - Method in class org.jgroups.util.ThreadPool
- getLast() - Method in class org.jgroups.util.SeqnoList
-
Returns the last seqno, this is also the highest seqno in the list as we add seqnos in order
- getLeastSignificantBits() - Method in class org.jgroups.util.UUID
- getLeaveTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
- getLeftMembers() - Method in class org.jgroups.protocols.pbcast.DeltaView
- getLength() - Method in class org.jgroups.BatchMessage
- getLength() - Method in class org.jgroups.blocks.GridFile.Metadata
- getLength() - Method in class org.jgroups.BytesMessage
- getLength() - Method in class org.jgroups.CompositeMessage
- getLength() - Method in class org.jgroups.EmptyMessage
- getLength() - Method in class org.jgroups.LongMessage
- getLength() - Method in interface org.jgroups.Message
-
Returns the length of the byte[] array payload.
- getLength() - Method in class org.jgroups.NioMessage
- getLength() - Method in class org.jgroups.ObjectMessage
- getLength() - Method in class org.jgroups.stack.GossipData
- getLength() - Method in class org.jgroups.util.ByteArray
- getLength() - Method in class org.jgroups.util.ObjectWrapperPrimitive
- getLength() - Method in class org.jgroups.util.ObjectWrapperSerializable
- 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.logging.Slf4jLogImpl
- getLevel() - Method in class org.jgroups.stack.Protocol
- getLinger() - Method in class org.jgroups.protocols.BasicTCP
- getLinger() - Method in class org.jgroups.protocols.FD_SOCK2
- getLinger() - Method in class org.jgroups.protocols.TUNNEL
- getLinger() - Method in class org.jgroups.stack.RouterStub
- 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.stack.DiagnosticsHandler
-
Returns the local datagram socket address (UDP) or the srv address (TCP)
- getLocalAddressAsString() - Method in class org.jgroups.blocks.ReplCache
- getLocalPhysicalAddress() - Method in class org.jgroups.protocols.TP
- getLocalTransport() - Method in class org.jgroups.protocols.TP
- getLocation() - Method in class org.jgroups.protocols.FILE_PING
- getLog() - Method in class org.jgroups.stack.Protocol
- getLog(Class<?>) - Method in interface org.jgroups.logging.CustomLogFactory
- getLog(Class<?>) - Static method in class org.jgroups.logging.LogFactory
- getLog(String) - Method in interface org.jgroups.logging.CustomLogFactory
- getLogAcceptError() - Method in class org.jgroups.blocks.cs.TcpServer
- getLogCollectMessages() - Method in class org.jgroups.protocols.pbcast.GMS
- 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
- getLogicalAddrCacheExpiration() - Method in class org.jgroups.protocols.TP
- getLogicalAddrCacheMaxSize() - Method in class org.jgroups.protocols.TP
- getLogicalAddrCacheReaperInterval() - Method in class org.jgroups.protocols.TP
- getLogicalAddressCache() - Method in class org.jgroups.protocols.TP
- 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
- getLoopback() - Static method in class org.jgroups.util.Util
- getLoopback(StackType) - Static method in class org.jgroups.util.Util
-
IP related utilities
- getLow() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- getLow() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getLow() - Method in class org.jgroups.util.Table
- getMagicId() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- getMagicId() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
- getMagicId() - Method in class org.jgroups.Header
-
Returns the magic-ID.
- getMagicId() - Method in class org.jgroups.protocols.AuthHeader
- getMagicId() - Method in class org.jgroups.protocols.BATCH.BatchHeader
- getMagicId() - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- getMagicId() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- getMagicId() - Method in class org.jgroups.protocols.COUNTER.CounterHeader
- getMagicId() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- getMagicId() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- getMagicId() - Method in class org.jgroups.protocols.EncryptHeader
- getMagicId() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
- getMagicId() - Method in class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- getMagicId() - Method in class org.jgroups.protocols.FcHeader
- getMagicId() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- getMagicId() - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- getMagicId() - Method in class org.jgroups.protocols.FORK.ForkHeader
- getMagicId() - Method in class org.jgroups.protocols.Frag3Header
- getMagicId() - Method in class org.jgroups.protocols.FragHeader
- getMagicId() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
- getMagicId() - Method in class org.jgroups.protocols.NakAckHeader
- getMagicId() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- getMagicId() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- getMagicId() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- getMagicId() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- getMagicId() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- getMagicId() - Method in class org.jgroups.protocols.PERF.PerfHeader
- getMagicId() - Method in class org.jgroups.protocols.PingHeader
- getMagicId() - Method in class org.jgroups.protocols.ProtPerfHeader
- getMagicId() - Method in class org.jgroups.protocols.relay.RelayHeader
- getMagicId() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- getMagicId() - Method in class org.jgroups.protocols.RTTHeader
- getMagicId() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- getMagicId() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- getMagicId() - Method in class org.jgroups.protocols.STOMP.StompHeader
- getMagicId() - Method in class org.jgroups.protocols.TpHeader
- getMagicId() - Method in class org.jgroups.protocols.UnicastHeader3
- getMagicId() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- getMagicId() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- getMagicNumber(Class<?>) - Static method in class org.jgroups.conf.ClassConfigurator
-
Returns the magic number for the class.
- getMajor() - Static method in class org.jgroups.Version
- getMajor(short) - Static method in class org.jgroups.Version
- getMaxAge() - Method in class org.jgroups.demos.JmxDemo
- getMaxBlockTime() - Method in class org.jgroups.protocols.FlowControl
- getMaxBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
- getMaxBytes() - Method in class org.jgroups.protocols.RATE_LIMITER
- getMaxCloseTime() - Method in class org.jgroups.protocols.BARRIER
- getMaxCompactionTime() - Method in class org.jgroups.util.DynamicBuffer
- getMaxCompactionTime() - Method in class org.jgroups.util.Table
- getMaxCredits() - Method in class org.jgroups.protocols.FlowControl
- getMaxInterval() - Method in class org.jgroups.protocols.MERGE3
- getMaxJoinAttempts() - Method in class org.jgroups.protocols.pbcast.GMS
- getMaxLength() - Method in class org.jgroups.blocks.cs.BaseServer
- getMaxLength() - Method in class org.jgroups.protocols.BasicTCP
- getMaxNumberOfEntries() - Method in class org.jgroups.blocks.Cache
- getMaxParticipantsInMerge() - Method in class org.jgroups.protocols.MERGE3
- getMaxQueueSize() - Method in class org.jgroups.protocols.MFC_NB
- getMaxQueueSize() - Method in class org.jgroups.protocols.UFC_NB
- getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST3
- getMaxSendBuffers() - Method in class org.jgroups.protocols.TCP_NIO2
- getMaxSiteMasters() - Method in class org.jgroups.protocols.relay.RELAY
- getMaxSize() - Method in class org.jgroups.protocols.BaseBundler
- getMaxSize() - Method in class org.jgroups.protocols.BatchBundler
- getMaxSize() - Method in interface org.jgroups.protocols.Bundler
-
Maximum number of bytes for messages to be queued until they are sent
- getMaxSize() - Method in class org.jgroups.protocols.NoBundler
- getMaxSize() - Method in class org.jgroups.protocols.PerDestinationBundler
- getMaxSize() - Method in class org.jgroups.protocols.SHUFFLE
- getMaxSize() - Method in class org.jgroups.protocols.TransferQueueBundler2
- getMaxThreads() - Method in class org.jgroups.util.ThreadPool
- 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.TimeScheduler3
- getMaxTime() - Method in class org.jgroups.protocols.SHUFFLE
- getMaxXmitReqSize() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getMaxXmitReqSize() - Method in class org.jgroups.protocols.ReliableMulticast
- getMaxXmitReqSize() - Method in class org.jgroups.protocols.UNICAST3
- 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
- getMcastAddress() - Method in class org.jgroups.stack.DiagnosticsHandler
- getMcastGroupAddr() - Method in class org.jgroups.protocols.UDP
- getMcastPort() - Method in class org.jgroups.protocols.MPING
- getMcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- getMcastRecvBufSize() - Method in class org.jgroups.protocols.UDP
- getMcastSendBufSize() - Method in class org.jgroups.protocols.UDP
- 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.FailureDetection
- getMembers() - Method in class org.jgroups.protocols.FD_SOCK
- getMembers() - Method in class org.jgroups.View
-
Returns the member list
- 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. - 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.util.SubmitToThreadPool.SingleMessageHandler
- getMessage(String) - Static method in class org.jgroups.util.Util
- getMessageFactory() - Method in class org.jgroups.protocols.TP
- getMessageFactoryClass() - Method in class org.jgroups.protocols.TP
- getMessageProcessingPolicy() - Method in class org.jgroups.protocols.TP
- getMessages() - Method in class org.jgroups.BatchMessage
- getMessageStats() - Method in class org.jgroups.protocols.TP
- getMetadata() - Method in class org.jgroups.protocols.SOS
- getMethod() - Method in class org.jgroups.blocks.MethodCall
- getMethod() - Method in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
- getMethodId() - Method in class org.jgroups.blocks.MethodCall
- getMethodInvoker() - Method in class org.jgroups.blocks.RpcDispatcher
- getMethodLookup() - Method in class org.jgroups.blocks.RpcDispatcher
- getMethodName() - Method in class org.jgroups.blocks.MethodCall
- getMicro() - Static method in class org.jgroups.Version
- getMicro(short) - Static method in class org.jgroups.Version
- getMinCredits() - Method in class org.jgroups.protocols.FlowControl
- getMinCredits() - Method in class org.jgroups.util.CreditMap
- getMinInterval() - Method in class org.jgroups.protocols.MERGE3
- getMinor() - Static method in class org.jgroups.Version
- getMinor(short) - Static method in class org.jgroups.Version
- getMinSize() - Method in class org.jgroups.protocols.COMPRESS
- getMinThreads() - Method in class org.jgroups.util.ThreadPool
- 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.TimeScheduler3
- getMinThreshold() - Method in class org.jgroups.protocols.FlowControl
- getMinThreshold() - Method in class org.jgroups.protocols.RED
- getMissing() - Method in class org.jgroups.util.Buffer
-
Returns a list of missing (= null) elements
- 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.RingBufferSeqnoLockless
- getMissing() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getMissing() - Method in class org.jgroups.util.Table
-
Returns a list of missing (= null) elements
- getMissing(int) - Method in class org.jgroups.util.Buffer
-
Returns a list of missing messages
- getMissing(int) - Method in class org.jgroups.util.Table
-
Returns a list of missing messages
- getMissingElements() - Method in class org.jgroups.util.Buffer.Missing
- getMissingElements() - Method in class org.jgroups.util.Table.Missing
- getMode() - Method in class org.jgroups.blocks.RequestOptions
- getMode() - Method in class org.jgroups.util.MessageBatch
- getModeAndPadding(String) - Static method in class org.jgroups.protocols.Encrypt
- 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.
- getMsgFactoryClass() - Method in class org.jgroups.protocols.TP
- getMulticastAddress() - Method in class org.jgroups.protocols.UDP
- getMulticastPort() - Method in class org.jgroups.protocols.UDP
- getMulticastTTL() - Method in class org.jgroups.protocols.UDP
- 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.FixedMembershipToken
- getName() - Method in class org.jgroups.auth.Krb5Token
- getName() - Method in class org.jgroups.auth.RegexMembership
- getName() - Method in class org.jgroups.auth.X509Token
- getName() - Method in interface org.jgroups.blocks.atomic.BaseCounter
- getName() - Method in class org.jgroups.blocks.GridFile
- getName() - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- getName() - Method in class org.jgroups.conf.XmlNode
- getName() - Method in class org.jgroups.demos.JmxDemo.MyNotification
- getName() - 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.stack.Protocol
- getName() - Method in class org.jgroups.stack.ProtocolStack
- getNamedAttribute(String) - Method in class org.jgroups.jmx.ResourceDMBean
- getNameFromAnnotation(AccessibleObject) - Static method in class org.jgroups.util.Util
- 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.UNICAST3
- getNewMembers() - Method in class org.jgroups.protocols.pbcast.DeltaView
- 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<Collection<Address>>) - Method in interface org.jgroups.stack.MembershipChangePolicy
-
Compute a new membership based on a number of subviews
- 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<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.
- 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
- getNewVirtualThreadFactoryHandle() - Static method in class org.jgroups.util.ThreadCreator
- getNext(Address) - Method in class org.jgroups.Membership
-
Returns the members next to mbr.
- getNextHigherPowerOfTwo(int) - Static method in class org.jgroups.util.Util
- getNextId() - Method in class org.jgroups.protocols.FRAG2
- getNextId() - Method in class org.jgroups.protocols.FRAG3
- getNextId() - Method in class org.jgroups.protocols.RSVP
- 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
- 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.
- getNonBlockingTaskHandling() - Method in interface org.jgroups.util.TimeScheduler
- getNonBlockingTaskHandling() - Method in class org.jgroups.util.TimeScheduler3
- getNonLoopbackAddress() - Static method in class org.jgroups.util.Util
-
Returns the first non-loopback address on any interface on the current host
- getNonLoopbackAddress(StackType) - Static method in class org.jgroups.util.Util
- getNonMemberMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getNonMemberMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- getNonSetMembers() - Method in class org.jgroups.util.MutableDigest
-
Returns an array of members whose seqno is not set.
- getNow(RspList<T>) - Method in class org.jgroups.blocks.GroupRequest
- getNow(T) - Method in class org.jgroups.blocks.UnicastRequest
- getNumAcksReceived() - Method in class org.jgroups.protocols.UNICAST3
- getNumAcksSent() - Method in class org.jgroups.protocols.UNICAST3
- getNumBatchesReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumBatchesSent() - Method in class org.jgroups.protocols.MsgStats
- getNumberAsString() - Method in class org.jgroups.demos.JmxDemo
- getNumberOfBackups() - Method in class org.jgroups.protocols.COUNTER
- getNumberOfBlockings() - Method in class org.jgroups.protocols.FlowControl
- getNumberOfBlockings() - Method in class org.jgroups.protocols.MFC
- getNumberOfBlockings() - Method in class org.jgroups.protocols.UFC
- getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FlowControl
-
Deprecated.
- getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FlowControl
-
Deprecated.
- getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FlowControl
-
Deprecated.
- getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FlowControl
-
Deprecated.
- getNumberOfDiscoveryRequestsSent() - Method in class org.jgroups.protocols.Discovery
- getNumberOfInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
- getNumberOfMessages() - Method in class org.jgroups.BatchMessage
- getNumberOfMessages() - Method in class org.jgroups.CompositeMessage
- getNumberOfNoRouteErrors() - Method in class org.jgroups.protocols.relay.RELAY
- getNumberOfQueuedMessages() - Method in class org.jgroups.protocols.MFC_NB
- getNumberOfQueuedMessages() - Method in class org.jgroups.protocols.UFC_NB
- getNumberOfQueuings() - Method in class org.jgroups.protocols.MFC_NB
- getNumberOfQueuings() - Method in class org.jgroups.protocols.UFC_NB
- getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.Fragmentation
- getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG
- getNumberOfSentFragments() - Method in class org.jgroups.protocols.Fragmentation
- getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
Deprecated.
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
Deprecated.
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getNumberOfThreadDumps() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumberOfThreadDumps() - Method in class org.jgroups.util.ThreadPool
-
Deprecated.
- getNumBlockings() - Method in class org.jgroups.protocols.NAKACK4
- getNumBlockings() - Method in class org.jgroups.util.Credit
- getNumBlockings() - Method in class org.jgroups.util.CreditMap
- getNumBytesReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumBytesSent() - Method in class org.jgroups.protocols.MsgStats
- getNumCompactions() - Method in class org.jgroups.util.DynamicBuffer
- getNumCompactions() - Method in class org.jgroups.util.Table
- getNumCompressions() - Method in class org.jgroups.protocols.COMPRESS
- getNumConnections() - Method in class org.jgroups.blocks.cs.BaseServer
- getNumConnections() - Method in class org.jgroups.protocols.STOMP
- getNumConnections() - Method in class org.jgroups.protocols.UNICAST3
- getNumDeliverable() - Method in class org.jgroups.util.Buffer
-
Returns the number of messages that can be delivered
- getNumDeliverable() - Method in class org.jgroups.util.Table
-
Returns the number of messages that can be delivered
- getNumForwardedToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY
- getNumForwardedToSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY
- getNumFrags() - Method in class org.jgroups.protocols.Frag3Header
- getNumHeaders() - Method in class org.jgroups.BaseMessage
- getNumHeaders() - Method in interface org.jgroups.Message
-
Returns the number of headers
- getNumLoopbacks() - Method in class org.jgroups.protocols.UNICAST3
- getNumMcastBytesReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumMcastBytesSent() - Method in class org.jgroups.protocols.MsgStats
- getNumMcastMsgsReceived() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumMcastMsgsSent() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumMcastsReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumMcastsSent() - Method in class org.jgroups.protocols.MsgStats
- getNumMergeEvents() - Method in class org.jgroups.protocols.MERGE3
- getNumMessagesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getNumMessagesReceived() - Method in class org.jgroups.protocols.ReliableMulticast
- getNumMessagesReceived() - Method in class org.jgroups.protocols.UNICAST3
-
Deprecated.
- getNumMessagesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getNumMessagesSent() - Method in class org.jgroups.protocols.ReliableMulticast
- getNumMessagesSent() - Method in class org.jgroups.protocols.UNICAST3
-
Deprecated.
- 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.DynamicBuffer
- getNumMoves() - Method in class org.jgroups.util.Table
- getNumMsgsReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumMsgsSent() - Method in class org.jgroups.protocols.MsgStats
- getNumOpenConnections() - Method in class org.jgroups.blocks.cs.BaseServer
- getNumPurges() - Method in class org.jgroups.util.DynamicBuffer
- getNumPurges() - Method in class org.jgroups.util.Table
- getNumReceiveConnections() - Method in class org.jgroups.protocols.UNICAST3
- getNumRejectedMsgs() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumRelayed() - Method in class org.jgroups.protocols.relay.RELAY
- getNumResizes() - Method in class org.jgroups.util.DynamicBuffer
- getNumResizes() - Method in class org.jgroups.util.Table
- getNumRoutes() - Method in class org.jgroups.protocols.relay.RELAY
- getNumRoutes() - Method in class org.jgroups.protocols.relay.Relayer
- getNumRows() - Method in class org.jgroups.util.DynamicBuffer
- getNumRows() - Method in class org.jgroups.util.Table
- getNumSendConnections() - Method in class org.jgroups.protocols.UNICAST3
- getNumSingleMsgsSent() - Method in class org.jgroups.protocols.MsgStats
- getNumSubscriptions() - Method in class org.jgroups.protocols.STOMP
- getNumSuspectedMembers() - Method in class org.jgroups.protocols.FD_SOCK
- getNumSuspectedMembers() - Method in class org.jgroups.protocols.FD_SOCK2
- 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
- getNumTries() - Method in class org.jgroups.protocols.FD_SOCK
- getNumUcastBytesReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumUcastBytesSent() - Method in class org.jgroups.protocols.MsgStats
- getNumUcastMsgsReceived() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumUcastMsgsSent() - Method in class org.jgroups.protocols.TP
-
Deprecated.
- getNumUcastsReceived() - Method in class org.jgroups.protocols.MsgStats
- getNumUcastsSent() - Method in class org.jgroups.protocols.MsgStats
- getNumUnackedMessages() - Method in class org.jgroups.protocols.UNICAST3
-
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
- getNumUncompressions() - Method in class org.jgroups.protocols.COMPRESS
- getNumVotes() - Method in class org.jgroups.protocols.pbcast.STABLE
- getNumXmits() - Method in class org.jgroups.protocols.UNICAST3
- getObject() - Method in class org.jgroups.BatchMessage
- getObject() - Method in class org.jgroups.BytesMessage
- getObject() - Method in class org.jgroups.CompositeMessage
- getObject() - Method in class org.jgroups.EmptyMessage
- getObject() - Method in class org.jgroups.LongMessage
- getObject() - Method in interface org.jgroups.Message
-
Gets an object from the payload.
- getObject() - Method in class org.jgroups.NioMessage
- getObject() - Method in class org.jgroups.ObjectMessage
- getObject() - Method in class org.jgroups.util.ObjectWrapperPrimitive
- getObject(ClassLoader) - Method in class org.jgroups.BytesMessage
-
Uses custom serialization to create an object from the array of the message.
- getObject(ClassLoader) - Method in class org.jgroups.NioMessage
-
Tries to unmarshal the byte buffer payload into an object
- getObject(Message) - Static method in class org.jgroups.util.Util
-
Tries to return a legible representation of a message's payload
- getObjects(Iterable<Message>) - Static method in class org.jgroups.util.Util
- getOffset() - Method in class org.jgroups.BatchMessage
- getOffset() - Method in class org.jgroups.BytesMessage
- getOffset() - Method in class org.jgroups.CompositeMessage
- getOffset() - Method in class org.jgroups.EmptyMessage
- getOffset() - Method in class org.jgroups.LongMessage
- getOffset() - Method in interface org.jgroups.Message
-
Returns the offset of the byte[] array at which user data starts.
- getOffset() - Method in class org.jgroups.NioMessage
- getOffset() - Method in class org.jgroups.ObjectMessage
- getOffset() - Method in class org.jgroups.protocols.FD_SOCK2
- getOffset() - Method in class org.jgroups.protocols.Frag3Header
- getOffset() - Method in class org.jgroups.stack.GossipData
- getOffset() - Method in class org.jgroups.util.ByteArray
- getOffset() - Method in class org.jgroups.util.Table
- getOfVirtualClass() - Static method in class org.jgroups.util.ThreadCreator
- getOfVirtualHandle() - Static method in class org.jgroups.util.ThreadCreator
- getOpenConnections() - Method in class org.jgroups.protocols.TCP_NIO2
- getOpenConnections() - Method in class org.jgroups.protocols.TCP
- getOption(SocketOption<T>) - Method in class org.jgroups.nio.MockSocketChannel
- getOrCreateAsyncCounter(String, long) - Method in class org.jgroups.blocks.atomic.CounterService
-
Returns an existing counter, or creates a new one if none exists
- getOrCreateAsyncCounter(String, long) - Method in class org.jgroups.protocols.COUNTER
- getOrCreateCounter(String, long) - Method in class org.jgroups.blocks.atomic.CounterService
-
Deprecated.since 5.2. Use
CounterService.getOrCreateSyncCounter(String, long)
instead. - getOrCreateCounter(String, long) - Method in class org.jgroups.protocols.COUNTER
-
Deprecated.
- GetOrCreateRequest() - Constructor for class org.jgroups.protocols.COUNTER.GetOrCreateRequest
- getOrCreateSyncCounter(String, long) - Method in class org.jgroups.blocks.atomic.CounterService
- getOriginalLength() - Method in class org.jgroups.protocols.Frag3Header
- getOriginalMessage() - Method in class org.jgroups.FragmentedMessage
- getOriginalSender() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- getOriginalSender() - Method in class org.jgroups.protocols.relay.RelayHeader
- getOriginalType() - Method in class org.jgroups.protocols.FragHeader
- getOrigSender() - Method in class org.jgroups.BatchMessage
- 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
- getOutputStream(Address, int) - Method in class org.jgroups.stack.GossipRouter
- getOwner() - Method in class org.jgroups.protocols.COUNTER
- getParameterString(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
- getParameterStringXml(String, String) - Static method in class org.jgroups.conf.ProtocolConfiguration
- getPasscode() - Method in class org.jgroups.stack.DiagnosticsHandler
- getPath() - Method in class org.jgroups.blocks.GridFile
- getPayload() - Method in class org.jgroups.BaseMessage
- getPayload() - Method in interface org.jgroups.Message
-
Returns the payload without any conversion (e.g.
- getPeerAddrReadTimeout() - Method in class org.jgroups.protocols.BasicTCP
- getPendingRsvpRequests() - Method in class org.jgroups.protocols.RSVP
- 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() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- getPhysicalAddress() - Method in class org.jgroups.protocols.SimpleTCP
- getPhysicalAddress() - Method in class org.jgroups.protocols.TCP_NIO2
- getPhysicalAddress() - Method in class org.jgroups.protocols.TCP
- 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
- getPhysicalAddress(Address) - Method in class org.jgroups.protocols.FD_HOST
- getPhysicalAddress(Address) - Method in class org.jgroups.protocols.relay.RELAY
- getPhysicalAddresses(Address) - Method in class org.jgroups.protocols.FD_SOCK2
-
Returns the physical addresses for in range [a+offset..a+offset+port_range
- getPhysicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
- 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_SOCK
- getPingDest() - Method in class org.jgroups.protocols.FD_SOCK2
- getPolicies() - Method in class org.jgroups.stack.Protocol
- getPort() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getPort() - Method in class org.jgroups.stack.DiagnosticsHandler
- getPort() - Method in class org.jgroups.stack.IpAddress
- getPortRange() - Method in class org.jgroups.protocols.FD_SOCK
- getPortRange() - Method in class org.jgroups.protocols.FD_SOCK2
- getPortRange() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getPortRange() - Method in class org.jgroups.protocols.TCPPING
- getPortRange() - Method in class org.jgroups.protocols.TP
- getPortRange() - Method in class org.jgroups.stack.DiagnosticsHandler
- getPreferredSize() - Method in class org.jgroups.demos.Draw.DrawPanel
- getPrevious(Address) - Method in class org.jgroups.Membership
-
Returns the members to the left of mbr
- getPrivateKey(String) - Method in class org.jgroups.util.ReloadingX509KeyManager
- getProbeHandlers() - Method in class org.jgroups.stack.DiagnosticsHandler
- getProcessing() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- getProcessing() - Method in class org.jgroups.util.RingBufferSeqnoOld
- getProperties() - Method in class org.jgroups.conf.ProtocolConfiguration
- getProperties() - Method in class org.jgroups.JChannel
-
Returns the protocol stack configuration in string format.
- getProperty(String) - Static method in class org.jgroups.util.Util
- 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, Properties) - Static method in class org.jgroups.util.Util
- 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.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.
- getProtocols() - Method in class org.jgroups.util.TLS
- getProtocolStack() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
- getProtocolStack() - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolStack() - Method in class org.jgroups.JChannel
- getProtocolStack() - Method in class org.jgroups.stack.Protocol
- getProtocolStackString() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
- getProtocolStackString() - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolStackString(boolean) - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolString() - Method in class org.jgroups.conf.ProtocolConfiguration
- getProtocolString(boolean) - Method in class org.jgroups.conf.ProtocolConfiguration
- getProtocolStringNewXml() - Method in class org.jgroups.conf.ProtocolConfiguration
- getProvider() - Method in class org.jgroups.util.TLS
- getPublicKeys() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- getQueue() - Method in class org.jgroups.util.ProcessingQueue
- getQueuedMessages() - Method in class org.jgroups.util.NonBlockingCredit
- getQueuedMessages() - Method in class org.jgroups.util.NonBlockingCreditMap
- getQueuedMessageSize() - Method in class org.jgroups.util.NonBlockingCredit
- getQueuedMessageSize() - Method in class org.jgroups.util.NonBlockingCreditMap
- getQueuedMessagesTo(Address) - Method in class org.jgroups.protocols.UFC_NB
- getQueuedSize() - Method in class org.jgroups.protocols.MFC_NB
- getQueuedSize() - Method in class org.jgroups.protocols.UFC_NB
- getQueueSize() - Method in class org.jgroups.protocols.BaseBundler
- getQueueSize() - Method in class org.jgroups.protocols.BatchBundler
- getQueueSize() - Method in interface org.jgroups.protocols.Bundler
-
If the bundler has a queue and it should be managed by a queuing discipline (like Random Early Detection), then return the number of elements in the queue, else -1.
- getQueueSize() - Method in class org.jgroups.protocols.NoBundler
- getQueueSize() - Method in class org.jgroups.protocols.PerDestinationBundler
- getQueueSize() - Method in class org.jgroups.protocols.RemoveQueueBundler
- getQueueSize() - Method in class org.jgroups.protocols.RingBufferBundler
- getQueueSize() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- getQueueSize() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- getQueueSize() - Method in class org.jgroups.protocols.TransferQueueBundler
- getQueueSize() - Method in class org.jgroups.protocols.TransferQueueBundler2
- getQueueSize() - Method in class org.jgroups.util.TimeScheduler3
- getRank(Collection<Address>, Address) - Static method in class org.jgroups.util.Util
- 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
- getReaderIdleTime() - Method in class org.jgroups.protocols.TCP_NIO2
- getReaperInterval() - Method in class org.jgroups.protocols.BasicTCP
- getReceiveInterfaces() - Method in class org.jgroups.protocols.MPING
- getReceiveInterfaces() - Method in class org.jgroups.protocols.TP
- getReceiver() - Method in class org.jgroups.JChannel
- getReceiverCreditsFor(Address) - Method in class org.jgroups.protocols.FlowControl
- getReceiverEntry(Address, long, boolean, short, Address) - Method in class org.jgroups.protocols.UNICAST3
- getReconnectInterval() - Method in class org.jgroups.protocols.TUNNEL
- getRecvBufSize() - Method in class org.jgroups.protocols.BasicTCP
- getRefViewId() - Method in class org.jgroups.protocols.pbcast.DeltaView
- getRejectedExecutionHandler() - Method in class org.jgroups.util.ThreadPool
- getRemoteAddress() - Method in class org.jgroups.nio.MockSocketChannel
- 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
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.AddAndGetRequest
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.DeleteRequest
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
- getRequestType() - Method in interface org.jgroups.protocols.COUNTER.Request
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.SetRequest
- getRequestType() - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
- getRequireClientAuthentication() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getResendInterval() - Method in class org.jgroups.protocols.RSVP
- getResendLastSeqnoMaxTimes() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getResolvedHosts() - Method in class org.jgroups.protocols.TCPPING
- getResourceAsStream(String, Class<?>) - Static method in class org.jgroups.util.Util
- getResourceAsStream(String, ClassLoader) - Static method in class org.jgroups.util.Util
- getResponsesComplete() - Method in class org.jgroups.blocks.GroupRequest
- getResponseType() - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
- getResponseType() - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
- getResponseType() - Method in class org.jgroups.protocols.COUNTER.ValueResponse
- getResult() - Method in class org.jgroups.util.Buffer.HighestDeliverable
- getResult() - Method in class org.jgroups.util.Buffer.NumDeliverable
- getResult() - Method in class org.jgroups.util.Buffer.Remover
- getResult() - Method in class org.jgroups.util.Promise
-
Returns when the result is available (blocking until tthe result is available)
- getResult() - Method in class org.jgroups.util.Table.HighestDeliverable
- getResult() - Method in class org.jgroups.util.Table.NumDeliverable
- getResult() - Method in class org.jgroups.util.Table.Remover
- 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(Callable<T>) - Method in class org.jgroups.blocks.UnicastRequest
- 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
- getRoute(String) - Method in class org.jgroups.protocols.relay.RELAY
-
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
-
Gets routes for a given site.
- getRoutes(String...) - Method in class org.jgroups.protocols.relay.Relayer
- getRouteStatusListener() - Method in class org.jgroups.protocols.relay.RELAY
- getRow(int) - Method in class org.jgroups.util.DynamicBuffer
-
Returns a row.
- getRow(int) - Method in class org.jgroups.util.Table
-
Returns a row.
- getRspFilter() - Method in class org.jgroups.blocks.RequestOptions
- getRTT() - Method in class org.jgroups.protocols.TP
- getRunnable() - Method in class org.jgroups.util.TimeScheduler3.Task
- getScopedInetAddress(Inet6Address) - Static method in class org.jgroups.conf.PropertyConverters.Default
- getSecretKeyAlgorithm() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSecretKeyFromAbove() - Method in class org.jgroups.protocols.KeyExchange
-
Fetches the secret key from a protocol above us
- getSelectAllPingdataSql() - Method in class org.jgroups.protocols.JDBC_PING
- getSelectAllPingdataSql() - Method in class org.jgroups.protocols.JDBC_PING2
- getSendBufSize() - Method in class org.jgroups.protocols.BasicTCP
- getSender() - Method in class org.jgroups.protocols.NakAckHeader
- getSender() - Method in class org.jgroups.protocols.pbcast.MergeData
- getSender() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- getSender() - Method in class org.jgroups.protocols.PingData
- getSender() - Method in class org.jgroups.stack.GossipData
- getSender() - Method in class org.jgroups.util.MessageBatch
- getSenderCreditsFor(Address) - Method in class org.jgroups.protocols.UFC
- getSenderEntry(Address) - Method in class org.jgroups.protocols.UNICAST3
- getSendInterfaces() - Method in class org.jgroups.protocols.MPING
- getSendWindow(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Used for testing only!
- getSeqno() - Method in class org.jgroups.protocols.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
- getSerialized() - Method in class org.jgroups.util.ObjectWrapperSerializable
- getServerAliases(String, Principal[]) - Method in class org.jgroups.util.ReloadingX509KeyManager
- getServerLocation() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- getServerLocation() - Method in class org.jgroups.protocols.KeyExchange
-
Returns the address of the server, e.g.
- getServerLocation() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getServerObject() - Method in class org.jgroups.blocks.RpcDispatcher
- getServerSocketAddress() - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
- getServerSSLContext() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSessionId() - Method in class org.jgroups.client.StompConnection
- getSessionVerifier() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSessionVerifierArg() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSessionVerifierClass() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSite() - Method in class org.jgroups.protocols.relay.RELAY
- getSite() - Method in class org.jgroups.protocols.relay.RelayHeader
- 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
- getSiteMasterPickerImpl() - Method in class org.jgroups.protocols.relay.RELAY
- getSiteMastersRatio() - Method in class org.jgroups.protocols.relay.RELAY
- getSiteNames() - Method in class org.jgroups.protocols.relay.Relayer
- getSites() - Method in class org.jgroups.protocols.relay.RELAY
- getSites() - Method in class org.jgroups.protocols.relay.RelayHeader
- getSites(View, String) - Static method in class org.jgroups.util.Util
- getSize() - Method in class org.jgroups.blocks.Cache
- getSizeOfAllMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getSizeOfAllMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getSizeOfAllMessagesInclHeaders() - Method in class org.jgroups.protocols.ReliableMulticast
- getSniMatchers() - Method in class org.jgroups.util.TLS
- getSockAddress() - Method in class org.jgroups.blocks.cs.TcpConnection
- getSockConnTimeout() - Method in class org.jgroups.protocols.BasicTCP
- getSockConnTimeout() - Method in class org.jgroups.protocols.FD_SOCK
- getSocketFactory() - Method in class org.jgroups.protocols.TP
- 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
- getSocketTimeout() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getSrc() - Method in class org.jgroups.BaseMessage
- getSrc() - Method in interface org.jgroups.Message
-
Returns the address of the sender
- getSSLContext() - Method in class org.jgroups.util.TLS
- 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(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the provided properties string.
- getStartPort() - Method in class org.jgroups.protocols.FD_SOCK
- getState() - Method in class org.jgroups.JChannel
- getState(OutputStream) - Method in class org.jgroups.blocks.MessageDispatcher
- getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
- getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedTree
- getState(OutputStream) - Method in class org.jgroups.demos.Draw
- getState(OutputStream) - Method in interface org.jgroups.Receiver
-
Allows an application to write the state to an OutputStream.
- getState(OutputStream) - Method in class org.jgroups.util.MyReceiver
- getState(Address, long) - Method in class org.jgroups.fork.ForkChannel
- getState(Address, long) - Method in class org.jgroups.JChannel
-
Retrieves the full state from the target member.
The state transfer is initiated by invoking getState() on this channel. - getStateFrom(JChannel, Protocol, String, String, DataOutputStream) - Method in class org.jgroups.protocols.FORK
- getStateFromApplication(Address, OutputStream, boolean) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getStateFromApplication(Address, Digest) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- getStateFromMainAndForkChannels(Event) - Method in class org.jgroups.protocols.FORK
- getStats() - Method in class org.jgroups.JChannel
- 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
- getSuppressTimeDifferentClusterWarnings() - Method in class org.jgroups.protocols.TP
- getSuppressTimeDifferentVersionWarnings() - Method in class org.jgroups.protocols.TP
- getSuppressTimeNonMemberWarnings() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getSuppressTimeNonMemberWarnings() - Method in class org.jgroups.protocols.ReliableMulticast
- getSuppressTimeOutOfBufferSpace() - Method in class org.jgroups.protocols.UDP
- getSuspectedMembers() - Method in class org.jgroups.protocols.FailureDetection
- 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.FailureDetection
- getSuspectMsgInterval() - Method in class org.jgroups.protocols.FD_SOCK
- getSuspectMsgInterval() - Method in class org.jgroups.protocols.FD_SOCK2
- getSuspects() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- getSuspects() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- getSyncMinInterval() - Method in class org.jgroups.protocols.UNICAST3
- 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
- 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.util.Runner
- getThreadDumpsEnabled() - Method in class org.jgroups.util.ThreadPool
- getThreadDumpsThreshold() - Method in class org.jgroups.util.ThreadPool
-
Deprecated.
- getThreadFactory() - Method in class org.jgroups.protocols.TP
- getThreadFactory() - Method in class org.jgroups.stack.Protocol
-
Supposed to be overwritten by subclasses.
- getThreadFactory() - Method in class org.jgroups.util.ThreadPool
- 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.protocols.TP
- getThreadPool() - Method in class org.jgroups.util.ThreadPool
- getThreadPoolCompletedTasks() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getThreadPoolFullSuppressTime() - Method in class org.jgroups.util.ThreadPool
- getThreadPoolSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- getThreadPoolSize() - Method in class org.jgroups.util.ThreadPool
- getThreadPoolSizeActive() - Method in class org.jgroups.util.ThreadPool
- getTimeForwardingToLocalMbr() - Method in class org.jgroups.protocols.relay.RELAY
- getTimeForwardingToSM() - Method in class org.jgroups.protocols.relay.RELAY
- getTimeout() - Method in class org.jgroups.blocks.Cache.Value
- 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.FailureDetection
- getTimeout() - Method in class org.jgroups.protocols.RSVP
- getTimeout() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- getTimeout() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- getTimeout() - Method in class org.jgroups.util.AgeOutCache
- getTimeout() - Method in class org.jgroups.util.ExpiryCache
- getTimeoutCheckerInfo() - Method in class org.jgroups.protocols.FailureDetection
- getTimeoutCheckerInfo() - Method in class org.jgroups.protocols.FD_ALL
- getTimeoutCheckerInfo() - Method in class org.jgroups.protocols.FD_ALL2
- getTimeoutCheckerInfo() - Method in class org.jgroups.protocols.FD_ALL3
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FailureDetection
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL2
- getTimeoutCheckInterval() - Method in class org.jgroups.protocols.FD_ALL3
- getTimePeriod() - Method in class org.jgroups.protocols.RATE_LIMITER
- getTimer() - Method in class org.jgroups.protocols.relay.RELAY
- getTimer() - Method in class org.jgroups.protocols.TP
- getTimerClass() - Method in class org.jgroups.protocols.TP
- getTimeRelaying() - Method in class org.jgroups.protocols.relay.RELAY
- getTimerThreads() - Method in class org.jgroups.protocols.TP
- getTimeService() - Method in class org.jgroups.protocols.TP
- getTimeServiceInterval() - Method in class org.jgroups.protocols.TP
- getTimestamp() - Method in class org.jgroups.blocks.cs.Connection
- 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
- getTimestamps() - Method in class org.jgroups.protocols.FailureDetection
- getTimestamps() - Method in class org.jgroups.protocols.FD_ALL
- getTimestamps() - Method in class org.jgroups.protocols.FD_ALL2
- getTimestamps() - Method in class org.jgroups.protocols.FD_ALL3
- getTimeUnit(AccessibleObject) - Static method in class org.jgroups.jmx.ResourceDMBean
- getToken() - Method in class org.jgroups.protocols.AuthHeader
- getTopoWaitTime() - Method in class org.jgroups.protocols.relay.RELAY2
- getTopProtocol() - Method in class org.jgroups.stack.ProtocolStack
- getTos() - Method in class org.jgroups.protocols.UDP
- getTotalBlockTime() - Method in class org.jgroups.protocols.RATE_LIMITER
- getTotalMessages() - Method in class org.jgroups.protocols.RED
-
Deprecated.
- getTransientFlags() - Method in class org.jgroups.blocks.RequestOptions
- getTransport() - Method in class org.jgroups.stack.Protocol
- getTransport() - Method in class org.jgroups.stack.ProtocolStack
-
Returns the bottom most protocol
- getTransport() - Method in class org.jgroups.util.SubmitToThreadPool
- getTruststore() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getTruststoreName() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getTruststorePassword() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getTruststorePassword() - Method in class org.jgroups.util.TLS
- getTruststorePath() - Method in class org.jgroups.util.TLS
- getTruststoreType() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- getTruststoreType() - Method in class org.jgroups.util.TLS
- getTtl() - Method in class org.jgroups.stack.DiagnosticsHandler
- getTTL() - Method in class org.jgroups.protocols.MPING
- getType() - Method in class org.jgroups.BatchMessage
- getType() - Method in class org.jgroups.BytesMessage
- getType() - Method in class org.jgroups.CompositeMessage
- getType() - Method in class org.jgroups.EmptyMessage
- getType() - Method in class org.jgroups.Event
- getType() - Method in class org.jgroups.FragmentedMessage
- getType() - Method in class org.jgroups.LongMessage
- getType() - Method in interface org.jgroups.Message
-
Returns the type of the message, e.g.
- getType() - Method in class org.jgroups.NioMessage
- getType() - Method in class org.jgroups.ObjectMessage
- getType() - Method in class org.jgroups.protocols.NakAckHeader
- 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.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.relay.RelayHeader
- getType() - Method in class org.jgroups.stack.GossipData
- getType(AccessibleObject) - Static method in class org.jgroups.jmx.ResourceDMBean
- getType(String) - Static method in class org.jgroups.conf.XmlConfigurator
- getUcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- getUcastRecvBufSize() - Method in class org.jgroups.protocols.UDP
- getUcastSendBufSize() - Method in class org.jgroups.protocols.UDP
- getUnicastProtocols() - Static method in class org.jgroups.util.Util
- getUnknownForkHandler() - Method in class org.jgroups.fork.ForkProtocolStack
- getUnknownForkHandler() - Method in class org.jgroups.protocols.FORK
- getUpDiscardRate() - Method in class org.jgroups.protocols.DISCARD
- getUpHandler() - Method in class org.jgroups.JChannel
- getUpMessages() - Method in class org.jgroups.protocols.SHUFFLE
- getUpProtocol() - Method in class org.jgroups.stack.Protocol
- getUpServices() - Method in class org.jgroups.stack.Protocol
-
Returns all services provided by the protocols above the current protocol
- getUseExternalKeyExchange() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- 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.LongTuple
- getVal1() - Method in class org.jgroups.util.Triple
- getVal1() - Method in class org.jgroups.util.Tuple
- getVal2() - Method in class org.jgroups.util.LongTuple
- 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.LongMessage
- getValue() - Method in class org.jgroups.util.Rsp
- getValue(Object) - Method in class org.jgroups.util.RspList
-
Returns the value associated with address key
- getValue(String) - Method in class org.jgroups.stack.Protocol
- getValueFromObject(Object, Field) - Static method in class org.jgroups.stack.Configurator
- getValueFromObject(Object, 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
- getView() - Method in class org.jgroups.blocks.ReplCache
- 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.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.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
- getViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
- 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.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
- getVisitedSites() - Method in class org.jgroups.protocols.relay.RelayHeader
- getWaiters() - Method in class org.jgroups.util.SizeBoundedQueue
- getWatcher() - Method in class org.jgroups.util.TLS
- getWhoHasCacheTimeout() - Method in class org.jgroups.protocols.TP
- getWindow(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Returns the receive window for sender; only used for testing.
- getWindow(Address) - Method in class org.jgroups.protocols.ReliableMulticast
-
Returns the receive window for sender; only used for testing.
- getWrapExceptions() - Method in class org.jgroups.blocks.MessageDispatcher
- getWriteIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- getWriteIndex(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- getXmitInterval() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitInterval() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitInterval() - Method in class org.jgroups.protocols.UNICAST3
- getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitRequestsReceived() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitRequestsSent() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitResponsesReceived() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitResponsesSent() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitTableCapacity() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableCapacity() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitTableDeliverableMessages() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableMaxCompactionTime() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableMaxCompactionTime() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableMaxCompactionTime() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- getXmitTableMissingMessages() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableMsgsPerRow() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableMsgsPerRow() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableMsgsPerRow() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumCompactions() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableNumCurrentRows() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumCurrentRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumMoves() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumPurges() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumResizes() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableNumRows() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableNumRows() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableNumRows() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableResizeFactor() - Method in class org.jgroups.protocols.NAKACK3
- getXmitTableResizeFactor() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableResizeFactor() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableUndeliveredMessages() - Method in class org.jgroups.protocols.UNICAST3
- getXmitTableUndeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- getXmitTableUndeliveredMsgs() - Method in class org.jgroups.protocols.ReliableMulticast
- Global - Class in org.jgroups
-
Global is a JGroups internal class defining global variables.
- GLOBAL - org.jgroups.util.Util.AddressScope
- global_views - Variable in class org.jgroups.protocols.relay.Topology
- globalViews() - Method in class org.jgroups.protocols.relay.Topology
- globalViews(boolean) - Method in class org.jgroups.protocols.relay.Topology
- gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
- gms - Variable in class org.jgroups.protocols.pbcast.Leaver
- gms - Variable in class org.jgroups.protocols.pbcast.Merger
- gms - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- GMS - Class in org.jgroups.protocols.pbcast
-
Group membership protocol.
- GMS() - Constructor for class org.jgroups.protocols.pbcast.GMS
- 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.SERIALIZE
- GMS.DefaultMembershipPolicy - Class in org.jgroups.protocols.pbcast
- GMS.GmsHeader - Class in org.jgroups.protocols.pbcast
- GmsHeader() - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GmsHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GmsHeader(byte, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
Used for JOIN_REQ or LEAVE_REQ header
- 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.Draw
- go() - Method in class org.jgroups.demos.StompDraw
- GOSSIP_ROUTER - Static variable in class org.jgroups.Global
- gossip_router_hosts - Variable in class org.jgroups.protocols.TUNNEL
- gossip_routers - Variable in class org.jgroups.protocols.TUNNEL
- GossipData - Class in org.jgroups.stack
-
Encapsulates data sent between GossipRouter and RouterStub (TCPGOSSIP and TUNNEL)
- 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, byte[]) - Constructor for class org.jgroups.stack.GossipData
- GossipData(GossipType, String, Address, byte[], int, int) - Constructor for class org.jgroups.stack.GossipData
- GossipData(GossipType, String, Address, String, PhysicalAddress) - 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
- 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(InetAddress, int) - Constructor for class org.jgroups.stack.GossipRouter
- GossipRouter.DumpMessages - Enum in org.jgroups.stack
- 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
- 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>) - Constructor for class org.jgroups.blocks.GridFilesystem
- GridFilesystem(ReplCache<String, byte[]>, ReplCache<String, GridFile.Metadata>, short, int) - Constructor for class org.jgroups.blocks.GridFilesystem
-
Creates an instance.
- GridInputStream - Class in org.jgroups.blocks
- GridOutputStream - Class in org.jgroups.blocks
- 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.
H
- h - Static variable in class org.jgroups.demos.ProgrammaticChat
- handle(Callback[]) - Method in class org.jgroups.auth.Krb5TokenUtils.LoginCallbackHandler
-
Handles the callbacks, and sets the user/password detail.
- handle(Address) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- handle(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handle(Message) - Method in class org.jgroups.blocks.MessageDispatcher
- handle(Message) - Method in interface org.jgroups.blocks.RequestHandler
-
Processes a request synchronously, ie.
- handle(Message) - Method in class org.jgroups.blocks.RpcDispatcher
-
Message contains MethodCall.
- handle(Message, Response) - Method in class org.jgroups.blocks.MessageDispatcher
- handle(Message, Response) - Method in interface org.jgroups.blocks.RequestHandler
-
Processes a request asynchronously.
- handle(DH_KEY_EXCHANGE.DhHeader, Address) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- handle(FD_SOCK2.FdHeader, Address) - Method in class org.jgroups.protocols.FD_SOCK2
- handle(FD_SOCK2.Request) - Method in class org.jgroups.protocols.FD_SOCK2
- handle(MERGE3.MergeHeader, Message) - Method in class org.jgroups.protocols.MERGE3
- handle(GMS.GmsHeader, Message) - Method in class org.jgroups.protocols.pbcast.GMS
- handle(STABLE.StableHeader, Address, Digest) - Method in class org.jgroups.protocols.pbcast.STABLE
- handle(StreamingStateTransfer.StateHeader, Message) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handle(PingHeader, Message) - Method in class org.jgroups.protocols.Discovery
- handle(VERIFY_SUSPECT.VerifyHeader) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- handle(VERIFY_SUSPECT2.VerifyHeader) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- handle(T) - Method in interface org.jgroups.util.ProcessingQueue.Handler
- handle_heartbeats - Variable in class org.jgroups.stack.RouterStub
- handle_unicasts - Variable in class org.jgroups.protocols.RSVP
- handleAccept(Socket) - Method in class org.jgroups.blocks.cs.TcpServer.Acceptor
- handleAccept(SelectionKey) - Method in class org.jgroups.blocks.cs.NioBaseServer
- handleAccept(SelectionKey) - Method in class org.jgroups.blocks.cs.NioServer
- handleAck(Address, long) - Method in class org.jgroups.protocols.NAKACK4
- handleAck(Address, long) - Method in class org.jgroups.protocols.ReliableMulticast
- handleAckReceived(Address, long, short, int) - Method in class org.jgroups.protocols.UNICAST3
-
Add the ACK to hashtable.sender.sent_msgs
- handleAdminMessage(RelayHeader, Address) - Method in class org.jgroups.protocols.relay.RELAY2
-
Handles SITES_UP/SITES_DOWN/TOPO_REQ/TOPO_RSP messages
- handleAdminMessage(RelayHeader, Message) - Method in class org.jgroups.protocols.relay.RELAY3
-
Handles SITES_UP/SITES_DOWN/TOPO_REQ/TOPO_RSP messages
- handleAttributeAccess(Map<String, String>, String, Object) - Static method in class org.jgroups.jmx.ReflectUtils
-
Handles an attribute read or write
- handleAttrWrite(Object, String, String) - Static method in class org.jgroups.jmx.ReflectUtils
- handleAttrWrite(String, String, String) - Method in class org.jgroups.JChannelProbeHandler
- handleAttrWrite(String, String, String) - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- handleAuthHeader(GMS.GmsHeader, AuthHeader, Message) - Method in class org.jgroups.protocols.AUTH
-
Handles a GMS header
- handleBatchFromSelf(MessageBatch, UNICAST3.Entry) - Method in class org.jgroups.protocols.UNICAST3
- handleBatchReceived(UNICAST3.ReceiverEntry, Address, List<LongTuple<Message>>, boolean, Address) - Method in class org.jgroups.protocols.UNICAST3
- handleConfig(Map<String, Object>) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- handleConfig(Map<String, Object>) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.FlowControl
- handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.UDP
- handleConnect() - Method in class org.jgroups.protocols.Discovery
- handleConnect() - Method in class org.jgroups.protocols.LOCAL_PING
- handleConnect() - Method in class org.jgroups.protocols.TCP_NIO2
- handleConnect() - Method in class org.jgroups.protocols.TCP
- handleConnect() - Method in class org.jgroups.protocols.TCPGOSSIP
- handleConnect() - Method in class org.jgroups.protocols.TP
- handleConnect() - Method in class org.jgroups.protocols.UDP
- handleCoordLeave() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleCoordLeave() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleCredit(Address, long) - Method in class org.jgroups.protocols.FlowControl
- handleCredit(Address, long) - Method in class org.jgroups.protocols.MFC
- handleCredit(Address, long) - Method in class org.jgroups.protocols.UFC
- handleCreditRequest(Map<Address, Credit>, Address, long) - Method in class org.jgroups.protocols.FlowControl
- handleDataReceived(Address, long, short, boolean, Message) - Method in class org.jgroups.protocols.UNICAST3
-
Check whether the hashtable contains an entry e for
sender
(create if not). - handleDataReceivedFromSelf(Address, long, Message) - Method in class org.jgroups.protocols.UNICAST3
-
Called when the sender of a message is the local member.
- handleDiagnosticProbe(SocketAddress, String, BiConsumer<SocketAddress, String>) - Method in class org.jgroups.stack.DiagnosticsHandler
- handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.Merger
- handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- handleDisconnect() - Method in class org.jgroups.protocols.Discovery
- handleDisconnect() - Method in class org.jgroups.protocols.LOCAL_PING
- handleDisconnect() - Method in class org.jgroups.protocols.TCP_NIO2
- handleDisconnect() - Method in class org.jgroups.protocols.TCP
- handleDisconnect() - Method in class org.jgroups.protocols.TCPGOSSIP
- handleDisconnect() - Method in class org.jgroups.protocols.TP
- handleDiscoveryResponse(List<PingData>, Address) - Method in class org.jgroups.protocols.Discovery
- handleDiscoveryResponse(PingData, Address) - Method in class org.jgroups.protocols.Discovery
- handleDownMessage(Message, int) - Method in class org.jgroups.protocols.FlowControl
- handleDownMessage(Message, int) - Method in class org.jgroups.protocols.MFC_NB
- handleDownMessage(Message, int) - Method in class org.jgroups.protocols.MFC
- handleDownMessage(Message, int) - Method in class org.jgroups.protocols.UFC_NB
- handleDownMessage(Message, int) - Method in class org.jgroups.protocols.UFC
- handleEncryptedMessage(Message) - Method in class org.jgroups.protocols.Encrypt
- handleEOF(Address) - Method in class org.jgroups.protocols.pbcast.STATE
- handleEOF(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.STATE
- handleException(Throwable) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleFrame(STOMP.Frame) - Method in class org.jgroups.protocols.STOMP.Connection
- handleGetMembersRequest(Address, DataInput) - Method in class org.jgroups.stack.GossipRouter
- handleHeartbeat(Address) - Method in class org.jgroups.stack.GossipRouter
- handleHeartbeats() - Method in class org.jgroups.stack.RouterStub
- handleHeartbeats(boolean) - Method in class org.jgroups.stack.RouterStub
- handleHighestSeqno(Address, long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Compares the sender's highest seqno with my highest seqno: if the sender's is higher, ask sender for retransmission
- handleHighestSeqno(Address, long) - Method in class org.jgroups.protocols.ReliableMulticast
-
Compares the sender's highest seqno with my highest seqno: if the sender's is higher, ask sender for retransmission
- handleJmx(Map<String, String>, String) - Method in class org.jgroups.JChannelProbeHandler
- handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleJoinResponse(JoinRsp) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
In case we get a different JOIN_RSP from a previous JOIN_REQ sent by us (as a client), we simply apply the new view if it is greater than ours
- handleLeaveResponse(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleLeaveResponse(Address) - Method in class org.jgroups.protocols.pbcast.Leaver
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
- handleMergeCancelled(MergeId) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.Merger
-
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
- handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
-
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
- handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
- handleMergeResponse(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
If merge_id is not equal to this.merge_id then discard.
- handleMergeView(MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- handleMessage(String, String) - Static method in class org.jgroups.demos.RelayDemoRpc
- handleMessage(Message, NakAckHeader) - Method in class org.jgroups.protocols.ReliableMulticast
-
Finds the corresponding retransmit buffer and adds the message to it (according to seqno).
- handleMessage(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Finds the corresponding retransmit buffer and adds the message to it (according to seqno).
- handleMessage(Message, TpHeader) - Method in class org.jgroups.util.RTT
-
Called when a message (request or response) is received
- handleMessage(RelayHeader, Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
Called to handle a message received by the transport
- handleMessageBatch(DataInput, boolean, MessageFactory) - Method in class org.jgroups.protocols.TP
- handleMessageBatch(MessageBatch) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- handleMessageBatch(MessageBatch) - Method in class org.jgroups.protocols.ReliableMulticast
- handleMulticastMessage() - Method in class org.jgroups.protocols.FlowControl
-
Whether the protocol handles message with dest == null || dest.isMulticastAddress()
- handleMulticastMessage() - Method in class org.jgroups.protocols.MFC
- handleMulticastMessage() - Method in class org.jgroups.protocols.UFC
- handleOperation(Map<String, String>, String) - Method in class org.jgroups.JChannelProbeHandler
-
Invokes an operation and puts the return value into map
- handleProbe(String...) - Method in class org.jgroups.blocks.RequestCorrelator.MyProbeHandler
- handleProbe(String...) - Method in class org.jgroups.JChannelProbeHandler
- handleProbe(String...) - Method in class org.jgroups.protocols.pbcast.GMS
- handleProbe(String...) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- handleProbe(String...) - Method in class org.jgroups.protocols.ReliableMulticast
- handleProbe(String...) - Method in class org.jgroups.protocols.TP
- handleProbe(String...) - Method in interface org.jgroups.stack.DiagnosticsHandler.ProbeHandler
-
Handles a probe.
- handleProbe(String...) - Method in class org.jgroups.stack.GossipRouter
- handler - Variable in class org.jgroups.util.ProcessingQueue
- handler() - Method in class org.jgroups.util.ShutdownRejectedExecutionHandler
- handleRegister(Address, DataInput) - Method in class org.jgroups.stack.GossipRouter
- handleRegularMessage(Message) - Method in class org.jgroups.protocols.pbcast.STABLE
- handleRelayerStarted(Relayer, long, T, Throwable) - Method in class org.jgroups.protocols.relay.RELAY3
- handleRelayMessage(Message) - Method in class org.jgroups.protocols.relay.RELAY
- handleRelayMessage(Message) - Method in class org.jgroups.protocols.relay.RELAY2
-
Called to handle a message received by the relayer
- handleRelayMessage(Message) - Method in class org.jgroups.protocols.relay.RELAY3
-
Called to handle a message received from a different site (via a bridge channel)
- handleRequest(Address, TpHeader) - Method in class org.jgroups.util.RTT
- handleRequest(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
-
Handle a request msg for this correlator
- handleResendingOfFirstMessage(Address, int) - Method in class org.jgroups.protocols.UNICAST3
-
We need to resend the first message with our conn_id
- handleResponse(Address, int) - Method in class org.jgroups.util.RTT
- handleResponse(Address, short) - Method in class org.jgroups.protocols.RSVP
- handleResponse(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
- handleResponse(COUNTER.Response, Address) - Method in class org.jgroups.protocols.COUNTER
- handlers - Variable in class org.jgroups.protocols.SOS
- handlers - Variable in class org.jgroups.stack.DiagnosticsHandler
- handleSecretKeyRequest(PublicKey, Address) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- handleSecretKeyResponse(PublicKey, byte[], byte[], Address) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- handleSingleMessage(DataInput, boolean) - Method in class org.jgroups.protocols.TP
- handleSocketClose(Exception) - Method in class org.jgroups.protocols.FD_SOCK
- handleStabilityMessage(Digest, Address, ViewId) - Method in class org.jgroups.protocols.pbcast.STABLE
- handleStableMessage(Digest, Address, ViewId) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Digest d contains (a) the highest seqnos deliverable for each sender and (b) the highest seqnos seen for each member.
- handleStateChunk(Address, byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE
- handleStateChunk(Address, byte[], int, int) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleStateReq(Address) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- handleStateReq(Address) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- handleStateReq(Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleStateRsp(Address, StreamingStateTransfer.StateHeader) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleStateRsp(Digest, Address, byte[]) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
Set the digest and the send the state up to the application
- handleUnicasts() - Method in class org.jgroups.protocols.RSVP
- handleUnicasts(boolean) - Method in class org.jgroups.protocols.RSVP
- handleUnknownForkChannel(Message, String) - Method in interface org.jgroups.fork.UnknownForkHandler
-
Handle a message that refers to an unknown fork channel
- handleUnknownForkStack(Message, String) - Method in interface org.jgroups.fork.UnknownForkHandler
-
Handle a message that refers to an unknown fork stack
- handleUnregister(DataInput) - Method in class org.jgroups.stack.GossipRouter
- handleUpEvent(Address, Message, UnicastHeader3) - Method in class org.jgroups.protocols.UNICAST3
- handleUpEvent(Event) - Method in class org.jgroups.blocks.MessageDispatcher
- handleUpEvent(Message, FcHeader) - Method in class org.jgroups.protocols.FlowControl
- handleView(View) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- handleView(View) - Method in class org.jgroups.protocols.COUNTER
- handleView(View) - Method in class org.jgroups.protocols.DAISYCHAIN
- handleView(View) - Method in class org.jgroups.protocols.Encrypt
- handleView(View) - Method in class org.jgroups.protocols.FD_HOST
- handleView(View) - Method in class org.jgroups.protocols.FD_SOCK2
- handleView(View) - Method in class org.jgroups.protocols.KeyExchange
- handleView(View) - Method in class org.jgroups.protocols.relay.RELAY
- handleView(View) - Method in class org.jgroups.protocols.relay.RELAY2
- handleView(View) - Method in class org.jgroups.protocols.relay.RELAY3
- handleView(View) - Method in class org.jgroups.protocols.RSVP
- handleView(View) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- handleView(View) - Method in class org.jgroups.protocols.STOMP
- handleView(View, View, boolean) - Method in class org.jgroups.protocols.FILE_PING
- handleViewChange(List<Address>) - Method in class org.jgroups.protocols.BATCH
- handleViewChange(List<Address>) - Method in class org.jgroups.protocols.BATCH2
- handleViewChange(List<Address>) - Method in class org.jgroups.protocols.FlowControl
- handleViewChange(List<Address>) - Method in class org.jgroups.protocols.MFC
- handleViewChange(List<Address>) - Method in class org.jgroups.protocols.UFC
- handleViewChange(View) - Method in class org.jgroups.protocols.FailureDetection
- handleViewChange(View) - Method in class org.jgroups.protocols.FRAG2
- handleViewChange(View) - Method in class org.jgroups.protocols.FRAG3
- handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STABLE
- handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK
- handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.STATE
- handleViewChange(View) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- handleViewChange(View) - Method in class org.jgroups.protocols.SEQUENCER
- handleViewChange(View) - Method in class org.jgroups.protocols.SEQUENCER2
- handleViewChange(View) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- handleViewChange(View) - Method in class org.jgroups.protocols.STATS
- handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- handleViewChange(View, Digest) - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
-
Called by the GMS when a VIEW is received.
- handleXmitReq(Address, SeqnoList, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Retransmits messsages first_seqno to last_seqno from original_sender from xmit_table to xmit_requester, called when XMIT_REQ is received.
- handleXmitReq(Address, SeqnoList, Address) - Method in class org.jgroups.protocols.ReliableMulticast
-
Retransmits messsages first_seqno to last_seqno from original_sender from xmit_table to xmit_requester, called when XMIT_REQ is received.
- handleXmitRequest(Address, SeqnoList) - Method in class org.jgroups.protocols.UNICAST3
- handleXmitRsp(Message, NakAckHeader) - Method in class org.jgroups.protocols.ReliableMulticast
- handleXmitRsp(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- HAS_FRAG_HEADER - Variable in class org.jgroups.protocols.FRAG
- HAS_FRAG_HEADER - Variable in class org.jgroups.protocols.FRAG2
- HAS_FRAG_HEADER - Variable in class org.jgroups.protocols.FRAG3
- HAS_HEADER - Variable in class org.jgroups.protocols.FailureDetection
- HAS_HEADER - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- HAS_HEADER - Variable in class org.jgroups.protocols.ReliableMulticast
- has_suspected_mbrs - Variable in class org.jgroups.protocols.FailureDetection
- has_suspected_mbrs - Variable in class org.jgroups.protocols.FD_HOST
- hasAllResponses() - Method in class org.jgroups.util.ResponseCollector
- hasArray() - Method in class org.jgroups.BatchMessage
- hasArray() - Method in class org.jgroups.BytesMessage
- hasArray() - Method in class org.jgroups.CompositeMessage
- hasArray() - Method in class org.jgroups.EmptyMessage
- hasArray() - Method in class org.jgroups.FragmentedMessage
- hasArray() - Method in class org.jgroups.LongMessage
- hasArray() - Method in interface org.jgroups.Message
-
Returns true if this message has a byte[] array as payload (even if it's null!), false otherwise
- hasArray() - Method in class org.jgroups.NioMessage
- hasArray() - Method in class org.jgroups.ObjectMessage
- hasBuffer() - Method in class org.jgroups.util.StateTransferResult
- hasConnection(Address) - Method in class org.jgroups.blocks.cs.BaseServer
- hasException() - Method in class org.jgroups.util.Rsp
- hasException() - Method in class org.jgroups.util.StateTransferResult
- hasExclusionList() - Method in class org.jgroups.blocks.RequestOptions
- hasExpired(long, long) - Method in class org.jgroups.util.ExpiryCache
- hasExpired(K) - Method in class org.jgroups.util.ExpiryCache
- hash(byte[]) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- hash(K, short) - Method in class org.jgroups.blocks.ReplCache.ConsistentHashFunction
- hash(K, short) - Method in interface org.jgroups.blocks.ReplCache.HashFunction
-
Function that, given a key and a replication count, returns replication_count number of different addresses of nodes.
- HASH - Static variable in class org.jgroups.protocols.relay.SiteMaster
- hashCode() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
- hashCode() - Method in class org.jgroups.protocols.PingData
- hashCode() - Method in class org.jgroups.protocols.relay.Route
- hashCode() - Method in class org.jgroups.protocols.relay.SiteMaster
- hashCode() - Method in class org.jgroups.protocols.relay.SiteUUID
- hashCode() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- hashCode() - Method in class org.jgroups.stack.IpAddress
- hashCode() - Method in class org.jgroups.stack.RouterStub
- hashCode() - Method in class org.jgroups.util.AsciiString
- hashCode() - Method in class org.jgroups.util.MergeId
- hashCode() - Method in class org.jgroups.util.Owner
- hashCode() - Method in class org.jgroups.util.Range
- hashCode() - Method in class org.jgroups.util.Rsp
- hashCode() - Method in class org.jgroups.util.UUID
-
Returns a hash code for this
UUID
. - hashCode() - Method in class org.jgroups.View
- hashCode() - Method in class org.jgroups.ViewId
- hasMessages() - Method in class org.jgroups.protocols.TransferQueueBundler2
- hasNext() - Method in class org.jgroups.BatchMessage.BatchMessageIterator
- hasNext() - Method in class org.jgroups.CompositeMessage.CompositeMessageIterator
- hasNext() - Method in class org.jgroups.nio.Buffers.BuffersIterator
- hasNext() - Method in class org.jgroups.util.ArrayIterator
- hasNext() - Method in class org.jgroups.util.Digest.MyIterator
- hasNext() - Method in class org.jgroups.util.DynamicBuffer.TableIterator
- hasNext() - Method in class org.jgroups.util.FastArray.FastIterator
- hasNext() - Method in class org.jgroups.util.FixedBuffer.FixedBufferIterator
- hasNext() - Method in class org.jgroups.util.Responses.PingDataIterator
- hasNext() - Method in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
- hasNext() - Method in class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- hasNext() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
- hasNext() - Method in class org.jgroups.util.Table.TableIterator
- hasPayload() - Method in class org.jgroups.BatchMessage
- hasPayload() - Method in class org.jgroups.BytesMessage
- hasPayload() - Method in class org.jgroups.CompositeMessage
- hasPayload() - Method in class org.jgroups.EmptyMessage
- hasPayload() - Method in class org.jgroups.FragmentedMessage
- hasPayload() - Method in class org.jgroups.LongMessage
- hasPayload() - Method in interface org.jgroups.Message
-
Returns true if the message has a payload, e.g.
- hasPayload() - Method in class org.jgroups.NioMessage
- hasPayload() - Method in class org.jgroups.ObjectMessage
- hasPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
- hasRemaining() - Method in class org.jgroups.nio.Buffers
- hasResult - Variable in class org.jgroups.util.Promise
- hasResult() - Method in class org.jgroups.util.Promise
-
Checks whether result is available.
- hasRouteTo(String) - Method in class org.jgroups.protocols.relay.Relayer
- hasSendConnectionTo(Address) - Method in class org.jgroups.protocols.UNICAST3
-
Used for testing only
- hasSites() - Method in class org.jgroups.protocols.relay.RelayHeader
- hasThreadPool(JChannel...) - Static method in class org.jgroups.util.Tests
- hasVirtualThreads() - Static method in class org.jgroups.util.ThreadCreator
- hasVisitedSites() - Method in class org.jgroups.protocols.relay.RelayHeader
- hasWaiters() - Method in class org.jgroups.util.SizeBoundedQueue
- hd - Variable in class org.jgroups.util.Buffer
-
The highest delivered (=removed) seqno
- hd - Variable in class org.jgroups.util.Digest.Entry
- hd - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
The highest delivered seqno.
- hd - Variable in class org.jgroups.util.RingBufferSeqnoOld
-
The highest delivered seqno.
- hd - Variable in class org.jgroups.util.Table
-
The highest delivered (= removed) seqno
- hd() - Method in class org.jgroups.util.Buffer
- HDRS - Class in org.jgroups.protocols
-
Prints the headers of all sent or received messages
- HDRS() - Constructor for class org.jgroups.protocols.HDRS
- header - Variable in class org.jgroups.protocols.TP
-
The header including the cluster name, sent with each message
- Header - Class in org.jgroups
-
Header is a JGroups internal base class for all JGroups headers.
- Header() - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
- Header() - Constructor for class org.jgroups.Header
- Header(byte, long, short) - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
- HEADER - Static variable in class org.jgroups.protocols.BATCH
- HEADER - Static variable in class org.jgroups.protocols.BATCH2
- headers - Variable in class org.jgroups.BaseMessage
- headers - Variable in class org.jgroups.protocols.STOMP.StompHeader
- headers() - Method in class org.jgroups.BaseMessage
- headers(Header[]) - Method in class org.jgroups.BaseMessage
- Headers - Class in org.jgroups.util
-
Helper class providing functions to manipulate the headers array in
BaseMessage
. - heartbeat(long, long) - Method in class org.jgroups.stack.RouterStubManager
- HEARTBEAT - org.jgroups.stack.GossipType
- heartbeat_interval - Variable in class org.jgroups.protocols.TUNNEL
- heartbeat_interval - Variable in class org.jgroups.stack.RouterStubManager
- heartbeat_sender - Variable in class org.jgroups.protocols.FailureDetection
- heartbeat_task - Variable in class org.jgroups.stack.RouterStubManager
- heartbeat_timeout - Variable in class org.jgroups.protocols.TUNNEL
- heartbeat_timeout - Variable in class org.jgroups.stack.RouterStubManager
- heartbeaterRunning() - Method in class org.jgroups.stack.RouterStubManager
- HeartbeatHeader() - Constructor for class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- help() - Static method in class org.jgroups.demos.Chat
- help() - Static method in class org.jgroups.demos.KeyStoreGenerator
- help() - Static method in class org.jgroups.demos.PubClient
- help() - Static method in class org.jgroups.demos.PubServer
- help() - Static method in class org.jgroups.demos.RelayDemo
- help() - Static method in class org.jgroups.demos.TotalOrder
- hexToBin(String) - Static method in class org.jgroups.util.Util
- high - Variable in class org.jgroups.util.Buffer
-
The highest received/sent seqno.
- high - Variable in class org.jgroups.util.Range
- high - Variable in class org.jgroups.util.RequestTable
- high() - Method in class org.jgroups.util.Buffer
- high() - Method in class org.jgroups.util.RequestTable
- highest_deliverable - Variable in class org.jgroups.util.Buffer.HighestDeliverable
- highest_deliverable - Variable in class org.jgroups.util.Table.HighestDeliverable
- highest_receive_rate - Variable in class org.jgroups.protocols.RATE
- highest_send_rate - Variable in class org.jgroups.protocols.RATE
- HIGHEST_SEQNO - Static variable in class org.jgroups.protocols.NakAckHeader
- HIGHEST_SEQNO - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
- highestContiguousSpaceAvailable() - Method in class org.jgroups.util.RequestTable
- HighestDeliverable() - Constructor for class org.jgroups.util.Buffer.HighestDeliverable
- HighestDeliverable() - Constructor for class org.jgroups.util.Table.HighestDeliverable
- highestDelivered() - Method in class org.jgroups.util.Buffer
- highestDelivered(long) - Method in class org.jgroups.util.Buffer
-
Only used internally on a state transfer (setting the digest).
- highestReceiveRate() - Method in class org.jgroups.protocols.RATE
- highestSendRate() - Method in class org.jgroups.protocols.RATE
- history - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- history_size - Variable in class org.jgroups.protocols.RATE
- hit_count - Variable in class org.jgroups.util.FastArray.FastIterator
- hitCount() - Method in class org.jgroups.util.FastArray.FastIterator
- holes - Variable in class org.jgroups.protocols.BARRIER
- hosts - Variable in class org.jgroups.protocols.FD_HOST
-
Map of hosts and their cluster members, updated on view changes.
- hostsToStr(Collection<PhysicalAddress>) - Static method in class org.jgroups.protocols.TCPPING
- hr - Variable in class org.jgroups.util.Digest.Entry
- hr - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
The highest received seqno.
- hr - Variable in class org.jgroups.util.RingBufferSeqnoOld
-
The highest received seqno.
- hr - Variable in class org.jgroups.util.Table
-
The highest received seqno
I
- I_HAVE_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- 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
- id - Variable in class org.jgroups.protocols.Frag3Header
- 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
- ID - Static variable in class org.jgroups.conf.ClassConfigurator
- ID - Static variable in class org.jgroups.fork.ForkConfig
- ID - Static variable in class org.jgroups.protocols.FORK
- ID - Static variable in class org.jgroups.protocols.ProtPerfHeader
- ids - Variable in class org.jgroups.protocols.RSVP
-
Used to store IDs and their acks
- 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.
- impl - Variable in class org.jgroups.protocols.pbcast.GMS
- impl_lock - 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
- IMPORT - org.jgroups.annotations.XmlInclude.Type
- 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.RATE
- in - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- 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_threads - Variable in class org.jgroups.protocols.BARRIER
- INCLUDE - org.jgroups.annotations.XmlInclude.Type
- 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
- incrCount() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- increase_max_size_dynamically - Variable in class org.jgroups.util.ThreadPool
- increment - Variable in class org.jgroups.util.FastArray
- increment() - Method in class org.jgroups.util.FastArray
- increment(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- increment(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- increment(int) - Method in class org.jgroups.util.FastArray
- increment(long, long) - Method in class org.jgroups.util.Credit
- increment(long, long) - Method in class org.jgroups.util.NonBlockingCredit
- incrementAndGet() - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically increments the counter and returns the new value
- incrementAndGet() - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Atomically increments the counter and returns the new value
- incrementRelayed() - Method in class org.jgroups.protocols.relay.RELAY
- incrInits() - Method in class org.jgroups.fork.ForkProtocolStack
- incrNumBatchesSent() - Method in class org.jgroups.protocols.MsgStats
- incrNumBatchesSent(int) - Method in class org.jgroups.protocols.MsgStats
- incrNumSingleMsgsSent() - Method in class org.jgroups.protocols.MsgStats
- index - Variable in class org.jgroups.BatchMessage
- index - Variable in class org.jgroups.CompositeMessage
- index - Variable in class org.jgroups.nio.Buffers.BuffersIterator
- index - Variable in class org.jgroups.protocols.FD_ALL3.Bitmap
- index - Variable in class org.jgroups.protocols.TpHeader
- index - Variable in class org.jgroups.util.ArrayIterator
- index - Variable in class org.jgroups.util.Digest.MyIterator
- index - Variable in class org.jgroups.util.FastArray
- index - Variable in class org.jgroups.util.Responses
- index - Variable in class org.jgroups.util.Responses.PingDataIterator
- index - Variable in class org.jgroups.util.SeqnoList.SeqnoListIterator
- index() - Method in class org.jgroups.protocols.TpHeader
- index() - Method in class org.jgroups.util.FastArray
- 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(long) - Method in class org.jgroups.util.FixedBuffer
- index(long) - Method in class org.jgroups.util.RequestTable
- index(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- index(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
- index(long) - Method in class org.jgroups.util.SeqnoList
- index(long, int) - Static method in class org.jgroups.util.RequestTable
- index(Collection<E>, E) - Static method in class org.jgroups.util.Util
- inflater_pool - Variable in class org.jgroups.protocols.COMPRESS
- info - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- info() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- info(String) - Method in class org.jgroups.logging.JDKLogImpl
- info(String) - Method in interface org.jgroups.logging.Log
- info(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- info(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- info(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- info(String, Object...) - Method in interface org.jgroups.logging.Log
- info(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- info(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- INFO - org.jgroups.protocols.MERGE3.MergeHeader.Type
- INFO - org.jgroups.protocols.STOMP.ServerVerb
- info_sender - Variable in class org.jgroups.protocols.MERGE3
- info_sender_future - Variable in class org.jgroups.protocols.MERGE3
- info_writer - Variable in class org.jgroups.protocols.FILE_PING
- info_writer_max_writes_after_view - Variable in class org.jgroups.protocols.FILE_PING
- info_writer_sleep_time - Variable in class org.jgroups.protocols.FILE_PING
- InfoSender() - Constructor for class org.jgroups.protocols.MERGE3.InfoSender
- InfoWriter(int, long) - Constructor for class org.jgroups.protocols.FILE_PING.InfoWriter
- init() - Method in class org.jgroups.auth.AuthToken
- init() - Method in class org.jgroups.blocks.ReplicatedHashMap
- init() - Static method in class org.jgroups.conf.ClassConfigurator
- init() - Method in class org.jgroups.fork.ForkProtocolStack
- init() - Method in class org.jgroups.JChannel
-
Initializes all variables.
- init() - Method in interface org.jgroups.Lifecycle
-
Called after an instance has been created and before it is started.
- 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() - Method in class org.jgroups.protocols.BasicTCP
- init() - Method in class org.jgroups.protocols.BATCH
- init() - Method in class org.jgroups.protocols.BATCH2
- init() - Method in class org.jgroups.protocols.BPING
- init() - Method in class org.jgroups.protocols.COMPRESS
- init() - Method in class org.jgroups.protocols.COUNTER
- init() - Method in class org.jgroups.protocols.DAISYCHAIN
- init() - Method in class org.jgroups.protocols.DELAY
- init() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- init() - Method in class org.jgroups.protocols.Discovery
- init() - Method in class org.jgroups.protocols.dns.DNS_PING
- init() - Method in class org.jgroups.protocols.Encrypt
- init() - Method in class org.jgroups.protocols.FailureDetection
- init() - Method in class org.jgroups.protocols.FD_ALL
- init() - Method in class org.jgroups.protocols.FD_ALL3
- 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.FRAG3
- init() - Method in class org.jgroups.protocols.JDBC_PING
- init() - Method in class org.jgroups.protocols.JDBC_PING2
- 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() - Method in class org.jgroups.protocols.NAKACK3
- 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.NAKACK2
- init() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.ServerGmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.STABLE
- 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.RATE_LIMITER2
- init() - Method in class org.jgroups.protocols.RATE
- init() - Method in class org.jgroups.protocols.relay.RELAY
- init() - Method in class org.jgroups.protocols.relay.RELAY3
- init() - Method in class org.jgroups.protocols.ReliableMulticast
- init() - Method in class org.jgroups.protocols.RSVP
- init() - Method in class org.jgroups.protocols.SEQUENCER
- init() - Method in class org.jgroups.protocols.SERIALIZE
- init() - Method in class org.jgroups.protocols.SHARED_LOOPBACK_PING
- init() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- init() - Method in class org.jgroups.protocols.SHUFFLE
- init() - Method in class org.jgroups.protocols.SimpleTCP
- init() - Method in class org.jgroups.protocols.SOS
- init() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- 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() - Method in class org.jgroups.protocols.TUNNEL
- init() - Method in class org.jgroups.protocols.UDP
- init() - Method in class org.jgroups.protocols.UNICAST3
- init() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- init() - Method in class org.jgroups.stack.GossipRouter
- init() - Method in class org.jgroups.stack.Protocol
-
Called after a protocol has been created and before the protocol is started.
- init() - Method in class org.jgroups.stack.ProtocolStack
- init() - Method in class org.jgroups.util.ThreadPool
- init() - Method in class org.jgroups.util.TLS
- init(String) - Method in class org.jgroups.protocols.CertficateCNMatcher
- init(String) - Method in interface org.jgroups.protocols.SSL_KEY_EXCHANGE.SessionVerifier
-
Called after creation with session_verifier_arg
- init(ProtocolStackConfigurator) - Method in class org.jgroups.JChannel
- init(TP) - Method in class org.jgroups.protocols.BaseBundler
- init(TP) - Method in class org.jgroups.protocols.BatchBundler
- init(TP) - Method in interface org.jgroups.protocols.Bundler
-
Called after creation of the bundler
- init(TP) - Method in interface org.jgroups.protocols.LocalTransport
-
Calls after the local transport has been created.
- init(TP) - Method in class org.jgroups.protocols.NoBundler
- init(TP) - Method in class org.jgroups.protocols.PerDestinationBundler
- init(TP) - Method in class org.jgroups.protocols.RemoveQueueBundler
- 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(TP) - Method in class org.jgroups.protocols.TransferQueueBundler
- init(TP) - Method in class org.jgroups.protocols.TransferQueueBundler2
- init(TP) - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
Called after creation.
- init(TP) - Method in class org.jgroups.util.MaxOneThreadPerSender
- init(TP) - Method in class org.jgroups.util.RTT
- init(TP) - Method in class org.jgroups.util.SubmitToThreadPool
- initCipher(Cipher, int, Key, byte[]) - Static method in class org.jgroups.protocols.Encrypt
- initComponents(Protocol, ProtocolConfiguration) - Static method in class org.jgroups.stack.ProtocolStack
- initConfig() - Static method in class org.jgroups.Version
- initial_delay - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
- initial_discovery - Variable in class org.jgroups.protocols.PingHeader
- initial_hosts - Variable in class org.jgroups.protocols.TCPPING
- initial_hosts_set_programmatically - Variable in class org.jgroups.protocols.TCPPING
- initial_hosts_str - Variable in class org.jgroups.protocols.TCPPING
- 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
- initialDiscovery() - Method in class org.jgroups.protocols.PingHeader
- initialDiscovery(boolean) - Method in class org.jgroups.protocols.PingHeader
- initialHosts() - Method in class org.jgroups.protocols.TCPGOSSIP
- initialHosts(Collection<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPPING
- InitialHosts() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts
- InitialHosts2() - Constructor for class org.jgroups.conf.PropertyConverters.InitialHosts2
- initialize(Collection<Protocol>) - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- initialize(Protocol[]) - Method in class org.jgroups.stack.NonReflectiveProbeHandler
- initialize_sql - Variable in class org.jgroups.protocols.JDBC_PING
- initialize_sql - Variable in class org.jgroups.protocols.JDBC_PING2
- initializeAttrs(Object, Map<String, String>, StackType) - Static method in class org.jgroups.stack.Configurator
- initializeAttrs(Protocol, ProtocolConfiguration, StackType) - Static method in class org.jgroups.stack.Configurator
-
Sets the attributes in a given protocol from properties
- initializeContext(SSLContext) - Method in class org.jgroups.util.SslContextFactory
- 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
- initMetadata() - Method in class org.jgroups.blocks.GridFile
- initProtocolStack(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.ProtocolStack
-
Calls @link{
Protocol.init()
} in all protocols, from bottom to top - initProtocolStack(List<ProtocolConfiguration>, ProtocolHook) - Method in class org.jgroups.stack.ProtocolStack
- inits - Variable in class org.jgroups.fork.ForkProtocolStack
- initState() - Method in class org.jgroups.protocols.pbcast.GMS
- initSymCiphers(String, Key) - Method in class org.jgroups.protocols.Encrypt
-
Initialises the ciphers for both encryption and decryption using the generated or supplied secret key
- INJECT_VIEW - Class in org.jgroups.protocols
-
Simple protocol to inject an arbitrary view on one or more cluster nodes.
- INJECT_VIEW() - Constructor for class org.jgroups.protocols.INJECT_VIEW
- injectDataSource(String) - Method in class org.jgroups.protocols.JDBC_PING
- injectDataSource(String) - Method in class org.jgroups.protocols.JDBC_PING2
- injectView(String) - Method in class org.jgroups.protocols.INJECT_VIEW
- 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
-
Constructs a
Base64.InputStream
in DECODE mode. - InputStream(InputStream, int) - Constructor for class org.jgroups.util.Base64.InputStream
-
Constructs a
Base64.InputStream
in either ENCODE or DECODE mode. - InputStreamAdapter - Class in org.jgroups.util
-
Extends
InputStream
from aByteArrayDataInputStream
. - InputStreamAdapter(ByteArrayDataInputStream) - Constructor for class org.jgroups.util.InputStreamAdapter
- inRange() - Method in class org.jgroups.util.PartialOutputStream
-
Checks if pos is in range [offset..end]
- insert(Connection, PingData, String) - Method in class org.jgroups.protocols.JDBC_PING2
- insert(Connection, PingData, String, String) - Method in class org.jgroups.protocols.JDBC_PING
- insert_single_sql - Variable in class org.jgroups.protocols.JDBC_PING
- insert_single_sql - Variable in class org.jgroups.protocols.JDBC_PING2
- insert_sp - Variable in class org.jgroups.protocols.JDBC_PING2
- insertProtocol(Protocol, ProtocolStack.Position, Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
- insertProtocol(Protocol, ProtocolStack.Position, Class<? extends Protocol>...) - Method in class org.jgroups.stack.ProtocolStack
- insertProtocol(Protocol, ProtocolStack.Position, String) - Method in class org.jgroups.stack.ProtocolStack
-
Inserts an already created (and initialized) protocol into the protocol list.
- insertProtocolAtTop(Protocol) - Method in class org.jgroups.stack.ProtocolStack
- insertProtocolInStack(Protocol, Protocol, ProtocolStack.Position) - Method in class org.jgroups.stack.ProtocolStack
- INSTALL_DIGEST - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- INSTALL_KEYS - Static variable in class org.jgroups.protocols.EncryptHeader
- INSTALL_MERGE_VIEW - Static variable in class org.jgroups.Event
- INSTALL_MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- 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.
- installPublicKeys(Address, byte[], int, int) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- installSharedGroupKey(Address, SecretKey, byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- installUpHandler(UpHandler, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sets the given UpHandler as the UpHandler for the channel.
- 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.
- installViewIfValidJoinRsp(Promise<JoinRsp>, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- INSTANCE - org.jgroups.util.CompletableFutures
- INT_SIZE - Static variable in class org.jgroups.Global
- interfaceHasIPAddresses(NetworkInterface, StackType) - Static method in class org.jgroups.util.Util
-
A function to check if an interface supports an IP version (i.e.
- interruptAndWaitToDie(Thread) - Static method in class org.jgroups.util.Util
- interruptAndWaitToDie(Thread, long) - Static method in class org.jgroups.util.Util
- 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.FailureDetection
- interval - Variable in class org.jgroups.protocols.FD_HOST
- interval - Variable in class org.jgroups.protocols.RATE_LIMITER2
- interval - Variable in class org.jgroups.protocols.RATE
- interval - Variable in class org.jgroups.protocols.SOS
- interval - Variable in class org.jgroups.util.TimeService
- interval() - Method in class org.jgroups.protocols.RATE_LIMITER2
- interval() - Method in class org.jgroups.protocols.RATE
- interval() - Method in class org.jgroups.util.TimeService
- interval(long) - Method in class org.jgroups.protocols.RATE_LIMITER2
- interval(long) - Method in class org.jgroups.protocols.RATE
- interval(long) - Method in class org.jgroups.util.TimeService
- intf - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
-
network interface to be used to send the ICMP packets
- IntHashMap<T> - Class in org.jgroups.util
-
A hashmap where keys have to be ints.
- IntHashMap(int) - Constructor for class org.jgroups.util.IntHashMap
-
Creates an instance
- inView(Address, String) - Method in class org.jgroups.protocols.Encrypt
- invoke(Object) - Method in class org.jgroups.blocks.MethodCall
-
Invokes the method with the supplied arguments against the target object.
- 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(Object) - Method in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
- invoke(Object) - Method in class org.jgroups.jmx.ResourceDMBean.NoopAccessor
- invoke(Object, short, Object[]) - Method in interface org.jgroups.blocks.MethodInvoker
-
An implementation invokes a method associated with a given ID and the given args against a target object
- invoke(Object, Object[]) - Method in class org.jgroups.blocks.MethodCall
- invoke(Method, Object, String[]) - Static method in class org.jgroups.jmx.ReflectUtils
- invoke(String, Object[], String[]) - Method in class org.jgroups.jmx.ResourceDMBean
- invoke(String, ResourceDMBean.Accessor, String, Object) - Static method in class org.jgroups.stack.NonReflectiveProbeHandler
- invokeCallback(int, Object) - Method in class org.jgroups.JChannel
- invokeOperation(Map<String, String>, String, Object) - Static method in class org.jgroups.jmx.ReflectUtils
-
Invokes an operation and puts the return value into map
- ip_addr - Variable in class org.jgroups.stack.IpAddress
- IP_ADDR - Static variable in interface org.jgroups.Address
- ip_mcast - Variable in class org.jgroups.protocols.UDP
- IP_PREFIX - Static variable in class org.jgroups.util.Util
- ip_ttl - Variable in class org.jgroups.protocols.MPING
- 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(int) - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(int, boolean) - 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(InetSocketAddress) - Constructor for class org.jgroups.stack.IpAddress
- ipMcast() - Method in class org.jgroups.protocols.UDP
- ipMcast(boolean) - Method in class org.jgroups.protocols.UDP
- IPv4 - org.jgroups.util.StackType
- IPv4 - Static variable in class org.jgroups.Global
- IPV4_SIZE - Static variable in class org.jgroups.Global
- IPv6 - org.jgroups.util.StackType
- IPv6 - 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.Discovery
- 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.SEQUENCER
- is_coord - Variable in class org.jgroups.protocols.SEQUENCER2
- is_coord - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
- is_empty - Variable in class org.jgroups.util.MessageCache
- 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_LOCAL - Static variable in class org.jgroups.Event
- IS_LOCAL_SITEMASTER - Static variable in class org.jgroups.Event
- 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_NUMBER - Static variable in class org.jgroups.util.Metrics
- 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.ReliableMulticast
- is_server - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
- is_site_master - Variable in class org.jgroups.protocols.relay.RELAY
- IS_SLF4J_AVAILABLE - Static variable in class org.jgroups.logging.LogFactory
- is_trace - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- is_trace - Variable in class org.jgroups.protocols.ReliableMulticast
- is_trace - Variable in class org.jgroups.protocols.TP
- is_trace - Variable in class org.jgroups.protocols.UNICAST3
- 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(String) - Method in class org.jgroups.protocols.FD_HOST
- isAlive(InetAddress, long) - Method in class org.jgroups.protocols.FD_HOST.ExternalPingCommand
- 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
- isAsciiString(String) - Static method in class org.jgroups.util.Util
- isAssignableProtocol(Class<? extends Protocol>, Class<?>) - Method in class org.jgroups.conf.ProtocolConfiguration
-
Determines if the class
other
is the same or superclass (or superinterface) as theProtocol
configured by this instance. - 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
- isCallerRunsHandler(RejectedExecutionHandler) - Static method in class org.jgroups.protocols.pbcast.NAKACK2
- isCallerRunsHandler(RejectedExecutionHandler) - Static method in class org.jgroups.protocols.ReliableMulticast
- isCallerRunsHandler(RejectedExecutionHandler) - Static method in class org.jgroups.protocols.UNICAST3
- isCallerRunsHandler(RejectedExecutionHandler) - Static method in class org.jgroups.stack.CheckCallerRunsPolicy
- isCallerRunsHandler(RejectedExecutionHandler) - Static method in class org.jgroups.stack.CheckForAbsenceOfRED
- 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.blocks.cs.Connection
- isClosed() - Method in class org.jgroups.blocks.cs.NioConnection
- isClosed() - Method in class org.jgroups.blocks.cs.TcpConnection
- isClosed() - Method in class org.jgroups.JChannel
- isClosed() - Method in class org.jgroups.protocols.BARRIER
- isClosed() - Method in class org.jgroups.util.BlockingInputStream
- isCommentEnd(InputStream, StringBuilder, boolean) - Static method in class org.jgroups.conf.XmlConfigurator
- isCommentStart(InputStream, StringBuilder, boolean) - Static method in class org.jgroups.conf.XmlConfigurator
-
Searches for a sequence of '!--'
- isCompatible(InetAddress, List<InterfaceAddress>) - Static method in class org.jgroups.stack.DiagnosticsHandler
-
Checks if there's any address in the address list that's compatible (same address family) to addr
- 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
- isComplete() - Method in class org.jgroups.protocols.FRAG3.FragEntry
-
Returns true if this fragmentation is complete, ie all fragments 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.client.StompConnection
- isConnected() - Method in class org.jgroups.JChannel
- isConnected() - Method in class org.jgroups.nio.MockSocketChannel
- isConnected() - Method in class org.jgroups.stack.RouterStub
- isConnecting() - Method in class org.jgroups.JChannel
- 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
- isCoord() - Method in class org.jgroups.protocols.MERGE3
- 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
- isCoord(Address) - Method in class org.jgroups.Membership
- isCoord(Address) - Method in class org.jgroups.protocols.Discovery
- isCoord(Address) - Method in class org.jgroups.util.Responses
- 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
- isDebugEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isDirect() - Method in class org.jgroups.NioMessage
- isDirectory() - Method in class org.jgroups.blocks.GridFile
- isDirectory() - Method in class org.jgroups.blocks.GridFile.Metadata
- isDone() - Method in class org.jgroups.util.ResponseCollectorTask
- isDone() - Method in class org.jgroups.util.Responses
- isDone() - Method in class org.jgroups.util.SizeBoundedQueue
- isDone() - Method in class org.jgroups.util.TimeScheduler3.Task
- isDown() - Method in class org.jgroups.protocols.SHUFFLE
- isDynamic() - Method in class org.jgroups.protocols.Discovery
- isDynamic() - Method in class org.jgroups.protocols.dns.DNS_PING
- isDynamic() - Method in class org.jgroups.protocols.FILE_PING
- isDynamic() - Method in class org.jgroups.protocols.LOCAL_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.Membership
- isEmpty() - Method in class org.jgroups.util.Buffer
- isEmpty() - Method in class org.jgroups.util.FastArray
- isEmpty() - Method in class org.jgroups.util.IntHashMap
- isEmpty() - Method in class org.jgroups.util.MessageBatch
- isEmpty() - Method in class org.jgroups.util.MessageCache
- isEmpty() - Method in class org.jgroups.util.Responses
- isEmpty() - Method in class org.jgroups.util.RingBuffer
- isEmpty() - Method in class org.jgroups.util.SeqnoList
- isEmpty() - Method in class org.jgroups.util.SizeBoundedQueue
- isEmpty() - Method in class org.jgroups.util.Table
- isEnabled() - Method in class org.jgroups.protocols.RED
- isEnabled() - Method in class org.jgroups.stack.DiagnosticsHandler
- isEnabled() - Method in class org.jgroups.util.ThreadPool
- 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
- isErrorEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isExcluded(Route, String...) - Static method in class org.jgroups.protocols.relay.Relayer
- isExpired(long) - Method in class org.jgroups.blocks.cs.Connection
- isFatalEnabled() - Method in class org.jgroups.logging.JDKLogImpl
- isFatalEnabled() - Method in interface org.jgroups.logging.Log
- isFatalEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
- isFatalEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isFile() - Method in class org.jgroups.blocks.GridFile
- isFile() - Method in class org.jgroups.blocks.GridFile.Metadata
- isFlag() - Static method in class org.jgroups.demos.JmxDemo
- isFlagSet(byte, byte) - Static method in class org.jgroups.util.Util
- isFlagSet(short) - Method in class org.jgroups.util.FlagsUUID
- isFlagSet(short, Message.Flag) - Static method in class org.jgroups.util.Util
- isFlagSet(Message.Flag) - Method in class org.jgroups.BaseMessage
-
Checks if a given flag is set
- isFlagSet(Message.Flag) - Method in class org.jgroups.blocks.RequestOptions
- isFlagSet(Message.Flag) - Method in interface org.jgroups.Message
-
Returns true if a flag is set, false otherwise
- isFlagSet(Message.TransientFlag) - Method in class org.jgroups.BaseMessage
- isFlagSet(Message.TransientFlag) - Method in interface org.jgroups.Message
-
Returns true if a transient flag is set, false otherwise
- isFractional(Class<?>) - Static method in class org.jgroups.jmx.ResourceDMBean
- isGetMethod(Method) - Static method in class org.jgroups.jmx.ResourceDMBean
- isHeartbeatSenderRunning() - Method in class org.jgroups.protocols.FailureDetection
- isHeartbeatTaskRunning() - Method in class org.jgroups.protocols.TUNNEL
- isInetAddressOrCompatibleType(Class<?>) - Static method in class org.jgroups.stack.Configurator
- isInfoEnabled() - Method in class org.jgroups.logging.JDKLogImpl
- isInfoEnabled() - Method in interface org.jgroups.logging.Log
- isInfoEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
- isInfoEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isInfoSenderRunning() - Method in class org.jgroups.protocols.MERGE3
- isInfoWriterRunning() - Method in class org.jgroups.protocols.FILE_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.ReplCache
- isLeaving() - Method in class org.jgroups.protocols.pbcast.GMS
- isLocal(Address) - Method in class org.jgroups.protocols.UNICAST3
- isLocal(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY
- isLocalMember(Address) - Method in interface org.jgroups.protocols.LocalTransport
-
Returns true if addr is a local member, false otherwise
- isLocalSitemaster(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY
- isLocalSiteMaster(Address) - Method in class org.jgroups.protocols.UNICAST3
- isLogicalAddressCacheReaperRunning() - Method in class org.jgroups.protocols.TP
- isLogSuspectedMessages() - Method in class org.jgroups.protocols.FD_SOCK
- 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.MERGE3
- 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
- isMigrateData() - Method in class org.jgroups.blocks.ReplCache
- isMulticast() - Method in interface org.jgroups.Address
-
Whether or not this address causes a message to be sent to mulitple members.
- isMulticast() - Method in class org.jgroups.protocols.relay.SiteMaster
- isMulticast() - Method in class org.jgroups.util.MessageBatch
- isMulticastCapable() - Method in class org.jgroups.protocols.TP
- isNodeCrashMonitorRunning() - Method in class org.jgroups.protocols.FD_SOCK
- isNumber(Class<?>) - Static method in class org.jgroups.jmx.ResourceDMBean
- isNumberAndScalar(AccessibleObject, Class<?>) - Static method in class org.jgroups.util.Metrics
- isNumeric(Class<?>) - Static method in class org.jgroups.jmx.ResourceDMBean
- isOpen() - Method in class org.jgroups.JChannel
- 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.util.Util
- isPrimitiveType(Object) - Static method in class org.jgroups.util.Util
- isPropertySet(String) - Static method in class org.jgroups.logging.LogFactory
- isQueuing() - Method in class org.jgroups.protocols.MFC_NB
- isQueuing() - Method in class org.jgroups.util.NonBlockingCredit
- isQueuing() - Method in class org.jgroups.util.NonBlockingCreditMap
- isQueuingTo(Address) - Method in class org.jgroups.protocols.UFC_NB
- 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
- isReconnectorTaskRunning() - Method in class org.jgroups.protocols.TUNNEL
- isRemovable() - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
- isResendTaskRunning() - Method in class org.jgroups.protocols.RSVP
- isRunning() - Method in class org.jgroups.blocks.cs.TcpConnection.Receiver
- isRunning() - Method in class org.jgroups.protocols.FailureDetection
- 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.
- isScalar(AccessibleObject) - Static method in class org.jgroups.util.Metrics
- isSelectorOpen() - Method in class org.jgroups.protocols.TCP_NIO2
- 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
- isSet() - Method in class org.jgroups.util.Ref
- isSetMethod(Method) - Static method in class org.jgroups.jmx.ResourceDMBean
- isSetPropertyMethod(Method, Class<?>) - Static method in class org.jgroups.stack.Configurator
- isShutdown() - Method in class org.jgroups.util.ThreadPool
- isShutdown() - Method in interface org.jgroups.util.TimeScheduler
-
Returns true if stop() has been called, false otherwise
- isShutdown() - Method in class org.jgroups.util.TimeScheduler3
- isSiteAddress() - Method in interface org.jgroups.Address
-
Whether or not this address is a
SiteAddress
. - isSiteAddress() - Method in class org.jgroups.protocols.relay.SiteUUID
- isSiteMaster() - Method in interface org.jgroups.Address
-
Whether or not this address is a
SiteMaster
. - isSiteMaster() - Method in class org.jgroups.protocols.relay.RELAY
- isSiteMaster() - Method in class org.jgroups.protocols.relay.SiteMaster
- isStackAvailable(boolean) - Static method in class org.jgroups.util.Util
- isSuspected(Address) - Method in class org.jgroups.util.RspList
- isTcpNodelay() - Method in class org.jgroups.protocols.TUNNEL
- isTimeoutCheckerRunning() - Method in class org.jgroups.protocols.FailureDetection
- isTimeoutCheckTaskRunning() - Method in class org.jgroups.protocols.TUNNEL
- isTrace() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- isTrace() - Method in class org.jgroups.protocols.ReliableMulticast
- isTrace() - Method in class org.jgroups.protocols.TP
- isTrace(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- isTrace(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- isTrace(boolean) - Method in class org.jgroups.protocols.TP
- isTraceEnabled() - Method in class org.jgroups.logging.JDKLogImpl
- isTraceEnabled() - Method in interface org.jgroups.logging.Log
- isTraceEnabled() - Method in class org.jgroups.logging.Log4J2LogImpl
- isTraceEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isTransientFlagSet(short, Message.TransientFlag) - Static method in class org.jgroups.util.Util
- isUp() - Method in class org.jgroups.protocols.SHUFFLE
- isUp(NetworkInterface) - Static method in class org.jgroups.util.Util
-
Always returns true unless there is a socket exception - will be removed when GraalVM issue https://github.com/oracle/graal/pull/1076 has been fixed
- 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
- isWarnEnabled() - Method in class org.jgroups.logging.Slf4jLogImpl
- isWrapped() - Method in class org.jgroups.ObjectMessage
- isXmitsEnabled() - Method in class org.jgroups.protocols.UNICAST3
- isXmitTaskRunning() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- isXmitTaskRunning() - Method in class org.jgroups.protocols.ReliableMulticast
- isXmitTaskRunning() - Method in class org.jgroups.protocols.UNICAST3
- iterate(MessageBatch, boolean, boolean, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- iterateOverAttributes(Class<?>, Map<String, XMLSchemaGenerator.DelayingElementWriter>, Document, Element, String) - Static method in class org.jgroups.util.XMLSchemaGenerator
- iterateOverMethods(Class<?>, Map<String, XMLSchemaGenerator.DelayingElementWriter>, Document, Element, String) - Static method in class org.jgroups.util.XMLSchemaGenerator
- iterator() - Method in class org.jgroups.BatchMessage
- iterator() - Method in class org.jgroups.CompositeMessage
- 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.DynamicBuffer
- iterator() - Method in class org.jgroups.util.FastArray
-
Iterator which iterates only over non-null elements, skipping null elements
- iterator() - Method in class org.jgroups.util.FixedBuffer
-
Returns an iterator over the elements of the ring buffer in the range [LOW+1 ..
- 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.RingBufferSeqnoLockless
-
Returns an iterator over the elements of the ring buffer in the range [HD+1 ..
- iterator() - Method in class org.jgroups.util.RingBufferSeqnoOld
-
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.util.Table
- iterator() - Method in class org.jgroups.View
- iterator(long, long) - Method in class org.jgroups.util.Buffer
- iterator(long, long) - Method in class org.jgroups.util.DynamicBuffer
- iterator(long, long) - Method in class org.jgroups.util.FixedBuffer
- iterator(long, long) - Method in class org.jgroups.util.Table
- iterator(Predicate<Message>) - Method in class org.jgroups.util.MessageBatch
-
Iterates over all non-null message which match filter
- iterator(Predicate<T>) - Method in class org.jgroups.util.FastArray
-
Iterates over all non-null elements which match filter
- iv - Variable in class org.jgroups.protocols.EncryptHeader
- iv() - Method in class org.jgroups.protocols.EncryptHeader
J
- JAVA_VERSION - Static variable in class org.jgroups.util.Util
- JAXP_MISSING_ERROR_MSG - Static variable in class org.jgroups.conf.ConfiguratorFactory
- JChannel - Class in org.jgroups
-
A channel represents a group communication endpoint (like a socket).
- JChannel() - Constructor for class org.jgroups.JChannel
-
Creates a
JChannel
with the default stack - JChannel(boolean) - Constructor for class org.jgroups.JChannel
-
Creates a JChannel without a protocol stack; used for programmatic creation of channel and protocol stack
- JChannel(InputStream) - Constructor for class org.jgroups.JChannel
-
Creates a channel with a configuration based on an input stream.
- JChannel(String) - Constructor for class org.jgroups.JChannel
-
Constructs a JChannel instance with the protocol stack configuration based upon the specified properties parameter.
- JChannel(List<Protocol>) - Constructor for class org.jgroups.JChannel
-
Creates a channel from a list of protocols.
- JChannel(ProtocolStackConfigurator) - Constructor for class org.jgroups.JChannel
-
Constructs a JChannel with the protocol stack configuration contained by the protocol stack configurator parameter.
- JChannel(Protocol...) - Constructor for class org.jgroups.JChannel
-
Creates a channel from an array of protocols.
- JChannel.State - Enum in org.jgroups
- JChannelProbeHandler - Class in org.jgroups
- JChannelProbeHandler(JChannel) - Constructor for class org.jgroups.JChannelProbeHandler
- JChannelProbeHandler.ThreadEntry - Class in org.jgroups
- JDBC_PING - Class in org.jgroups.protocols
-
Discovery protocol using a JDBC connection to a shared database.
- JDBC_PING() - Constructor for class org.jgroups.protocols.JDBC_PING
- JDBC_PING2 - Class in org.jgroups.protocols
-
New version of
JDBC_PING
. - JDBC_PING2() - Constructor for class org.jgroups.protocols.JDBC_PING2
- JDKLogImpl - Class in org.jgroups.logging
-
Logger that delivers messages to a JDK logger
- JDKLogImpl(Class<?>) - Constructor for class org.jgroups.logging.JDKLogImpl
- JDKLogImpl(String) - Constructor for class org.jgroups.logging.JDKLogImpl
- jmx - Variable in class org.jgroups.stack.GossipRouter
- jmx() - Method in class org.jgroups.stack.GossipRouter
- jmx(boolean) - Method in class org.jgroups.stack.GossipRouter
- JmxConfigurator - Class in org.jgroups.jmx
- JmxDemo - Class in org.jgroups.demos
-
Shows how annotations can be used to expose attributes and operations
- JmxDemo() - Constructor for class org.jgroups.demos.JmxDemo
- JmxDemo.MyNotification - Class in org.jgroups.demos
- join() - Method in class org.jgroups.blocks.GroupRequest
- join() - Method in class org.jgroups.blocks.UnicastRequest
- join(CompletableFuture<T>) - Static method in enum org.jgroups.util.CompletableFutures
-
Waits for the
CompletableFuture
to complete. - join(CompletionStage<T>) - Static method in enum org.jgroups.util.CompletableFutures
-
Same as
CompletableFutures.join(CompletableFuture)
but it receives aCompletionStage
as parameter. - join(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- join(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- join(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- join(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- JOIN - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- join_promise - Variable in class org.jgroups.protocols.pbcast.ClientGmsImpl
- JOIN_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- JOIN_REQ_WITH_STATE_TRANSFER - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- JOIN_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- join_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
- join_timeout - Variable in class org.jgroups.protocols.relay.Bridge
- join_timeout - Variable in class org.jgroups.util.Runner
- JOIN_WITH_STATE_TRANSFER - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- joinGroupOnInterfaces(List<NetworkInterface>, MulticastSocket, InetAddress) - Method in class org.jgroups.protocols.UDP
-
Joins a multicast address on all interfaces
- joining - Variable in class org.jgroups.protocols.pbcast.GMS
-
Members joined but for which no view has been received yet
- joinInternal(Address, boolean) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
-
Makes this process join a group.
- JoinRsp - Class in org.jgroups.protocols.pbcast
-
Result of a JOIN request (sent by the GMS client).
- JoinRsp() - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- JoinRsp(String) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- JoinRsp(View, Digest) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
K
- keep_alive - Variable in class org.jgroups.protocols.FD_SOCK
- keep_alive_time - Variable in class org.jgroups.util.ThreadPool
- keepAlive() - Method in class org.jgroups.protocols.FD_SOCK
- keepAlive(boolean) - Method in class org.jgroups.protocols.FD_SOCK
- key - Variable in class org.jgroups.blocks.cs.NioConnection
- key - Variable in class org.jgroups.util.Delayer.Entry
- key() - Method in class org.jgroups.blocks.cs.NioConnection
- key(SelectionKey) - Method in class org.jgroups.blocks.cs.NioConnection
- key_agreement - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
-
Diffie-Hellman protocol engine
- key_exchange - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- key_map - Variable in class org.jgroups.protocols.Encrypt
- key_map_max_size - Variable in class org.jgroups.protocols.Encrypt
- key_pair - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- key_pair_gen - Static variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
- key_password - Variable in class org.jgroups.protocols.SYM_ENCRYPT
- key_server_addr - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- key_store - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- keyAlias(String) - Method in class org.jgroups.util.SslContextFactory
- KeyExchange - Class in org.jgroups.protocols
-
Base class for protocols implementing key exchange: a secret key to be used for encryption is exchanged between 2 parties (usually the key server and a new cluster member) securely; ie.
- KeyExchange() - Constructor for class org.jgroups.protocols.KeyExchange
- keyExists(byte[]) - Method in class org.jgroups.util.ExtendedUUID
- keyExists(String) - Method in class org.jgroups.util.ExtendedUUID
- keyManager() - Method in class org.jgroups.util.SslContextFactory.Context
- keyPair() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- keyPress(String) - Static method in class org.jgroups.util.Util
- keys - Variable in class org.jgroups.util.ExtendedUUID
- keys() - Method in class org.jgroups.util.CreditMap
- keyServerAddr() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- keyServerAddr(Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- keySet() - Method in class org.jgroups.blocks.LazyRemovalCache
- keyStore(KeyStore) - Method in class org.jgroups.util.SslContextFactory
- keystore_alias - Variable in class org.jgroups.util.TLS
- keystore_name - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- keystore_name - Variable in class org.jgroups.protocols.SYM_ENCRYPT
- keystore_password - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- keystore_password - Variable in class org.jgroups.util.TLS
- keystore_path - Variable in class org.jgroups.auth.X509Token
- keystore_path - Variable in class org.jgroups.util.TLS
- keystore_type - Variable in class org.jgroups.auth.X509Token
- keystore_type - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- keystore_type - Variable in class org.jgroups.protocols.SYM_ENCRYPT
- keystore_type - Variable in class org.jgroups.util.TLS
- keyStoreFileName(String) - Method in class org.jgroups.util.SslContextFactory
- KeyStoreGenerator - Class in org.jgroups.demos
-
Generates a keystore file that has a SecretKey in it.
- keystoreName() - Method in class org.jgroups.protocols.SYM_ENCRYPT
- keystoreName(String) - Method in class org.jgroups.protocols.SYM_ENCRYPT
- keyStorePassword(char[]) - Method in class org.jgroups.util.SslContextFactory
- keyStorePassword(String) - Method in class org.jgroups.util.SslContextFactory
- keyStoreType(String) - Method in class org.jgroups.util.SslContextFactory
- Krb5Token - Class in org.jgroups.auth
-
JGroups AuthToken Class to for Kerberos v5 authentication.
- Krb5Token() - Constructor for class org.jgroups.auth.Krb5Token
- Krb5TokenUtils - Class in org.jgroups.auth
-
Support class that implements all the low level Kerberos security calls
- Krb5TokenUtils() - Constructor for class org.jgroups.auth.Krb5TokenUtils
- Krb5TokenUtils.LoginCallbackHandler - Class in org.jgroups.auth
L
- LargestWinningPolicy - Class in org.jgroups.stack
-
Policy which picks the new coordinator in a merge from the largest subview.
- LargestWinningPolicy() - Constructor for class org.jgroups.stack.LargestWinningPolicy
- last() - Method in class org.jgroups.util.MessageBatch
- last_access - Variable in class org.jgroups.blocks.cs.Connection
- last_compaction_timestamp - Variable in class org.jgroups.util.DynamicBuffer
-
The time when the last compaction took place.
- last_compaction_timestamp - Variable in class org.jgroups.util.Table
-
The time when the last compaction took place.
- last_conn_id - Variable in class org.jgroups.protocols.UNICAST3
- last_credit_request - Variable in class org.jgroups.protocols.MFC
-
Last time a credit request was sent.
- last_credit_request - Variable in class org.jgroups.util.Credit
- last_discovery_request - Variable in class org.jgroups.protocols.TP
- last_heartbeat - Variable in class org.jgroups.stack.RouterStub
- last_key_request - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
-
Time (ms) when the last key request was sent, prevents too many requests
- last_seqno_resender - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- last_seqno_resender - Variable in class org.jgroups.protocols.ReliableMulticast
- last_seqno_resent - Variable in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
- last_sync_sent - Variable in class org.jgroups.protocols.UNICAST3
-
Keep track of when a SEND_FIRST_SEQNO message was sent to a given sender
- lastHeartbeat() - Method in class org.jgroups.stack.RouterStub
- lastLoaded() - Method in class org.jgroups.util.ReloadingX509KeyManager
- lastLoaded() - Method in class org.jgroups.util.ReloadingX509TrustManager
- LastSeqnoResender() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
- LastSeqnoResender() - Constructor for class org.jgroups.protocols.ReliableMulticast.LastSeqnoResender
- latencyInMs() - Method in class org.jgroups.protocols.PERF
- latencyInNs() - Method in class org.jgroups.protocols.PERF
- LazyRemovalCache<K,V> - Class in org.jgroups.blocks
-
Cache which doesn't remove elements on remove(), removeAll() or retainAll(), but only removes elements when a configurable size limit has been exceeded.
- LazyRemovalCache() - Constructor for class org.jgroups.blocks.LazyRemovalCache
- LazyRemovalCache(int, long) - Constructor for class org.jgroups.blocks.LazyRemovalCache
-
Creates a new instance
- LazyRemovalCache.Entry<V> - Class in org.jgroups.blocks
- LazyRemovalCache.Printable<K,V> - Interface in org.jgroups.blocks
- LazyThreadFactory - Class in org.jgroups.util
-
Lazily names threads: whenever the address or cluster name is changed, all threads are renamed
- LazyThreadFactory(String, boolean, boolean) - Constructor for class org.jgroups.util.LazyThreadFactory
- leastSigBits - Variable in class org.jgroups.util.UUID
- leave() - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- leave() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
The coordinator itself wants to leave the group
- leave() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- leave() - Method in class org.jgroups.protocols.pbcast.Leaver
-
Sends a LEAVE-REQ to the coordinator.
- leave() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- LEAVE - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- leave_promise - Variable in class org.jgroups.protocols.pbcast.Leaver
- LEAVE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- LEAVE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- leave_timeout - Variable in class org.jgroups.protocols.pbcast.GMS
- leaver - Variable in class org.jgroups.protocols.pbcast.GMS
- leaver - Variable in class org.jgroups.protocols.pbcast.GmsImpl
- Leaver - Class in org.jgroups.protocols.pbcast
-
Handles the leaving of a member from a group.
- Leaver(GMS) - Constructor for class org.jgroups.protocols.pbcast.Leaver
- leaving - Variable in class org.jgroups.protocols.pbcast.GMS
-
Members excluded from group, but for which no view has been received yet
- leaving - Variable in class org.jgroups.protocols.pbcast.Leaver
- leaving - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- leaving - Variable in class org.jgroups.protocols.ReliableMulticast
- left_mbrs - Variable in class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
- left_members - Variable in class org.jgroups.protocols.pbcast.DeltaView
-
Members which left the view corresponding to ref_view_id
- leftMembers(Collection<Address>, Collection<Address>) - Static method in class org.jgroups.util.Util
- leftMembers(View, View) - Static method in class org.jgroups.View
-
Returns a list of members which left from view one to two
- length - Variable in class org.jgroups.BytesMessage
-
The number of bytes in the array
- length() - Method in class org.jgroups.blocks.GridFile
- length() - Method in class org.jgroups.util.AsciiString
- length() - Method in class org.jgroups.util.ExtendedUUID
-
The number of non-null keys
- length() - Method in class org.jgroups.util.MessageBatch
-
Returns the total number of bytes of the message batch (by calling
Message.getLength()
on all messages) - length_buf - Variable in class org.jgroups.blocks.cs.NioConnection
- length_buf - Variable in class org.jgroups.blocks.cs.TcpConnection
- level(String) - Method in class org.jgroups.stack.Protocol
- levels - Static variable in class org.jgroups.logging.Log4J2LogImpl
- Lifecycle - Interface in org.jgroups
-
Interface that defines lifecycle methods.
- limit - Variable in class org.jgroups.nio.Buffers
- limit - Variable in class org.jgroups.util.ByteArrayDataInputStream
- limit() - Method in class org.jgroups.nio.Buffers
- limit() - Method in class org.jgroups.util.ByteArrayDataInputStream
- limit(int) - Method in class org.jgroups.nio.Buffers
- linger - Variable in class org.jgroups.blocks.cs.BaseServer
- linger - Variable in class org.jgroups.protocols.BasicTCP
- linger - Variable in class org.jgroups.protocols.FD_SOCK2
- linger - Variable in class org.jgroups.protocols.TUNNEL
- linger - Variable in class org.jgroups.stack.RouterStub
- linger() - Method in class org.jgroups.blocks.cs.BaseServer
- linger(int) - Method in class org.jgroups.blocks.cs.BaseServer
- linger_timeout - Variable in class org.jgroups.stack.GossipRouter
- lingerTimeout() - Method in class org.jgroups.stack.GossipRouter
- lingerTimeout(int) - Method in class org.jgroups.stack.GossipRouter
- LINK_LOCAL - org.jgroups.util.Util.AddressScope
- list - Variable in class org.jgroups.util.MyReceiver
- list() - Method in class org.jgroups.blocks.GridFile
- list() - Method in class org.jgroups.util.MyReceiver
- list(FilenameFilter) - Method in class org.jgroups.blocks.GridFile
- list(Function<T, String>) - Method in class org.jgroups.util.MyReceiver
- LIST - Static variable in class org.jgroups.protocols.TP
- listAllOperations(Collection<?>) - Static method in class org.jgroups.JChannelProbeHandler
- listeners - Variable in class org.jgroups.client.StompConnection
- listFiles() - Method in class org.jgroups.blocks.GridFile
- listFiles(FileFilter) - Method in class org.jgroups.blocks.GridFile
- listFiles(FilenameFilter) - Method in class org.jgroups.blocks.GridFile
- listObjects(String) - Method in class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
List files in a folder
- listObjects(String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
List files in a folder
- listOperations(Class<?>) - Static method in class org.jgroups.jmx.ReflectUtils
-
Prints all operations of clazz annotated with
ManagedOperation
- listOperations(Map<String, String>, String) - Method in class org.jgroups.JChannelProbeHandler
- listToArray(List<View>) - Static method in class org.jgroups.MergeView
- loadClass(String, Class<?>) - Static method in class org.jgroups.util.Util
-
Tries to load the class from the current thread's context class loader.
- loadClass(String, ClassLoader) - Static method in class org.jgroups.util.Util
-
Tries to load the class from the preferred loader.
- loadDriver() - Method in class org.jgroups.protocols.JDBC_PING
- loadDriver() - Method in class org.jgroups.protocols.JDBC_PING2
- loader - Variable in class org.jgroups.util.ObjectInputStreamWithClassloader
- loadProtocolClass(Class<?>) - Method in class org.jgroups.conf.ProtocolConfiguration
-
Load the class of the
Protocol
configured by this instance. - loadProtocolClass(String, Class<?>) - Static method in class org.jgroups.util.Util
- local - Variable in class org.jgroups.stack.RouterStub
- local() - Method in class org.jgroups.stack.RouterStub
- local_addr - Variable in class org.jgroups.blocks.cs.BaseServer
- local_addr - Variable in class org.jgroups.blocks.MessageDispatcher
- local_addr - Variable in class org.jgroups.blocks.RequestCorrelator
-
The address of this group member
- local_addr - Variable in class org.jgroups.demos.RelayDemoRpc
- local_addr - Variable in class org.jgroups.JChannel
- local_addr - Variable in class org.jgroups.protocols.BatchBundler
- local_addr - Variable in class org.jgroups.protocols.PerDestinationBundler
- local_addr - Variable in class org.jgroups.stack.Protocol
- local_addr - Variable in class org.jgroups.stack.RouterStubManager
- local_host - Variable in class org.jgroups.protocols.FD_HOST
- local_physical_addr - Variable in class org.jgroups.protocols.TP
-
The address (host and port) of this member
- LOCAL_PING - Class in org.jgroups.protocols
-
Discovery protocol for finding members in the local process only.
- LOCAL_PING() - Constructor for class org.jgroups.protocols.LOCAL_PING
- local_sm_cache - Variable in class org.jgroups.protocols.relay.StickySiteMasterPicker
- local_transport - Variable in class org.jgroups.protocols.TP
- local_transport_class - Variable in class org.jgroups.protocols.TP
- local_xmit_table - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- local_xmit_table - Variable in class org.jgroups.protocols.ReliableMulticast
- localAddress() - Method in class org.jgroups.blocks.cs.BaseServer
- localAddress() - Method in interface org.jgroups.blocks.cs.Client
- localAddress() - Method in class org.jgroups.blocks.cs.Connection
- localAddress() - Method in class org.jgroups.blocks.cs.NioConnection
- localAddress() - Method in class org.jgroups.blocks.cs.TcpConnection
- localAddress() - Method in class org.jgroups.stack.GossipRouter
- localAddress(InetAddress, int, InetAddress, int) - Static method in class org.jgroups.blocks.cs.BaseServer
- LocalAddress - Annotation Type in org.jgroups.annotations
-
This is an assertion, checked at startup time.
- localPhysicalAddress() - Method in class org.jgroups.protocols.TP
- LocalTransport - Interface in org.jgroups.protocols
-
A local transport is used for sending messages only to single (or all) members of the same host.
- location - Variable in class org.jgroups.protocols.FILE_PING
- lock - Variable in class org.jgroups.blocks.GroupRequest
- lock - Variable in class org.jgroups.protocols.BARRIER
- lock - Variable in class org.jgroups.protocols.BaseBundler
- lock - Variable in class org.jgroups.protocols.FailureDetection
- lock - Variable in class org.jgroups.protocols.FD_SOCK
- lock - Variable in class org.jgroups.protocols.FRAG2.FragEntry
- lock - Variable in class org.jgroups.protocols.FRAG3.FragEntry
- lock - Variable in class org.jgroups.protocols.pbcast.STABLE
- lock - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- lock - Variable in class org.jgroups.protocols.RATE_LIMITER
- lock - Variable in class org.jgroups.protocols.RATE_LIMITER2
- lock - Variable in class org.jgroups.protocols.RED
- lock - Variable in class org.jgroups.util.AckTable
- lock - Variable in class org.jgroups.util.BlockingInputStream
- lock - Variable in class org.jgroups.util.Buffer
- lock - Variable in class org.jgroups.util.CondVar
- lock - Variable in class org.jgroups.util.Credit
- lock - Variable in class org.jgroups.util.CreditMap
- lock - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- lock - Variable in class org.jgroups.util.Promise
- lock - Variable in class org.jgroups.util.RequestTable
- lock - Variable in class org.jgroups.util.Responses
- lock - Variable in class org.jgroups.util.RingBuffer
- lock - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
Lock for adders to block on when the buffer is full
- lock - Variable in class org.jgroups.util.RingBufferSeqnoOld
-
Lock for adders to block on when the buffer is full
- lock - Variable in class org.jgroups.util.SizeBoundedQueue
- lock - Variable in class org.jgroups.util.Table
- lock - Variable in class org.jgroups.util.TimeService
- lock() - Method in class org.jgroups.util.Buffer
- log - Variable in class org.jgroups.auth.AuthToken
- log - Variable in class org.jgroups.blocks.cs.BaseServer
- log - Variable in class org.jgroups.blocks.MessageDispatcher
- log - Variable in class org.jgroups.blocks.ReplicatedHashMap
- log - Variable in class org.jgroups.blocks.ReplicatedTree
- log - Static variable in class org.jgroups.blocks.RequestCorrelator
- log - Variable in class org.jgroups.client.StompConnection
- log - Static variable in class org.jgroups.conf.XmlConfigurator
- log - Variable in class org.jgroups.demos.PubServer
- log - Variable in class org.jgroups.JChannel
- log - Variable in class org.jgroups.JChannelProbeHandler
- log - Variable in class org.jgroups.jmx.ResourceDMBean
- log - Variable in class org.jgroups.protocols.BaseBundler
- log - Variable in class org.jgroups.protocols.NoBundler
- log - Variable in class org.jgroups.protocols.pbcast.GmsImpl
- log - Variable in class org.jgroups.protocols.pbcast.Leaver
- log - Variable in class org.jgroups.protocols.pbcast.Merger
- log - Variable in class org.jgroups.protocols.PerDestinationBundler
- log - Variable in class org.jgroups.protocols.relay.Bridge
- log - Variable in class org.jgroups.protocols.relay.Relayer
- log - Variable in class org.jgroups.protocols.relay.Route
- log - Variable in class org.jgroups.protocols.TransferQueueBundler2
- log - Static variable in class org.jgroups.stack.Configurator
- log - Variable in class org.jgroups.stack.DiagnosticsHandler
- log - Variable in class org.jgroups.stack.GossipRouter
- log - Variable in class org.jgroups.stack.Protocol
- log - Static variable in class org.jgroups.stack.RouterStub
- log - Variable in class org.jgroups.stack.RouterStubManager
- log - Variable in class org.jgroups.util.DefaultThreadFactory
- log - Variable in class org.jgroups.util.SubmitToThreadPool
- log - Variable in class org.jgroups.util.SuppressLog
- log - Variable in class org.jgroups.util.ThreadPool
- log - Static variable in class org.jgroups.util.TimeScheduler3
- log() - Method in class org.jgroups.blocks.cs.BaseServer
- log() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- log() - Method in class org.jgroups.protocols.relay.Relayer
- log(Log) - Method in class org.jgroups.blocks.cs.BaseServer
- log(Log) - Method in class org.jgroups.util.DefaultThreadFactory
- log(Log) - Method in class org.jgroups.util.ThreadPool
- log(SuppressLog.Level, T, long, Object...) - Method in class org.jgroups.util.SuppressLog
-
Logs a message from a given member if is hasn't been logged for timeout ms
- Log - Interface in org.jgroups.logging
-
Simple logging wrapper for log4j or JDK logging.
- log_accept_error - Variable in class org.jgroups.blocks.cs.TcpServer
- log_accept_error - Variable in class org.jgroups.protocols.TCP
- LOG_CLASS - Static variable in class org.jgroups.Global
- log_collect_msgs - Variable in class org.jgroups.protocols.pbcast.GMS
- log_details - Variable in class org.jgroups.blocks.cs.BaseServer
- log_details - Variable in class org.jgroups.protocols.BasicTCP
- log_discard_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
If true, logs messages discarded because received from other members
- log_discard_msgs - Variable in class org.jgroups.protocols.ReliableMulticast
-
If true, logs messages discarded because received from other members
- log_discard_msgs - Variable in class org.jgroups.protocols.TP
-
Whether warnings about messages from different groups are logged - private flag, not for common use
- log_discard_msgs_version - Variable in class org.jgroups.protocols.TP
- log_not_found_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- log_not_found_msgs - Variable in class org.jgroups.protocols.ReliableMulticast
- log_not_found_msgs - Variable in class org.jgroups.protocols.UNICAST3
- log_suspected_msgs - Variable in class org.jgroups.protocols.FD_SOCK
- log_view_warnings - Variable in class org.jgroups.protocols.pbcast.GMS
- Log4J2LogImpl - Class in org.jgroups.logging
-
Logger that delivers messages to a Log4J2 logger
- Log4J2LogImpl(Class<?>) - Constructor for class org.jgroups.logging.Log4J2LogImpl
- Log4J2LogImpl(String) - Constructor for class org.jgroups.logging.Log4J2LogImpl
- logAcceptError() - Method in class org.jgroups.protocols.TCP
- logAcceptError(boolean) - Method in class org.jgroups.protocols.TCP
- logCollectMessages() - Method in class org.jgroups.protocols.pbcast.GMS
- logCollectMessages(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- logDetails() - Method in class org.jgroups.blocks.cs.BaseServer
- logDetails() - Method in class org.jgroups.protocols.BasicTCP
- logDetails(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- logDetails(boolean) - Method in class org.jgroups.protocols.BasicTCP
- logDiscardMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- logDiscardMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- logDiscardMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- logDiscardMessages(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- logDiscardMsgs() - Method in class org.jgroups.protocols.TP
- logDiscardMsgs(boolean) - Method in class org.jgroups.protocols.TP
- logDiscardMsgsVersion() - Method in class org.jgroups.protocols.TP
- logDiscardMsgsVersion(boolean) - Method in class org.jgroups.protocols.TP
- LogFactory - Class in org.jgroups.logging
-
Factory that creates
Log
instances. - logger - Variable in class org.jgroups.logging.JDKLogImpl
- logger - Variable in class org.jgroups.logging.Log4J2LogImpl
- loggerType() - Static method in class org.jgroups.logging.LogFactory
- loggerType() - Static method in class org.jgroups.protocols.TP
- logical_addr - Variable in class org.jgroups.protocols.PDC.Mapping
- logical_addr_cache - Variable in class org.jgroups.protocols.TP
-
Cache which maintains mappings between logical and physical addresses.
- logical_addr_cache_expiration - Variable in class org.jgroups.protocols.TP
- logical_addr_cache_max_size - Variable in class org.jgroups.protocols.TP
- logical_addr_cache_reaper - Variable in class org.jgroups.protocols.TP
- logical_addr_cache_reaper_interval - Variable in class org.jgroups.protocols.TP
- logical_name - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
- logical_name - Variable in class org.jgroups.protocols.PDC.Mapping
- logical_name - Variable in class org.jgroups.protocols.PingData
- logical_name - Variable in class org.jgroups.stack.GossipRouter.Entry
- logical_name - Variable in class org.jgroups.stack.RouterStubManager
- LoginCallbackHandler() - Constructor for class org.jgroups.auth.Krb5TokenUtils.LoginCallbackHandler
- LoginCallbackHandler(String) - Constructor for class org.jgroups.auth.Krb5TokenUtils.LoginCallbackHandler
- LoginCallbackHandler(String, String) - Constructor for class org.jgroups.auth.Krb5TokenUtils.LoginCallbackHandler
- logNotFoundMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- logNotFoundMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- logNotFoundMessages(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- logNotFoundMessages(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- logNotFoundMsgs() - Method in class org.jgroups.protocols.UNICAST3
- logNotFoundMsgs(boolean) - Method in class org.jgroups.protocols.UNICAST3
- logViewWarnings() - Method in class org.jgroups.protocols.pbcast.GMS
- logViewWarnings(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- LONG_MSG - Static variable in interface org.jgroups.Message
- LONG_SIZE - Static variable in class org.jgroups.Global
- LongMessage - Class in org.jgroups
-
Message with a long as payload.
- LongMessage() - Constructor for class org.jgroups.LongMessage
- LongMessage(Address, long) - Constructor for class org.jgroups.LongMessage
- LongSizeStreamable - Class in org.jgroups.util
- LongSizeStreamable() - Constructor for class org.jgroups.util.LongSizeStreamable
- LongSizeStreamable(long) - Constructor for class org.jgroups.util.LongSizeStreamable
- LongTuple<V> - Class in org.jgroups.util
-
A tuple with a long (primitive) first value
- LongTuple(long, V) - Constructor for class org.jgroups.util.LongTuple
- LOOKUP - Static variable in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
- loopback - Variable in class org.jgroups.protocols.UNICAST3
- loopback - Variable in class org.jgroups.util.MaxOneThreadPerSender.BatchHandlerLoop
- loopback() - Method in class org.jgroups.protocols.UNICAST3
- loopback(boolean) - Method in class org.jgroups.protocols.UNICAST3
- loopback(Message, boolean) - Method in class org.jgroups.protocols.TP
- loopback(Message, boolean) - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
Process a message that was not received from the transport but from above (e.g.
- loopback(Message, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender
- loopback(Message, boolean) - Method in class org.jgroups.util.PassRegularMessagesUpDirectly
- loopback(Message, boolean) - Method in class org.jgroups.util.SubmitToThreadPool
- LOOPBACK - org.jgroups.util.Util.AddressScope
- loopback_copy - Variable in class org.jgroups.protocols.TP
- loopback_separate_thread - Variable in class org.jgroups.protocols.TP
- loopbackCopy() - Method in class org.jgroups.protocols.TP
- loopbackCopy(boolean) - Method in class org.jgroups.protocols.TP
- loopbackSeparateThread() - Method in class org.jgroups.protocols.TP
- loopbackSeparateThread(boolean) - Method in class org.jgroups.protocols.TP
- low - Variable in class org.jgroups.util.Buffer
-
sender: highest seqno seen by everyone, receiver: highest delivered seqno
- low - Variable in class org.jgroups.util.Range
- low - Variable in class org.jgroups.util.RequestTable
- low - Variable in class org.jgroups.util.RingBufferSeqnoLockless
-
The lowest seqno.
- low - Variable in class org.jgroups.util.RingBufferSeqnoOld
-
The lowest seqno.
- low - Variable in class org.jgroups.util.Table
-
The highest seqno purged
- low() - Method in class org.jgroups.util.Buffer
- low() - Method in class org.jgroups.util.RequestTable
- ltime - Variable in class org.jgroups.protocols.pbcast.GMS
M
- 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.EchoServer
- 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.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.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.protocols.JDBC_PING
- main(String[]) - Static method in class org.jgroups.protocols.JDBC_PING2
- 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.GenerateGettersAndSetters
- main(String[]) - Static method in class org.jgroups.util.GenerateProfilingScript
- main(String[]) - Static method in class org.jgroups.util.GetNetworkInterfaces
- main(String[]) - Static method in class org.jgroups.util.Metrics
- 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.WriteVersionTo
- 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
- makeInt(byte[], int, int) - Static method in class org.jgroups.util.Bits
- makeInt(DataInput, int) - Static method in class org.jgroups.util.Bits
- makeInt(ByteBuffer, int) - Static method in class org.jgroups.util.Bits
- makeIv() - Method in class org.jgroups.protocols.Encrypt
- makeLengthBuffer(int) - Method in class org.jgroups.blocks.cs.NioConnection
- makeLong(byte[], int, int) - Static method in class org.jgroups.util.Bits
- makeLong(DataInput, int) - Static method in class org.jgroups.util.Bits
- makeLong(ByteBuffer, int) - Static method in class org.jgroups.util.Bits
- makePublicKey(byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Used to reconstitute public key sent in byte form from peer
- makeReply(Message) - Static method in class org.jgroups.blocks.RequestCorrelator
- makeShort(byte, 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.DefaultMessageFactory
- map - Variable in class org.jgroups.util.Delayer
- map - Variable in class org.jgroups.util.ExpiryCache
- map - Variable in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- map - Variable in class org.jgroups.util.MessageCache
- 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
- markSupported() - Method in class org.jgroups.util.InputStreamAdapter
- marshal(Collection<? extends Address>) - Static method in class org.jgroups.protocols.pbcast.GMS
- marshal(List<PingData>) - Static method in class org.jgroups.protocols.Discovery
- marshal(LazyRemovalCache<Address, IpAddress>) - Static method in class org.jgroups.protocols.FD_SOCK
- marshal(JoinRsp) - Static method in class org.jgroups.protocols.pbcast.GMS
- marshal(PingData) - Static method in class org.jgroups.protocols.Discovery
- marshal(PingData...) - Static method in class org.jgroups.protocols.Discovery
- marshal(View) - Static method in class org.jgroups.protocols.MERGE3
- marshal(ViewId) - Static method in class org.jgroups.protocols.pbcast.GMS
- marshal(View, Digest) - Static method in class org.jgroups.protocols.pbcast.GMS
- marshalledSize(Header[]) - Static method in class org.jgroups.util.Headers
- 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(String, String) - Static method in class org.jgroups.fork.ForkConfig
- match(String, String) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- match(InetAddress, Util.AddressScope) - Static method in class org.jgroups.util.Util
- match(IpAddress, InetSocketAddress) - Static method in class org.jgroups.auth.FixedMembershipToken
- match(T, T) - 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
- matches(String) - Method in class org.jgroups.protocols.relay.ForwardingRoute
- matchMergeId(MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
- matrix - Variable in class org.jgroups.util.DynamicBuffer
- matrix - Variable in class org.jgroups.util.Table
- max - Variable in class org.jgroups.protocols.RED
- 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_batch_size - Variable in class org.jgroups.protocols.BATCH
- max_batch_size - Variable in class org.jgroups.protocols.BATCH2
- max_batch_size - Variable in class org.jgroups.protocols.BatchBundler
- max_batch_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- max_batch_size - Variable in class org.jgroups.protocols.ReliableMulticast
- max_batch_size - Variable in class org.jgroups.protocols.UNICAST3
- max_block_time - Variable in class org.jgroups.protocols.FlowControl
-
Max time (in milliseconds) to block.
- max_buffer_size - Variable in class org.jgroups.util.MaxOneThreadPerSender
- 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.RATE_LIMITER2
- max_close_time - Variable in class org.jgroups.protocols.BARRIER
- max_compaction_time - Variable in class org.jgroups.util.DynamicBuffer
-
Time (in nanoseconds) 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.MERGE3
- max_join_attempts - Variable in class org.jgroups.protocols.pbcast.GMS
- max_leave_attempts - Variable in class org.jgroups.protocols.pbcast.GMS
-
Deprecated.
- max_length - Variable in class org.jgroups.blocks.cs.BaseServer
- max_length - Variable in class org.jgroups.nio.Buffers
- max_length - Variable in class org.jgroups.protocols.BasicTCP
- max_length - Variable in class org.jgroups.stack.GossipRouter
- max_list_print_size - Static variable in class org.jgroups.stack.ProtocolStack
- MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.Global
- MAX_LIST_PRINT_SIZE - Static variable in class org.jgroups.util.Util
-
The max size of an address list, used in View or Digest when toString() is called.
- max_members_in_discovery_request - Variable in class org.jgroups.protocols.Discovery
- max_num_msgs - Variable in class org.jgroups.util.Buffer.Missing
- 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 - Variable in class org.jgroups.protocols.FD_SOCK2
- MAX_PORT - Static variable in class org.jgroups.util.Util
- max_queue_size - Variable in class org.jgroups.protocols.MFC_NB
- max_queue_size - Variable in class org.jgroups.protocols.UFC_NB
- max_rank_to_reply - Variable in class org.jgroups.protocols.Discovery
- max_results - Variable in class org.jgroups.util.Buffer.Remover
- max_results - Variable in class org.jgroups.util.Table.Remover
- 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_send_queue - Variable in class org.jgroups.blocks.cs.TcpBaseServer
- max_send_queue - Variable in class org.jgroups.protocols.TCP
- max_send_queue - Variable in class org.jgroups.protocols.TUNNEL
- max_send_queue - Variable in class org.jgroups.stack.GossipRouter
- max_send_queue - Variable in class org.jgroups.stack.RouterStub
- max_send_queue - Variable in class org.jgroups.stack.RouterStubManager
- max_site_masters - Variable in class org.jgroups.protocols.relay.RELAY
- max_size - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- max_size - Variable in class org.jgroups.protocols.BaseBundler
-
Maximum number of bytes for messages to be queued until they are sent.
- max_size - Variable in class org.jgroups.protocols.BatchBundler
-
Maximum number of bytes for messages to be queued until they are sent.
- max_size - Variable in class org.jgroups.protocols.PerDestinationBundler
-
Maximum number of bytes for messages to be queued until they are sent.
- max_size - Variable in class org.jgroups.protocols.SHUFFLE
- max_size - Variable in class org.jgroups.protocols.TransferQueueBundler2
-
Maximum number of bytes for messages to be queued until they are sent.
- max_size - Variable in class org.jgroups.util.BoundedHashMap
- max_size - Variable in class org.jgroups.util.SizeBoundedQueue
- 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_threads - Variable in class org.jgroups.protocols.AsyncNoBundler
- max_threads - Variable in class org.jgroups.util.ThreadPool
- max_threshold - Variable in class org.jgroups.protocols.RED
- max_time - Variable in class org.jgroups.protocols.SHUFFLE
- max_writes - Variable in class org.jgroups.protocols.FILE_PING.InfoWriter
- max_xmit_req_size - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- max_xmit_req_size - Variable in class org.jgroups.protocols.ReliableMulticast
- max_xmit_req_size - Variable in class org.jgroups.protocols.UNICAST3
- maxBytes() - Method in class org.jgroups.protocols.RATE_LIMITER2
- maxBytes(int) - Method in class org.jgroups.protocols.RATE_LIMITER2
- maxBytesExceeded(int) - Method in class org.jgroups.protocols.pbcast.STABLE
- maxLength() - Method in class org.jgroups.nio.Buffers
- maxLength() - Method in class org.jgroups.stack.GossipRouter
- maxLength(int) - Method in class org.jgroups.nio.Buffers
- maxLength(int) - Method in class org.jgroups.stack.GossipRouter
- MaxOneThreadPerSender - Class in org.jgroups.util
-
MessageProcessingPolicy
which processes regular messages and message batches by assigning a max of 1 thread per message from the same sender. - MaxOneThreadPerSender() - Constructor for class org.jgroups.util.MaxOneThreadPerSender
- MaxOneThreadPerSender.BatchHandlerLoop - Class in org.jgroups.util
- MaxOneThreadPerSender.Entry - Class in org.jgroups.util
- MaxOneThreadPerSender.MessageTable - Class in org.jgroups.util
- maxSendBuffers() - Method in class org.jgroups.blocks.cs.NioBaseServer
- maxSendBuffers(int) - Method in class org.jgroups.blocks.cs.NioBaseServer
- maxSendQueue() - Method in class org.jgroups.blocks.cs.TcpBaseServer
- maxSendQueue() - Method in class org.jgroups.protocols.TCP
- maxSendQueue() - Method in class org.jgroups.protocols.TUNNEL
- maxSendQueue() - Method in class org.jgroups.stack.GossipRouter
- maxSendQueue() - Method in class org.jgroups.stack.RouterStub
- maxSendQueue() - Method in class org.jgroups.stack.RouterStubManager
- maxSendQueue(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
- maxSendQueue(int) - Method in class org.jgroups.protocols.TCP
- maxSendQueue(int) - Method in class org.jgroups.protocols.TUNNEL
- maxSendQueue(int) - Method in class org.jgroups.stack.GossipRouter
- maxSendQueue(int) - Method in class org.jgroups.stack.RouterStub
- maxSendQueue(int) - Method in class org.jgroups.stack.RouterStubManager
- maxSize() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- maxSize(int) - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- MBean - Annotation Type in org.jgroups.annotations
-
Optional annotation that exposes all public methods in the class hierarchy (excluding Object) as MBean operations.
- mbr - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- mbr - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- mbr - Variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- mbr(Address) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- MBR_UNREACHABLE - Static variable in class org.jgroups.Event
- MBR_UNREACHABLE - Static variable in class org.jgroups.protocols.relay.RelayHeader
- mbrs - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- mbrs - Variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- mbrs - Variable in class org.jgroups.protocols.PingData
- mbrs() - Method in class org.jgroups.protocols.PingData
- mbrs(Collection<? extends Address>) - Method in class org.jgroups.protocols.PingData
- mbrs(Collection<Address>) - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- mbrs(Set<Address>) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- mcast - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- mcast(boolean) - Method in class org.jgroups.util.MessageBatch
- mcast_addr - Variable in class org.jgroups.protocols.MPING
- mcast_addr - Variable in class org.jgroups.protocols.UDP
-
The multicast address (mcast address and port) this member uses
- mcast_addr - Variable in class org.jgroups.stack.DiagnosticsHandler
- mcast_group_addr - Variable in class org.jgroups.protocols.UDP
- MCAST_NAME - Static variable in class org.jgroups.protocols.UDP
- mcast_port - Variable in class org.jgroups.protocols.MPING
- mcast_port - Variable in class org.jgroups.protocols.UDP
- mcast_queue - Variable in class org.jgroups.protocols.BARRIER
- mcast_receive_sock - Variable in class org.jgroups.protocols.MPING
- mcast_receivers - 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_send_sock - Variable in class org.jgroups.protocols.MPING
- mcast_send_sockets - Variable in class org.jgroups.protocols.MPING
- mcast_sent - Variable in class org.jgroups.protocols.FailureDetection
- mcast_sock - Variable in class org.jgroups.protocols.UDP
-
IP multicast socket for receiving multicast packets
- mcastAddress(InetAddress) - Method in class org.jgroups.protocols.MPING
- mcastEntries() - Method in class org.jgroups.blocks.ReplCache
- mcastRetransmissionAvailable(JChannel...) - Static method in class org.jgroups.util.Tests
- mcasts - Variable in class org.jgroups.util.MaxOneThreadPerSender
- measure_serialized_size - Variable in class org.jgroups.protocols.RATE
- measureSerializedSize() - Method in class org.jgroups.protocols.RATE
- measureSerializedSize(boolean) - Method in class org.jgroups.protocols.RATE
- 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.Membership
- members - Variable in class org.jgroups.protocols.DISCARD
- members - Variable in class org.jgroups.protocols.FailureDetection
- 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.FD_SOCK2
- members - Variable in class org.jgroups.protocols.FRAG
- members - Variable in class org.jgroups.protocols.FRAG2
- members - Variable in class org.jgroups.protocols.FRAG3
- 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.RELAY
- members - Variable in class org.jgroups.protocols.ReliableMulticast
- members - Variable in class org.jgroups.protocols.RSVP
- members - Variable in class org.jgroups.protocols.SIZE
- 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.UNICAST3
- members - Variable in class org.jgroups.util.Digest
- members - Variable in class org.jgroups.View
-
An array containing all the members of the view.
- members() - Method in class org.jgroups.protocols.relay.RELAY
- members(List<PingData>) - Method in class org.jgroups.protocols.TCPGOSSIP
- members(List<PingData>) - Method in interface org.jgroups.stack.RouterStub.MembersNotification
- 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(Address...) - Constructor for class org.jgroups.Membership
- membership_change_policy - Variable in class org.jgroups.protocols.pbcast.GMS
- MembershipChangePolicy - Interface in org.jgroups.stack
-
Policy used to determine the new membership after a membership change (join, leave) or a merge.
- memberUnreachable(Address) - Method in class org.jgroups.blocks.GroupRequest
- memberUnreachable(Address) - Method in class org.jgroups.blocks.Request
- memberUnreachable(Address) - Method in class org.jgroups.blocks.UnicastRequest
- memberUnreachable(Address) - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- memberUnreachable(Address) - Method in interface org.jgroups.protocols.relay.RouteStatusListener
-
Sent back to the original sender when the unicast destination is not part of the local cluster (site)
- 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(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)
- merge(Digest) - Method in class org.jgroups.util.MutableDigest
-
Adds a digest to this digest.
- 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 - Static variable in class org.jgroups.Event
- MERGE - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- MERGE_DIGEST - Static variable in class org.jgroups.Event
- 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 - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- merge_rejected - Variable in class org.jgroups.protocols.pbcast.MergeData
- MERGE_REJECTED - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- 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
- 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
- MergeData - Class in org.jgroups.protocols.pbcast
-
Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW (handleMergeView()).
- MergeData(Address, View, Digest) - Constructor for class org.jgroups.protocols.pbcast.MergeData
- MergeData(Address, View, Digest, boolean) - 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.
- mergeDigest(Digest) - Method in class org.jgroups.protocols.ReliableMulticast
-
For all members of the digest, adjust the retransmit buffers in xmit_table.
- 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(Address, long, List<Address>, List<View>) - Constructor for class org.jgroups.MergeView
-
Creates a new view
- 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
- Message - Interface in org.jgroups
-
A Message is used to send data to members of a group.
- MESSAGE - org.jgroups.protocols.STOMP.ServerVerb
- MESSAGE - org.jgroups.protocols.STOMP.StompHeader.Type
- MESSAGE - org.jgroups.stack.GossipType
- message_format - Variable in class org.jgroups.util.SuppressLog
- message_processing_policy - Variable in class org.jgroups.protocols.TP
- Message.Flag - Enum in org.jgroups
- Message.TransientFlag - Enum in org.jgroups
- MessageBatch - Class in org.jgroups.util
-
Represents a message batch; multiple messages from the same sender to the same receiver(s).
- MessageBatch() - Constructor for class org.jgroups.util.MessageBatch
- 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, MessageBatch.Mode, int) - Constructor for class org.jgroups.util.MessageBatch
- MessageBatch.Mode - Enum in org.jgroups.util
- MessageCache - Class in org.jgroups.util
-
A cache associating members and messages
- MessageCache() - Constructor for class org.jgroups.util.MessageCache
- 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(JChannel) - Constructor for class org.jgroups.blocks.MessageDispatcher
- MessageDispatcher(JChannel, RequestHandler) - Constructor for class org.jgroups.blocks.MessageDispatcher
- MessageDispatcher.ProtocolAdapter - Class in org.jgroups.blocks
- MessageFactory - Interface in org.jgroups
- messageFromBuffer(byte[], int, int, MessageFactory) - Static method in class org.jgroups.util.Util
- messageFromByteArray(byte[], MessageFactory) - Static method in class org.jgroups.protocols.COMPRESS
- messageFromByteBuffer(byte[], int, int, MessageFactory) - Static method in class org.jgroups.util.Util
- MessageProcessingPolicy - Interface in org.jgroups.stack
-
Policy which decides how to process a received message or message batch.
- messages - Variable in class org.jgroups.protocols.TransferQueueBundler2
- messages - Variable in class org.jgroups.util.MessageBatch
-
The storage of the messages; removed messages have a null element
- MESSAGES - Static variable in class org.jgroups.demos.StompChat
- MessageTable() - Constructor for class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- messageToBuffer(Message) - Static method in class org.jgroups.protocols.FD_SOCK2
- messageToBuffer(Message) - Static method in class org.jgroups.util.Util
- messageToByteArray(Message) - Static method in class org.jgroups.protocols.COMPRESS
- messageToByteBuffer(Message) - Static method in class org.jgroups.util.Util
- metadata - Variable in class org.jgroups.blocks.GridFilesystem
- Metadata() - Constructor for class org.jgroups.blocks.GridFile.Metadata
- Metadata(int, long, int, byte) - Constructor for class org.jgroups.blocks.GridFile.Metadata
- method - Variable in class org.jgroups.blocks.MethodCall
- method - Variable in class org.jgroups.jmx.ResourceDMBean.MethodAccessor
- method_id - Variable in class org.jgroups.blocks.MethodCall
- method_invoker - Variable in class org.jgroups.blocks.RpcDispatcher
- method_lookup - Variable in class org.jgroups.blocks.RpcDispatcher
- method_name - Variable in class org.jgroups.blocks.MethodCall
- 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
-
Needed for deserialization
- MethodCall(short, Object...) - Constructor for class org.jgroups.blocks.MethodCall
- MethodCall(Method, Object...) - Constructor for class org.jgroups.blocks.MethodCall
- MethodCall(String, Object[], Class<?>[]) - Constructor for class org.jgroups.blocks.MethodCall
- MethodInvoker - Interface in org.jgroups.blocks
-
Can be used by
RpcDispatcher
/MethodCall
to invoke a method against a given target object - 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.ReplCache
- methods - Static variable in class org.jgroups.blocks.ReplicatedHashMap
- methodToString(Method) - Static method in class org.jgroups.jmx.ReflectUtils
- Metrics - Class in org.jgroups.util
-
Extracts all attributes and methods annotated with
ManagedAttribute
and returns them as a map of names associated with [getter-method/description tuples]. - Metrics() - Constructor for class org.jgroups.util.Metrics
- Metrics.Entry<T> - Class in org.jgroups.util
- mf - Static variable in class org.jgroups.BatchMessage
- mf - Static variable in class org.jgroups.CompositeMessage
- mf - Variable in class org.jgroups.protocols.SERIALIZE
- 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_NB - Class in org.jgroups.protocols
-
Non-blocking alternative to
MFC
.
JIRA: JIRA: https://issues.redhat.com/browse/JGRP-2172 - MFC_NB() - Constructor for class org.jgroups.protocols.MFC_NB
- MFC_REPLENISH_HDR - Static variable in class org.jgroups.protocols.MFC
- mh - Variable in class org.jgroups.jmx.ResourceDMBean.FieldAccessor
- micro - Static variable in class org.jgroups.Version
- micros() - Static method in class org.jgroups.util.Util
- min - Variable in class org.jgroups.protocols.RED
- min - Variable in class org.jgroups.util.AckTable
- min - Variable in class org.jgroups.util.AverageMinMax
- min() - Method in class org.jgroups.util.AckTable
- 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.MERGE3
- min_port - Variable in class org.jgroups.protocols.FD_SOCK2
- 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_threads - Variable in class org.jgroups.util.ThreadPool
- 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_threshold - Variable in class org.jgroups.protocols.RED
- MIN_TYPE - Static variable in class org.jgroups.DefaultMessageFactory
- MIN_WAIT_BETWEEN_DISCOVERIES - Static variable in class org.jgroups.protocols.TP
- minor - Static variable in class org.jgroups.Version
- missing() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- missing() - Method in class org.jgroups.util.RingBufferSeqnoOld
- Missing(long, int) - Constructor for class org.jgroups.util.Buffer.Missing
- 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.Buffer.Missing
- missing_elements - Variable in class org.jgroups.util.Table.Missing
- MIXED - org.jgroups.util.MessageBatch.Mode
- 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.
- 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.blocks.RequestOptions
- mode() - Method in class org.jgroups.util.MessageBatch
- mode(ResponseMode) - Method in class org.jgroups.blocks.RequestOptions
- 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
- mostSigBits - Variable in class org.jgroups.util.UUID
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.Draw.DrawPanel
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.Draw.DrawPanel
- move(int) - Method in class org.jgroups.util.DynamicBuffer
-
Moves contents of matrix num_rows down.
- move(int) - Method in class org.jgroups.util.Table
-
Moves contents of matrix num_rows down.
- 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 - Variable in class org.jgroups.protocols.FRAG3.FragEntry
- msg - Variable in class org.jgroups.util.SubmitToThreadPool.SingleLoopbackHandler
- msg - Variable in class org.jgroups.util.SubmitToThreadPool.SingleMessageHandler
- MSG - Static variable in class org.jgroups.protocols.NakAckHeader
- MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
- MSG_BUF_SIZE - Static variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- msg_cache - Variable in class org.jgroups.protocols.UNICAST3
- MSG_CONSUMER - Static variable in class org.jgroups.stack.GossipRouter
- msg_factory - Variable in class org.jgroups.protocols.COMPRESS
- msg_factory - Variable in class org.jgroups.protocols.Encrypt
- msg_factory - Variable in class org.jgroups.protocols.FRAG
- msg_factory - Variable in class org.jgroups.protocols.FRAG2.FragEntry
- msg_factory - Variable in class org.jgroups.protocols.FRAG2
- msg_factory - Variable in class org.jgroups.protocols.FRAG3
- msg_factory - Variable in class org.jgroups.protocols.SEQUENCER
- msg_factory - Variable in class org.jgroups.protocols.TP
- msg_factory_class - Variable in class org.jgroups.protocols.TP
- MSG_OVERHEAD - Static variable in class org.jgroups.protocols.TP
- msg_processing_policy - Variable in class org.jgroups.protocols.TP
- msg_queue - Variable in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- msg_queue - Variable in class org.jgroups.util.NonBlockingCredit
- msg_queue - Variable in class org.jgroups.util.NonBlockingCreditMap
- msg_stats - Variable in class org.jgroups.protocols.TP
- msgFactory(MessageFactory) - Method in class org.jgroups.protocols.Encrypt
- msgFromXmitRsp(Message, NakAckHeader) - Method in class org.jgroups.protocols.ReliableMulticast
- msgFromXmitRsp(Message, NakAckHeader2) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- msgMap - Variable in class org.jgroups.protocols.BATCH
- msgMap - Variable in class org.jgroups.protocols.BATCH2
- msgMap - Variable in class org.jgroups.protocols.BatchBundler
- msgs - Variable in class org.jgroups.BatchMessage
- msgs - Variable in class org.jgroups.CompositeMessage
- msgs - Variable in class org.jgroups.protocols.BaseBundler
-
Keys are destinations, values are lists of Messages
- msgs - Variable in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- msgs - Variable in class org.jgroups.protocols.UNICAST3.Entry
- msgs_forwarded - Variable in class org.jgroups.protocols.DAISYCHAIN
- msgs_sent - Variable in class org.jgroups.protocols.DAISYCHAIN
- MsgStats - Class in org.jgroups.protocols
-
Class which has all the stats about received/sent messages etc.
- MsgStats() - Constructor for class org.jgroups.protocols.MsgStats
- mstats - Variable in class org.jgroups.protocols.STATS
-
Global stats
- 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
- multicast(boolean) - Method in class org.jgroups.util.MessageBatch
- MULTICAST - org.jgroups.util.RpcStats.Type
- MULTICAST - Static variable in class org.jgroups.protocols.TP
- multicast_receiver_threads - Variable in class org.jgroups.protocols.UDP
- 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
- mustBeRouted(Message) - Method in class org.jgroups.protocols.relay.RELAY3
-
Determines if a message should be routed.
- MutableDigest - Class in org.jgroups.util
-
A mutable version of Digest.
- MutableDigest() - Constructor for class org.jgroups.util.MutableDigest
- MutableDigest(Address[]) - Constructor for class org.jgroups.util.MutableDigest
- MutableDigest(Digest) - Constructor for class org.jgroups.util.MutableDigest
-
Only used for testing
- my_digest - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- my_merge_id - Variable in class org.jgroups.protocols.pbcast.Merger.MergeKiller
- 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, long) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
- MyNotification(String, Object, long, long, String) - Constructor for class org.jgroups.demos.JmxDemo.MyNotification
- MyNotification(String, Object, 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
N
- NAKACK2 - Class in org.jgroups.protocols.pbcast
-
Negative AcKnowledgement layer (NAKs).
- NAKACK2 - Static variable in class org.jgroups.stack.CheckCallerRunsPolicy
- NAKACK2 - Static variable in class org.jgroups.stack.CheckForAbsenceOfRED
- NAKACK2() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2
- NAKACK2.LastSeqnoResender - Class in org.jgroups.protocols.pbcast
-
Class which is called by RetransmitTask to resend the last seqno sent (if resend_last_seqno is enabled)
- NAKACK2.RetransmitTask - Class in org.jgroups.protocols.pbcast
-
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
- NAKACK3 - Class in org.jgroups.protocols
-
Negative AcKnowledgement layer (NAKs).
- NAKACK3() - Constructor for class org.jgroups.protocols.NAKACK3
- NAKACK4 - Class in org.jgroups.protocols
-
New multicast protocols based on fixed-size xmit windows and message ACKs
Details: https://issues.redhat.com/browse/JGRP-2780 - NAKACK4() - Constructor for class org.jgroups.protocols.NAKACK4
- NakAckHeader - Class in org.jgroups.protocols
- NakAckHeader() - Constructor for class org.jgroups.protocols.NakAckHeader
- NakAckHeader2 - Class in org.jgroups.protocols.pbcast
-
Header used by
NAKACK2
- NakAckHeader2() - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader2
- name - Variable in class org.jgroups.conf.XmlNode
- name - Variable in class org.jgroups.demos.EchoServer
- name - Variable in class org.jgroups.demos.JmxDemo.MyNotification
- name - Variable in class org.jgroups.demos.PubClient
- name - Variable in class org.jgroups.JChannel
- name - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
-
The name of the field or method.
- name - Variable in class org.jgroups.protocols.COUNTER.CounterImpl
- name - Variable in class org.jgroups.protocols.COUNTER.SimpleRequest
- name - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
- name - Variable in class org.jgroups.protocols.relay.config.RelayConfig.SiteConfig
- name - Variable in class org.jgroups.protocols.relay.SiteUUID
- name - Variable in class org.jgroups.util.MyReceiver
- name() - Method in annotation type org.jgroups.annotations.Component
- name() - Method in annotation type org.jgroups.annotations.ManagedAttribute
- name() - Method in annotation type org.jgroups.annotations.Property
- name() - Method in annotation type org.jgroups.annotations.XmlElement
- name() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- name() - Method in class org.jgroups.JChannel
- name() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- name() - Method in class org.jgroups.util.MyReceiver
- name(String) - Method in class org.jgroups.fork.ForkChannel
- name(String) - Method in class org.jgroups.JChannel
- name(String) - Method in class org.jgroups.util.MyReceiver
- NAME - Static variable in class org.jgroups.conf.ClassConfigurator
- NAME - Static variable in class org.jgroups.util.CustomRejectionPolicy
- NAME - Static variable in class org.jgroups.util.ProgressCheckRejectionPolicy
- NAME_CACHE_MAX_AGE - Static variable in class org.jgroups.Global
- NAME_CACHE_MAX_ELEMENTS - Static variable in class org.jgroups.Global
- NameCache - Class in org.jgroups.util
-
Maintains the mappings between addresses and logical names (moved out of UUID.cache into a separate class)
- NameCache() - Constructor for class org.jgroups.util.NameCache
- names - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
- names - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
- NAMES_SEPARATOR - Static variable in class org.jgroups.protocols.INJECT_VIEW
- namespace() - Method in annotation type org.jgroups.annotations.XmlInclude
- NEED - org.jgroups.util.TLSClientAuth
- needMoreResponses() - Method in interface org.jgroups.blocks.RspFilter
-
Right after calling
RspFilter.isAcceptable(Object, org.jgroups.Address)
, this method is called to see whether we are done with the request and can unblock the caller - needs_deserialization - Variable in class org.jgroups.protocols.COMPRESS.CompressHeader
- needs_deserialization - Variable in class org.jgroups.protocols.EncryptHeader
- needs_deserialization - Variable in class org.jgroups.protocols.FRAG2.FragEntry
- needs_deserialization - Variable in class org.jgroups.protocols.FRAG3.FragEntry
- needs_deserialization - Variable in class org.jgroups.protocols.Frag3Header
- needs_deserialization - Variable in class org.jgroups.protocols.FragHeader
- needsAuthentication(Message, GMS.GmsHeader) - Method in class org.jgroups.protocols.AUTH
- needsDeserialization() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- needsDeserialization() - Method in class org.jgroups.protocols.EncryptHeader
- needsDeserialization() - Method in class org.jgroups.protocols.Frag3Header
- needsDeserialization() - Method in class org.jgroups.protocols.FragHeader
- needsDeserialization(boolean) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- needsDeserialization(boolean) - Method in class org.jgroups.protocols.EncryptHeader
- needsDeserialization(boolean) - Method in class org.jgroups.protocols.Frag3Header
- needsDeserialization(boolean) - Method in class org.jgroups.protocols.FragHeader
- needsToBeSuspected(Address, T) - Method in class org.jgroups.protocols.FailureDetection
- needsToBeSuspected(Address, T) - Method in class org.jgroups.protocols.FD_ALL
- needsToBeSuspected(Address, T) - Method in class org.jgroups.protocols.FD_ALL2
- needsToBeSuspected(Address, T) - Method in class org.jgroups.protocols.FD_ALL3
- needsToSuspect() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
-
Returns true if all bits are 0, false otherwise
- needToSendCreditRequest() - Method in class org.jgroups.protocols.MFC
- needToSendCreditRequest(long) - Method in class org.jgroups.util.Credit
- network_req_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- network_rsp_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- NetworkInterfaceList() - Constructor for class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
- networkRequest() - Method in class org.jgroups.protocols.RTTHeader
-
The time the request has spent on the network, between serializing it at the caller and de-serializing it at the receiver
- networkResponse() - Method in class org.jgroups.protocols.RTTHeader
-
The time a response has spent on the network, between serializing the response and de-serializing it
- new_coord - Variable in class org.jgroups.protocols.SEQUENCER.Flusher
- new_mbrs - Variable in class org.jgroups.protocols.Discovery.DiscoveryCacheDisseminationTask
- new_members - Variable in class org.jgroups.protocols.pbcast.DeltaView
-
Members which joined the view corresponding to ref_view_id
- newElements(List<T>, List<T>) - Static method in class org.jgroups.util.Util
- newLength(int) - Static method in class org.jgroups.util.Responses
- newMembers(List<Address>, List<Address>) - Static method in class org.jgroups.util.Util
- newMembers(View, View) - Static method in class org.jgroups.View
- newThread(Runnable) - Method in class org.jgroups.util.DefaultThreadFactory
- newThread(Runnable) - Method in class org.jgroups.util.LazyThreadFactory
- newThread(Runnable, String) - Method in class org.jgroups.util.DefaultThreadFactory
- newThread(Runnable, String) - Method in class org.jgroups.util.LazyThreadFactory
- newThread(Runnable, String) - Method in interface org.jgroups.util.ThreadFactory
- newThread(Runnable, String, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
- next - Variable in class org.jgroups.protocols.DAISYCHAIN
- next() - Method in class org.jgroups.BatchMessage.BatchMessageIterator
- next() - Method in class org.jgroups.CompositeMessage.CompositeMessageIterator
- next() - Method in class org.jgroups.nio.Buffers.BuffersIterator
- next() - Method in class org.jgroups.util.ArrayIterator
- next() - Method in class org.jgroups.util.Digest.MyIterator
- next() - Method in class org.jgroups.util.DynamicBuffer.TableIterator
- next() - Method in class org.jgroups.util.FastArray.FastIterator
- next() - Method in class org.jgroups.util.FixedBuffer.FixedBufferIterator
- next() - Method in class org.jgroups.util.Responses.PingDataIterator
- next() - Method in class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
- next() - Method in class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- next() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
- next() - Method in class org.jgroups.util.Table.TableIterator
- next_to_copy - Variable in class org.jgroups.nio.Buffers
- nextAddress() - Method in interface org.jgroups.util.ResourceManager.IpAddressRep
- nextChar(String, int) - Static method in class org.jgroups.util.Util
- nextClearBit(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the index of the first bit that is set to
false
that occurs on or after the specified starting index. - nextInterval() - Method in class org.jgroups.protocols.FILE_PING.InfoWriter
- nextInterval() - Method in class org.jgroups.protocols.MERGE3.InfoSender
- nextInterval() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
- nextInterval() - Method in class org.jgroups.protocols.pbcast.STABLE.StableTask
- nextInterval() - Method in interface org.jgroups.util.TimeScheduler.Task
- nextSetBit(int) - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns the index of the first bit that is set to
true
that occurs on or after the specified starting index. - nextToCopy() - Method in class org.jgroups.nio.Buffers
- nextToCopy(int) - Method in class org.jgroups.nio.Buffers
- NIL - Static variable in class org.jgroups.protocols.TransferQueueBundler2
- NIO_MSG - Static variable in interface org.jgroups.Message
- NioBaseServer - Class in org.jgroups.blocks.cs
- NioBaseServer(ThreadFactory, SocketFactory, int) - Constructor for class org.jgroups.blocks.cs.NioBaseServer
- NioBaseServer.Acceptor - Class in org.jgroups.blocks.cs
- NioClient - Class in org.jgroups.blocks.cs
- NioClient(InetAddress, int, InetAddress, int) - Constructor for class org.jgroups.blocks.cs.NioClient
-
Creates an instance of an
NioClient
that acts as a client: no server channel is created and no acceptor is started to listen for incoming connections. - NioClient(IpAddress, IpAddress) - Constructor for class org.jgroups.blocks.cs.NioClient
-
Creates an instance of an
NioClient
that acts as a client: no server channel is created and no acceptor is started to listen for incoming connections. - NioConnection - Class in org.jgroups.blocks.cs
-
An NIO based impl of
Connection
- NioConnection(SocketChannel, NioBaseServer) - Constructor for class org.jgroups.blocks.cs.NioConnection
- NioConnection(Address, NioBaseServer) - Constructor for class org.jgroups.blocks.cs.NioConnection
-
Creates a connection stub and binds it, use
NioConnection.connect(Address)
to connect - NioMessage - Class in org.jgroups
-
A
Message
with a (heap-based or direct)ByteBuffer
as payload.
Note that the payload of an NioMessage must not be modified after sending it (ie. - NioMessage() - Constructor for class org.jgroups.NioMessage
- NioMessage(Address) - Constructor for class org.jgroups.NioMessage
-
Constructs a message given a destination address
- NioMessage(Address, ByteBuffer) - Constructor for class org.jgroups.NioMessage
-
Constructs a message given a destination and source address and the payload byte buffer
- NioServer - Class in org.jgroups.blocks.cs
-
Server for sending and receiving messages via NIO channels.
- NioServer(InetAddress, int) - Constructor for class org.jgroups.blocks.cs.NioServer
-
Creates an instance of
NioServer
that opens a server channel and listens for connections. - NioServer(ThreadFactory, SocketFactory, InetAddress, int, int, InetAddress, int, int) - Constructor for class org.jgroups.blocks.cs.NioServer
- NioServer(ThreadFactory, SocketFactory, InetAddress, int, int, InetAddress, int, int, String) - Constructor for class org.jgroups.blocks.cs.NioServer
-
Creates an instance of
NioServer
that opens a server channel and listens for connections. - no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- no_dummy_and_no_oob_delivered_msgs_and_no_dont_loopback_msgs - Variable in class org.jgroups.protocols.ReliableMulticast
- NO_FC - org.jgroups.Message.Flag
- NO_OP_SEND_FUNCTION - Static variable in class org.jgroups.util.NonBlockingCredit
- NO_OP_SEND_FUNCTION - Static variable in class org.jgroups.util.NonBlockingCreditMap
- NO_OPTIONS - Static variable in class org.jgroups.util.Base64
-
No options specified.
- no_pending_threads - Variable in class org.jgroups.protocols.BARRIER
-
signals to waiting threads that the barrier is open again
- NO_RELAY - org.jgroups.Message.Flag
- NO_RELIABILITY - org.jgroups.Message.Flag
- NO_TOTAL_ORDER - org.jgroups.Message.Flag
- NoBundler - Class in org.jgroups.protocols
-
Bundler which doesn't bundle :-) Can be used to measure the diff between bundling and non-bundling (e.g.
- NoBundler() - Constructor for class org.jgroups.protocols.NoBundler
- NODE_VIEWS_SEPARATOR - Static variable in class org.jgroups.protocols.INJECT_VIEW
- nodeAdded(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- nodeModified(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- nodeRemoved(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- non_blocking_sends - Variable in class org.jgroups.blocks.cs.TcpBaseServer
- non_blocking_sends - Variable in class org.jgroups.protocols.TCP
- non_blocking_sends - Variable in class org.jgroups.protocols.TUNNEL
- non_blocking_sends - Variable in class org.jgroups.stack.GossipRouter
- non_blocking_sends - Variable in class org.jgroups.stack.RouterStub
- non_blocking_sends - Variable in class org.jgroups.stack.RouterStubManager
- NON_BLOCKING_SENDS - Class in org.jgroups.protocols
-
Detects sends during processing of incoming messages and sets flag
Message.TransientFlag.DONT_BLOCK
to prevent blocking the incoming thread on a send.
JIRA: https://issues.redhat.com/browse/JGRP-2772 - NON_BLOCKING_SENDS() - Constructor for class org.jgroups.protocols.NON_BLOCKING_SENDS
- non_blocking_task_handling - Variable in class org.jgroups.util.TimeScheduler3
- NON_LOOPBACK - org.jgroups.util.Util.AddressScope
- NON_LOOPBACK_ADDRESS - Static variable in class org.jgroups.Global
- NonBlockingCredit - Class in org.jgroups.util
-
Non-blocking credit for a unicast destination.
Instead of blocking when insufficient credits are available for sending a message, this class queues the message and sends it at a later time when enough credits have been received to send it.
JIRA: https://issues.redhat.com/browse/JGRP-2172 - NonBlockingCredit(long, int, Lock) - Constructor for class org.jgroups.util.NonBlockingCredit
- NonBlockingCredit(long, int, Lock, Consumer<Message>) - Constructor for class org.jgroups.util.NonBlockingCredit
- NonBlockingCreditMap - Class in org.jgroups.util
- NonBlockingCreditMap(long, int, Lock) - Constructor for class org.jgroups.util.NonBlockingCreditMap
- NonBlockingCreditMap(long, int, Lock, Consumer<Message>) - Constructor for class org.jgroups.util.NonBlockingCreditMap
- nonBlockingSends() - Method in class org.jgroups.blocks.cs.TcpBaseServer
- nonBlockingSends() - Method in class org.jgroups.protocols.TCP
- nonBlockingSends() - Method in class org.jgroups.protocols.TUNNEL
- nonBlockingSends() - Method in class org.jgroups.stack.GossipRouter
- nonBlockingSends() - Method in class org.jgroups.stack.RouterStub
- nonBlockingSends() - Method in class org.jgroups.stack.RouterStubManager
- nonBlockingSends(boolean) - Method in class org.jgroups.blocks.cs.TcpBaseServer
- nonBlockingSends(boolean) - Method in class org.jgroups.protocols.TCP
- nonBlockingSends(boolean) - Method in class org.jgroups.protocols.TUNNEL
- nonBlockingSends(boolean) - Method in class org.jgroups.stack.GossipRouter
- nonBlockingSends(boolean) - Method in class org.jgroups.stack.RouterStub
- nonBlockingSends(boolean) - Method in class org.jgroups.stack.RouterStubManager
- NONE - org.jgroups.stack.GossipRouter.DumpMessages
- NONE - org.jgroups.util.TLSClientAuth
- nonNegativeValue(T) - Static method in class org.jgroups.util.Util
- NonReflectiveProbeHandler - Class in org.jgroups.stack
-
A
DiagnosticsHandler.ProbeHandler
that does not use reflection. - NonReflectiveProbeHandler(JChannel) - Constructor for class org.jgroups.stack.NonReflectiveProbeHandler
- nonRemovedValues() - Method in class org.jgroups.blocks.LazyRemovalCache
-
Adds all value which have not been marked as removable to the returned set
- NoopAccessor() - Constructor for class org.jgroups.jmx.ResourceDMBean.NoopAccessor
- NoProgressException - Exception in org.jgroups.util
-
Exception raised when a threadpool rejects jobs but shows no progress.
- NoProgressException(String) - Constructor for exception org.jgroups.util.NoProgressException
- NORMAL_TERMINATION - Static variable in class org.jgroups.protocols.FD_SOCK
- not_empty - Variable in class org.jgroups.util.BlockingInputStream
-
Signalled when the buf becomes 'readable'; ie.
- not_empty - Variable in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- not_empty - Variable in class org.jgroups.util.RingBuffer
- not_empty - Variable in class org.jgroups.util.SizeBoundedQueue
- not_empty_lock - Variable in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- not_full - Variable in class org.jgroups.util.BlockingInputStream
-
Signalled when the buf becomes 'writeable'; ie.
- not_full - Variable in class org.jgroups.util.RingBuffer
- not_full - Variable in class org.jgroups.util.SizeBoundedQueue
- notFound(String, String) - Static method in class org.jgroups.conf.ClassConfigurator
- notifyChannelClosed(JChannel) - Method in class org.jgroups.JChannel
- notifyChannelConnected(JChannel) - Method in class org.jgroups.JChannel
- notifyChannelDisconnected(JChannel) - Method in class org.jgroups.JChannel
- notifyConnectionClosed(Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- notifyConnectionEstablished(Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- notifyListeners(Consumer<ChannelListener>, String) - Method in class org.jgroups.JChannel
- notifyListeners(Map<String, String>) - Method in class org.jgroups.client.StompConnection
- notifyListeners(Map<String, String>, byte[], int, int) - Method in class org.jgroups.client.StompConnection
- notifyResponse(String, List<PingData>) - Method in class org.jgroups.stack.RouterStub
- notifySiteMasterListener(boolean) - Method in class org.jgroups.protocols.relay.RELAY
- NULL - Static variable in interface org.jgroups.Address
- NULL - Static variable in class org.jgroups.protocols.BARRIER
- NULL - Static variable in class org.jgroups.protocols.PerDestinationBundler
- NULL_ADDRESS - Static variable in class org.jgroups.Global
- NULL_BYTE - Static variable in class org.jgroups.protocols.STOMP
- NULL_DEST - Static variable in class org.jgroups.protocols.STATS
- NULL_KEY - Variable in class org.jgroups.util.SuppressCache
- NULL_MSG - Static variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- nullAddress - Variable in class org.jgroups.protocols.BATCH
- nullAddress - Variable in class org.jgroups.protocols.BATCH2
- nullAddress - Variable in class org.jgroups.protocols.BatchBundler
- NullAddress - Class in org.jgroups
- NullAddress() - Constructor for class org.jgroups.NullAddress
- nullData() - Method in class org.jgroups.nio.Buffers
-
Looks at all buffers in range [position ..
- nullFields() - Method in class org.jgroups.fork.ForkChannel
- nullify - Variable in class org.jgroups.util.Table.Remover
- nullOrNoFilterMatch(int) - Method in class org.jgroups.util.FastArray.FastIterator
- num_acks - Variable in class org.jgroups.protocols.SEQUENCER
- num_acks_received - Variable in class org.jgroups.protocols.UNICAST3
- num_acks_sent - Variable in class org.jgroups.protocols.UNICAST3
- num_backups - Variable in class org.jgroups.protocols.COUNTER
- num_batches_received - Variable in class org.jgroups.protocols.MsgStats
- num_batches_sent - Variable in class org.jgroups.protocols.MsgStats
- num_batches_sent - Variable in class org.jgroups.protocols.PerDestinationBundler
- num_bits - Variable in class org.jgroups.protocols.FD_ALL3
- num_blockings - Variable in class org.jgroups.protocols.RATE_LIMITER
- num_blockings - Variable in class org.jgroups.protocols.RATE_LIMITER2
- num_blockings - Variable in class org.jgroups.util.Credit
- num_blockings - Variable in class org.jgroups.util.CreditMap
- num_blockings - Variable in class org.jgroups.util.FixedBuffer
- num_bytes_received - Variable in class org.jgroups.protocols.pbcast.STABLE
-
The total number of bytes received from unicast and multicast messages
- num_bytes_sent - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- num_bytes_sent - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- num_bytes_sent_in_period - Variable in class org.jgroups.protocols.RATE_LIMITER
-
Keeps track of the number of bytes sent in the current time period
- num_compactions - Variable in class org.jgroups.util.DynamicBuffer
- num_compactions - Variable in class org.jgroups.util.Table
- num_compressions - Variable in class org.jgroups.protocols.COMPRESS
- num_credit_requests_received - Variable in class org.jgroups.protocols.FlowControl
- num_credit_requests_sent - Variable in class org.jgroups.protocols.FlowControl
- num_credit_responses_received - Variable in class org.jgroups.protocols.FlowControl
- num_credit_responses_sent - Variable in class org.jgroups.protocols.FlowControl
- num_decompressions - Variable in class org.jgroups.protocols.COMPRESS
- num_deliverable - Variable in class org.jgroups.util.Buffer.NumDeliverable
- num_deliverable - Variable in class org.jgroups.util.Table.NumDeliverable
- num_discards - Variable in class org.jgroups.protocols.DISCARD_PAYLOAD
- num_discovery_requests - Variable in class org.jgroups.protocols.Discovery
- num_discovery_runs - Variable in class org.jgroups.protocols.Discovery
- num_down - Variable in class org.jgroups.protocols.DISCARD
- num_dropped_msgs - Variable in class org.jgroups.protocols.RATE_LIMITER2
- num_drops_on_full_queue - Variable in class org.jgroups.protocols.TransferQueueBundler
- num_drops_on_full_thread_pool - Variable in class org.jgroups.util.AsyncExecutor
- num_ebs_sent - Variable in class org.jgroups.protocols.BATCH
- num_ebs_sent - Variable in class org.jgroups.protocols.BATCH2
- num_ebs_sent - Variable in class org.jgroups.protocols.BatchBundler
- num_ebs_sent_due_to_full_queue - Variable in class org.jgroups.protocols.BATCH
- num_ebs_sent_due_to_full_queue - Variable in class org.jgroups.protocols.BATCH2
- num_ebs_sent_due_to_full_queue - Variable in class org.jgroups.protocols.BatchBundler
- num_ebs_sent_due_to_max_number_of_msgs - Variable in class org.jgroups.protocols.BATCH
- num_ebs_sent_due_to_max_number_of_msgs - Variable in class org.jgroups.protocols.BATCH2
- num_ebs_sent_due_to_max_number_of_msgs - Variable in class org.jgroups.protocols.BatchBundler
- num_ebs_sent_due_to_timeout - Variable in class org.jgroups.protocols.BATCH
- num_ebs_sent_due_to_timeout - Variable in class org.jgroups.protocols.BATCH2
- num_ebs_sent_due_to_timeout - Variable in class org.jgroups.protocols.BatchBundler
- num_expected_rsps - Variable in class org.jgroups.util.Responses
- num_frags - Variable in class org.jgroups.protocols.FRAG3.FragEntry
- num_frags - Variable in class org.jgroups.protocols.Frag3Header
- num_frags - Variable in class org.jgroups.protocols.FragHeader
- num_frags_received - Variable in class org.jgroups.protocols.Fragmentation
- num_frags_sent - Variable in class org.jgroups.protocols.Fragmentation
- num_heartbeats_received - Variable in class org.jgroups.protocols.FailureDetection
- num_heartbeats_sent - Variable in class org.jgroups.protocols.FailureDetection
- num_liveness_checks - Variable in class org.jgroups.protocols.FD_HOST
- num_loopbacks - Variable in class org.jgroups.protocols.UNICAST3
- num_mcast_bytes_received - Variable in class org.jgroups.protocols.MsgStats
- num_mcast_bytes_sent - Variable in class org.jgroups.protocols.MsgStats
- num_mcasts_received - Variable in class org.jgroups.protocols.MsgStats
- num_mcasts_sent - Variable in class org.jgroups.protocols.MsgStats
- num_merge_events - Variable in class org.jgroups.protocols.MERGE3
- num_messages_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- num_messages_received - Variable in class org.jgroups.protocols.ReliableMulticast
- num_messages_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- num_messages_sent - Variable in class org.jgroups.protocols.ReliableMulticast
- num_moves - Variable in class org.jgroups.util.DynamicBuffer
- num_moves - Variable in class org.jgroups.util.Table
- num_msgs - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- num_msgs - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- num_msgs - Variable in class org.jgroups.util.Buffer.Missing
- num_msgs - Variable in class org.jgroups.util.Table.Missing
- num_msgs_dropped - Variable in class org.jgroups.protocols.FlowControl
- num_msgs_received - Variable in class org.jgroups.protocols.UNICAST3
- num_msgs_sent - Variable in class org.jgroups.protocols.BATCH
- num_msgs_sent - Variable in class org.jgroups.protocols.BATCH2
- num_msgs_sent - Variable in class org.jgroups.protocols.BatchBundler
- num_msgs_sent - Variable in class org.jgroups.protocols.UNICAST3
- num_msgs_to_reverse - Variable in class org.jgroups.protocols.REVERSE
- num_prev_mbrs - Variable in class org.jgroups.protocols.pbcast.GMS
- num_prev_views - Variable in class org.jgroups.protocols.pbcast.GMS
- num_purges - Variable in class org.jgroups.util.DynamicBuffer
- num_purges - Variable in class org.jgroups.util.Table
- num_queued - Variable in class org.jgroups.util.NonBlockingCredit
- num_queued - Variable in class org.jgroups.util.NonBlockingCreditMap
- num_received - Variable in class org.jgroups.blocks.GroupRequest
- num_rejected - Variable in class org.jgroups.util.AsyncExecutor
- num_rejected_msgs - Variable in class org.jgroups.util.ThreadPool
- num_removes - Variable in class org.jgroups.util.RequestTable
- num_replenishments - Variable in class org.jgroups.protocols.RATE_LIMITER2
- num_reqs - Variable in class org.jgroups.util.RTT
- num_resends - Variable in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
- num_resizes - Variable in class org.jgroups.util.DynamicBuffer
- num_resizes - Variable in class org.jgroups.util.Table
- num_results - Variable in class org.jgroups.util.Buffer.Remover
- num_results - Variable in class org.jgroups.util.Table.Remover
- num_rows - Variable in class org.jgroups.util.DynamicBuffer
- num_rows - Variable in class org.jgroups.util.Table
- num_rules_generated - Variable in class org.jgroups.util.GenerateProfilingScript
- num_selects - Variable in class org.jgroups.blocks.cs.NioBaseServer
- num_send_due_to_no_msgs - Variable in class org.jgroups.protocols.PerDestinationBundler
- num_senders - Variable in class org.jgroups.protocols.SenderSendsBundler
- num_sends - Variable in class org.jgroups.util.AsyncExecutor
- num_sends_because_full_queue - Variable in class org.jgroups.protocols.TransferQueueBundler
- num_sends_because_full_queue - Variable in class org.jgroups.protocols.TransferQueueBundler2
- num_sends_because_no_msgs - Variable in class org.jgroups.protocols.TransferQueueBundler
- num_sends_because_no_msgs - Variable in class org.jgroups.protocols.TransferQueueBundler2
- num_sends_due_to_max_size - Variable in class org.jgroups.protocols.PerDestinationBundler
- num_sends_on_callers_thread - Variable in class org.jgroups.util.AsyncExecutor
- num_seqnos - Variable in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- num_single_msgs_received - Variable in class org.jgroups.protocols.MsgStats
- num_single_msgs_sent - Variable in class org.jgroups.protocols.MsgStats
- num_single_msgs_sent - Variable in class org.jgroups.protocols.PerDestinationBundler
- num_spins - Variable in class org.jgroups.protocols.RingBufferBundler
- num_stability_msgs_received - Variable in class org.jgroups.protocols.pbcast.STABLE
- num_stability_msgs_sent - Variable in class org.jgroups.protocols.pbcast.STABLE
- num_stable_msgs_received - Variable in class org.jgroups.protocols.pbcast.STABLE
- num_stable_msgs_sent - Variable in class org.jgroups.protocols.pbcast.STABLE
- num_state_reqs - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- num_state_reqs - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- num_suspect_events - Variable in class org.jgroups.protocols.FailureDetection
- num_suspect_events - Variable in class org.jgroups.protocols.FD_HOST
- num_suspect_events - Variable in class org.jgroups.protocols.FD_SOCK
- num_suspect_events - Variable in class org.jgroups.protocols.FD_SOCK2
- num_threads - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- num_threads - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- num_tries - Variable in class org.jgroups.protocols.FD_SOCK
- num_ucast_bytes_received - Variable in class org.jgroups.protocols.MsgStats
- num_ucast_bytes_sent - Variable in class org.jgroups.protocols.MsgStats
- num_ucasts_received - Variable in class org.jgroups.protocols.MsgStats
- num_ucasts_sent - Variable in class org.jgroups.protocols.MsgStats
- num_up - Variable in class org.jgroups.protocols.DISCARD
- num_valid - Variable in class org.jgroups.blocks.GroupRequest
- num_views - Variable in class org.jgroups.protocols.pbcast.GMS
- num_writes - Variable in class org.jgroups.protocols.FILE_PING.InfoWriter
- num_xmits - Variable in class org.jgroups.protocols.UNICAST3
- number_of_frags_recvd - Variable in class org.jgroups.protocols.FRAG2.FragEntry
- numberOfRejectedMessages() - Method in class org.jgroups.util.ThreadPool
- numberOfValidResponses() - Method in class org.jgroups.util.ResponseCollector
- numBlockings() - Method in class org.jgroups.util.FixedBuffer
- NumDeliverable() - Constructor for class org.jgroups.util.Buffer.NumDeliverable
- NumDeliverable() - Constructor for class org.jgroups.util.Table.NumDeliverable
- numDropsOnFullThreadPool() - Method in class org.jgroups.util.AsyncExecutor
- numHeaders(Message) - Static method in class org.jgroups.protocols.SIZE
- numHeaders(MessageBatch) - Static method in class org.jgroups.protocols.SIZE
- numMessagesToReverse() - Method in class org.jgroups.protocols.REVERSE
- numMessagesToReverse(int) - Method in class org.jgroups.protocols.REVERSE
- numMissing() - Method in class org.jgroups.util.Buffer
-
Returns the number of null elements in the range [hd+1 ..
- numPartialWrites() - Method in class org.jgroups.blocks.cs.NioBaseServer
- numPartialWrites() - Method in class org.jgroups.blocks.cs.NioConnection
- numPartialWrites() - Method in class org.jgroups.protocols.TCP_NIO2
- numReceived() - Method in class org.jgroups.util.RspList
- numRegisteredClients() - Method in class org.jgroups.stack.GossipRouter
- numRegisteredClusters() - Method in class org.jgroups.stack.GossipRouter
- numRejected() - Method in class org.jgroups.util.AsyncExecutor
- numReqs() - Method in class org.jgroups.util.RTT
- numReqs(int) - Method in class org.jgroups.util.RTT
- numResponses() - Method in class org.jgroups.util.Responses
- numSelects() - Method in class org.jgroups.blocks.cs.NioBaseServer
- numSelects() - Method in class org.jgroups.protocols.TCP_NIO2
- numSends() - Method in class org.jgroups.util.AsyncExecutor
- numSendsOnCallersThread() - Method in class org.jgroups.util.AsyncExecutor
- numSpins() - Method in class org.jgroups.protocols.RingBufferBundler
- numSpins(int) - Method in class org.jgroups.protocols.RingBufferBundler
- numSuspectedMembers() - Method in class org.jgroups.util.RspList
O
- obj - Variable in class org.jgroups.jmx.ResourceDMBean
- obj - Variable in class org.jgroups.ObjectMessage
- obj - Variable in class org.jgroups.util.ObjectWrapperPrimitive
- obj - Variable in class org.jgroups.util.Ref
- OBJ_MSG - Static variable in interface org.jgroups.Message
- OBJECT_METHODS - Static variable in class org.jgroups.jmx.ResourceDMBean
- objectFromBuffer(ByteArray, ClassLoader) - Static method in class org.jgroups.util.Util
- objectFromByteBuffer(byte[]) - Static method in class org.jgroups.util.Util
-
Creates an object from a byte buffer
- objectFromByteBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
- objectFromByteBuffer(byte[], int, int, ClassLoader) - Static method in class org.jgroups.util.Util
- objectFromByteBuffer(ByteBuffer, ClassLoader) - Static method in class org.jgroups.util.Util
-
Parses an object from a
ByteBuffer
. - objectFromStream(DataInput) - Static method in class org.jgroups.util.Util
- objectFromStream(DataInput, ClassLoader) - Static method in class org.jgroups.util.Util
- ObjectInputStreamWithClassloader - Class in org.jgroups.util
-
Override
ObjectInputStream.resolveClass(java.io.ObjectStreamClass)
using the passed-in classloader - ObjectInputStreamWithClassloader() - Constructor for class org.jgroups.util.ObjectInputStreamWithClassloader
- ObjectInputStreamWithClassloader(InputStream) - Constructor for class org.jgroups.util.ObjectInputStreamWithClassloader
- ObjectInputStreamWithClassloader(InputStream, ClassLoader) - Constructor for class org.jgroups.util.ObjectInputStreamWithClassloader
- ObjectInputStreamWithClassloader(ClassLoader) - Constructor for class org.jgroups.util.ObjectInputStreamWithClassloader
- ObjectMessage - Class in org.jgroups
-
A
Message
with an object as payload. - ObjectMessage() - Constructor for class org.jgroups.ObjectMessage
- ObjectMessage(Address) - Constructor for class org.jgroups.ObjectMessage
-
Constructs a message given a destination address
- ObjectMessage(Address, Object) - Constructor for class org.jgroups.ObjectMessage
-
Constructs a message given a destination address and the payload object
- ObjectMessage(Address, SizeStreamable) - Constructor for class org.jgroups.ObjectMessage
-
Constructs a message given a destination address and the payload object
- objectName() - Method in annotation type org.jgroups.annotations.MBean
- objectToBuffer(Object) - Static method in class org.jgroups.util.Util
-
Serializes/Streams an object into a byte buffer.
- objectToByteBuffer(Object) - Static method in class org.jgroups.util.Util
- objectToStream(Object, DataOutput) - Static method in class org.jgroups.util.Util
- ObjectWrapperPrimitive - Class in org.jgroups.util
-
Wraps a primitive object (e.g.
- ObjectWrapperPrimitive() - Constructor for class org.jgroups.util.ObjectWrapperPrimitive
- ObjectWrapperPrimitive(Object) - Constructor for class org.jgroups.util.ObjectWrapperPrimitive
- ObjectWrapperSerializable - Class in org.jgroups.util
-
Wraps an object and its serialized form.
- ObjectWrapperSerializable() - Constructor for class org.jgroups.util.ObjectWrapperSerializable
- ObjectWrapperSerializable(Object) - Constructor for class org.jgroups.util.ObjectWrapperSerializable
- objSize() - Method in class org.jgroups.ObjectMessage
- offer(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
-
Drops elements if capacity has been reached.
- offer(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
-
Drops elements if capacity has been reached.
- offer(T, long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- offer(T, long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- offset - Variable in class org.jgroups.BytesMessage
-
The index into the payload
- offset - Variable in class org.jgroups.protocols.FD_SOCK2
- offset - Variable in class org.jgroups.protocols.Frag3Header
- offset - Variable in class org.jgroups.util.Buffer
- offset - Variable in class org.jgroups.util.PartialOutputStream
- offset - Variable in class org.jgroups.util.RingBufferSeqnoLockless
- offset - Variable in class org.jgroups.util.RingBufferSeqnoOld
- offset - Variable in class org.jgroups.util.SeqnoList
- offset - Variable in class org.jgroups.util.Table
-
The first seqno, at matrix[0][0]
- offset() - Method in class org.jgroups.util.Buffer
- OK - Static variable in class org.jgroups.blocks.cs.BaseServer
- onConnect() - Method in interface org.jgroups.client.StompConnection.ConnectionCallback
- OneTimeAddressGenerator - Class in org.jgroups.util
-
Implementation of
AddressGenerator
which is configured with an initial value, and after that random values are generated. - OneTimeAddressGenerator(long) - Constructor for class org.jgroups.util.OneTimeAddressGenerator
- onInfo(Map<String, String>) - Method in interface org.jgroups.client.StompConnection.Listener
- onInfo(Map<String, String>) - Method in class org.jgroups.demos.StompChat
- onInfo(Map<String, String>) - Method in class org.jgroups.demos.StompDraw
- onMessage(Map<String, String>, byte[], int, int) - Method in interface org.jgroups.client.StompConnection.Listener
- onMessage(Map<String, String>, byte[], int, int) - Method in class org.jgroups.demos.StompChat
- onMessage(Map<String, String>, byte[], int, int) - Method in class org.jgroups.demos.StompDraw
- oob - Variable in class org.jgroups.util.RTT
- oob() - Method in class org.jgroups.util.RTT
- oob(boolean) - Method in class org.jgroups.util.RTT
- OOB - org.jgroups.Message.Flag
- OOB - org.jgroups.util.MessageBatch.Mode
- OOB_DELIVERED - org.jgroups.Message.TransientFlag
- oob_map_mcast - Variable in class org.jgroups.protocols.MAKE_BATCH
- oob_map_ucast - Variable in class org.jgroups.protocols.MAKE_BATCH
- open - Variable in class org.jgroups.util.FixedBuffer
-
Used to unblock blocked senders on close()
- OPEN - org.jgroups.JChannel.State
- OPEN - org.jgroups.protocols.UNICAST3.State
- OPEN_BARRIER - Static variable in class org.jgroups.Event
- openBarrier() - Method in class org.jgroups.protocols.BARRIER
- openBarrier() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- openBarrier() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- openBarrierAndResumeStable() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- openBarrierAndResumeStable() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- operations - Variable in class org.jgroups.stack.NonReflectiveProbeHandler
- opInfo - Variable in class org.jgroups.jmx.ResourceDMBean
- ops - Variable in class org.jgroups.jmx.ResourceDMBean
- options - Variable in class org.jgroups.blocks.Request
- Options() - Constructor for class org.jgroups.util.Buffer.Options
- ORDERED - Static variable in class org.jgroups.util.Base64
-
Encode using the special "ordered" dialect of Base64 described here: http://www.faqs.org/qa/rfcc-1940.html.
- orderedPermutation(List<E>, List<E>) - Static method in class org.jgroups.util.Util
-
Performs an ordered permutation of the elements of a and b such that the order of elements in list a and b is preserved.
- org.jgroups - package org.jgroups
-
Provides top-level public JGroups classes such as Channel, Message, etc.
- org.jgroups.annotations - package org.jgroups.annotations
- org.jgroups.auth - package org.jgroups.auth
- org.jgroups.blocks - package org.jgroups.blocks
-
Provides building blocks that are layered on top of channels.
- org.jgroups.blocks.atomic - package org.jgroups.blocks.atomic
- org.jgroups.blocks.cs - package org.jgroups.blocks.cs
- org.jgroups.client - package org.jgroups.client
- org.jgroups.conf - package org.jgroups.conf
-
Provides ways to configure a protocol stack.
- org.jgroups.demos - package org.jgroups.demos
-
Provides demonstrations of JGroups functionality.
- org.jgroups.fork - package org.jgroups.fork
- org.jgroups.jmx - package org.jgroups.jmx
- org.jgroups.logging - package org.jgroups.logging
- org.jgroups.nio - package org.jgroups.nio
- org.jgroups.protocols - package org.jgroups.protocols
-
Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.
- org.jgroups.protocols.dns - package org.jgroups.protocols.dns
- org.jgroups.protocols.pbcast - package org.jgroups.protocols.pbcast
- org.jgroups.protocols.relay - package org.jgroups.protocols.relay
- org.jgroups.protocols.relay.config - package org.jgroups.protocols.relay.config
- org.jgroups.stack - package org.jgroups.stack
-
Support for managing protocol stacks.
- org.jgroups.util - package org.jgroups.util
-
Provides useful functionality which cannot be assigned to any particular other package.
- orig_src - Variable in class org.jgroups.BatchMessage
- original_flags - Variable in class org.jgroups.protocols.relay.RelayHeader
- original_hdrs - Variable in class org.jgroups.protocols.relay.RelayHeader
- original_length - Variable in class org.jgroups.protocols.Frag3Header
- original_msg - Variable in class org.jgroups.FragmentedMessage
- original_sender - Variable in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- original_sender - Variable in class org.jgroups.protocols.relay.RelayHeader
- original_size - Variable in class org.jgroups.protocols.COMPRESS.CompressHeader
- original_type - Variable in class org.jgroups.protocols.FragHeader
- originalFlags() - Method in class org.jgroups.protocols.relay.RelayHeader
- originalFlags(short) - Method in class org.jgroups.protocols.relay.RelayHeader
- originalHeaders() - Method in class org.jgroups.protocols.relay.RelayHeader
- originalHeaders(Header[]) - Method in class org.jgroups.protocols.relay.RelayHeader
- otherSites(View, String) - Static method in class org.jgroups.util.Util
-
Returns the sites of the view (all addresses are SiteUUIDs) minus the given site, Example: bridge_view=A:net1,B:net1,X:net2,Y:net2, excluding_site=net1 -> ["net2"]
- out - Variable in class org.jgroups.blocks.cs.TcpConnection
- out - Variable in class org.jgroups.client.StompConnection
- out - Variable in class org.jgroups.protocols.RATE
- out - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- out - Variable in class org.jgroups.protocols.STOMP.Connection
- out - Variable in class org.jgroups.util.PartialOutputStream
- out_delay - Variable in class org.jgroups.protocols.DELAY
- out_delay_nanos - Variable in class org.jgroups.protocols.DELAY
- outgoing_copies - Variable in class org.jgroups.protocols.DUPL
- output - Variable in class org.jgroups.protocols.BaseBundler
- output - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
- output - Variable in class org.jgroups.util.OutputStreamAdapter
- output_streams - Variable in class org.jgroups.stack.GossipRouter
- OutputStream(OutputStream) - Constructor for class org.jgroups.util.Base64.OutputStream
-
Constructs a
Base64.OutputStream
in ENCODE mode. - OutputStream(OutputStream, int) - Constructor for class org.jgroups.util.Base64.OutputStream
-
Constructs a
Base64.OutputStream
in either ENCODE or DECODE mode. - OutputStreamAdapter - Class in org.jgroups.util
-
Extends
OutputStream
from aByteArrayDataOutputStream
. - OutputStreamAdapter(ByteArrayDataOutputStream) - Constructor for class org.jgroups.util.OutputStreamAdapter
- OVERWRITE_DIGEST - Static variable in class org.jgroups.Event
- overwriteDigest(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Overwrites existing entries, but does NOT remove entries not found in the digest
- overwriteDigest(Digest) - Method in class org.jgroups.protocols.ReliableMulticast
-
Overwrites existing entries, but does NOT remove entries not found in the digest
- owner - Variable in class org.jgroups.protocols.COUNTER.SimpleRequest
- Owner - Class in org.jgroups.util
-
Represents an 'owner', which is an address and thread ID
- Owner() - Constructor for class org.jgroups.util.Owner
- Owner(Address, long) - Constructor for class org.jgroups.util.Owner
P
- p - Variable in class org.jgroups.protocols.relay.ForwardingRoute
- p(double) - Method in class org.jgroups.util.AverageMinMax
- 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) - 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.Topology
- paintComponent(Graphics) - Method in class org.jgroups.demos.Draw.DrawPanel
- PARK - Static variable in class org.jgroups.protocols.RingBufferBundler
- parse(byte[], int, int, BiConsumer<Short, Message>, BiConsumer<Short, MessageBatch>, Consumer<GossipData>, boolean, boolean) - Static method in class org.jgroups.util.Util
- parse(InputStream) - Static method in class org.jgroups.conf.ClassConfigurator
- parse(InputStream) - 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(InputStream, BiConsumer<Short, Message>, BiConsumer<Short, MessageBatch>, Consumer<GossipData>, boolean, boolean) - Static method in class org.jgroups.util.Util
- 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(String) - Static method in class org.jgroups.Version
- parse(XmlNode) - Static method in class org.jgroups.conf.XmlConfigurator
- parse(XmlNode) - Static method in class org.jgroups.fork.ForkConfig
- parse(XmlNode) - Method in class org.jgroups.protocols.FORK
- parse(XmlNode) - Method in class org.jgroups.protocols.relay.RELAY
- parse(XmlNode) - Method in class org.jgroups.stack.Protocol
-
Called by the XML parser when subelements are found in the configuration of a protocol.
- parse(XmlNode, Map<String, RelayConfig.SiteConfig>) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- parseBridges(RelayConfig.SiteConfig, XmlNode) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- parseBridgesAndForwards(RelayConfig.SiteConfig, XmlNode) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- 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]".
- parseCommaDelimitedHostsInto(Collection<PhysicalAddress>, Collection<String>, String, int, StackType) - Static method in class org.jgroups.util.Util
-
Parses a string into a list of IpAddresses
- parseCommaDelimitedStrings(String) - Static method in class org.jgroups.util.Util
-
e.g.
- parseForkStack(Map<String, List<ProtocolConfiguration>>, XmlNode) - Static method in class org.jgroups.fork.ForkConfig
- parseForwards(RelayConfig.SiteConfig, XmlNode) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- parseHost(String) - Static method in class org.jgroups.util.Util
-
Parses a host:IP string into an InetSocketAddress
- parseInterfaceList(String) - Static method in class org.jgroups.util.Util
- parseLines(InputStream) - Static method in class org.jgroups.conf.ClassConfigurator
- parseNextString(String, int) - Static method in class org.jgroups.conf.ClassConfigurator
- parsePropertiesString(Map<String, String>) - Method in class org.jgroups.conf.ProtocolConfiguration
- parseProtocols(XmlNode) - Static method in class org.jgroups.conf.XmlConfigurator
- parseRejectionPolicy(String) - Static method in class org.jgroups.util.Util
- parseSiteConfiguration(Map<String, RelayConfig.SiteConfig>) - Method in class org.jgroups.protocols.relay.RELAY
-
Parses the configuration by reading the config file
- parseSiteMasters(String) - Static method in class org.jgroups.demos.RelayDemoRpc
- parseSites(Map<String, RelayConfig.SiteConfig>, XmlNode) - Static method in class org.jgroups.protocols.relay.config.RelayConfig
- parseStringArray(String, String) - Static method in class org.jgroups.util.Util
- parseStringList(String, String) - Static method in class org.jgroups.util.Util
- parseVersionAndCodenameFromPOM(String) - Static method in class org.jgroups.util.WriteVersionTo
- parseXmlDocument(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
-
Reads XML and returns a simple tree of XmlNodes
- PART - Static variable in class org.jgroups.protocols.pbcast.GMS
- partial_writes - Variable in class org.jgroups.blocks.cs.NioConnection
- PartialOutputStream - Class in org.jgroups.util
-
Decorates an output stream (
DataOutput
) and writes only a subset [start..end] (both indices inclusive) of the original data to the underlying output stream.
Example: - PartialOutputStream(DataOutput, int, int) - Constructor for class org.jgroups.util.PartialOutputStream
- ParticipantGmsImpl - Class in org.jgroups.protocols.pbcast
- ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- passBatchUp() - Method in class org.jgroups.util.MaxOneThreadPerSender.BatchHandlerLoop
- passBatchUp() - Method in class org.jgroups.util.SubmitToThreadPool.BatchHandler
- passBatchUp(MessageBatch, boolean, boolean) - Method in class org.jgroups.protocols.TP
- passcode - Variable in class org.jgroups.stack.DiagnosticsHandler
- passMessageUp(Message, byte[], boolean, boolean, boolean) - Method in class org.jgroups.protocols.TP
- PassRegularMessagesUpDirectly - Class in org.jgroups.util
-
MessageProcessingPolicy
which passes regular messages and message batches up directly (on the same thread), but passes OOB messages to the thread pool. - PassRegularMessagesUpDirectly() - Constructor for class org.jgroups.util.PassRegularMessagesUpDirectly
- passUp(Message) - Method in class org.jgroups.protocols.relay.RELAY3
-
Sends a message up the stack.
- 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
- PDC - Class in org.jgroups.protocols
-
Persistent Discovery Cache.
- PDC() - Constructor for class org.jgroups.protocols.PDC
- PDC.Mapping - Class in org.jgroups.protocols
- peer_addr - Variable in class org.jgroups.blocks.cs.Connection
- peer_addr - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- peer_addr_read_timeout - Variable in class org.jgroups.blocks.cs.TcpBaseServer
- peer_addr_read_timeout - Variable in class org.jgroups.protocols.BasicTCP
- peerAddress() - Method in class org.jgroups.blocks.cs.Connection
- peerAddressReadTimeout() - Method in class org.jgroups.blocks.cs.TcpBaseServer
- peerAddressReadTimeout(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
- pending_requests - Variable in class org.jgroups.protocols.COUNTER
- percentile(double) - Method in class org.jgroups.util.AverageMinMax
- percentiles() - Method in class org.jgroups.util.AverageMinMax
- percentiles(AverageMinMax, int) - Static method in class org.jgroups.util.RTT
- PerDestinationBundler - Class in org.jgroups.protocols
-
Queues messages per destination ('null' is a special destination), sending when the last sender thread to the same destination returns or max_size has been reached.
- PerDestinationBundler() - Constructor for class org.jgroups.protocols.PerDestinationBundler
- PerDestinationBundler.SendBuffer - Class in org.jgroups.protocols
- 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
- permute(List<E>, List<E>, int, int) - Static method in class org.jgroups.util.Util
- permute(List<E>, List<E>, int, List<List<E>>) - Static method in class org.jgroups.util.Util
- permute(List<E>, List<List<E>>) - Static method in class org.jgroups.util.Util
-
Inefficient permutation of a generic list; uses too much copying among other things.
- 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
- 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
- pickNext(List<T>, T, int) - Static method in class org.jgroups.util.Util
-
Returns the next min(N,list.size()) elements after obj
- pickPrevious(List<T>, T) - Static method in class org.jgroups.util.Util
- pickPrevious(T[], T) - Static method in class org.jgroups.util.Util
-
Returns the element before el.
- pickRandomElement(Collection<T>) - Static method in class org.jgroups.util.Util
- 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 class org.jgroups.protocols.relay.RandomSiteMasterPicker
- 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.
- pickRoute(String, List<Route>, Address) - Method in class org.jgroups.protocols.relay.StickySiteMasterPicker
- pickSiteMaster(List<Address>, Address) - Method in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- 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
- pickSiteMaster(List<Address>, Address) - Method in class org.jgroups.protocols.relay.StickySiteMasterPicker
- pickSiteMaster(Address) - Method in class org.jgroups.protocols.relay.RELAY
-
Returns a site master from site_masters
- 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
- 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_SOCK
- ping_dest - Variable in class org.jgroups.protocols.FD_SOCK2
- 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_SOCK
- pingable_mbrs - Variable in class org.jgroups.protocols.FD_SOCK2
- 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, boolean, String, PhysicalAddress) - Constructor for class org.jgroups.protocols.PingData
- PingDataIterator(PingData[], int) - Constructor for class org.jgroups.util.Responses.PingDataIterator
- PingDest() - Constructor for class org.jgroups.protocols.FD_SOCK2.PingDest
- pinger_thread - Variable in class org.jgroups.protocols.FD_SOCK
- PingHeader - Class in org.jgroups.protocols
-
Used to send discovery requests and responses
- PingHeader() - Constructor for class org.jgroups.protocols.PingHeader
- PingHeader(byte) - Constructor for class org.jgroups.protocols.PingHeader
- PingTask() - Constructor for class org.jgroups.protocols.FD_HOST.PingTask
- policies - Variable in class org.jgroups.stack.Protocol
- policies() - Method in class org.jgroups.stack.Protocol
- Policy - Interface in org.jgroups.stack
-
A policy implementation checks that a condition is met or throws an exception if not.
- PolicyConverter() - Constructor for class org.jgroups.conf.PropertyConverters.PolicyConverter
- poll() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- poll() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- poll(long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- poll(long, TimeUnit) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- poll_timeout - Variable in class org.jgroups.protocols.BATCH2
- poll_timeout - Variable in class org.jgroups.protocols.TransferQueueBundler2
- pool - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
- pool - Variable in class org.jgroups.util.TimeScheduler3
-
Thread pool used to execute the tasks
- pool() - Method in class org.jgroups.util.ThreadPool
- pool_size - Variable in class org.jgroups.protocols.COMPRESS
- pool_thread_keep_alive - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- port - Variable in class org.jgroups.protocols.SHARED_LOOPBACK
- port - Variable in class org.jgroups.protocols.SimpleTCP.Acceptor
- 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.DiagnosticsHandler
- port - Variable in class org.jgroups.stack.GossipRouter
- port - Variable in class org.jgroups.stack.IpAddress
- 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.FD_SOCK2
- port_range - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- port_range - Variable in class org.jgroups.protocols.TCPPING
- port_range - Variable in class org.jgroups.protocols.TP
- port_range - Variable in class org.jgroups.stack.DiagnosticsHandler
- portRange(int) - Method in class org.jgroups.protocols.TCPPING
- pos - Variable in class org.jgroups.util.BaseDataOutputStream
- pos - Variable in class org.jgroups.util.ByteArrayDataInputStream
- position - Variable in class org.jgroups.nio.Buffers
- position() - Method in class org.jgroups.nio.Buffers
- position() - Method in class org.jgroups.util.BaseDataOutputStream
- position() - Method in class org.jgroups.util.ByteArrayDataInputStream
- position(int) - Method in class org.jgroups.nio.Buffers
- position(int) - Method in class org.jgroups.util.BaseDataOutputStream
- position(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
- pred - Variable in class org.jgroups.util.Delayer.Entry
- preferred_size - Variable in class org.jgroups.demos.Draw.DrawPanel
- prefix(String, String) - Static method in class org.jgroups.jmx.ResourceDMBean
- PREFIX - Static variable in class org.jgroups.Global
- PREFIX - Static variable in class org.jgroups.util.GenerateProfilingScript
- prepare(Connection, String, int, int) - Static method in class org.jgroups.protocols.JDBC_PING2
- prepareStatement(Connection, String, int, int) - Static method in class org.jgroups.protocols.JDBC_PING
- prettyPrint(Object, AccessibleObject) - Static method in class org.jgroups.jmx.ResourceDMBean
- 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
- 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. - primitiveFromStream(DataInput) - Static method in class org.jgroups.util.Util
- primitiveFromStream(DataInput, byte) - Static method in class org.jgroups.util.Util
- primitives - Static variable in class org.jgroups.jmx.ResourceDMBean
- primitiveToStream(Object, DataOutput) - Static method in class org.jgroups.util.Util
- print() - Static method in class org.jgroups.protocols.LOCAL_PING
- print() - Method in class org.jgroups.protocols.relay.Topology
- 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.FastArray
- print() - Method in class org.jgroups.util.Responses
- print(boolean) - Method in class org.jgroups.protocols.relay.SiteUUID
- print(double, TimeUnit) - Static method in class org.jgroups.util.Util
- print(int) - Method in class org.jgroups.conf.XmlNode
- print(int) - Method in class org.jgroups.util.FastArray
- print(long) - Static method in class org.jgroups.protocols.RTTHeader
- print(short) - Static method in class org.jgroups.Version
-
Method copied from http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
- print(Object[]) - Static method in class org.jgroups.util.Util
- print(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Prints a representation of the node defined by
fqn
. - print(String) - Method in class org.jgroups.JChannelProbeHandler.ThreadEntry
- print(String) - Method in class org.jgroups.protocols.relay.Topology
-
Dumps the members for a given site, or all sites
- print(Collection<T>) - Static method in class org.jgroups.util.Util
- print(BiConsumer<Integer, Integer>) - Static method in class org.jgroups.protocols.RingBufferBundler
- print(List<NetworkInterface>) - Static method in class org.jgroups.util.Util
- print(List<PingData>) - Static method in class org.jgroups.protocols.Discovery
- print(Map<String, Map<String, Metrics.Entry<T>>>) - Static method in class org.jgroups.util.Metrics
- print(Map<T, T>) - Static method in class org.jgroups.util.Util
- print(K, V) - Method in interface org.jgroups.blocks.LazyRemovalCache.Printable
- print(AverageMinMax, boolean, TimeUnit, int) - Static method in class org.jgroups.util.RTT
- print_details - Variable in class org.jgroups.util.Profiler
- 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.ExtendedUUID
- print_function - Static variable in class org.jgroups.util.NameCache
- print_headers - Variable in class org.jgroups.stack.DiagnosticsHandler
- print_limit - Variable in class org.jgroups.util.FastArray
- 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_to_stdout - Variable in class org.jgroups.protocols.DETECT_LOOPBACKS
- print_up - Variable in class org.jgroups.protocols.HDRS
- print_view_details - Variable in class org.jgroups.protocols.pbcast.GMS
- print16(PublicKey) - Static method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- printAckTable() - Method in class org.jgroups.protocols.NAKACK4
- printAddressTable() - Method in class org.jgroups.protocols.SimpleTCP
- printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST3
- printBatches() - Method in class org.jgroups.protocols.ReliableMulticast
- 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(double) - Static method in class org.jgroups.util.Util
-
MB nowadays doesn't mean 1024 * 1024 bytes, but 1 million bytes, see http://en.wikipedia.org/wiki/Megabyte
- printCache() - 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.NameCache
- printCache(LazyRemovalCache.Printable) - Method in class org.jgroups.blocks.LazyRemovalCache
- printCachedGroupKeys() - Method in class org.jgroups.protocols.Encrypt
- printClassMap() - Static method in class org.jgroups.conf.ClassConfigurator
- printConnections() - Method in class org.jgroups.blocks.cs.BaseServer
- printConnections() - Method in class org.jgroups.protocols.BasicTCP
- printConnections() - Method in class org.jgroups.protocols.FD_SOCK2
- printConnections() - Method in class org.jgroups.protocols.TCP_NIO2
- printConnections() - Method in class org.jgroups.protocols.TCP
- 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
- 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.
- printDiff(Address[][]) - Static method in class org.jgroups.View
- printDigest() - Method in class org.jgroups.protocols.pbcast.STABLE
- printDigest(Digest) - Method in class org.jgroups.protocols.pbcast.STABLE
- printDigestHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- printDigestHistory() - Method in class org.jgroups.protocols.ReliableMulticast
- printDown() - Method in class org.jgroups.protocols.HDRS
- printDown(boolean) - Method in class org.jgroups.protocols.HDRS
- printEvents(List<Integer>) - Static method in class org.jgroups.stack.Configurator
- printHeaders() - Method in class org.jgroups.BaseMessage
- printHeaders() - Method in interface org.jgroups.Message
-
Returns a pretty-printed string of the headers
- printHeaders() - Method in class org.jgroups.util.MessageBatch
- printHeaders(Function<Boolean, String>) - Method in class org.jgroups.stack.DiagnosticsHandler
- printHeaders(Header[]) - Static method in class org.jgroups.util.Headers
- printHostAddress() - Method in class org.jgroups.stack.IpAddress
- printHosts() - Method in class org.jgroups.protocols.FD_HOST
- printInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
- printIpAddress() - Method in interface org.jgroups.PhysicalAddress
- printIpAddress() - Method in class org.jgroups.stack.IpAddress
- printIpAddress2() - Method in class org.jgroups.stack.IpAddress
- printLimit() - Method in class org.jgroups.util.FastArray
- printLimit(int) - Method in class org.jgroups.util.FastArray
- printList(Collection<T>) - Static method in class org.jgroups.util.Util
- 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
- printLocalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
- printLocalAddress(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- printLocalTopology() - Method in class org.jgroups.protocols.relay.RELAY2
- printLocalTopology() - Method in class org.jgroups.protocols.relay.RELAY3
- printLogicalAddressCache() - Method in class org.jgroups.protocols.TP
- printMap(Map<Address, ? extends 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<LongTuple<Message>>) - Method in class org.jgroups.protocols.UNICAST3
- printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- printMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- printMissing() - Method in class org.jgroups.util.AckCollector
- printName(UUID) - Static method in class org.jgroups.util.UUID
- printOthers() - Method in class org.jgroups.protocols.relay.SiteUUID
- printPayload(Message, StringBuilder) - Static method in class org.jgroups.protocols.SNIFF
- printPhysicalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
- printPhysicalAddress(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- printPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
- 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
-
Dumps all protocols in string format.
- 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
- printReceiveHistory() - Method in class org.jgroups.protocols.RATE
- printReceiverCredits() - Method in class org.jgroups.protocols.FlowControl
- 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
- printRoutes() - Method in class org.jgroups.protocols.relay.RELAY
- printRoutes() - Method in class org.jgroups.protocols.relay.Relayer
- printRTTStatsByDest() - Method in class org.jgroups.util.RpcStats
- printSenderCredits() - Method in class org.jgroups.protocols.FlowControl
- printSenderCredits() - Method in class org.jgroups.protocols.MFC
- printSenderCredits() - Method in class org.jgroups.protocols.UFC
- printSendHistory() - Method in class org.jgroups.protocols.RATE
- printSendWindowMessages() - Method in class org.jgroups.protocols.UNICAST3
- printSites() - Method in class org.jgroups.protocols.relay.RELAY
- printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- printStabilityMessages() - Method in class org.jgroups.protocols.ReliableMulticast
- printStats() - Method in class org.jgroups.protocols.STATS
- printStatsByDest() - Method in class org.jgroups.util.RpcStats
- printStubs() - Method in class org.jgroups.protocols.TCPGOSSIP
- printStubs() - Method in class org.jgroups.protocols.TUNNEL
- printStubs() - Method in class org.jgroups.stack.RouterStubManager
- printSuspectHistory() - Method in class org.jgroups.protocols.FailureDetection
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_HOST
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK2
- printTime(double, 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_ALL3
- printTimestamps() - Method in class org.jgroups.protocols.FD_HOST
- printTopo(String, String, boolean) - Method in class org.jgroups.demos.RelayDemo
- printTopology(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
- printTopology(boolean) - Method in class org.jgroups.protocols.relay.RELAY3
- printType() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- printType() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- printUp() - Method in class org.jgroups.protocols.HDRS
- printUp(boolean) - Method in class org.jgroups.protocols.HDRS
- printVersion() - Static method in class org.jgroups.Version
-
Returns the version field as a String.
- printViewDetails() - Method in class org.jgroups.protocols.pbcast.GMS
- printViewDetails(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- printViews(JChannel...) - Static method in class org.jgroups.util.Util
- printVotes() - Method in class org.jgroups.protocols.pbcast.STABLE
- printWhoHasCache() - Method in class org.jgroups.protocols.TP
- probe_handler - Variable in class org.jgroups.blocks.RequestCorrelator
- probe_handler - Variable in class org.jgroups.JChannel
- probe_transport_ports - Variable in class org.jgroups.protocols.dns.DNS_PING
- process() - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
We're guaranteed that only one thread will be called with this method at any time
- process() - Method in class org.jgroups.util.ProcessingQueue
- process(boolean, Message) - Method in class org.jgroups.protocols.relay.RELAY3
-
This method has all the routing logic, for both site masters and regular members
- process(String) - Method in class org.jgroups.demos.RelayDemo
- process(Socket) - Method in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
- process(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.GMS
- process(Message, boolean) - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
Process a message received from the transport
- process(Message, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- process(Message, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- process(Message, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender
- process(Message, boolean) - Method in class org.jgroups.util.PassRegularMessagesUpDirectly
- process(Message, boolean) - Method in class org.jgroups.util.SubmitToThreadPool
- process(MessageBatch) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- process(MessageBatch) - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- process(MessageBatch, boolean) - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
Process a batch received from the transport
- process(MessageBatch, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender
- process(MessageBatch, boolean) - Method in class org.jgroups.util.PassRegularMessagesUpDirectly
- process(MessageBatch, boolean) - Method in class org.jgroups.util.SubmitToThreadPool
- process(MessageBatch, boolean) - Method in class org.jgroups.util.UnbatchOOBBatches
- PROCESS - org.jgroups.protocols.ASYM_ENCRYPT.Processing
- process_state_events - Variable in class org.jgroups.protocols.FORK
- processBatch(MessageBatch, boolean) - Method in class org.jgroups.protocols.TP
- processDownMessage() - Method in class org.jgroups.protocols.BATCH2
- processEncryptMessage(Message, EncryptHeader, boolean) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- processing - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- processing - Variable in class org.jgroups.util.RingBufferSeqnoLockless
- processing - Variable in class org.jgroups.util.RingBufferSeqnoOld
- processing() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- processing(boolean) - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
To be used by testing only!
- processing_done - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- processing_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- processingPolicyIs(Class<? extends MessageProcessingPolicy>, JChannel...) - Static method in class org.jgroups.util.Tests
- 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
- processingTime() - Method in class org.jgroups.protocols.RTTHeader
-
Time between reception of a message and sending of a response (= time spent in application code)
- processStateEvents() - Method in class org.jgroups.protocols.FORK
- processStateEvents(boolean) - Method in class org.jgroups.protocols.FORK
- producer_lock - Variable in class org.jgroups.util.ProcessingQueue
- productGreaterThan(long, long, long) - Static method in class org.jgroups.util.Util
- Profiler - Class in org.jgroups.util
-
Maintains averages for time values measured between
Profiler.start()
andProfiler.stop()
. - Profiler() - Constructor for class org.jgroups.util.Profiler
- 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.InitialHosts - Class in org.jgroups.conf
- PropertyConverters.InitialHosts2 - Class in org.jgroups.conf
- PropertyConverters.NetworkInterfaceList - Class in org.jgroups.conf
- PropertyConverters.PolicyConverter - Class in org.jgroups.conf
-
Creates a list of Policy objects from a comma-separated list of classnames
- PropertyHelper - Class in org.jgroups.conf
- 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
- protocolAdapter() - Method in class org.jgroups.blocks.MessageDispatcher
- ProtocolAdapter() - Constructor for class org.jgroups.blocks.MessageDispatcher.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
- protocols - Variable in class org.jgroups.util.TLS
- ProtocolStack - Class in org.jgroups.stack
-
A ProtocolStack manages a number of protocols layered above each other.
- ProtocolStack() - Constructor for class org.jgroups.stack.ProtocolStack
-
Used for programmatic creation of ProtocolStack
- ProtocolStack(JChannel) - Constructor for class org.jgroups.stack.ProtocolStack
- ProtocolStack.Position - Enum in org.jgroups.stack
- ProtocolStackConfigurator - Interface in org.jgroups.conf
- ProtPerfHeader - Class in org.jgroups.protocols
- ProtPerfHeader() - Constructor for class org.jgroups.protocols.ProtPerfHeader
- prots_above - Variable in class org.jgroups.protocols.relay.RELAY
- providedDownServices() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- 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 from down below)
- providedUpServices() - Method in class org.jgroups.protocols.Discovery
- providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- providedUpServices() - Method in class org.jgroups.protocols.ReliableMulticast
- 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.Encrypt
- provider - Variable in class org.jgroups.util.TLS
- provider(String) - Method in class org.jgroups.util.SslContextFactory
- pub_map - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- 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
- PubServer() - Constructor for class org.jgroups.demos.PubServer
- 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.Buffer
-
Removes all elements <= seqno from the buffer.
- 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.Buffer
-
Purges (nulls) all elements <= seqno.
- purge(long, boolean) - Method in class org.jgroups.util.DynamicBuffer
-
Removes all elements less than or equal to seqno from the buffer.
- purge(long, boolean) - Method in class org.jgroups.util.FixedBuffer
- purge(long, boolean) - Method in class org.jgroups.util.Table
-
Removes all elements less than or equal to seqno from the table.
- put(byte[], byte[]) - Method in class org.jgroups.util.ExtendedUUID
- put(int, byte[], byte[]) - Method in class org.jgroups.util.ExtendedUUID
- put(int, T) - Method in class org.jgroups.util.IntHashMap
- put(String, byte[]) - Method in class org.jgroups.util.ExtendedUUID
- put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a key and value to a given node.
- put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a new node to the tree and sets its data.
- put(String, View) - Method in class org.jgroups.protocols.relay.Topology
-
Called when a response has been received.
- 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(K, V, long) - Method in class org.jgroups.blocks.Cache
- 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, short, long, boolean) - Method in class org.jgroups.blocks.ReplCache
-
Places a key/value pair into one or several nodes in the cluster.
- put(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- put(T) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- 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.
- 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.
- putHeader(short, Header) - Method in class org.jgroups.BaseMessage
-
Puts a header given an ID into the hashmap.
- putHeader(short, Header) - Method in interface org.jgroups.Message
-
Adds a header to the message
- putHeader(short, Header, boolean) - Method in class org.jgroups.BaseMessage
- 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.BaseMessage
- putHeaderIfAbsent(short, Header) - Method in interface org.jgroups.Message
-
Adds a header to a message if not present
- putIfAbsent(String, JChannel) - Method in class org.jgroups.fork.ForkProtocolStack
- putIfAbsent(String, Protocol) - Method in class org.jgroups.protocols.FORK
- putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- putIfAbsent(Address) - Method in class org.jgroups.util.CreditMap
- 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.
Q
- queue - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- queue - Variable in class org.jgroups.protocols.REVERSE
- queue - Variable in class org.jgroups.protocols.TransferQueueBundler
- queue - Variable in class org.jgroups.protocols.TransferQueueBundler2
- queue - Variable in class org.jgroups.util.ProcessingQueue
- queue - Variable in class org.jgroups.util.SizeBoundedQueue
- queue - Variable in class org.jgroups.util.TimeScheduler3
-
DelayQueue with tasks being sorted according to execution times (next execution first)
- queue(Message) - Method in class org.jgroups.protocols.MAKE_BATCH
- queue_capacity - Variable in class org.jgroups.protocols.RED
- queue_size - Variable in class org.jgroups.protocols.RemoveQueueBundler
- queued_batches - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- queued_msgs - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- queuedMessages() - Method in class org.jgroups.protocols.REVERSE
- queueMessage(Message, long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- queueMessage(Message, long) - Method in class org.jgroups.protocols.ReliableMulticast
- queueSize() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- queueSize() - Method in class org.jgroups.util.SizeBoundedQueue
-
For testing only - should always be the same as size()
- queuing - Variable in class org.jgroups.util.NonBlockingCredit
- queuing - Variable in class org.jgroups.util.NonBlockingCreditMap
R
- 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
- RACKSPACE_PING.RackspaceClient - Class in org.jgroups.protocols
-
A thread safe Rackspace ReST client
- rackspaceClient - Variable in class org.jgroups.protocols.RACKSPACE_PING
- RackspaceClient(URL, String, String) - Constructor for class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
Constructor
- random(long) - Static method in class org.jgroups.util.Util
-
Returns a random value in the range [1 - range].
- RandomSiteMasterPicker - Class in org.jgroups.protocols.relay
-
Implementation of
SiteMasterPicker
which picks random site masters / routes to site masters - RandomSiteMasterPicker() - Constructor for class org.jgroups.protocols.relay.RandomSiteMasterPicker
- randomUUID() - Static method in class org.jgroups.util.ExtendedUUID
- randomUUID() - Static method in class org.jgroups.util.FlagsUUID
- randomUUID() - Static method in class org.jgroups.util.UUID
-
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
- randomUUID(String) - Static method in class org.jgroups.util.ExtendedUUID
- randomUUID(String) - Static method in class org.jgroups.util.FlagsUUID
- 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
- RATE - Class in org.jgroups.protocols
-
Measures incoming and outgoing rates: messages/sec, bytes/sec.
- RATE() - Constructor for class org.jgroups.protocols.RATE
- 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
- RATE_LIMITER2 - Class in org.jgroups.protocols
-
Rate limiter based credits (max_bytes).
- RATE_LIMITER2() - Constructor for class org.jgroups.protocols.RATE_LIMITER2
- 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.RemoveQueueBundler
- rb - Variable in class org.jgroups.protocols.RingBufferBundler
- read() - Method in class org.jgroups.blocks.cs.NioConnection
-
Read the length first, then the actual data.
- read() - Method in class org.jgroups.blocks.GridInputStream
- read() - Method in class org.jgroups.protocols.SOS
- 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() - Method in class org.jgroups.util.BlockingInputStream
- read() - Method in class org.jgroups.util.ByteArrayDataInputStream
-
Reads the next byte of data from buf.
- read() - Method in class org.jgroups.util.ByteBufferInputStream
- read() - Method in class org.jgroups.util.InputStreamAdapter
- read(byte[]) - Method in class org.jgroups.blocks.GridInputStream
- read(byte[]) - Method in class org.jgroups.util.BlockingInputStream
- read(byte[]) - Method in class org.jgroups.util.InputStreamAdapter
- read(byte[], int, int) - Method in class org.jgroups.blocks.GridInputStream
- read(byte[], int, int) - Method in class org.jgroups.util.Base64.InputStream
-
Calls
Base64.InputStream.read()
repeatedly until the end of stream is reached or len bytes are read. - read(byte[], int, int) - Method in class org.jgroups.util.BlockingInputStream
- read(byte[], int, int) - Method in class org.jgroups.util.ByteArrayDataInputStream
- read(byte[], int, int) - Method in class org.jgroups.util.InputStreamAdapter
- read(DataInput) - Method in class org.jgroups.util.ExtendedUUID
- read(File) - Method in class org.jgroups.protocols.FILE_PING
- read(InputStream) - Method in class org.jgroups.protocols.Discovery
- read(InputStream) - Method in class org.jgroups.protocols.FILE_PING
- read(Class<T>, DataInput) - Static method in class org.jgroups.util.Util
- read(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
- read(ByteBuffer[], int, int) - Method in class org.jgroups.nio.MockSocketChannel
- read(SocketChannel) - Method in class org.jgroups.nio.Buffers
-
Performs a scattering read into all (contiguous) non-null buffers in range [position ..
- 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) - Static method in class org.jgroups.util.Util
- readAddresses(DataInput, IntFunction<T>) - Static method in class org.jgroups.util.Util
- 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.FILE_PING
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.JDBC_PING
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.JDBC_PING2
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.RACKSPACE_PING
- readAll(List<Address>, String, Responses) - Method in class org.jgroups.protocols.SWIFT_PING
- readArg(DataInput) - Method in class org.jgroups.blocks.MethodCall
- readArgs(DataInput) - Method in class org.jgroups.blocks.MethodCall
- readAsciiString(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads an AsciiString from buf.
- readAsciiString(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads an AsciiString from buf.
- readAttribute(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
- 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
- readBuffer(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
-
Non-copying reading of len bytes from the input stream into a
ByteBuffer
. - 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() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readChar() - Method in class org.jgroups.util.ByteBufferInputStream
- readChar(byte[], int) - Static method in class org.jgroups.util.Bits
- readChar(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readContents(InputStream) - Static method in class org.jgroups.util.Util
- readDouble() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readDouble() - Method in class org.jgroups.util.ByteBufferInputStream
- readDouble(byte[], int) - Static method in class org.jgroups.util.Bits
- readDouble(DataInput) - Static method in class org.jgroups.util.Bits
- readDouble(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readDoubleFromStdin(String) - Static method in class org.jgroups.util.Util
- readDurationLong(String, TimeUnit) - Static method in class org.jgroups.util.Util
- reader_idle_time - Variable in class org.jgroups.blocks.cs.NioBaseServer
- 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(long) - Method in class org.jgroups.protocols.TCP_NIO2
- readException(DataInput, int) - Static method in class org.jgroups.util.Util
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.Cache.Value
- readFile(String) - Static method in class org.jgroups.util.Util
- readFileContents(InputStream) - Static method in class org.jgroups.util.Util
- readFloat() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readFloat() - Method in class org.jgroups.util.ByteBufferInputStream
- readFloat(byte[], int) - Static method in class org.jgroups.util.Bits
- readFloat(DataInput) - Static method in class org.jgroups.util.Bits
- readFloat(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readFrame(DataInputStream) - Static method in class org.jgroups.protocols.STOMP
- 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.RegexMembership
- readFrom(DataInput) - Method in class org.jgroups.auth.X509Token
- readFrom(DataInput) - Method in class org.jgroups.BaseMessage
- 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.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.MergeView
- readFrom(DataInput) - Method in class org.jgroups.NullAddress
- readFrom(DataInput) - Method in class org.jgroups.protocols.AuthHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.BATCH.BatchHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- readFrom(DataInput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- 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.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.DH_KEY_EXCHANGE.DhHeader
- 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.FailureDetection.HeartbeatHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.FcHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.FORK.ForkHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.Frag3Header
- readFrom(DataInput) - Method in class org.jgroups.protocols.FragHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.MERGE3.MergeHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.NakAckHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.pbcast.DeltaView
- 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.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.ProtPerfHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.relay.RelayHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.relay.SiteUUID
- readFrom(DataInput) - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.RTTHeader
- 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.TpHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.UnicastHeader3
- readFrom(DataInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- readFrom(DataInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.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.ByteArray
- readFrom(DataInput) - Method in class org.jgroups.util.Digest
- readFrom(DataInput) - Method in class org.jgroups.util.ExtendedUUID
- readFrom(DataInput) - Method in class org.jgroups.util.FlagsUUID
- readFrom(DataInput) - Method in class org.jgroups.util.LongSizeStreamable
- readFrom(DataInput) - Method in class org.jgroups.util.MergeId
- readFrom(DataInput) - Method in class org.jgroups.util.ObjectWrapperPrimitive
- readFrom(DataInput) - Method in class org.jgroups.util.ObjectWrapperSerializable
- 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 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
- readFrom(DataInput, boolean) - Method in class org.jgroups.stack.GossipData
- readFrom(DataInput, boolean) - Method in class org.jgroups.util.Digest
- readFrom(DataInput, boolean, boolean) - Method in class org.jgroups.stack.GossipData
- readFromDB(String) - Method in class org.jgroups.protocols.JDBC_PING2
- readFully(byte[]) - 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.ByteArrayDataInputStream
- 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
- readHeaders(DataInput) - Static method in class org.jgroups.util.Headers
- 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() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readInt() - Method in class org.jgroups.util.ByteBufferInputStream
- readInt(byte[], int) - Static method in class org.jgroups.util.Bits
- readInt(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readIntCompressed(byte[], int) - Static method in class org.jgroups.util.Bits
- readIntCompressed(DataInput) - Static method in class org.jgroups.util.Bits
- readIntCompressed(ByteBuffer) - 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() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readLong() - Method in class org.jgroups.util.ByteBufferInputStream
- readLong(byte[], int) - Static method in class org.jgroups.util.Bits
- readLong(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readLongCompressed(byte[], int) - Static method in class org.jgroups.util.Bits
- readLongCompressed(DataInput) - Static method in class org.jgroups.util.Bits
- readLongCompressed(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readLongFromStdin(String) - Static method in class org.jgroups.util.Util
- readLongSequence(DataInput, long[], int) - Static method in class org.jgroups.util.Bits
-
Reads 2 compressed longs into an array of 2 longs.
- readLongSequence(ByteBuffer, long[]) - Static method in class org.jgroups.util.Bits
-
Reads 2 compressed longs from buf into seqnos
- 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, MessageFactory) - Static method in class org.jgroups.util.Util
- readMessageBatch(DataInput, boolean, MessageFactory) - Static method in class org.jgroups.util.Util
-
Reads a list of messages into 2 MessageBatches: regular OOB
- readMessageList(DataInput, short, MessageFactory) - 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
- readNode(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
- readObject(String, String) - Method in class org.jgroups.protocols.RACKSPACE_PING.RackspaceClient
-
Read the content of a file
- readObject(String, String) - Method in class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Read the content of a file
- readPayload(DataInput) - Method in class org.jgroups.BatchMessage
- readPayload(DataInput) - Method in class org.jgroups.BytesMessage
- readPayload(DataInput) - Method in class org.jgroups.CompositeMessage
- readPayload(DataInput) - Method in class org.jgroups.EmptyMessage
- readPayload(DataInput) - Method in class org.jgroups.FragmentedMessage
- readPayload(DataInput) - Method in class org.jgroups.LongMessage
- readPayload(DataInput) - Method in interface org.jgroups.Message
- readPayload(DataInput) - Method in class org.jgroups.NioMessage
- readPayload(DataInput) - Method in class org.jgroups.ObjectMessage
- 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
- readQuotedString(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
-
Reads the characters between a start and end quote (").
- readReconciliationLongs(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
- readReconciliationNames(DataInput, int) - Static method in class org.jgroups.protocols.COUNTER
- readRequest(DataInput) - Method in class org.jgroups.stack.GossipRouter
- readRequest(DataInput, GossipType) - Method in class org.jgroups.stack.GossipRouter
- 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() - Method in class org.jgroups.util.ByteArrayDataInputStream
- readShort() - Method in class org.jgroups.util.ByteBufferInputStream
- readShort(byte[], int) - Static method in class org.jgroups.util.Bits
- readShort(ByteBuffer) - Static method in class org.jgroups.util.Bits
- readSizeStreamable(DataInput, ClassLoader) - Static method in class org.jgroups.util.Util
- readState(InputStream) - Method in class org.jgroups.demos.Draw.DrawPanel
- readStreamable(Supplier<T>, DataInput) - Static method in class org.jgroups.util.Util
- readString(DataInput) - Static method in class org.jgroups.util.Bits
-
Reads a string from buf.
- readString(DataInput) - Static method in class org.jgroups.util.Util
- readString(ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Reads a string from buf.
- readStringFromStdin(String) - Static method in class org.jgroups.util.Util
- readTillMatchingCharacter(InputStream, char) - Static method in class org.jgroups.util.Util
-
Returns all characters read from the current position until the next occurrence of 'c' has been read (including 'c'), or eof, whichever comes first
- readTillMatchingParens(InputStream) - Static method in class org.jgroups.conf.ClassConfigurator
- 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
- readUntilBracket(InputStream) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
Reads until the next bracket '}' and returns the string excluding the bracket, or throws an exception if no bracket has been found
- 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
- reaper_interval - Variable in class org.jgroups.stack.GossipRouter
- reaperInterval - Variable in class org.jgroups.blocks.cs.BaseServer
- reaperInterval() - Method in class org.jgroups.blocks.cs.BaseServer
- reaperInterval() - Method in class org.jgroups.stack.GossipRouter
- reaperInterval(long) - Method in class org.jgroups.blocks.cs.BaseServer
- reaperInterval(long) - Method in class org.jgroups.protocols.BasicTCP
- reaperInterval(long) - Method in class org.jgroups.stack.GossipRouter
- RECEIPT - org.jgroups.protocols.STOMP.ServerVerb
- 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, byte[], int, int) - 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, byte[], int, int) - Method in class org.jgroups.demos.PubClient
- receive(Address, byte[], int, int) - Method in class org.jgroups.demos.PubServer
- receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.FD_SOCK2
- 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(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, DataInput) - Method in interface org.jgroups.blocks.cs.Receiver
-
Deprecated, for removal: This API element is subject to removal in a future version.
- receive(Address, DataInput, int) - Method in class org.jgroups.blocks.cs.BaseServer
- receive(Address, DataInput, int) - Method in interface org.jgroups.blocks.cs.Receiver
-
Receive data from the given sender
- receive(Address, DataInput, int) - Method in class org.jgroups.demos.PubClient
- receive(Address, DataInput, int) - Method in class org.jgroups.demos.PubServer
- receive(Address, DataInput, int) - Method in class org.jgroups.protocols.FD_SOCK2
- receive(Address, DataInput, int) - Method in class org.jgroups.protocols.TP
- receive(Address, DataInput, int) - Method in class org.jgroups.stack.GossipRouter
- receive(Address, DataInput, int) - Method in class org.jgroups.stack.RouterStub
- receive(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
-
Called by a
Connection
implementation when a message has been received - receive(Address, ByteBuffer) - Method in interface org.jgroups.blocks.cs.Receiver
-
Delivers a message from a given sender to the application
- receive(Address, ByteBuffer) - Method in class org.jgroups.demos.PubClient
- receive(Address, ByteBuffer) - Method in class org.jgroups.demos.PubServer
- receive(Address, ByteBuffer) - Method in class org.jgroups.stack.GossipRouter
- receive(Event) - Method in class org.jgroups.blocks.RequestCorrelator
-
Callback.
- receive(Message) - Method in class org.jgroups.blocks.ReplicatedTree
-
Callback.
- receive(Message) - Method in class org.jgroups.demos.Chat
- receive(Message) - Method in class org.jgroups.demos.Draw
- receive(Message) - Method in class org.jgroups.demos.RelayDemo
- receive(Message) - Method in class org.jgroups.protocols.relay.Bridge
- receive(Message) - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
- receive(Message) - Method in interface org.jgroups.Receiver
-
Called when a message is received.
- receive(Message) - Method in class org.jgroups.util.MyReceiver
- receive(GossipData) - Method in class org.jgroups.protocols.TUNNEL
- receive(GossipData) - Method in interface org.jgroups.stack.RouterStub.StubReceiver
- receive(MessageBatch) - Method in interface org.jgroups.Receiver
-
Called when a batch of messages is received
- receive_interfaces - Variable in class org.jgroups.protocols.MPING
-
List
of interfaces to receive multicasts on. - 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.MPING
- receive_on_all_interfaces - Variable in class org.jgroups.protocols.TP
- receive_req - Variable in class org.jgroups.protocols.RTTHeader
- 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.FRAG3.FragEntry
- received - Variable in class org.jgroups.protocols.pbcast.STABLE
- received - Variable in class org.jgroups.protocols.STATS
-
Maintains stats per receiver
- received(Address, int) - Method in class org.jgroups.protocols.MsgStats
- received(Message) - Method in class org.jgroups.protocols.MsgStats
- received(Message) - Method in class org.jgroups.protocols.STATS
- received(MessageBatch) - Method in class org.jgroups.protocols.MsgStats
- received(MessageBatch) - Method in class org.jgroups.protocols.STATS
- RECEIVED - Static variable in class org.jgroups.util.Rsp
-
Flag that represents whether the response was received
- received_bcasts - Variable in class org.jgroups.protocols.SEQUENCER
- received_forwards - Variable in class org.jgroups.protocols.SEQUENCER
- received_msgs - Variable in class org.jgroups.protocols.SEQUENCER2
- 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
- receiveOnAllInterfaces() - Method in class org.jgroups.protocols.TP
- receiveOnAllInterfaces(boolean) - Method in class org.jgroups.protocols.TP
- receiver - Variable in class org.jgroups.blocks.cs.BaseServer
- receiver - Variable in class org.jgroups.blocks.cs.TcpConnection
- receiver - Variable in class org.jgroups.blocks.MessageDispatcher
- receiver - Variable in class org.jgroups.JChannel
- receiver - Variable in class org.jgroups.protocols.BPING
- receiver - Variable in class org.jgroups.protocols.MPING
- receiver - Variable in class org.jgroups.stack.RouterStub
- receiver() - Method in class org.jgroups.blocks.cs.BaseServer
- receiver() - Method in class org.jgroups.stack.RouterStub
- receiver(Receiver) - Method in class org.jgroups.blocks.cs.BaseServer
- receiver(Receiver) - Method in class org.jgroups.JChannel
- receiver(RouterStub.StubReceiver) - Method in class org.jgroups.stack.RouterStub
- Receiver - Interface in org.jgroups.blocks.cs
-
Receiver interface to be used with
BaseServer
instances - Receiver - Interface in org.jgroups
-
Defines the callbacks that are invoked when messages, views etc are received
- Receiver(ThreadFactory) - Constructor for class org.jgroups.blocks.cs.TcpConnection.Receiver
- ReceiverAdapter - Class in org.jgroups.blocks.cs
-
An impl of
Receiver
. - ReceiverAdapter() - Constructor for class org.jgroups.blocks.cs.ReceiverAdapter
- ReceiverEntry(Table<Message>, short, Address) - Constructor for class org.jgroups.protocols.UNICAST3.ReceiverEntry
- receiveReq(long) - Method in class org.jgroups.protocols.RTTHeader
- 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).
- receiveView(View) - Method in class org.jgroups.blocks.RequestCorrelator
-
View received: mark all responses from members that are not in new_view as suspected
- receiving - Variable in class org.jgroups.blocks.cs.TcpConnection.Receiver
- RecommendedForUpgrade - Annotation Type in org.jgroups.annotations
-
Protocols annotated with this annotation should upgrade to a newer version (e.g.
- RECONCILE - org.jgroups.protocols.COUNTER.RequestType
- RECONCILE - org.jgroups.protocols.COUNTER.ResponseType
- 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_interval - Variable in class org.jgroups.protocols.TCPGOSSIP
- reconnect_interval - Variable in class org.jgroups.protocols.TUNNEL
- reconnect_interval - Variable in class org.jgroups.stack.RouterStubManager
- reconnectInterval() - Method in class org.jgroups.protocols.TCPGOSSIP
- reconnectInterval(long) - Method in class org.jgroups.protocols.TCPGOSSIP
- reconnector_task - Variable in class org.jgroups.stack.RouterStubManager
- reconnectorRunning() - Method in class org.jgroups.stack.RouterStubManager
- recorder - Variable in class org.jgroups.nio.MockSocketChannel
- recorder() - Method in class org.jgroups.nio.MockSocketChannel
- recorder(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
- RecurringTask(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit, boolean) - 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_buf_size - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK
- recv_buf_size - Variable in class org.jgroups.protocols.SimpleTCP
- recv_buf_size - Variable in class org.jgroups.stack.GossipRouter
- recv_history - Variable in class org.jgroups.protocols.RATE
- recv_table - Variable in class org.jgroups.protocols.UNICAST3
- recv_table_lock - Variable in class org.jgroups.protocols.UNICAST3
- recvBufferSize() - Method in class org.jgroups.stack.GossipRouter
- recvBufferSize(int) - Method in class org.jgroups.stack.GossipRouter
- RED - Class in org.jgroups.protocols
-
Implementation of Random Early Drop: messages are discarded when the bundler's queue in the transport nears exhaustion.
- RED - Static variable in class org.jgroups.stack.CheckForAbsenceOfRED
- RED() - Constructor for class org.jgroups.protocols.RED
- Ref<T> - Class in org.jgroups.util
-
Keeps a reference to another object
- Ref(T) - Constructor for class org.jgroups.util.Ref
- 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
- ReflectUtils - Class in org.jgroups.jmx
-
Methods to get/set attributes and invoke operations of a given instance.
- ReflectUtils() - Constructor for class org.jgroups.jmx.ReflectUtils
- refresh() - Method in class org.jgroups.protocols.relay.Topology
- refresh(String) - Method in class org.jgroups.protocols.relay.Topology
-
Refreshes the topology for a given site.
- refresh(String, boolean) - Method in class org.jgroups.protocols.relay.Topology
- REG - org.jgroups.util.MessageBatch.Mode
- 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(short, Supplier<? extends Message>) - Method in class org.jgroups.DefaultMessageFactory
- register(short, Supplier<? extends Message>) - Method in interface org.jgroups.MessageFactory
-
Registers a new creator of messages
- register(Object, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
- register(SelectableChannel, int, NioConnection) - Method in class org.jgroups.blocks.cs.NioBaseServer
- register(AsciiString, Address, SHARED_LOOPBACK) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
- REGISTER - org.jgroups.stack.GossipType
- register_shutdown_hook - Variable in class org.jgroups.protocols.FILE_PING
- registerChannel(JChannel, String) - Static method in class org.jgroups.util.Util
- registerChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Registers an already created channel with the given MBeanServer.
- 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, ObjectName, String, boolean) - Static method in class org.jgroups.jmx.JmxConfigurator
- 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
- registerShutdownHook() - Method in class org.jgroups.protocols.FILE_PING
- registerShutdownHook(boolean) - Method in class org.jgroups.protocols.FILE_PING
- registration - Variable in class org.jgroups.blocks.cs.NioBaseServer
- REGISTRATION - org.jgroups.stack.GossipRouter.DumpMessages
- 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
- rejection_policy - Variable in class org.jgroups.util.ThreadPool
- rel - Variable in class org.jgroups.protocols.relay.Bridge
- relay - Variable in class org.jgroups.demos.RelayDemo
- relay - Variable in class org.jgroups.protocols.relay.Bridge
- relay - Variable in class org.jgroups.protocols.relay.Relayer
- relay - Variable in class org.jgroups.protocols.relay.Route
- relay - Variable in class org.jgroups.protocols.relay.Topology
- relay() - Method in class org.jgroups.protocols.relay.Relayer
- RELAY - Class in org.jgroups.protocols.relay
- RELAY - Static variable in class org.jgroups.Global
- RELAY() - Constructor for class org.jgroups.protocols.relay.RELAY
- RELAY_CONFIG - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- relay_multicasts - Variable in class org.jgroups.protocols.relay.RELAY2
- relay_present - Variable in class org.jgroups.protocols.UNICAST3
- 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.
- RELAY2() - Constructor for class org.jgroups.protocols.relay.RELAY2
- relay3 - Variable in class org.jgroups.protocols.relay.Route
- RELAY3 - Class in org.jgroups.protocols.relay
-
Provides relaying of messages between autonomous sites.
Design: ./doc/design/RELAY2.txt and at https://github.com/belaban/JGroups/blob/master/doc/design/RELAY2.txt.
JIRA: https://issues.redhat.com/browse/JGRP-1433 - RELAY3() - Constructor for class org.jgroups.protocols.relay.RELAY3
- 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
-
Forwards to site 'to' via route 'gateway'.
- 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.RELAY
-
Number of messages relayed by the local SiteMaster to a remote SiteMaster
- relayed_time - Variable in class org.jgroups.protocols.relay.RELAY
-
Total time spent relaying messages from the local SiteMaster to remote SiteMasters (in ns)
- relayer - Variable in class org.jgroups.protocols.relay.RELAY
- Relayer - Class in org.jgroups.protocols.relay
-
Base class for all relayers
- Relayer(RELAY, Log) - Constructor for class org.jgroups.protocols.relay.Relayer
- Relayer2 - Class in org.jgroups.protocols.relay
-
Maintains bridges and routing table.
- Relayer2(RELAY2, Log) - Constructor for class org.jgroups.protocols.relay.Relayer2
- Relayer2.Bridge - Class in org.jgroups.protocols.relay
- Relayer3 - Class in org.jgroups.protocols.relay
-
Maintains bridges and routing table.
- Relayer3(RELAY, Log) - Constructor for class org.jgroups.protocols.relay.Relayer3
- RelayHeader - Class in org.jgroups.protocols.relay
- RelayHeader() - Constructor for class org.jgroups.protocols.relay.RelayHeader
- RelayHeader(byte) - Constructor for class org.jgroups.protocols.relay.RelayHeader
- RelayHeader(byte, Address, Address) - Constructor for class org.jgroups.protocols.relay.RelayHeader
- relayMulticasts() - Method in class org.jgroups.protocols.relay.RELAY2
- relayMulticasts(boolean) - Method in class org.jgroups.protocols.relay.RELAY2
- ReliableMulticast - Class in org.jgroups.protocols
-
Base class for reliable multicast protocols
- ReliableMulticast() - Constructor for class org.jgroups.protocols.ReliableMulticast
- ReliableMulticast.LastSeqnoResender - Class in org.jgroups.protocols
-
Class which is called by RetransmitTask to resend the last seqno sent (if resend_last_seqno is enabled)
- ReliableMulticast.RetransmitTask - Class in org.jgroups.protocols
-
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
- reload() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE.SSLContextReloader
- reload(boolean) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE.SSLContextReloader
- reload_threshold - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- ReloadingX509KeyManager - Class in org.jgroups.util
-
A
X509ExtendedKeyManager
which uses a @FileWatcher
to check for changes. - ReloadingX509KeyManager(FileWatcher, Path, Function<Path, X509ExtendedKeyManager>) - Constructor for class org.jgroups.util.ReloadingX509KeyManager
- ReloadingX509TrustManager - Class in org.jgroups.util
-
A
X509ExtendedTrustManager
which uses a @FileWatcher
to check for changes. - ReloadingX509TrustManager(FileWatcher, Path, Function<Path, X509ExtendedTrustManager>) - Constructor for class org.jgroups.util.ReloadingX509TrustManager
- reloadKeystoreAndTruststore() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- remaining() - Method in class org.jgroups.nio.Buffers
- remaining() - Method in class org.jgroups.util.BlockingInputStream
- remaining() - Method in class org.jgroups.util.PartialOutputStream
-
Number of bytes left to be written
- 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_sa - Variable in class org.jgroups.stack.RouterStub
- remoteAddress() - Method in interface org.jgroups.blocks.cs.Client
- remoteAddress() - Method in class org.jgroups.blocks.cs.NioClient
- remoteAddress() - Method in class org.jgroups.blocks.cs.TcpClient
- remoteAddress(IpAddress) - Method in class org.jgroups.blocks.cs.NioClient
-
Sets the address of the server.
- remoteAddress(IpAddress) - Method in class org.jgroups.blocks.cs.TcpClient
-
Sets the address of the server.
- removable - Variable in class org.jgroups.blocks.LazyRemovalCache.Entry
- remove() - Method in class org.jgroups.nio.Buffers.BuffersIterator
- remove() - Method in class org.jgroups.protocols.STOMP.Connection
- remove() - Method in class org.jgroups.util.Buffer
- remove() - Method in class org.jgroups.util.Digest.MyIterator
- remove() - Method in class org.jgroups.util.FastArray.FastIterator
- remove() - Method in class org.jgroups.util.FixedBuffer.FixedBufferIterator
- remove() - Method in class org.jgroups.util.Responses.PingDataIterator
- 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() - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Removes the next element (at hd +1).
- remove() - Method in class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- remove() - Method in class org.jgroups.util.SeqnoList.SeqnoListIterator
- remove() - Method in class org.jgroups.util.SizeBoundedQueue
-
Removes and returns the first element or null if the queue is empty
- remove() - Method in class org.jgroups.util.Table
- remove(boolean) - Method in class org.jgroups.util.Buffer
- remove(boolean) - Method in class org.jgroups.util.DynamicBuffer
-
Removes the next non-null element and nulls the index if nullify=true
- remove(boolean) - Method in class org.jgroups.util.FixedBuffer
-
Removes the next non-null element and advances hd
- remove(boolean) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Removes the next element (at hd +1).
- remove(boolean) - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Removes the next element (at hd +1).
- remove(boolean) - Method in class org.jgroups.util.Table
-
Removes the next non-null element and nulls the index if nullify=true
- remove(byte[]) - Method in class org.jgroups.util.ExtendedUUID
- remove(int) - Method in class org.jgroups.nio.Buffers
-
Nulls the buffer at index
- remove(int) - Method in class org.jgroups.util.FastArray
- remove(long) - Method in class org.jgroups.util.RequestTable
-
Removes the element at the index matching seqno.
- remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Removes the key (and its corresponding value) from this map.
- remove(Object) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- remove(Object) - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- 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) - Method in class org.jgroups.fork.ForkProtocolStack
- remove(String) - Method in class org.jgroups.protocols.FORK
- remove(String) - Method in class org.jgroups.util.ExtendedUUID
- remove(String, boolean) - Method in class org.jgroups.blocks.GridFilesystem
- remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Removes
key
from the node's hashmap - remove(String, Address) - Method in class org.jgroups.protocols.FILE_PING
- remove(String, Address) - Method in class org.jgroups.protocols.JDBC_PING
- remove(String, Address) - Method in class org.jgroups.protocols.JDBC_PING2
- remove(String, Address) - Method in class org.jgroups.protocols.RACKSPACE_PING
- remove(String, Address) - Method in class org.jgroups.protocols.SWIFT_PING
- remove(Collection<Address>) - Method in class org.jgroups.Membership
-
Removes all the members contained in v from this membership
- remove(Collection<R>) - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
Removes requests as long as they match - breaks at the first non-matching request or when requests is empty This method must catch all exceptions; or else process() might return without setting processing to true again!
- remove(List<Address>) - Method in class org.jgroups.util.ResponseCollector
- remove(K) - Method in class org.jgroups.blocks.Cache
- remove(K) - Method in class org.jgroups.blocks.LazyRemovalCache
- 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) - Method in class org.jgroups.util.AgeOutCache
- remove(K) - Method in class org.jgroups.util.ExpiryCache
- remove(K, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
- 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(Address) - Method in class org.jgroups.Membership
-
Removes a member from the membership.
- remove(Address) - Method in class org.jgroups.util.CreditMap
- remove(Address) - Static method in class org.jgroups.util.NameCache
- remove(Address) - Method in class org.jgroups.util.NonBlockingCreditMap
- remove(Address) - Method in class org.jgroups.util.ResponseCollector
- REMOVE_ADDRESS - Static variable in class org.jgroups.Event
- remove_all_data_on_view_change - Variable in class org.jgroups.protocols.FILE_PING
- remove_filter - Static variable in class org.jgroups.protocols.ReliableMulticast
- remove_filter - Variable in class org.jgroups.util.Buffer.Options
- remove_filter() - Method in class org.jgroups.util.Buffer.Options
- remove_from_batch - Variable in class org.jgroups.util.Buffer.Options
- remove_old_coords_on_view_change - Variable in class org.jgroups.protocols.FILE_PING
- remove_queue - Variable in class org.jgroups.protocols.BATCH2
- remove_queue - Variable in class org.jgroups.protocols.RemoveQueueBundler
- remove_queue - Variable in class org.jgroups.protocols.TransferQueueBundler
- remove_queue - Variable in class org.jgroups.protocols.TransferQueueBundler2
- removeAddressGenerator(AddressGenerator) - Method in class org.jgroups.JChannel
- removeAddressMapping(String, Address) - Method in class org.jgroups.stack.GossipRouter
- 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.JDBC_PING
- removeAll(String) - Method in class org.jgroups.protocols.JDBC_PING2
- removeAll(String) - Method in class org.jgroups.protocols.RACKSPACE_PING
- removeAll(String) - Method in class org.jgroups.protocols.SWIFT_PING
- removeAll(Collection<String>) - Method in class org.jgroups.protocols.relay.Topology
- removeAll(Collection<K>) - Method in class org.jgroups.blocks.LazyRemovalCache
- removeAll(Collection<K>) - Method in class org.jgroups.util.AgeOutCache
- removeAll(Collection<K>) - Method in class org.jgroups.util.ExpiryCache
- removeAll(Collection<K>, boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
- removeAll(Collection<Address>) - Static method in class org.jgroups.util.NameCache
- removeAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
- 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 !
- removeAllDataOnViewChange() - Method in class org.jgroups.protocols.FILE_PING
- removeAllDataOnViewChange(boolean) - Method in class org.jgroups.protocols.FILE_PING
- removeAllFlags() - Method in class org.jgroups.protocols.CLEAR_FLAGS
- removeAndDeliver(Buffer<Message>, Address, boolean, AsciiString) - Method in class org.jgroups.protocols.ReliableMulticast
-
Efficient way of checking whether another thread is already processing messages from sender.
- removeAndDeliver(Table<Message>, Address) - Method in class org.jgroups.protocols.SEQUENCER2
- removeAndDeliver(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.
- removeAndDeliver(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.
- removeAndDispatchNonBundledMessages(MessageBatch) - Method in class org.jgroups.util.SubmitToThreadPool
-
Removes messages with flags DONT_BUNDLE and OOB set and executes them in the oob or internal thread pool.
- removeCallback(StompConnection.ConnectionCallback) - Method in class org.jgroups.client.StompConnection
- removeCancelledTasks() - Method in interface org.jgroups.util.TimeScheduler
- removeCancelledTasks() - Method in class org.jgroups.util.TimeScheduler3
- removeCancelledTimerTasks() - Method in class org.jgroups.protocols.TP
- 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.JChannel
- removeConnectionIfPresent(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
-
Only removes the connection if conns.get(address) == conn
- removeConnectionListener(ConnectionListener) - Method in class org.jgroups.blocks.cs.BaseServer
- removeConnections(boolean, boolean) - Method in class org.jgroups.protocols.UNICAST3
-
Removes send- and/or receive-connections whose state is not OPEN (CLOSING or CLOSED).
- removeDownFilter(Predicate<Message>) - Method in class org.jgroups.protocols.DROP
- removedRoutes(View, View) - Static method in class org.jgroups.protocols.relay.Bridge
-
Returns a list of routes that were in old_view, but are no longer in new_view
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.jgroups.util.BoundedHashMap
- removeEntry(long) - Method in class org.jgroups.blocks.RequestCorrelator
- removeExpired() - Method in class org.jgroups.util.ThreadPool
- 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
- removeFilter(Predicate<Message>) - Method in class org.jgroups.util.Buffer.Options
- removeFlag(boolean, String) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- removeFlag(boolean, Message.Flag) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- removeFromAddressMappings(Address) - Method in class org.jgroups.stack.GossipRouter
- removeFromBatch() - Method in class org.jgroups.util.Buffer.Options
- removeFromBatch(boolean) - Method in class org.jgroups.util.Buffer.Options
- removeFromHead() - Method in class org.jgroups.util.BoundedList
- removeFromPingableMembers(Address) - Method in class org.jgroups.protocols.FD_SOCK
- removeFromViews(Address, JChannel...) - Static method in class org.jgroups.util.Util
- removeHigherThan(long) - Method in class org.jgroups.util.SeqnoList
-
Removes all seqnos > seqno
- removeIf(Predicate<Message>, boolean) - Method in class org.jgroups.util.MessageBatch
- removeIf(Predicate<T>, boolean) - Method in class org.jgroups.util.FastArray
- removeIgnoredMember(Address) - Method in class org.jgroups.protocols.DISCARD
- removeInitialHost(String, int) - Method in class org.jgroups.protocols.TCPGOSSIP
- removeKeysFromMessageAndInstall(Message, byte[]) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Removes the public and/or private keys from the payload of msg and installs them.
- removeListener(StompConnection.Listener) - Method in class org.jgroups.client.StompConnection
- removeLogicalAddressFromCache(Address) - Method in class org.jgroups.protocols.TP
- removeLowerThan(long) - Method in class org.jgroups.util.SeqnoList
-
Removes all seqnos < seqno
- removeMany(boolean, int) - Method in class org.jgroups.util.Buffer
- removeMany(boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- removeMany(boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoOld
- removeMany(boolean, int) - Method in class org.jgroups.util.Table
- removeMany(boolean, int, Predicate<T>) - Method in class org.jgroups.util.Buffer
- removeMany(boolean, int, Predicate<T>) - Method in class org.jgroups.util.DynamicBuffer
- removeMany(boolean, int, Predicate<T>) - Method in class org.jgroups.util.FixedBuffer
- removeMany(boolean, int, Predicate<T>) - Method in class org.jgroups.util.Table
- removeMany(boolean, int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Method in class org.jgroups.util.Buffer
- removeMany(boolean, int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Method in class org.jgroups.util.DynamicBuffer
-
Removes elements from the table and adds them to the result created by result_creator.
- removeMany(boolean, int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Method in class org.jgroups.util.FixedBuffer
- removeMany(boolean, int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Method in class org.jgroups.util.Table
-
Removes elements from the table and adds them to the result created by result_creator.
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- removeMany(AtomicBoolean, boolean, int) - Method in class org.jgroups.util.RingBufferSeqnoOld
- removeMany(LongStream, Consumer<T>) - Method in class org.jgroups.util.RequestTable
-
Removes all elements in the stream.
- removeMarkedElements() - Method in class org.jgroups.blocks.LazyRemovalCache
-
Removes elements marked as removable
- removeMarkedElements(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache
-
Removes elements marked as removable
- removeMembershipListener(Receiver) - Method in class org.jgroups.blocks.ReplCache
- removeNode(Object) - Method in class org.jgroups.demos.Topology
- removeNodeFromDisk(Address) - Method in class org.jgroups.protocols.PDC
- removeNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
- removeOldCoordsOnViewChange() - Method in class org.jgroups.protocols.FILE_PING
- removeOldCoordsOnViewChange(boolean) - Method in class org.jgroups.protocols.FILE_PING
- removePolicy(Policy) - Method in class org.jgroups.stack.Protocol
- removeProtocol(Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
- removeProtocol(Class<? extends Protocol>...) - Method in class org.jgroups.stack.ProtocolStack
- removeProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Removes a protocol from the stack.
- removeProtocol(T) - Method in class org.jgroups.stack.ProtocolStack
- removeProtocols(Class<? extends 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
- RemoveQueueBundler - Class in org.jgroups.protocols
-
Bundler implementation which sends message batches (or single messages) as soon as the remove queue is full (or max_bundler_size would be exceeded).
Messages are removed from the main queue and processed as follows (assuming they all fit into the remove queue):
A B B C C A causes the following sends: {AA} -> {CC} -> {BB}
Note that null is also a valid destination (send-to-all).
Contrary toTransferQueueBundler
, this bundler uses aRingBuffer
rather than an ArrayBlockingQueue and the size of the remove queue is fixed. - RemoveQueueBundler() - Constructor for class org.jgroups.protocols.RemoveQueueBundler
- removeQueueSize() - Method in class org.jgroups.protocols.TransferQueueBundler
- removeQueueSize() - Method in class org.jgroups.protocols.TransferQueueBundler2
- removeQueueSize(int) - Method in class org.jgroups.protocols.TransferQueueBundler2
- Remover(boolean, int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Constructor for class org.jgroups.util.Table.Remover
- Remover(int, Predicate<T>, Supplier<R>, BiConsumer<R, T>) - Constructor for class org.jgroups.util.Buffer.Remover
- 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
- removeResponse(String, RouterStub.MembersNotification) - Method in class org.jgroups.stack.RouterStub
- removeRoute(String) - Method in class org.jgroups.protocols.relay.Relayer
- removes_till_compaction - Variable in class org.jgroups.util.RequestTable
- removeSendConnection(Predicate<Address>) - Method in class org.jgroups.protocols.UNICAST3
- 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.FD_SOCK2.BroadcastTask
- removeSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- removeSuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- removeSuspectedMember(Address) - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
- removeTerminatedThreads() - Method in class org.jgroups.util.LazyThreadFactory
- removeUpFilter(Predicate<Message>) - Method in class org.jgroups.protocols.DROP
- renameThread() - Method in interface org.jgroups.protocols.Bundler
- renameThread() - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- renameThread() - Method in class org.jgroups.protocols.RemoveQueueBundler
- renameThread() - Method in class org.jgroups.protocols.RingBufferBundler
- renameThread() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- renameThread() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- renameThread() - Method in class org.jgroups.protocols.TransferQueueBundler
- renameThread() - Method in class org.jgroups.protocols.TransferQueueBundler2
- renameThread(String, Thread) - Method in class org.jgroups.util.DefaultThreadFactory
- renameThread(String, Thread) - Method in interface org.jgroups.util.ThreadFactory
- 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
- renameThreads() - Method in class org.jgroups.util.LazyThreadFactory
- reorderAndSend(List<Message>, Lock, Consumer<Message>) - Method in class org.jgroups.protocols.SHUFFLE
- replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(T) - Method in class org.jgroups.util.FastArray.FastIterator
- replaceConnection(Address, Connection) - Method in class org.jgroups.blocks.cs.BaseServer
- replaceIf(Predicate<T>, T, boolean) - Method in class org.jgroups.util.FastArray
-
Replaces any or all elements matching filter with a new element
- replaceProtocol(Protocol, Protocol) - Method in class org.jgroups.stack.ProtocolStack
-
Replaces one protocol instance with another.
- replaceVariables(InputStream, OutputStream, Properties) - Static method in class org.jgroups.util.PropertiesToAsciidoc
-
Reads from the input stream and replaces occurrences of ${PROT} with p.get("PROT") and writes this to the output stream.
- 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() - Method in class org.jgroups.protocols.RATE_LIMITER2
- replenish(Address, long) - Method in class org.jgroups.protocols.MFC
- replenish(Address, long) - Method in class org.jgroups.util.CreditMap
- replenish(Address, long) - Method in class org.jgroups.util.NonBlockingCreditMap
- REPLENISH - Static variable in class org.jgroups.protocols.FcHeader
- 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(ConcurrentMap<K, V>, JChannel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Constructs a new ReplicatedHashMap using provided map instance.
- ReplicatedHashMap(JChannel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Constructs a new ReplicatedHashMap with channel.
- 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() - Constructor for class org.jgroups.blocks.ReplicatedTree
- 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(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 - Variable in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
- REQ - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
- REQ - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
- REQ - Static variable in class org.jgroups.protocols.TpHeader
- req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
- req_handler - Variable in class org.jgroups.protocols.FD_SOCK2
- 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_matcher - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- REQ_ONLY - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
- req_processor - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- req_up_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- reqMatcher() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- reqMatcher(BiPredicate<R, R>) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- reqProcessor() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- reqProcessor(Consumer<Collection<R>>) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- Request<T> - Class in org.jgroups.blocks
-
Abstract class for a unicast or multicast request
- Request(int) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl.Request
- Request(int, Address) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl.Request
- Request(int, Address, Map<Address, View>) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl.Request
- Request(RequestCorrelator, RequestOptions) - Constructor for class org.jgroups.blocks.Request
- Request(FD_SOCK2.Request.Type, Address) - Constructor for class org.jgroups.protocols.FD_SOCK2.Request
- REQUEST - Static variable in class org.jgroups.protocols.COUNTER
- 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(Protocol, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
-
Constructor.
- 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
- requestFromDataInput(DataInput) - Static method in class org.jgroups.protocols.COUNTER
- RequestHandler - Interface in org.jgroups.blocks
- requestId() - Method in class org.jgroups.blocks.Request
- requestId() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- requestId(long) - Method in class org.jgroups.blocks.Request
- requestId(long) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- 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(RequestOptions) - 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(ResponseMode, long, boolean, RspFilter) - 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, Message.Flag...) - Constructor for class org.jgroups.blocks.RequestOptions
- requests - Variable in class org.jgroups.blocks.RequestCorrelator
-
The table of pending requests (keys=Long (request IDs), values=RequestEntry)
- requests - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- RequestTable<T> - Class in org.jgroups.util
-
Table for storing requests associated with monotonically increasing sequence numbers (seqnos).
- 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
- 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(Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- resend(Message) - Method in class org.jgroups.protocols.ReliableMulticast
- resend(Message) - Method in class org.jgroups.protocols.UNICAST3
- 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_PENDING_REQUESTS - org.jgroups.protocols.COUNTER.RequestType
- resend_task - Variable in class org.jgroups.protocols.RSVP
- resendLastSeqno(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- 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.FD_SOCK2.PingDest
- reset() - Method in class org.jgroups.protocols.MsgStats
- reset() - Method in class org.jgroups.protocols.pbcast.Leaver
-
Interrupts and stops the current leave process (if one is in progress).
- reset() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- reset() - Method in class org.jgroups.protocols.ReliableMulticast
- reset() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- reset() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- reset() - Method in interface org.jgroups.stack.MessageProcessingPolicy
-
To reset stats
- reset() - Method in class org.jgroups.util.ByteBufferOutputStream
- reset() - Method in class org.jgroups.util.Credit
-
Sets this credit to be done and releases all blocked threads.
- reset() - Method in class org.jgroups.util.CreditMap
-
Sets this credit to be done and releases all blocked threads.
- reset() - Method in class org.jgroups.util.InputStreamAdapter
- reset() - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- reset() - Method in class org.jgroups.util.MaxOneThreadPerSender
- reset() - Method in class org.jgroups.util.MessageBatch
- reset() - Method in class org.jgroups.util.MyReceiver
- reset() - Method in class org.jgroups.util.NonBlockingCredit
- reset() - Method in class org.jgroups.util.NonBlockingCreditMap
- reset() - Method in class org.jgroups.util.Profiler
- reset() - Method in class org.jgroups.util.Promise
-
Causes all waiting threads to return
- reset() - Method in class org.jgroups.util.ResponseCollector
- reset() - Method in class org.jgroups.util.RpcStats
- reset(boolean) - Method in class org.jgroups.util.Promise
- reset(Collection<Address>) - Method in class org.jgroups.util.AckCollector
- reset(Collection<Address>) - Method in class org.jgroups.util.ResponseCollector
- reset(Collection<Address>, Collection<Address>) - Method in class org.jgroups.util.AckCollector
- reset(Collection<Address>, Address...) - Method in class org.jgroups.util.AckCollector
- reset(Address...) - Method in class org.jgroups.util.ResponseCollector
- resetAllStats() - Method in class org.jgroups.JChannelProbeHandler
- resetCacheAddresses(boolean, boolean) - Static method in class org.jgroups.util.Util
- resetConnectResult() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- 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
- resetPingableMembers(Collection<Address>) - Method in class org.jgroups.protocols.FD_SOCK
- resetStatistics() - Method in class org.jgroups.stack.Protocol
- resetStats() - Method in class org.jgroups.protocols.AlternatingBundler
- resetStats() - Method in class org.jgroups.protocols.BaseBundler
- resetStats() - Method in class org.jgroups.protocols.BATCH
- resetStats() - Method in class org.jgroups.protocols.BATCH2
- resetStats() - Method in class org.jgroups.protocols.BatchBundler
- resetStats() - Method in interface org.jgroups.protocols.Bundler
- resetStats() - Method in class org.jgroups.protocols.COMPRESS
- resetStats() - Method in class org.jgroups.protocols.DAISYCHAIN
- resetStats() - Method in class org.jgroups.protocols.DISCARD
- resetStats() - Method in class org.jgroups.protocols.Discovery
- resetStats() - Method in class org.jgroups.protocols.FailureDetection
- 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.FD_SOCK2
- 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.FRAG3
- resetStats() - Method in class org.jgroups.protocols.Fragmentation
- resetStats() - Method in interface org.jgroups.protocols.LocalTransport
- resetStats() - Method in class org.jgroups.protocols.MFC
- resetStats() - Method in class org.jgroups.protocols.NAKACK4
- resetStats() - Method in class org.jgroups.protocols.pbcast.GMS
- 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.PerDestinationBundler
- resetStats() - Method in class org.jgroups.protocols.PERF
- resetStats() - Method in class org.jgroups.protocols.RATE_LIMITER
- resetStats() - Method in class org.jgroups.protocols.RATE_LIMITER2
- resetStats() - Method in class org.jgroups.protocols.RATE
- resetStats() - Method in class org.jgroups.protocols.RED
- resetStats() - Method in class org.jgroups.protocols.relay.RELAY
- resetStats() - Method in class org.jgroups.protocols.ReliableMulticast
- resetStats() - Method in class org.jgroups.protocols.RemoveQueueBundler
- 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.THREAD_COUNT
- resetStats() - Method in class org.jgroups.protocols.TIME
- resetStats() - Method in class org.jgroups.protocols.TP
- resetStats() - Method in class org.jgroups.protocols.TransferQueueBundler
- resetStats() - Method in class org.jgroups.protocols.TransferQueueBundler2
- resetStats() - Method in class org.jgroups.protocols.UFC
- resetStats() - Method in class org.jgroups.protocols.UNICAST3
- resetStats() - Method in class org.jgroups.stack.Protocol
- resetStats() - Method in class org.jgroups.util.AsyncExecutor
- resetStats() - Method in class org.jgroups.util.Buffer
- resetStats() - Method in class org.jgroups.util.Credit
- resetStats() - Method in class org.jgroups.util.CreditMap
- resetStats() - Method in class org.jgroups.util.DynamicBuffer
- resetStats() - Method in class org.jgroups.util.FixedBuffer
- resetStats() - Method in class org.jgroups.util.NonBlockingCredit
- resetStats() - Method in class org.jgroups.util.NonBlockingCreditMap
- resetStats() - Method in class org.jgroups.util.Table
- resetStats() - Method in class org.jgroups.util.ThreadPool
- resetThreadDumps() - Method in class org.jgroups.util.ThreadPool
-
Deprecated.
- resize(int) - Method in class org.jgroups.util.ExtendedUUID
- resize(int) - Method in class org.jgroups.util.FastArray
- resize(int) - Method in class org.jgroups.util.MessageBatch
- resize(int) - Method in class org.jgroups.util.Responses
- resize(long) - Method in class org.jgroups.util.DynamicBuffer
-
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(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_factor - Variable in class org.jgroups.util.DynamicBuffer
- resize_factor - Variable in class org.jgroups.util.Table
- resolveAEntries(String) - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- resolveAEntries(String, String) - Method in class org.jgroups.protocols.dns.AddressedDNSResolver
- resolveAEntries(String, String) - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- resolveAndAssignField(Object, Field, Map<String, String>, StackType) - Static method in class org.jgroups.stack.Configurator
- resolveAndAssignFields(Object, Map<String, String>, StackType) - Static method in class org.jgroups.stack.Configurator
- resolveAndInvokePropertyMethod(Object, Method, Map<String, String>, StackType) - Static method in class org.jgroups.stack.Configurator
- resolveAndInvokePropertyMethods(Object, Map<String, String>, StackType) - Static method in class org.jgroups.stack.Configurator
- resolveClass(ObjectStreamClass) - Method in class org.jgroups.util.ObjectInputStreamWithClassloader
- resolveIps(String, DNSResolver.DNSRecordType) - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- resolveIps(String, DNSResolver.DNSRecordType) - Method in interface org.jgroups.protocols.dns.DNSResolver
- resolveRemoteAddress() - Method in class org.jgroups.stack.RouterStub
-
Creates remote from remote_sa.
- resolveSRVEntries(String) - Method in class org.jgroups.protocols.dns.DefaultDNSResolver
- 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(Object, Predicate<AccessibleObject>) - 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 - Interface in org.jgroups.blocks
-
A handback object shipped as a parameter to
RequestHandler.handle(Message,Response)
. - RESPONSE - Static variable in class org.jgroups.protocols.COUNTER
- 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() - Constructor for class org.jgroups.util.ResponseCollector
- ResponseCollector(Collection<Address>) - Constructor for class org.jgroups.util.ResponseCollector
- ResponseCollector(Address...) - 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
- responseFromDataInput(DataInput) - 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
- 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.UnicastRequest
- responseToBuffer(COUNTER.Response<?>) - Static method in class org.jgroups.protocols.COUNTER
- result - Variable in class org.jgroups.protocols.COUNTER.ValueResponse
- result - Variable in class org.jgroups.util.Buffer.Remover
- result - Variable in class org.jgroups.util.Promise
- result - Variable in class org.jgroups.util.Table.Remover
- Result() - Constructor for class org.jgroups.util.RpcStats.Result
- result_accumulator - Variable in class org.jgroups.util.Buffer.Remover
- result_accumulator - Variable in class org.jgroups.util.Table.Remover
- result_creator - Variable in class org.jgroups.util.Buffer.Remover
- result_creator - Variable in class org.jgroups.util.Table.Remover
- resume() - Method in class org.jgroups.protocols.pbcast.STABLE
- resume() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- 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
- 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<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.blocks.cs.BaseServer
-
Removes all connections which are not in current_mbrs
- retainAll(Collection<Address>) - Method in class org.jgroups.Membership
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.BasicTCP
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.RSVP.Entry
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP_NIO2
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP
- retainAll(Collection<Address>) - Method in class org.jgroups.util.AckCollector
- retainAll(Collection<Address>) - Static method in class org.jgroups.util.NameCache
- retainAll(Collection<Address>) - Method in class org.jgroups.util.RpcStats
- retainAll(Collection<T>) - Method in class org.jgroups.util.ProcessingQueue
- retainAll(Collection<T>) - Method in class org.jgroups.util.SuppressCache
- retainAll(List<Address>) - Method in class org.jgroups.util.ResponseCollector
- retainAll(List<Address>) - Method in class org.jgroups.util.ResponseCollectorTask
- retainKeys(List<Address>) - Method in class org.jgroups.protocols.FailureDetection
- retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- 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(SeqnoList, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- retransmit(SeqnoList, Address, boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- retransmit(SeqnoList, Address, Address) - Method in class org.jgroups.protocols.UNICAST3
-
Sends a retransmit request to the given sender
- RetransmitTask() - Constructor for class org.jgroups.protocols.pbcast.NAKACK2.RetransmitTask
- RetransmitTask() - Constructor for class org.jgroups.protocols.ReliableMulticast.RetransmitTask
- RetransmitTask() - Constructor for class org.jgroups.protocols.UNICAST3.RetransmitTask
- return_entire_cache - Variable in class org.jgroups.protocols.Discovery
- return_entire_cache - Variable in class org.jgroups.protocols.relay.RelayHeader
- returnEntireCache() - Method in class org.jgroups.protocols.Discovery
- returnEntireCache() - Method in class org.jgroups.protocols.relay.RelayHeader
- returnEntireCache(boolean) - Method in class org.jgroups.protocols.Discovery
- returnEntireCache(boolean) - Method in class org.jgroups.protocols.relay.RelayHeader
- reuse_message_batches - Variable in class org.jgroups.protocols.ReliableMulticast
- reuseMessageBatches() - Method in class org.jgroups.protocols.ReliableMulticast
- reuseMessageBatches(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- REVERSE - Class in org.jgroups.protocols
-
Reverses the next N messages that are received.
- REVERSE() - Constructor for class org.jgroups.protocols.REVERSE
- 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>) - Constructor for class org.jgroups.util.RingBuffer
- RingBuffer(Class<T>, int) - Constructor for class org.jgroups.util.RingBuffer
- RingBufferBundler - Class in org.jgroups.protocols
-
Bundler which uses
RingBuffer
to store messages. - RingBufferBundler() - Constructor for class org.jgroups.protocols.RingBufferBundler
- RingBufferBundler(int) - Constructor for class org.jgroups.protocols.RingBufferBundler
- RingBufferBundler(RingBuffer<Message>) - 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(AtomicReferenceArray<T>) - Constructor for class org.jgroups.util.RingBufferSeqnoLockless.RingBufferIterator
- RingBufferIterator(T[]) - Constructor for class org.jgroups.util.RingBufferSeqnoOld.RingBufferIterator
- 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
- RingBufferSeqnoOld<T> - Class in org.jgroups.util
-
Ring buffer, implemented with a circular array.
- RingBufferSeqnoOld(int, long) - Constructor for class org.jgroups.util.RingBufferSeqnoOld
-
Creates a RingBuffer
- RingBufferSeqnoOld.RingBufferIterator - Class in org.jgroups.util
- ringBufferSize() - Method in class org.jgroups.protocols.RemoveQueueBundler
- root_dir - Variable in class org.jgroups.protocols.FILE_PING
- root_dir - Variable in class org.jgroups.protocols.PDC
- ROOT_PACKAGE - Static variable in class org.jgroups.util.PropertiesToAsciidoc
- route(String, Address, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
- route(String, Address, ByteBuffer) - Method in class org.jgroups.stack.GossipRouter
- route(Message, Collection<String>) - Method in class org.jgroups.protocols.relay.RELAY3
-
Sends a message to the given sites, or all sites (excluding the local site)
- 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, RELAY, Log) - Constructor for class org.jgroups.protocols.relay.Route
- route_cache - Variable in class org.jgroups.protocols.relay.StickySiteMasterPicker
- route_status_listener - Variable in class org.jgroups.protocols.relay.RELAY
- RouterStub - Class in org.jgroups.stack
-
Client stub that talks to a remote GossipRouter via blocking or non-blocking TCP
- RouterStub(InetSocketAddress, InetSocketAddress, boolean, RouterStub.CloseListener, SocketFactory) - Constructor for class org.jgroups.stack.RouterStub
- RouterStub(InetSocketAddress, InetSocketAddress, boolean, RouterStub.CloseListener, SocketFactory, int) - Constructor for class org.jgroups.stack.RouterStub
- RouterStub(InetSocketAddress, InetSocketAddress, boolean, RouterStub.CloseListener, SocketFactory, int, boolean, int) - Constructor for class org.jgroups.stack.RouterStub
-
Creates a stub to a remote_sa
GossipRouter
. - 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(Log, TimeScheduler, String, Address, String, PhysicalAddress, long) - Constructor for class org.jgroups.stack.RouterStubManager
- 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
- routeThen(Message, List<String>, Supplier<Object>) - Method in class org.jgroups.protocols.relay.RELAY3
- routing_table - Static variable in class org.jgroups.protocols.SHARED_LOOPBACK
-
Map of cluster names and address-protocol mappings.
- row - Variable in class org.jgroups.util.DynamicBuffer.TableIterator
- row - Variable in class org.jgroups.util.Table.TableIterator
- 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(JChannel, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
- 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.RTTStat - Class in org.jgroups.util
- RpcStats.Type - Enum in org.jgroups.util
- Rsp<T> - Class in org.jgroups.util
-
Class that represents a response from a communication
- Rsp() - Constructor for class org.jgroups.util.Rsp
- Rsp(Throwable) - Constructor for class org.jgroups.util.Rsp
- Rsp(T) - Constructor for class org.jgroups.util.Rsp
- RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
- RSP - Static variable in class org.jgroups.protocols.RSVP.RsvpHeader
- RSP - Static variable in class org.jgroups.protocols.TpHeader
- rsp_dispatched - Variable in class org.jgroups.protocols.RTTHeader
- rsp_filter - Variable in class org.jgroups.blocks.RequestOptions
-
Allows for filtering of responses
- rsp_up_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- rspDispatched(long) - Method in class org.jgroups.protocols.RTTHeader
- rspExpected() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- rspFilter() - Method in class org.jgroups.blocks.RequestOptions
- rspFilter(RspFilter) - Method in class org.jgroups.blocks.RequestOptions
- 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(int) - Constructor for class org.jgroups.util.RspList
- RspList(Map<Address, Rsp<T>>) - Constructor for class org.jgroups.util.RspList
- rsps - Variable in class org.jgroups.blocks.GroupRequest
-
Correlates requests and responses
- RSVP - Class in org.jgroups.protocols
-
Protocol which implements synchronous messages (https://issues.redhat.com/browse/JGRP-1389).
- RSVP - org.jgroups.Message.Flag
- RSVP() - Constructor for class org.jgroups.protocols.RSVP
- RSVP_NB - org.jgroups.Message.Flag
- 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
- rtt - Variable in class org.jgroups.protocols.TP
- rtt() - Method in class org.jgroups.util.RTT
- rtt(int, boolean) - Method in class org.jgroups.util.RTT
-
Sends N requests to all members and computes RTTs
- rtt(int, int, boolean, boolean) - Method in class org.jgroups.util.RTT
-
Sends N requests to all members and computes RTTs
- RTT - Class in org.jgroups.util
-
Measures round-trip times (RTT) between nodes
- RTT() - Constructor for class org.jgroups.util.RTT
- RTT_ID - Static variable in class org.jgroups.protocols.RTTHeader
- rtt_stats - Variable in class org.jgroups.util.RpcStats
- RTTHeader - Class in org.jgroups.protocols
-
Header to measure round-trip times (in nanoseconds) for sync RPCs (https://issues.redhat.com/browse/JGRP-2604)
- RTTHeader() - Constructor for class org.jgroups.protocols.RTTHeader
- rtts - Variable in class org.jgroups.util.RTT
- RTTStat() - Constructor for class org.jgroups.util.RpcStats.RTTStat
- 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.TcpConnection.Receiver
- run() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- run() - Method in class org.jgroups.blocks.cs.TcpServer.Acceptor
- run() - Method in class org.jgroups.client.StompConnection
- run() - Method in class org.jgroups.demos.EchoServer.ConnectionHandler
- run() - Method in class org.jgroups.protocols.AlternatingBundler
- run() - Method in class org.jgroups.protocols.BATCH.FlushTask
- run() - Method in class org.jgroups.protocols.BatchBundler.FlushTask
- 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_HOST.PingTask
- 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.FD_SOCK2.BroadcastTask
- run() - Method in class org.jgroups.protocols.FILE_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.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.PerDestinationBundler.SendBuffer
- run() - Method in class org.jgroups.protocols.ReliableMulticast.RetransmitTask
- run() - Method in class org.jgroups.protocols.RemoveQueueBundler
- run() - Method in class org.jgroups.protocols.RSVP.ResendTask
- run() - Method in class org.jgroups.protocols.SEQUENCER.Flusher
- run() - Method in class org.jgroups.protocols.SimpleTCP.Acceptor
- run() - Method in class org.jgroups.protocols.SimpleTCP.Connection
- run() - Method in class org.jgroups.protocols.SOS.DumperTask
- run() - Method in class org.jgroups.protocols.STOMP.Connection
- run() - Method in class org.jgroups.protocols.STOMP
- run() - Method in class org.jgroups.protocols.TransferQueueBundler
- run() - Method in class org.jgroups.protocols.TransferQueueBundler2
- run() - Method in class org.jgroups.protocols.UDP.PacketReceiver
- 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.protocols.VERIFY_SUSPECT2
-
Started when a suspected member is added to suspects.
- run() - Method in class org.jgroups.stack.RouterStubManager
- run() - Method in class org.jgroups.util.AsyncExecutor.Task
- run() - Method in class org.jgroups.util.Delayer.Entry
- run() - Method in class org.jgroups.util.FileWatcher
- run() - Method in class org.jgroups.util.MaxOneThreadPerSender.BatchHandlerLoop
- run() - Method in class org.jgroups.util.Runner
- run() - Method in class org.jgroups.util.SubmitToThreadPool.BatchHandler
- run() - Method in class org.jgroups.util.SubmitToThreadPool.SingleLoopbackHandler
- run() - Method in class org.jgroups.util.SubmitToThreadPool.SingleMessageHandler
- 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
- runner - Variable in class org.jgroups.client.StompConnection
- runner - Variable in class org.jgroups.protocols.BATCH2
- runner - Variable in class org.jgroups.protocols.RemoveQueueBundler
- runner - Variable in class org.jgroups.protocols.SimpleTCP.Acceptor
- runner - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- runner - Variable in class org.jgroups.util.ResponseCollectorTask
- 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
- Runner - Class in org.jgroups.util
-
Runs a given function in a loop (in a separate thread) until it is stopped
- Runner(String, Runnable, Runnable) - Constructor for class org.jgroups.util.Runner
- Runner(ThreadFactory, String, Runnable, Runnable) - Constructor for class org.jgroups.util.Runner
- running - Variable in class org.jgroups.blocks.cs.BaseServer
- running - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- running - Variable in class org.jgroups.client.StompConnection
- running - Variable in class org.jgroups.demos.PubClient
- running - Variable in class org.jgroups.protocols.BATCH
- running - Variable in class org.jgroups.protocols.BATCH2
- running - Variable in class org.jgroups.protocols.BatchBundler
- 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.RATE_LIMITER2
- running - Variable in class org.jgroups.protocols.ReliableMulticast
- 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.TransferQueueBundler2
- running - Variable in class org.jgroups.protocols.UNICAST3
- running - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- running - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- running - Variable in class org.jgroups.stack.GossipRouter
- running - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- running - Variable in class org.jgroups.util.RingBufferSeqnoLockless
- running - Variable in class org.jgroups.util.RingBufferSeqnoOld
- running - Variable in class org.jgroups.util.Runner
- running() - Method in class org.jgroups.blocks.cs.BaseServer
- running() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- running() - Method in class org.jgroups.stack.GossipRouter
- running() - Method in class org.jgroups.util.TimeService
- runTCP() - Method in class org.jgroups.stack.DiagnosticsHandler
- runUDP() - Method in class org.jgroups.stack.DiagnosticsHandler
S
- same_cluster - Variable in class org.jgroups.stack.DiagnosticsHandler
- sameCluster(String) - Method in class org.jgroups.protocols.TP
- sameCluster(Function<String, Boolean>) - 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
- sameMembers(View, View) - Static method in class org.jgroups.View
-
Checks if two views have the same members regardless of order.
- sameMembersOrdered(View, View) - Static method in class org.jgroups.View
-
Checks if two views have the same members observing order.
- sameSite(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY3
- sameViews(Collection<View>) - Static method in class org.jgroups.View
- sameViews(View...) - Static method in class org.jgroups.View
-
Returns true if all views are the same.
- sanitize(String) - Static method in class org.jgroups.conf.XmlConfigurator
-
Fixes errors like "/ >" with "/>"
- 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://issues.redhat.com/browse/JGRP-1061).
- sanityCheck(byte[], int, int) - Static method in class org.jgroups.util.BlockingInputStream
-
Verifies that length doesn't exceed a buffer's length
- sanityCheck(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Throws an exception if sanity check fails.
- saturation() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- saturation() - Method in class org.jgroups.util.RingBufferSeqnoOld
- sayName() - Static method in class org.jgroups.demos.JmxDemo
- SCALAR - org.jgroups.conf.AttributeType
- 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, boolean) - Method in interface org.jgroups.util.TimeScheduler
- schedule(Runnable, long, TimeUnit, boolean) - Method in class org.jgroups.util.TimeScheduler3
- 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, boolean) - Method in interface org.jgroups.util.TimeScheduler
- scheduleAtFixedRate(Runnable, long, long, TimeUnit, boolean) - Method in class org.jgroups.util.TimeScheduler3
- scheduleBarrierOpener() - Method in class org.jgroups.protocols.BARRIER
- scheduleRecurring(Runnable, TimeScheduler3.TaskType, long, long, TimeUnit, boolean) - Method in class org.jgroups.util.TimeScheduler3
- scheduleWithDynamicInterval(TimeScheduler.Task) - Method in interface org.jgroups.util.TimeScheduler
-
Schedule a task for execution at varying intervals.
- scheduleWithDynamicInterval(TimeScheduler.Task, boolean) - Method in interface org.jgroups.util.TimeScheduler
- scheduleWithDynamicInterval(TimeScheduler.Task, boolean) - Method in class org.jgroups.util.TimeScheduler3
-
Schedule a task for execution at varying intervals.
- 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, boolean) - Method in interface org.jgroups.util.TimeScheduler
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit, boolean) - Method in class org.jgroups.util.TimeScheduler3
- schema() - Method in annotation type org.jgroups.annotations.XmlInclude
- secondNibble(byte) - Static method in class org.jgroups.util.Bits
- secret_key - Variable in class org.jgroups.protocols.Encrypt
- secret_key_algorithm - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
- secret_key_algorithm - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- secret_key_length - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE
- SECRET_KEY_REQ - org.jgroups.protocols.DH_KEY_EXCHANGE.Type
- SECRET_KEY_REQ - org.jgroups.protocols.SSL_KEY_EXCHANGE.Type
- SECRET_KEY_RSP - org.jgroups.protocols.DH_KEY_EXCHANGE.Type
- SECRET_KEY_RSP - org.jgroups.protocols.SSL_KEY_EXCHANGE.Type
- secret_key_version - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- secretKey() - Method in class org.jgroups.protocols.Encrypt
- secure_random - Variable in class org.jgroups.protocols.Encrypt
- secureRandom() - Method in class org.jgroups.protocols.Encrypt
- secureRandom(SecureRandom) - Method in class org.jgroups.protocols.Encrypt
-
Allows callers to replace secure_random with impl of their choice, e.g.
- select_all_pingdata_sql - Variable in class org.jgroups.protocols.JDBC_PING
- select_all_pingdata_sql - Variable in class org.jgroups.protocols.JDBC_PING2
- selector - Variable in class org.jgroups.blocks.cs.NioBaseServer
- selectorOpen() - Method in class org.jgroups.blocks.cs.NioBaseServer
- send() - Method in class org.jgroups.blocks.cs.NioConnection
- send(byte[], int, int) - 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(byte[], int, int) - Method in class org.jgroups.blocks.cs.NioClient
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.NioConnection
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpClient
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpConnection
- send(byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- send(byte[], int, int) - Method in class org.jgroups.protocols.SimpleTCP.Connection
- send(Object, boolean) - Method in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
- send(Object, boolean) - Method in interface org.jgroups.blocks.Response
-
Sends a response, usually called from a thread spawned by
AsyncRequestHandler#handle(Message,Response)
- send(String) - Method in class org.jgroups.demos.PubClient
- send(String) - Method in class org.jgroups.demos.StompChat
- send(String, byte[]) - Method in class org.jgroups.client.StompConnection
- send(String, byte[], int, int) - Method in class org.jgroups.client.StompConnection
- 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(ByteBuffer) - Method in interface org.jgroups.blocks.cs.Client
-
Sends data to the remote server.
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.Connection
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.NioClient
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.NioConnection
-
Sends a message.
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpClient
- send(ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpConnection
- send(ByteBuffer, boolean) - Method in class org.jgroups.blocks.cs.NioConnection
- send(Address, byte[]) - Method in class org.jgroups.JChannel
-
Sends a message.
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.BaseServer
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.NioClient
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.cs.TcpClient
- send(Address, byte[], int, int) - Method in class org.jgroups.JChannel
-
Sends a message to a destination.
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP_NIO2
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
- send(Address, Object) - Method in class org.jgroups.JChannel
-
Helper method to create a Message with given parameters and invoke
JChannel.send(Message)
. - send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
- send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.NioClient
- send(Address, ByteBuffer) - Method in class org.jgroups.blocks.cs.TcpClient
- send(Address, Address, Message) - Method in class org.jgroups.protocols.relay.Route
- send(Address, Address, Message, Collection<String>) - Method in class org.jgroups.protocols.relay.Route
- send(Address, ByteArray) - Method in class org.jgroups.protocols.COUNTER
- send(Message) - Method in class org.jgroups.fork.ForkChannel
- send(Message) - Method in class org.jgroups.JChannel
-
Sends a message.
- send(Message) - Method in class org.jgroups.protocols.AsyncNoBundler
- send(Message) - Method in class org.jgroups.protocols.BaseBundler
- send(Message) - Method in class org.jgroups.protocols.BatchBundler
- send(Message) - Method in interface org.jgroups.protocols.Bundler
- send(Message) - Method in class org.jgroups.protocols.NoBundler
- send(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(Message) - Method in class org.jgroups.protocols.PerDestinationBundler
- send(Message) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- send(Message) - Method in class org.jgroups.protocols.RemoveQueueBundler
- 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.TransferQueueBundler
- send(Message) - Method in class org.jgroups.protocols.TransferQueueBundler2
- send(Message, boolean) - Method in class org.jgroups.blocks.RequestCorrelator.ResponseImpl
- send(Message, boolean) - Method in interface org.jgroups.blocks.Response
-
Similar to
Response.send(Object,boolean)
, but passes a message instead of an object. - send(Message, Buffer<Message>) - Method in class org.jgroups.protocols.NAKACK4
- send(Message, Buffer<Message>) - Method in class org.jgroups.protocols.ReliableMulticast
-
Adds the message to the sent_msgs table and then passes it down the stack.
- SEND - org.jgroups.protocols.STOMP.ClientVerb
- send_atomically - Variable in class org.jgroups.protocols.NAKACK4
- 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_buf_size - Variable in class org.jgroups.protocols.SimpleTCP
- send_cache_on_join - Variable in class org.jgroups.protocols.Discovery
- send_cond - Variable in class org.jgroups.protocols.SEQUENCER
- SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UnicastHeader3
- send_function - Variable in class org.jgroups.protocols.MFC_NB
- send_function - Variable in class org.jgroups.protocols.UFC_NB
- send_function - Variable in class org.jgroups.util.NonBlockingCredit
- send_function - Variable in class org.jgroups.util.NonBlockingCreditMap
- send_group_keys - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- send_heartbeat - Variable in class org.jgroups.stack.RouterStubManager
- send_history - Variable in class org.jgroups.protocols.RATE
- send_info - Variable in class org.jgroups.protocols.STOMP
- send_interfaces - Variable in class org.jgroups.protocols.MPING
-
List
of interfaces to send multicasts on. - 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_on_all_interfaces - Variable in class org.jgroups.protocols.MPING
-
If true, the transport should use all available interfaces to send multicast messages.
- SEND_OPTIONS - Static variable in class org.jgroups.protocols.NAKACK4
- send_own_state_on_merge - Variable in class org.jgroups.demos.Draw
- send_req - Variable in class org.jgroups.protocols.RTTHeader
- send_rsp - Variable in class org.jgroups.protocols.RTTHeader
- send_table - Variable in class org.jgroups.protocols.UNICAST3
- sendAck(Address, long, short, Address) - Method in class org.jgroups.protocols.UNICAST3
- sendAck(Address, Buffer<Message>) - Method in class org.jgroups.protocols.NAKACK4
- sendAck(Address, Buffer<Message>) - Method in class org.jgroups.protocols.ReliableMulticast
- sendAnycastRequest(Message, Collection<Address>) - Method in class org.jgroups.blocks.RequestCorrelator
- sendAtomically() - Method in class org.jgroups.protocols.NAKACK4
- sendAtomically(boolean) - Method in class org.jgroups.protocols.NAKACK4
- sendBatch(boolean) - Method in class org.jgroups.protocols.BATCH.Buffer
- sendBatch(boolean) - Method in class org.jgroups.protocols.BATCH2.Buffer
- sendBatch(boolean) - Method in class org.jgroups.protocols.BatchBundler.Buffer
- sendBatch(Address, FastArray<Message>) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- sendBuf() - Method in class org.jgroups.protocols.ReliableMulticast
- SendBuffer(Address) - Constructor for class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- 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() - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- sendBundledMessages() - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- sendBundledMessages() - Method in class org.jgroups.protocols.TransferQueueBundler2
- 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 ..
- sendCacheInformation() - Method in class org.jgroups.protocols.Discovery
- sendCacheOnJoin() - Method in class org.jgroups.protocols.Discovery
- sendCacheOnJoin(boolean) - Method in class org.jgroups.protocols.Discovery
- 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
- 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 !
- sendCreditRequestsIfNeeded() - Method in class org.jgroups.protocols.MFC_NB
-
Checks the sent table: if some credits are in queueing mode and credits left are less than min_credits: send a credit request
- sendCreditRequestsIfNeeded() - Method in class org.jgroups.protocols.UFC_NB
-
Checks the sent table: if some credits are in queueing mode and credits left are less than min_credits: send a credit request
- sendDiscoveryRequest(String, List<Address>, boolean) - Method in class org.jgroups.protocols.PING
- sendDiscoveryRequest(Message) - Method in class org.jgroups.protocols.dns.DNS_PING
- sendDiscoveryRequest(Message) - Method in class org.jgroups.protocols.TCPPING
- sendDiscoveryResponse(List<PingData>, Address) - Method in class org.jgroups.protocols.Discovery
- 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.BaseMessage
- sender - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- sender - Variable in class org.jgroups.protocols.NakAckHeader
- sender - Variable in class org.jgroups.protocols.pbcast.MergeData
- sender - Variable in class org.jgroups.protocols.PingData
- sender - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- 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(ThreadFactory) - Constructor for class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- SenderEntry(short) - Constructor for class org.jgroups.protocols.UNICAST3.SenderEntry
- senderRunning() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- SenderSendsBundler - Class in org.jgroups.protocols
- SenderSendsBundler() - Constructor for class org.jgroups.protocols.SenderSendsBundler
- 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
- sendHeartbeat() - Method in class org.jgroups.stack.RouterStubManager
- 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
- sendInfoMessage(PingData) - Method in class org.jgroups.protocols.MERGE3
- sendJoinRejectionMessage(Address, String) - Method in class org.jgroups.protocols.AUTH
- sendJoinResponse(JoinRsp, Address) - Method in class org.jgroups.protocols.pbcast.GMS
- sendJoinResponse(ByteArray, Address) - Method in class org.jgroups.protocols.pbcast.GMS
- sendJoinResponses(JoinRsp, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
- sendLeaveRequest(Address, Address) - Method in class org.jgroups.protocols.pbcast.Leaver
- 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 our port number.
- 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
- sendMemberUnreachableTo(Address, Address) - Method in class org.jgroups.protocols.relay.RELAY3
-
Sends a MBR-UNREACHABLE message to the sender of a unicast message
- 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
- sendMergeResponse(Address, View, Digest, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
Send back a response containing view and digest to sender
- sendMergeView(Collection<Address>, MergeData, MergeId) - Method in class org.jgroups.protocols.pbcast.Merger
-
Sends the new view and digest to all subgroup coordinators.
- sendMessage(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- sendMessage(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
-
Sends a unicast message and - depending on the options - returns a result
- sendMessageList(Address, Address, List<Message>) - Method in class org.jgroups.protocols.BaseBundler
- sendMessageList(Address, Address, List<Message>) - Method in class org.jgroups.protocols.RemoveQueueBundler
- sendMessageList(Address, Address, Message[], int) - Method in class org.jgroups.protocols.BatchBundler.Buffer
- sendMessageList(Address, Address, FastArray<Message>) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- sendMessages(Address, Address, FastArray<Message>) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- 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
- sendMulticastRequest(Collection<Address>, Message, Request<T>, RequestOptions) - Method in class org.jgroups.blocks.RequestCorrelator
-
Sends a request to a group.
- sendOptions() - Method in class org.jgroups.protocols.NAKACK4
- sendOptions() - Method in class org.jgroups.protocols.ReliableMulticast
- 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
- sendRejectionMessage(byte, Address, String) - Method in class org.jgroups.protocols.AUTH
- sendReply(Message, long, Object, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- sendReq(long) - Method in class org.jgroups.protocols.RTTHeader
- sendRequest(Address, COUNTER.Request) - Method in class org.jgroups.protocols.COUNTER
- sendRequest(Message) - Method in class org.jgroups.blocks.GroupRequest
- sendRequest(Message) - Method in class org.jgroups.blocks.Request
- sendRequest(Message) - Method in class org.jgroups.blocks.UnicastRequest
- sendRequest(Message, Collection<Address>) - Method in class org.jgroups.blocks.GroupRequest
- sendRequestForFirstSeqno(Address, Address) - Method in class org.jgroups.protocols.UNICAST3
- sendResponse(DatagramSocket, SocketAddress, byte[]) - Method in class org.jgroups.stack.DiagnosticsHandler
- sendResponse(Address, short) - Method in class org.jgroups.protocols.RSVP
- sendResponse(Address, COUNTER.Response<?>) - Method in class org.jgroups.protocols.COUNTER
- sendResponse(Message, long, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- sendResponsesForAllSites(Address) - Method in class org.jgroups.protocols.relay.RELAY3
- sendResponseTo(Address, boolean) - Method in class org.jgroups.protocols.relay.RELAY3
-
Returns information about all members of all sites, or only the local members of a given site
- sendRsp(long) - Method in class org.jgroups.protocols.RTTHeader
- sends_can_block - Variable in class org.jgroups.protocols.Discovery
- sends_can_block - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- sends_can_block - Variable in class org.jgroups.protocols.ReliableMulticast
- sends_can_block - Variable in class org.jgroups.protocols.UNICAST3
- sendsCanBlock() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- sendsCanBlock() - Method in class org.jgroups.protocols.ReliableMulticast
- sendsCanBlock() - Method in class org.jgroups.protocols.UNICAST3
- sendsCanBlock(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- sendsCanBlock(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- sendsCanBlock(boolean) - Method in class org.jgroups.protocols.UNICAST3
- sendSeqnoRequest(int) - Method in class org.jgroups.protocols.SEQUENCER2
- sendSeqnoResponse(Address, long, int) - Method in class org.jgroups.protocols.SEQUENCER2
- sendSingleMessage(Address, Message) - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- sendSingleMessage(Message) - Method in class org.jgroups.protocols.BaseBundler
- sendSingleMessage(Message, ByteArrayDataOutputStream) - Method in class org.jgroups.protocols.NoBundler
- sendSiteUnreachableTo(Address, String) - Method in class org.jgroups.protocols.relay.RELAY2
-
Sends a SITE-UNREACHABLE message to the sender of the message.
- sendSiteUnreachableTo(Address, String) - Method in class org.jgroups.protocols.relay.RELAY3
-
Sends a SITE-UNREACHABLE message to the sender of the message.
- sendStabilityMessage(Digest, ViewId) - Method in class org.jgroups.protocols.pbcast.STABLE
-
Sends a stability message to all members except self.
- 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).
- sendSubscribe(String) - Method in class org.jgroups.client.StompConnection
- sendTo(String) - Method in class org.jgroups.demos.RelayDemo
- sendTo(Address, byte[], int, int) - Method in interface org.jgroups.protocols.LocalTransport
-
Sends a message to a given local member.
- sendTo(Address, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- sendTo(Address, byte[], int, int) - Method in class org.jgroups.protocols.SimpleTCP
- sendTo(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
- sendTo(Address, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
- SENDTO - Static variable in class org.jgroups.demos.RelayDemo
- sendToAll(byte[], int, int) - Method in class org.jgroups.blocks.cs.BaseServer
- sendToAll(byte[], int, int) - Method in interface org.jgroups.protocols.LocalTransport
-
Sends a message to all local members.
- sendToAll(byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- sendToAll(byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Fetches the physical addrs for all mbrs and sends the msg to each physical address.
- sendToAll(byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
- sendToAll(byte[], int, int) - Method in class org.jgroups.protocols.UDP
- sendToAll(ByteBuffer) - Method in class org.jgroups.blocks.cs.BaseServer
- sendToAllMembers(String, Address, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
- sendToAllMembers(String, Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
- sendToAllMembersInGroup(Set<Map.Entry<Address, GossipRouter.Entry>>, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
- sendToAllMembersInGroup(Set<Map.Entry<Address, GossipRouter.Entry>>, ByteBuffer) - Method in class org.jgroups.stack.GossipRouter
- sendToAllMembersInGroup(Set<Map.Entry<Address, GossipRouter.Entry>>, GossipData) - 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
- sendToLocalSiteMaster(Address, Message) - Method in class org.jgroups.protocols.relay.RELAY3
- sendToMember(String, Address, Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
- sendToMember(Address, byte[], int, int) - Method in class org.jgroups.stack.GossipRouter
- sendToMember(Address, ByteBuffer) - Method in class org.jgroups.stack.GossipRouter
- sendToMember(Address, GossipData) - Method in class org.jgroups.stack.GossipRouter
- sendTopoReq(JChannel, Address) - Method in class org.jgroups.protocols.relay.RELAY2
- sendToSingleMember(String, Address, Address, byte[], int, int) - Method in interface org.jgroups.protocols.TUNNEL.TUNNELPolicy
- sendUnicast(Address, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
- 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.SimpleTCP
- sendUnicast(PhysicalAddress, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Send a unicast to a 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(Message, Request<T>, RequestOptions) - Method in class org.jgroups.blocks.RequestCorrelator
-
Sends a request to a single destination
- sendUnsubscribe(String) - Method in class org.jgroups.client.StompConnection
- sendViewAck(Address) - Method in class org.jgroups.protocols.pbcast.GMS
- sendXmitRsp(Address, Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Sends a message msg to the requester.
- sendXmitRsp(Address, Message) - Method in class org.jgroups.protocols.ReliableMulticast
-
Sends a message msg to the requester.
- sent - Variable in class org.jgroups.protocols.STATS
-
Maintains stats per target destination
- sent - Variable in class org.jgroups.protocols.UFC
-
Map: keys are members, values are credits left.
- sent(Address, int) - Method in class org.jgroups.protocols.MsgStats
- sent(Message) - Method in class org.jgroups.protocols.MsgStats
- sent(Message) - Method in class org.jgroups.protocols.STATS
- 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.NakAckHeader
- seqno - Variable in class org.jgroups.protocols.ReliableMulticast
- 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.UnicastHeader3
- seqno(int) - Method in class org.jgroups.util.SeqnoList
- SEQNO_GETTER - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- SEQNO_GETTER - Variable in class org.jgroups.protocols.ReliableMulticast
- seqno_reqs - Variable in class org.jgroups.protocols.SEQUENCER2
- 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) - Constructor for class org.jgroups.util.SeqnoList
- SeqnoList(int, long) - Constructor for class org.jgroups.util.SeqnoList
-
Creates a SeqnoList with a capacity for size elements.
- SeqnoList.SeqnoListIterator - Class in org.jgroups.util
- SeqnoListIterator() - Constructor for class org.jgroups.util.SeqnoList.SeqnoListIterator
- seqnos - Variable in class org.jgroups.util.Digest
- 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() - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- SequencerHeader(byte) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
- SequencerHeader(byte) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- SequencerHeader(byte, long) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
- SequencerHeader(byte, long) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- SequencerHeader(byte, long, int) - Constructor for class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- serialize(long) - Method in class org.jgroups.protocols.RTTHeader
-
Since we don't know whether we're serializing a request or a response, the following happens: since the request is serialized _before_ the response, we check if
RTTHeader.serialize_req
is 0: if so we set it, otherwise we setRTTHeader.serialize_rsp
instead. - SERIALIZE - Class in org.jgroups.protocols
-
Serializes the entire message (including payload, headers, flags and destination and src) into the payload of another message that's then sent.
- SERIALIZE() - Constructor for class org.jgroups.protocols.SERIALIZE
- serialize_req - Variable in class org.jgroups.protocols.RTTHeader
- serialize_rsp - Variable in class org.jgroups.protocols.RTTHeader
- serialized - Variable in class org.jgroups.util.ObjectWrapperSerializable
- SERIALIZED - org.jgroups.Message.Flag
- serializedSize() - Method in class org.jgroups.BaseMessage
- serializedSize() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- serializedSize() - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
- serializedSize() - Method in class org.jgroups.MergeView
- serializedSize() - Method in class org.jgroups.NullAddress
- serializedSize() - Method in class org.jgroups.protocols.AuthHeader
- serializedSize() - Method in class org.jgroups.protocols.BATCH.BatchHeader
- serializedSize() - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- serializedSize() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- serializedSize() - Method in class org.jgroups.protocols.COUNTER.CounterHeader
- serializedSize() - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- serializedSize() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- serializedSize() - Method in class org.jgroups.protocols.EncryptHeader
- serializedSize() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
- serializedSize() - Method in class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- serializedSize() - Method in class org.jgroups.protocols.FcHeader
- serializedSize() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- serializedSize() - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- serializedSize() - Method in class org.jgroups.protocols.FORK.ForkHeader
- serializedSize() - Method in class org.jgroups.protocols.Frag3Header
- serializedSize() - Method in class org.jgroups.protocols.FragHeader
- serializedSize() - Method in class org.jgroups.protocols.MERGE3.MergeHeader
- serializedSize() - Method in class org.jgroups.protocols.NakAckHeader
- serializedSize() - Method in class org.jgroups.protocols.pbcast.DeltaView
- serializedSize() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- serializedSize() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- serializedSize() - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- serializedSize() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- serializedSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- serializedSize() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- serializedSize() - Method in class org.jgroups.protocols.PERF.PerfHeader
- serializedSize() - Method in class org.jgroups.protocols.PingData
- serializedSize() - Method in class org.jgroups.protocols.PingHeader
- serializedSize() - Method in class org.jgroups.protocols.ProtPerfHeader
- serializedSize() - Method in class org.jgroups.protocols.relay.RelayHeader
- serializedSize() - Method in class org.jgroups.protocols.relay.SiteUUID
- serializedSize() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- serializedSize() - Method in class org.jgroups.protocols.RTTHeader
- serializedSize() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- serializedSize() - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- serializedSize() - Method in class org.jgroups.protocols.STOMP.StompHeader
- serializedSize() - Method in class org.jgroups.protocols.TpHeader
- serializedSize() - Method in class org.jgroups.protocols.UnicastHeader3
- serializedSize() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- serializedSize() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- serializedSize() - Method in class org.jgroups.stack.GossipData
- serializedSize() - Method in class org.jgroups.stack.IpAddress
- serializedSize() - Method in class org.jgroups.util.ByteArray
- serializedSize() - Method in class org.jgroups.util.Digest
- serializedSize() - Method in class org.jgroups.util.ExtendedUUID
-
The number of bytes required to serialize this instance
- serializedSize() - Method in class org.jgroups.util.FlagsUUID
-
The number of bytes required to serialize this instance
- serializedSize() - Method in class org.jgroups.util.LongSizeStreamable
- serializedSize() - Method in class org.jgroups.util.ObjectWrapperPrimitive
- serializedSize() - Method in class org.jgroups.util.ObjectWrapperSerializable
- serializedSize() - Method in class org.jgroups.util.Range
- serializedSize() - Method in class org.jgroups.util.SeqnoList
- serializedSize() - Method in interface org.jgroups.util.SizeStreamable
-
Returns the size (in bytes) of the marshalled object
- serializedSize() - Method in class org.jgroups.util.UUID
- serializedSize() - Method in class org.jgroups.View
- serializedSize() - Method in class org.jgroups.ViewId
- serializedSize(boolean) - Method in class org.jgroups.util.Digest
- serializeKeys(Map<Address, byte[]>) - Static method in class org.jgroups.protocols.ASYM_ENCRYPT
- serializeKeys(ByteArrayDataOutputStream, boolean, Address) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Serializes all public keys and their corresponding encrypted shared group keys into a buffer
- 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.Connection
- server - Variable in class org.jgroups.demos.PubServer
- server - Variable in class org.jgroups.protocols.EncryptHeader
- server - Variable in class org.jgroups.protocols.TCP_NIO2
- server - Variable in class org.jgroups.stack.GossipRouter
- server() - Method in class org.jgroups.protocols.EncryptHeader
- server(boolean) - Method in class org.jgroups.protocols.PingData
- server(Address) - Method in class org.jgroups.protocols.EncryptHeader
- server_destinations - Variable in class org.jgroups.client.StompConnection
- server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
- server_ssl_ctx - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- server_ssl_ctx_reloader - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- serverAddress(Address) - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- ServerGmsImpl - Class in org.jgroups.protocols.pbcast
-
Common super class for CoordGmsImpl and ParticipantGmsImpl
- ServerGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ServerGmsImpl
- serverSocket - Variable in class org.jgroups.protocols.pbcast.STATE_SOCK.StateProviderAcceptor
- ServerSocketHandler() - Constructor for class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
- service_principal_name - Variable in class org.jgroups.auth.Krb5Token
- SERVICE_PRINCIPAL_NAME - Static 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() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
- 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 specifiedto
(inclusive) totrue
. - set(int, ByteBuffer) - Method in class org.jgroups.nio.Buffers
- set(int, Message) - Method in class org.jgroups.protocols.FRAG2.FragEntry
-
adds on fragmentation buffer to the message
- set(int, T) - Method in class org.jgroups.util.FastArray
- set(long) - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Sets the counter to a new value.
- set(long) - Method in interface org.jgroups.blocks.atomic.CounterView
-
Sets the counter's value.
- set(long) - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Sets the counter to a new value
- set(long) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
- set(long) - Method in class org.jgroups.protocols.COUNTER.VersionedValue
- 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(Address, long, long) - Method in class org.jgroups.util.MutableDigest
- set(Address, Address, Message[]) - Method in class org.jgroups.util.MessageBatch
- set(Membership) - Method in class org.jgroups.Membership
-
Clears the membership and adds all members of a given membership parameter.
- set(Message, Frag3Header) - Method in class org.jgroups.protocols.FRAG3.FragEntry
-
Adds a fragment to the full message
- set(Digest) - Method in class org.jgroups.util.MutableDigest
- set(T) - Method in class org.jgroups.util.Ref
- set(T[]) - Method in class org.jgroups.util.FastArray
- SET - org.jgroups.protocols.COUNTER.RequestType
- SET_DIGEST - 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
- setAckThreshold(int) - Method in class org.jgroups.protocols.UNICAST3
- setAddress() - Method in class org.jgroups.JChannel
-
Generates local_addr.
- 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
- setAddress(Address) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- setAddress(Address) - Method in class org.jgroups.protocols.DISCARD
- setAddress(Address) - Method in class org.jgroups.protocols.FORK
- setAddress(Address) - Method in class org.jgroups.protocols.TP
- setAddress(Address) - Method in class org.jgroups.stack.Protocol
- setAddress(Address) - Method in class org.jgroups.util.ThreadPool
- setAddressToLocalHost() - Method in class org.jgroups.stack.IpAddress
- setAnycasting(boolean) - Method in class org.jgroups.blocks.RequestOptions
- setArgs(Object...) - Method in class org.jgroups.blocks.MethodCall
- setArray(byte[]) - Method in interface org.jgroups.Message
- setArray(byte[], int, int) - Method in class org.jgroups.BatchMessage
- setArray(byte[], int, int) - Method in class org.jgroups.BytesMessage
-
Sets the internal array to point to a subset of a given array.
- setArray(byte[], int, int) - Method in class org.jgroups.CompositeMessage
- setArray(byte[], int, int) - Method in class org.jgroups.EmptyMessage
- setArray(byte[], int, int) - Method in class org.jgroups.LongMessage
- setArray(byte[], int, int) - Method in interface org.jgroups.Message
-
Sets the byte array in a message.
Throws an exception if the message does not have a byte[] array payload (Message.hasArray()
is false).
Note that this is a convenience method, as most messages are of typeBytesMessage
. - setArray(byte[], int, int) - Method in class org.jgroups.NioMessage
-
Sets the internal buffer to point to a subset of a given buffer.
- setArray(byte[], int, int) - Method in class org.jgroups.ObjectMessage
- setArray(ByteArray) - Method in class org.jgroups.BatchMessage
- setArray(ByteArray) - Method in class org.jgroups.BytesMessage
-
Sets the array
- setArray(ByteArray) - Method in class org.jgroups.CompositeMessage
- setArray(ByteArray) - Method in class org.jgroups.EmptyMessage
- setArray(ByteArray) - Method in class org.jgroups.LongMessage
- setArray(ByteArray) - Method in interface org.jgroups.Message
-
Sets the byte array in a message.
Throws an exception if the message does not have a byte[] array payload (Message.hasArray()
is false).
Note that this is a convenience method, as most messages are of typeBytesMessage
. - setArray(ByteArray) - Method in class org.jgroups.NioMessage
-
Sets the buffer
- setArray(ByteArray) - Method in class org.jgroups.ObjectMessage
- setAsyncExecutor(AsyncExecutor<Object>) - Method in class org.jgroups.protocols.TP
- setAsynDispatching(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- setAttribute(Attribute) - Method in class org.jgroups.jmx.ResourceDMBean
- setAttributes(Map<String, String>) - Method in class org.jgroups.conf.XmlNode
- 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
- setBecomeServerQueueSize(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setBecomeServerQueueSize(int) - Method in class org.jgroups.protocols.ReliableMulticast
- setBindAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
- setBindAddr(InetAddress) - Method in class org.jgroups.protocols.TP
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.FD_SOCK
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.FD_SOCK2
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.TP
- setBindAddress(InetAddress) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- setBindAddress(InetAddress) - Method in class org.jgroups.stack.DiagnosticsHandler
- setBindInterfaces(List<NetworkInterface>) - Method in class org.jgroups.stack.DiagnosticsHandler
- 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)
- setBuf(ByteBuffer) - Method in class org.jgroups.NioMessage
- setBufferedInputStreamSize(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
- setBufferedInputStreamSize(int) - Method in class org.jgroups.protocols.TCP
- setBufferedOutputStreamSize(int) - Method in class org.jgroups.blocks.cs.TcpBaseServer
- setBufferedOutputStreamSize(int) - Method in class org.jgroups.protocols.TCP
- setBufferSize(DatagramSocket, int, int) - Method in class org.jgroups.protocols.UDP
- setBundler(Bundler) - Method in class org.jgroups.protocols.TP
-
Installs a bundler
- setBundlerType(String) - Method in class org.jgroups.protocols.TP
- setBypassBundling(boolean) - Method in class org.jgroups.protocols.COUNTER
- setCacheMaxAge(long) - Method in class org.jgroups.protocols.FD_SOCK
- setCacheMaxElements(int) - Method in class org.jgroups.protocols.FD_SOCK
- setCachingTime(long) - Method in class org.jgroups.blocks.ReplCache
- setCallInsertSp(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setCallTimeout(long) - Method in class org.jgroups.blocks.ReplCache
- setCapacity(int) - Method in class org.jgroups.protocols.BaseBundler
- setCapacity(int) - Method in class org.jgroups.protocols.TransferQueueBundler2
- 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
- setChangeKeyOnCoordLeave(boolean) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- setChangeKeyOnLeave(boolean) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- setChannel(JChannel) - Method in class org.jgroups.blocks.atomic.CounterService
- setChannel(JChannel) - Method in class org.jgroups.blocks.MessageDispatcher
- setChannel(JChannel) - Method in class org.jgroups.stack.ProtocolStack
- setCheckInterval(long) - Method in class org.jgroups.protocols.MERGE3
- setCipherSuites(String[]) - Method in class org.jgroups.util.TLS
- setClearSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setClearSql(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setClientAuth(TLSClientAuth) - Method in class org.jgroups.util.TLS
- setClientBindAddr(InetAddress) - Method in class org.jgroups.protocols.BasicTCP
- setClientBindPort(int) - Method in class org.jgroups.protocols.BasicTCP
- setClientBindPort(int) - Method in class org.jgroups.protocols.FD_SOCK
- setClientBindPort(int) - Method in class org.jgroups.protocols.FD_SOCK2
- setClientSSLContext(SSLContext) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- 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.protocols.Discovery
- setClusterName(String) - Method in class org.jgroups.protocols.relay.config.RelayConfig.BridgeConfig
- 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
- setClusterName(AsciiString) - Method in class org.jgroups.util.MessageBatch
- setCommand(String) - Method in class org.jgroups.protocols.FD_HOST
- setCommand(String) - Method in class org.jgroups.protocols.SOS
- setConfig(String) - Method in class org.jgroups.protocols.FORK
- setConfig(String) - Method in class org.jgroups.protocols.relay.RELAY
- setConnCloseTimeout(long) - Method in class org.jgroups.protocols.UNICAST3
- setConnectionDriver(String) - Method in class org.jgroups.protocols.JDBC_PING
- setConnectionDriver(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setConnectionPassword(String) - Method in class org.jgroups.protocols.JDBC_PING
- setConnectionPassword(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setConnectionUrl(String) - Method in class org.jgroups.protocols.JDBC_PING
- setConnectionUrl(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setConnectionUsername(String) - Method in class org.jgroups.protocols.JDBC_PING
- setConnectionUsername(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setConnectResult(boolean) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- setConnExpireTime(long) - Method in class org.jgroups.protocols.BasicTCP
- setConnExpiryTimeout(long) - Method in class org.jgroups.protocols.UNICAST3
- setContainsSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setContext(SSLContext) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE.SSLContextReloader
- setCopyMulticastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
- setCopyUnicastMsgs(boolean) - Method in class org.jgroups.protocols.DUPL
- setCorrectSocketBufferSize(MulticastSocket, int, int, boolean, boolean) - Method in class org.jgroups.protocols.UDP
- setCorrelator(RequestCorrelator) - Method in class org.jgroups.blocks.MessageDispatcher
- setCustomLogFactory(CustomLogFactory) - Static method in class org.jgroups.logging.LogFactory
- setDataSource(DataSource) - Method in class org.jgroups.protocols.JDBC_PING
- setDataSource(DataSource) - Method in class org.jgroups.protocols.JDBC_PING2
- setDatasourceInjecterClass(String) - Method in class org.jgroups.protocols.JDBC_PING
- setDatasourceInjecterClass(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setDatasourceJndiName(String) - Method in class org.jgroups.protocols.JDBC_PING
- setDatasourceJndiName(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setDefaultAddressValues(Object, StackType) - Static method in class org.jgroups.stack.Configurator
- setDefaultAddressValues(List<Protocol>, StackType) - Static method in class org.jgroups.stack.Configurator
-
Processes fields and methods which are inet address related, and assigns them default values defined by (
Property.defaultValueIPv4()
andProperty.defaultValueIPv6()
). - setDefaultAddressValuesFields(Object, StackType, InetAddress) - Static method in class org.jgroups.stack.Configurator
- setDefaultAddressValuesMethods(Object, StackType, InetAddress) - Static method in class org.jgroups.stack.Configurator
- setDefaultReplicationCount(short) - Method in class org.jgroups.blocks.ReplCache
- setDeleteSingleSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setDeleteSingleSql(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setDeliveryTableMaxSize(int) - Method in class org.jgroups.protocols.SEQUENCER
- setDelta(int) - Method in class org.jgroups.util.ThreadPool
- setDesiredAverageGossip(long) - Method in class org.jgroups.protocols.pbcast.STABLE
- setDest(Address) - Method in class org.jgroups.BaseMessage
- setDest(Address) - Method in interface org.jgroups.Message
-
Sets the destination address to send the message to.
- setDest(Address) - Method in class org.jgroups.util.MessageBatch
- setDiagnosticsHandler(DiagnosticsHandler) - Method in class org.jgroups.protocols.TP
-
Sets a
DiagnosticsHandler
. - 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) - Method in class org.jgroups.protocols.ReliableMulticast
-
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.
- setDigest(Digest, boolean) - Method in class org.jgroups.protocols.ReliableMulticast
-
Sets or merges the digest.
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- setDiscardOwnMessages(boolean) - Method in class org.jgroups.JChannel
- setDNSQuery(String) - Method in class org.jgroups.protocols.dns.DNS_PING
- setDNSResolver(DNSResolver) - Method in class org.jgroups.protocols.dns.DNS_PING
- 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.blocks.MessageDispatcher.ProtocolAdapter
- setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
- setEnabled(boolean) - Method in class org.jgroups.protocols.RED
- setEnabled(boolean) - Method in class org.jgroups.stack.DiagnosticsHandler
- setErgonomics(boolean) - Method in class org.jgroups.stack.Protocol
- setException(Throwable) - Method in class org.jgroups.util.Rsp
- setExternalAddr(InetAddress) - Method in class org.jgroups.protocols.TP
- setExternalAddress(InetAddress) - Method in class org.jgroups.protocols.FD_SOCK
- setExternalAddress(InetAddress) - Method in class org.jgroups.protocols.FD_SOCK2
- setExternalPort(int) - Method in class org.jgroups.protocols.FD_SOCK
- setExternalPort(int) - Method in class org.jgroups.protocols.FD_SOCK2
- setExternalPort(int) - Method in class org.jgroups.protocols.TP
- setFactory(SslContextFactory) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE.SSLContextReloader
- setFailReason(String) - Method in class org.jgroups.protocols.pbcast.JoinRsp
- setField(Field, Object, Object) - Static method in class org.jgroups.util.Util
- setFileName(String) - Method in class org.jgroups.protocols.SOS
- setFinalDestination(Address) - Method in class org.jgroups.protocols.relay.RelayHeader
- setFinalizerTask(Consumer<ResponseCollectorTask<T>>) - Method in class org.jgroups.util.ResponseCollectorTask
- setFixedMembersSeparator(String) - Method in class org.jgroups.auth.FixedMembershipToken
- setFlag(byte, byte) - Static method in class org.jgroups.util.Util
- setFlag(short) - Method in class org.jgroups.util.FlagsUUID
- setFlag(short, boolean) - Method in interface org.jgroups.Message
-
Sets the flags as a short; this way, multiple flags can be set in one operation
- setFlag(short, boolean, boolean) - Method in class org.jgroups.BaseMessage
- setFlag(short, boolean, boolean) - Method in interface org.jgroups.Message
-
Sets the flags as a short; this way, multiple flags can be set in one operation
- setFlag(Message.Flag...) - Method in class org.jgroups.BaseMessage
-
Sets a number of flags in a message
- setFlag(Message.Flag...) - Method in class org.jgroups.BytesMessage
- setFlag(Message.Flag...) - Method in interface org.jgroups.Message
-
Sets one or more flags (xor-ing existing flags)
- setFlag(Message.TransientFlag...) - Method in class org.jgroups.BaseMessage
-
Same as
BaseMessage.setFlag(Flag...)
except that transient flags are not marshalled - setFlag(Message.TransientFlag...) - Method in interface org.jgroups.Message
-
Sets one or more transient flags (xor-ing).
- setFlagIfAbsent(Message.TransientFlag) - Method in class org.jgroups.BaseMessage
-
Atomically checks if a given flag is set and - if not - sets it.
- setFlagIfAbsent(Message.TransientFlag) - Method in interface org.jgroups.Message
-
Atomically sets a transient flag if not set.
- setFlags(short) - Method in class org.jgroups.blocks.RequestOptions
-
Not recommended as the internal representation of flags might change (e.g.
- setFlags(Message.Flag...) - Method in class org.jgroups.blocks.RequestOptions
- setFlushTimeout(long) - Method in class org.jgroups.protocols.BARRIER
- setForkChannelId(String) - Method in class org.jgroups.protocols.FORK.ForkHeader
- setForkStackId(String) - Method in class org.jgroups.protocols.FORK.ForkHeader
- setFragId(int) - Method in class org.jgroups.protocols.Frag3Header
- setFragSize(int) - Method in class org.jgroups.protocols.Fragmentation
- setGetCacheTimeout(long) - Method in class org.jgroups.protocols.FD_SOCK
- 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(ReplCache.HashFunction<K>) - Method in class org.jgroups.blocks.ReplCache
- setHashFunctionFactory(ReplCache.HashFunctionFactory<K>) - Method in class org.jgroups.blocks.ReplCache
- setHeader(Message) - Method in class org.jgroups.fork.ForkChannel
- setHighestDelivered(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
- setHighestDelivered(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
- 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.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
- setIncreaseMaxSizeDynamically(boolean) - Method in class org.jgroups.util.ThreadPool
- setInDelay(int) - Method in class org.jgroups.protocols.DELAY
- setInDelayNanos(int) - Method in class org.jgroups.protocols.DELAY
- setInfoWriterMaxWritesAfterView(int) - Method in class org.jgroups.protocols.FILE_PING
- setInfoWriterSleepTime(long) - Method in class org.jgroups.protocols.FILE_PING
- setInitialHosts(Collection<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPGOSSIP
- setInitialHosts(Collection<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPPING
- setInitialHosts(List<InetSocketAddress>) - Method in class org.jgroups.protocols.TCPGOSSIP
- setInitialHosts2(Collection<PhysicalAddress>) - Method in class org.jgroups.protocols.TCPPING
- setInitializeSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setInitializeSql(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setInsertSingleSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setInsertSingleSql(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setInsertSp(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setInterface(InetAddress, MulticastSocket) - Method in class org.jgroups.protocols.MPING
- setInterval(long) - Method in class org.jgroups.protocols.FailureDetection
- setInterval(long) - Method in class org.jgroups.protocols.FD_ALL3
- setInterval(long) - Method in class org.jgroups.protocols.SOS
- setIpTTL(int) - Method in class org.jgroups.protocols.UDP
- setJoinTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
- setJoinTimeout(long) - Method in class org.jgroups.util.Runner
- setKeepAliveTime(long) - Method in class org.jgroups.util.ThreadPool
- 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.TimeScheduler3
- setKeystore(KeyStore) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setKeystoreAlias(String) - Method in class org.jgroups.util.TLS
- setKeyStoreEntry(E) - Method in class org.jgroups.protocols.Encrypt
-
Sets the key store entry used to configure this protocol.
- setKeyStoreEntry(KeyStore.PrivateKeyEntry) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- setKeyStoreEntry(KeyStore.SecretKeyEntry) - Method in class org.jgroups.protocols.SYM_ENCRYPT
- setKeystoreName(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setKeystorePassword(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setKeystorePassword(String) - Method in class org.jgroups.util.TLS
- setKeyStorePassword(String) - Method in class org.jgroups.auth.X509Token
- setKeystorePath(String) - Method in class org.jgroups.util.TLS
- setKeystoreType(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setKeystoreType(String) - Method in class org.jgroups.util.TLS
- setL1Cache(Cache<K, V>) - Method in class org.jgroups.blocks.ReplCache
- setL2Cache(Cache<K, ReplCache.Value<V>>) - Method in class org.jgroups.blocks.ReplCache
- setLeaveTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
- 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.logging.Slf4jLogImpl
- setLevel(String) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setLevel(String) - Method in class org.jgroups.protocols.ReliableMulticast
- setLevel(String) - Method in class org.jgroups.protocols.TP
- setLevel(String) - Method in class org.jgroups.protocols.UNICAST3
- setLevel(String) - Method in class org.jgroups.stack.Protocol
-
Sets the level of a logger.
- setLinger(int) - Method in class org.jgroups.protocols.BasicTCP
- setLinger(int) - Method in class org.jgroups.protocols.FD_SOCK2
- setLinger(int) - Method in class org.jgroups.protocols.TUNNEL
- setLinger(int) - Method in class org.jgroups.stack.RouterStub
- setLocalAddress(Address) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- 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 interface org.jgroups.UpHandler
- setLocalTransport(String) - Method in class org.jgroups.protocols.TP
- setLocalTransport(LocalTransport) - Method in class org.jgroups.protocols.TP
- setLocation(String) - Method in class org.jgroups.protocols.FILE_PING
- setLogAcceptError(boolean) - Method in class org.jgroups.blocks.cs.TcpServer
- setLogCollectMessages(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- setLogDiscardMessages(boolean) - Method in class org.jgroups.protocols.TP
- setLogDiscardMessagesVersion(boolean) - Method in class org.jgroups.protocols.TP
- setLogicalAddrCacheExpiration(long) - Method in class org.jgroups.protocols.TP
- setLogicalAddrCacheMaxSize(int) - Method in class org.jgroups.protocols.TP
- setLogicalAddrCacheReaperInterval(long) - Method in class org.jgroups.protocols.TP
- setLogSuspectedMessages(boolean) - Method in class org.jgroups.protocols.FD_SOCK
- setMaxAge(int) - Method in class org.jgroups.demos.JmxDemo
- setMaxBlockTime(long) - Method in class org.jgroups.protocols.FlowControl
- setMaxBytes(long) - Method in class org.jgroups.protocols.pbcast.STABLE
- setMaxBytes(long) - Method in class org.jgroups.protocols.RATE_LIMITER
- setMaxCloseTime(long) - Method in class org.jgroups.protocols.BARRIER
- setMaxCompactionTime(long) - Method in class org.jgroups.util.DynamicBuffer
- setMaxCompactionTime(long) - Method in class org.jgroups.util.Table
- setMaxCredits(long) - Method in class org.jgroups.protocols.FlowControl
- setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE3
- setMaxJoinAttempts(int) - Method in class org.jgroups.protocols.pbcast.GMS
- setMaxLength(int) - Method in class org.jgroups.blocks.cs.BaseServer
- setMaxLength(int) - Method in class org.jgroups.protocols.BasicTCP
- setMaxNumberOfEntries(int) - Method in class org.jgroups.blocks.Cache
- setMaxParticipantsInMerge(int) - Method in class org.jgroups.protocols.MERGE3
- setMaxQueueSize(int) - Method in class org.jgroups.protocols.MFC_NB
- setMaxQueueSize(int) - Method in class org.jgroups.protocols.UFC_NB
- setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST3
- setMaxSendBuffers(int) - Method in class org.jgroups.protocols.TCP_NIO2
- setMaxSiteMasters(int) - Method in class org.jgroups.protocols.relay.RELAY
- setMaxSize(int) - Method in class org.jgroups.protocols.BaseBundler
- setMaxSize(int) - Method in class org.jgroups.protocols.BatchBundler
- setMaxSize(int) - Method in interface org.jgroups.protocols.Bundler
- setMaxSize(int) - Method in class org.jgroups.protocols.PerDestinationBundler
- setMaxSize(int) - Method in class org.jgroups.protocols.SHUFFLE
- setMaxSize(int) - Method in class org.jgroups.protocols.TransferQueueBundler2
- setMaxThreads(int) - Method in class org.jgroups.util.ThreadPool
- setMaxThreads(int) - Method in interface org.jgroups.util.TimeScheduler
-
Sets the max pool size.
- setMaxThreads(int) - Method in class org.jgroups.util.TimeScheduler3
- setMaxTime(long) - Method in class org.jgroups.protocols.SHUFFLE
- setMaxXmitReqSize(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setMaxXmitReqSize(int) - Method in class org.jgroups.protocols.ReliableMulticast
- setMaxXmitReqSize(int) - Method in class org.jgroups.protocols.UNICAST3
- setMcastAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
- setMcastAddress(InetAddress) - Method in class org.jgroups.stack.DiagnosticsHandler
- setMcastGroupAddr(InetAddress) - Method in class org.jgroups.protocols.UDP
- setMcastPort(int) - Method in class org.jgroups.protocols.MPING
- setMcastReceiverThreads(int) - Method in class org.jgroups.protocols.UDP
- setMcastRecvBufSize(int) - Method in class org.jgroups.protocols.UDP
- setMcastSendBufSize(int) - Method in class org.jgroups.protocols.UDP
- setMemberList(String) - Method in class org.jgroups.auth.FixedMembershipToken
- setMembers(List<Address>) - Method in class org.jgroups.blocks.MessageDispatcher
- setMembershipChangePolicy(String) - Method in class org.jgroups.protocols.pbcast.GMS
- setMembershipChangePolicy(MembershipChangePolicy) - Method in class org.jgroups.protocols.pbcast.GMS
- setMemberUnreachable(Address) - Method in class org.jgroups.blocks.RequestCorrelator
- 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
- setMessageFactory(MessageFactory) - Method in class org.jgroups.protocols.TP
- setMessageProcessingPolicy(String) - Method in class org.jgroups.protocols.TP
- setMethod(Method) - Method in class org.jgroups.blocks.MethodCall
- setMethodId(short) - Method in class org.jgroups.blocks.MethodCall
- setMethodInvoker(MethodInvoker) - Method in class org.jgroups.blocks.RpcDispatcher
- setMethodLookup(MethodLookup) - Method in class org.jgroups.blocks.RpcDispatcher
- setMigrateData(boolean) - Method in class org.jgroups.blocks.ReplCache
- setMinCredits(long) - Method in class org.jgroups.protocols.FlowControl
- setMinInterval(long) - Method in class org.jgroups.protocols.MERGE3
- setMinSize(int) - Method in class org.jgroups.protocols.COMPRESS
- setMinThreads(int) - Method in class org.jgroups.util.ThreadPool
- setMinThreads(int) - Method in interface org.jgroups.util.TimeScheduler
-
Sets the core pool size.
- setMinThreads(int) - Method in class org.jgroups.util.TimeScheduler3
- setMinThreshold(double) - Method in class org.jgroups.protocols.FlowControl
- setMode(ResponseMode) - Method in class org.jgroups.blocks.RequestOptions
- setMode(MessageBatch.Mode) - Method in class org.jgroups.util.MessageBatch
- setModificationTime(long) - Method in class org.jgroups.blocks.GridFile.Metadata
- setMsgFactoryClass(String) - Method in class org.jgroups.protocols.TP
- setMulticastAddress(String) - Method in class org.jgroups.protocols.MPING
- setMulticastAddress(InetAddress) - Method in class org.jgroups.protocols.UDP
- setMulticasting(boolean) - 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.demos.JmxDemo.MyNotification
- setName(String) - Method in class org.jgroups.fork.ForkChannel
- setName(String) - Method in class org.jgroups.JChannel
-
Sets the logical name for the channel.
- setNamedAttribute(Attribute) - Method in class org.jgroups.jmx.ResourceDMBean
- setNetworkInterface(InetAddress, MulticastSocket) - Method in class org.jgroups.protocols.UDP
- setNonBlockingTaskHandling(boolean) - Method in interface org.jgroups.util.TimeScheduler
- setNonBlockingTaskHandling(boolean) - Method in class org.jgroups.util.TimeScheduler3
- setNumber(int) - Method in class org.jgroups.demos.JmxDemo
- setNumberOfBackups(int) - Method in class org.jgroups.protocols.COUNTER
- setNumFrags(int) - Method in class org.jgroups.protocols.Frag3Header
- setNumMessagesReceived(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setNumMessagesReceived(int) - Method in class org.jgroups.protocols.ReliableMulticast
- setNumMessagesSent(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setNumMessagesSent(int) - Method in class org.jgroups.protocols.ReliableMulticast
- setNumTries(int) - Method in class org.jgroups.protocols.FD_SOCK
- setObject(Object) - Method in class org.jgroups.BatchMessage
- setObject(Object) - Method in class org.jgroups.BytesMessage
-
Takes an object and uses Java serialization to generate the byte array which is set in the message.
- setObject(Object) - Method in class org.jgroups.CompositeMessage
- setObject(Object) - Method in class org.jgroups.EmptyMessage
- setObject(Object) - Method in class org.jgroups.LongMessage
-
Sets the value
- setObject(Object) - Method in interface org.jgroups.Message
-
Sets an object in a message.
- setObject(Object) - Method in class org.jgroups.NioMessage
-
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the message.
- setObject(Object) - Method in class org.jgroups.ObjectMessage
-
Sets the object.
- setObject(Object) - Method in class org.jgroups.util.ObjectWrapperPrimitive
- setObject(Object) - Method in class org.jgroups.util.ObjectWrapperSerializable
- setObject(SizeStreamable) - Method in class org.jgroups.ObjectMessage
-
Sets the payload to a
SizeStreamable
(or null). - setOffset(int) - Method in class org.jgroups.protocols.FD_SOCK2
- setOffset(int) - Method in class org.jgroups.protocols.Frag3Header
- setOption(SocketOption<T>, T) - Method in class org.jgroups.nio.MockSocketChannel
- setOriginalLength(int) - Method in class org.jgroups.protocols.Frag3Header
- setOriginalSender(Address) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- setOriginalSender(Address) - Method in class org.jgroups.protocols.relay.RelayHeader
- setOriginalType(short) - Method in class org.jgroups.protocols.FragHeader
- setOrigSender(Address) - Method in class org.jgroups.BatchMessage
- 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
- setPasscode(String) - Method in class org.jgroups.stack.DiagnosticsHandler
- setPattern(String) - Method in class org.jgroups.util.DefaultThreadFactory
- setPattern(String) - Method in interface org.jgroups.util.ThreadFactory
- setPayload(Object) - Method in class org.jgroups.BaseMessage
- setPayload(Object) - Method in interface org.jgroups.Message
-
Sets the payload
- setPeerAddrReadTimeout(int) - Method in class org.jgroups.protocols.BasicTCP
- setPeriodicTask(Consumer<ResponseCollectorTask<T>>) - Method in class org.jgroups.util.ResponseCollectorTask
- setPingData(List<PingData>) - Method in class org.jgroups.stack.GossipData
- setPolicies(List<Policy>) - Method in class org.jgroups.stack.Protocol
- setPort(int) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setPort(int) - Method in class org.jgroups.stack.DiagnosticsHandler
- setPortRange(int) - Method in class org.jgroups.protocols.FD_SOCK
- setPortRange(int) - Method in class org.jgroups.protocols.FD_SOCK2
- setPortRange(int) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setPortRange(int) - Method in class org.jgroups.protocols.TCPPING
- setPortRange(int) - Method in class org.jgroups.protocols.TP
- setPortRange(int) - Method in class org.jgroups.stack.DiagnosticsHandler
- setPrintFunction(Function<ExtendedUUID, String>) - Static method in class org.jgroups.util.ExtendedUUID
- setProps(String) - Method in class org.jgroups.blocks.ReplCache
- setProtId(short) - Method in class org.jgroups.Header
- setProtocols(String[]) - Method in class org.jgroups.util.TLS
- setProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Protocol
- setProvider(String) - Method in class org.jgroups.util.TLS
- setReaderIdleTime(long) - Method in class org.jgroups.protocols.TCP_NIO2
- setReaperInterval(long) - Method in class org.jgroups.protocols.BasicTCP
- setReceived() - Method in class org.jgroups.util.Rsp
- setReceiver(Receiver) - Method in class org.jgroups.blocks.MessageDispatcher
- setReceiver(Receiver) - Method in class org.jgroups.blocks.RpcDispatcher
- setReceiver(Receiver) - Method in class org.jgroups.JChannel
- setReconnectInterval(long) - Method in class org.jgroups.protocols.TUNNEL
- setRecvBufSize(int) - Method in class org.jgroups.protocols.BasicTCP
- setRejectedExecutionHandler(RejectedExecutionHandler) - Method in class org.jgroups.util.ThreadPool
- setRejectionPolicy(String) - Method in class org.jgroups.util.ThreadPool
- setReloadThreshold(long) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setRemoteCalls(boolean) - Method in class org.jgroups.blocks.ReplicatedTree
- setRemovable(boolean) - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
- 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
- setRequireClientAuthentication(boolean) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setResendInterval(long) - Method in class org.jgroups.protocols.RSVP
- setResendLastSeqno(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setResendLastSeqnoMaxTimes(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setResponseFilter(RspFilter) - Method in class org.jgroups.blocks.Request
- setResult(T) - Method in class org.jgroups.util.Promise
-
Sets the result and notifies any threads waiting for it
- setRootNode(ReplicatedTree.Node) - Method in class org.jgroups.blocks.ReplicatedTree
- setRouteStatusListener(RouteStatusListener) - Method in class org.jgroups.protocols.relay.RELAY
- setRspFilter(RspFilter) - Method in class org.jgroups.blocks.RequestOptions
- setRunning(boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- setSecretKey(SecretKey) - Method in class org.jgroups.protocols.SYM_ENCRYPT
- setSecretKeyAbove(Tuple<SecretKey, byte[]>) - Method in class org.jgroups.protocols.KeyExchange
-
Sets the secret key in a protocol above us
- setSecretKeyAlgorithm(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setSelectAllPingdataSql(String) - Method in class org.jgroups.protocols.JDBC_PING
- setSelectAllPingdataSql(String) - Method in class org.jgroups.protocols.JDBC_PING2
- setSendBufSize(int) - Method in class org.jgroups.protocols.BasicTCP
- setSender(Address) - Method in class org.jgroups.stack.GossipData
- setSender(Address) - Method in class org.jgroups.util.MessageBatch
- setServerObject(Object) - Method in class org.jgroups.blocks.RpcDispatcher
- setServerSocketConfigurator(Consumer<ServerSocket>) - Method in class org.jgroups.util.DefaultSocketFactory
- setServerSSLContext(SSLContext) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setSessionVerifier(SSL_KEY_EXCHANGE.SessionVerifier) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setSessionVerifierArg(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setSessionVerifierClass(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setSite(String) - Method in class org.jgroups.protocols.relay.RELAY
- setSiteMasterListener(Consumer<Boolean>) - Method in class org.jgroups.protocols.relay.RELAY
- setSiteMasterPickerImpl(String) - Method in class org.jgroups.protocols.relay.RELAY
- setSiteMastersRatio(double) - Method in class org.jgroups.protocols.relay.RELAY
- 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)
- setSizeStreamable(SizeStreamable) - Method in class org.jgroups.ObjectMessage
- setSniMatchers(List<SNIMatcher>) - Method in class org.jgroups.util.TLS
- setSockConnTimeout(int) - Method in class org.jgroups.protocols.BasicTCP
- setSockConnTimeout(int) - Method in class org.jgroups.protocols.FD_SOCK
- setSocketConfigurator(Consumer<Socket>) - Method in class org.jgroups.util.DefaultSocketFactory
- setSocketFactory(SocketFactory) - Method in class org.jgroups.protocols.TCP
- 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
- setSocketTimeout(int) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- 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.BaseMessage
- setSrc(Address) - Method in interface org.jgroups.Message
-
Sets the address of the sender of this message
- setSSLContext(SSLContext) - Method in class org.jgroups.util.TLS
- setSslProtocol(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setStartPort(int) - Method in class org.jgroups.protocols.FD_SOCK
- setState(InputStream) - Method in class org.jgroups.blocks.MessageDispatcher
- 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 interface org.jgroups.Receiver
-
Allows an application to read the state from an InputStream.
- setState(InputStream) - Method in class org.jgroups.util.MyReceiver
- setStateInApplication(InputStream, Object, Address) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- setStateInMainAndForkChannels(InputStream) - Method in class org.jgroups.protocols.FORK
- setStats(boolean) - Method in class org.jgroups.JChannel
- setSuppressTimeDifferentClusterWarnings(long) - Method in class org.jgroups.protocols.TP
- setSuppressTimeDifferentVersionWarnings(long) - Method in class org.jgroups.protocols.TP
- setSuppressTimeNonMemberWarnings(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setSuppressTimeNonMemberWarnings(long) - Method in class org.jgroups.protocols.ReliableMulticast
- setSuppressTimeOutOfBufferSpace(long) - Method in class org.jgroups.protocols.UDP
- setSuspected() - Method in class org.jgroups.util.Rsp
- setSuspected(Address) - Method in class org.jgroups.blocks.GroupRequest
- setSuspectMsgInterval(long) - Method in class org.jgroups.protocols.FD_SOCK
- setSuspectMsgInterval(long) - Method in class org.jgroups.protocols.FD_SOCK2
- setSyncMinInterval(long) - Method in class org.jgroups.protocols.UNICAST3
- setTcpNodelay(boolean) - Method in class org.jgroups.protocols.TUNNEL
- 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
- setters - Variable in class org.jgroups.stack.NonReflectiveProbeHandler
- setThreadDumpsEnabled(boolean) - Method in class org.jgroups.util.ThreadPool
- setThreadDumpsThreshold(int) - Method in class org.jgroups.util.ThreadPool
-
Deprecated.
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.ThreadPool
- setThreadFactory(ThreadFactory) - Method in interface org.jgroups.util.TimeScheduler
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.util.TimeScheduler3
- setThreadNames() - Method in class org.jgroups.protocols.TP
- setThreadNames() - Method in class org.jgroups.stack.DiagnosticsHandler
- setThreadPool(Executor) - Method in class org.jgroups.protocols.TP
- setThreadPool(Executor) - Method in class org.jgroups.util.ThreadPool
- setThreadPool(Executor) - Method in class org.jgroups.util.TimeScheduler3
- setThreadPoolFullSuppressTime(long) - Method in class org.jgroups.util.ThreadPool
- 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.FailureDetection
- setTimeout(long) - Method in class org.jgroups.protocols.FD_ALL3
- setTimeout(long) - Method in class org.jgroups.protocols.RSVP
- setTimeout(long) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- setTimeout(long) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- 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
- setTimePeriod(long) - Method in class org.jgroups.protocols.RATE_LIMITER
- 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.ReliableMulticast
-
Only used for unit tests, don't use !
- setTimer(TimeScheduler) - Method in class org.jgroups.protocols.TP
-
Sets a new timer.
- setTimeService(TimeService) - Method in class org.jgroups.protocols.TP
- setTimeServiceInterval(long) - 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
- setTopoWaitTime(long) - Method in class org.jgroups.protocols.relay.RELAY2
- setTos(int) - Method in class org.jgroups.protocols.UDP
- setTransientFlags(short) - Method in class org.jgroups.blocks.RequestOptions
-
Not recommended as the internal representation of flags might change (e.g.
- setTransientFlags(Message.TransientFlag...) - Method in class org.jgroups.blocks.RequestOptions
- setTruststore(KeyStore) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setTruststoreName(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setTruststorePassword(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setTruststorePassword(String) - Method in class org.jgroups.util.TLS
- setTruststorePath(String) - Method in class org.jgroups.util.TLS
- setTruststoreType(String) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- setTruststoreType(String) - Method in class org.jgroups.util.TLS
- setTtl(int) - Method in class org.jgroups.stack.DiagnosticsHandler
- setTTL(int) - Method in class org.jgroups.protocols.MPING
- setTUNNELPolicy(TUNNEL.TUNNELPolicy) - Method in class org.jgroups.protocols.TUNNEL
- setUcastReceiverThreads(int) - Method in class org.jgroups.protocols.UDP
- setUcastRecvBufSize(int) - Method in class org.jgroups.protocols.UDP
- setUcastSendBufSize(int) - Method in class org.jgroups.protocols.UDP
- setUnknownForkHandler(UnknownForkHandler) - Method in class org.jgroups.fork.ForkProtocolStack
- setUnknownForkHandler(UnknownForkHandler) - Method in class org.jgroups.protocols.FORK
- setUnreachable() - Method in class org.jgroups.util.Rsp
- setup(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.ProtocolStack
- setup(List<ProtocolConfiguration>, ProtocolHook) - Method in class org.jgroups.stack.ProtocolStack
- setUp(boolean) - Method in class org.jgroups.protocols.SHUFFLE
- setUpDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
- setUpHandler(UpHandler) - Method in class org.jgroups.JChannel
- setupPingSocket(IpAddress) - Method in class org.jgroups.protocols.FD_SOCK
-
Creates a socket to
dest
, and assigns it to ping_sock. - setUpProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
- setupProtocolStack(List<ProtocolConfiguration>) - Method in class org.jgroups.stack.Configurator
- setupProtocolStack(List<ProtocolConfiguration>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
Sets up the protocol stack.
- setUseExternalKeyExchange(boolean) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- setVal1(V1) - Method in class org.jgroups.util.Triple
- setVal2(V2) - Method in class org.jgroups.util.Triple
- setVal3(V3) - Method in class org.jgroups.util.Triple
- setValue(long) - Method in class org.jgroups.LongMessage
- setValue(String, Object) - Method in class org.jgroups.stack.Protocol
- setValue(Properties) - Method in class org.jgroups.auth.Krb5Token
- setValue(T) - Method in class org.jgroups.util.Rsp
- setViewAckCollectionTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
- setViewHandler(BiConsumer<String, View>) - Method in class org.jgroups.protocols.relay.Topology
-
Sets a view handler
- setWatcher(FileWatcher) - Method in class org.jgroups.util.TLS
- setWhoHasCacheTimeout(long) - Method in class org.jgroups.protocols.TP
- setWrapExceptions(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- setWrapped(boolean) - Method in class org.jgroups.ObjectMessage
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- setXmitInterval(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitInterval(long) - Method in class org.jgroups.protocols.ReliableMulticast
- setXmitInterval(long) - Method in class org.jgroups.protocols.UNICAST3
- setXmitsEnabled(boolean) - Method in class org.jgroups.protocols.UNICAST3
- setXmitTableMaxCompactionTime(long) - Method in class org.jgroups.protocols.NAKACK3
- setXmitTableMaxCompactionTime(long) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitTableMaxCompactionTime(long) - Method in class org.jgroups.protocols.UNICAST3
- setXmitTableMsgsPerRow(int) - Method in class org.jgroups.protocols.NAKACK3
- setXmitTableMsgsPerRow(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitTableMsgsPerRow(int) - Method in class org.jgroups.protocols.UNICAST3
- setXmitTableNumRows(int) - Method in class org.jgroups.protocols.NAKACK3
- setXmitTableNumRows(int) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitTableNumRows(int) - Method in class org.jgroups.protocols.UNICAST3
- setXmitTableResizeFactor(double) - Method in class org.jgroups.protocols.NAKACK3
- setXmitTableResizeFactor(double) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- setXmitTableResizeFactor(double) - Method in class org.jgroups.protocols.UNICAST3
- 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
-
Discovery protocol running over
SHARED_LOOPBACK
only. - 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
- showStatus(String) - Method in class org.jgroups.demos.StompChat
- shuffle(MessageBatch) - Static method in class org.jgroups.protocols.SHUFFLE
- shuffle(T[], int, int) - Static method in class org.jgroups.util.Util
-
Reorders elements of an array in-place.
- 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
- shut_down_pool - Variable in class org.jgroups.util.TimeScheduler3
- shutdown(JChannel) - 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
- 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
- shuttin_down - Variable in class org.jgroups.protocols.FD_SOCK
- shutting_down - Variable in class org.jgroups.protocols.FD_SOCK2
- signal(boolean) - Method in class org.jgroups.util.CondVar
-
Wakes up one (signal_all=false) or all (signal_all=true) blocked threads.
- signalToString(int) - Static method in class org.jgroups.protocols.FD_SOCK
- simIvLength() - Method in class org.jgroups.protocols.Encrypt
- SimpleRequest() - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
- SimpleRequest(Owner, String) - Constructor for class org.jgroups.protocols.COUNTER.SimpleRequest
- SimpleTCP - Class in org.jgroups.protocols
-
Bare-bones thread-per-connection TCP-based transport.
- SimpleTCP() - Constructor for class org.jgroups.protocols.SimpleTCP
- SimpleTCP.Acceptor - Class in org.jgroups.protocols
-
Calls ServerSocket.accept() and creates new Connection objects
- SimpleTCP.Connection - Class in org.jgroups.protocols
-
1 connection per peer to send and receive messages
- 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
- SingleLoopbackHandler(Message) - Constructor for class org.jgroups.util.SubmitToThreadPool.SingleLoopbackHandler
- SingleMessageHandler(Message) - Constructor for class org.jgroups.util.SubmitToThreadPool.SingleMessageHandler
- SingleMessageHandlerWithClusterName(Message, byte[]) - Constructor for class org.jgroups.util.SubmitToThreadPool.SingleMessageHandlerWithClusterName
- site - Variable in class org.jgroups.protocols.relay.RELAY
- site - Variable in class org.jgroups.protocols.relay.SiteUUID
- site() - Method in class org.jgroups.protocols.relay.RELAY
- site(String) - Method in class org.jgroups.protocols.relay.RELAY
- SITE - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- site_config - Variable in class org.jgroups.protocols.relay.RELAY
- SITE_LOCAL - org.jgroups.util.Util.AddressScope
- site_master - Variable in class org.jgroups.protocols.relay.Route
-
SiteUUID: address of the site master
- SITE_MASTER - Static variable in interface org.jgroups.Address
- site_master_listener - Variable in class org.jgroups.protocols.relay.RELAY
-
Listens for notifications about becoming site master (arg: true), or ceasing to be site master (arg: false)
- site_master_picker - Variable in class org.jgroups.protocols.relay.RELAY
- site_master_picker_impl - Variable in class org.jgroups.protocols.relay.RELAY
- site_masters - Variable in class org.jgroups.protocols.relay.RELAY
- SITE_MASTERS - Static variable in class org.jgroups.demos.RelayDemo
- site_masters_ratio - Variable in class org.jgroups.protocols.relay.RELAY
- site_status - Variable in class org.jgroups.protocols.relay.RELAY3
- SITE_UNREACHABLE - Static variable in class org.jgroups.Event
- SITE_UNREACHABLE - Static variable in class org.jgroups.protocols.relay.RelayHeader
- site_unreachable_delayer - Variable in class org.jgroups.protocols.relay.RELAY3
- SITE_UUID - Static variable in interface org.jgroups.Address
- SITE_UUID_PREFIX - Static variable in class org.jgroups.util.Util
- SiteAddress - Interface in org.jgroups.protocols.relay
-
Address with a site suffix
- SiteAddress.Type - Enum in org.jgroups.protocols.relay
- 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
- siteMasterPicker(SiteMasterPicker) - Method in class org.jgroups.protocols.relay.RELAY
- SiteMasterPicker - Interface in org.jgroups.protocols.relay
-
Allows an implementation to pick a
SiteMaster
or aRoute
from a list (if multiple site masters are enabled). - siteMasters() - Method in class org.jgroups.protocols.relay.RELAY
- siteNames() - Method in class org.jgroups.protocols.relay.RELAY
- sites - Variable in class org.jgroups.protocols.relay.RELAY
-
A map containing site names (e.g.
- sites - Variable in class org.jgroups.protocols.relay.RelayHeader
- sites - Variable in class org.jgroups.protocols.relay.SiteStatus
- SITES - Static variable in class org.jgroups.protocols.relay.config.RelayConfig
- SITES_DOWN - Static variable in class org.jgroups.protocols.relay.RelayHeader
- SITES_UP - Static variable in class org.jgroups.protocols.relay.RelayHeader
- sitesChange(boolean, Set<String>) - Method in class org.jgroups.protocols.relay.RELAY
- sitesDown(String...) - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- sitesDown(String...) - Method in interface org.jgroups.protocols.relay.RouteStatusListener
-
The sites went down
- siteStatus() - Method in class org.jgroups.protocols.relay.RELAY3
- SiteStatus - Class in org.jgroups.protocols.relay
-
Maintains the status of sites (up, down, undefined).
- SiteStatus() - Constructor for class org.jgroups.protocols.relay.SiteStatus
- SiteStatus.Status - Enum in org.jgroups.protocols.relay
- sitesUnreachable(String...) - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- sitesUnreachable(String...) - Method in interface org.jgroups.protocols.relay.RouteStatusListener
-
The sites are unreachable (no route to them)
- sitesUp(String...) - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- 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, byte[], byte[]) - Constructor for class org.jgroups.protocols.relay.SiteUUID
-
Deprecated.
- SiteUUID(long, long, String, String) - Constructor for class org.jgroups.protocols.relay.SiteUUID
- SiteUUID(UUID, String, String) - Constructor for class org.jgroups.protocols.relay.SiteUUID
- size - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- size - Variable in class org.jgroups.util.Buffer
-
The number of non-null elements
- size - Variable in class org.jgroups.util.FastArray
- size - Variable in class org.jgroups.util.FixedSizeBitSet
- size - Variable in class org.jgroups.util.IntHashMap
- size - Variable in class org.jgroups.util.RTT
- size - Variable in class org.jgroups.util.SizeBoundedQueue.El
- size - Variable in class org.jgroups.util.Table
- size() - Method in class org.jgroups.auth.AuthToken
-
The size of the marshalled AuthToken
- size() - Method in class org.jgroups.auth.FixedMembershipToken
- size() - Method in class org.jgroups.auth.Krb5Token
- size() - Method in class org.jgroups.auth.RegexMembership
- size() - Method in class org.jgroups.auth.X509Token
- size() - Method in class org.jgroups.BaseMessage
- size() - Method in class org.jgroups.BatchMessage
- size() - Method in class org.jgroups.blocks.LazyRemovalCache
- size() - Method in class org.jgroups.BytesMessage
- size() - Method in class org.jgroups.CompositeMessage
- size() - Method in class org.jgroups.LongMessage
- size() - Method in class org.jgroups.Membership
-
Returns the number of addresses in this membership
- size() - Method in interface 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.NioMessage
- size() - Method in class org.jgroups.ObjectMessage
- size() - Method in class org.jgroups.protocols.BaseBundler
-
Returns the total number of messages in the hashmap
- size() - Method in class org.jgroups.protocols.BatchBundler
- size() - Method in interface org.jgroups.protocols.Bundler
-
The number of unsent messages in the bundler
- size() - Method in class org.jgroups.protocols.NoBundler
- size() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- size() - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- size() - Method in class org.jgroups.protocols.PerDestinationBundler
- size() - Method in class org.jgroups.protocols.RemoveQueueBundler
- size() - Method in class org.jgroups.protocols.RingBufferBundler
- 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.SimplifiedTransferQueueBundler
- size() - Method in class org.jgroups.protocols.TransferQueueBundler
- size() - Method in class org.jgroups.protocols.TransferQueueBundler2
- size() - Method in class org.jgroups.util.AckCollector
- size() - Method in class org.jgroups.util.AckTable
- size() - Method in class org.jgroups.util.AgeOutCache
- size() - Method in class org.jgroups.util.BlockingInputStream
- size() - Method in class org.jgroups.util.Buffer
- size() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- size() - Method in class org.jgroups.util.Delayer
- size() - Method in class org.jgroups.util.ExpiryCache
- size() - Method in class org.jgroups.util.FastArray
- size() - Method in class org.jgroups.util.FixedSizeBitSet
- size() - Method in class org.jgroups.util.IntHashMap
- 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.MessageCache
-
Returns a count of all messages
- size() - Method in class org.jgroups.util.MyReceiver
- size() - Method in class org.jgroups.util.ProcessingQueue
- 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() - Method in class org.jgroups.util.RingBuffer
- size() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- size() - Method in class org.jgroups.util.RingBufferSeqnoOld
- size() - Method in class org.jgroups.util.RTT
- size() - Method in class org.jgroups.util.SeqnoList
- size() - Method in class org.jgroups.util.SizeBoundedQueue
-
Returns the accumulated size of all elements in the queue
- size() - Method in class org.jgroups.util.SuppressCache
-
Returns the total count of all values
- size() - Method in class org.jgroups.util.Table
-
Returns an appromximation of the number 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.TimeScheduler3
- size() - Method in class org.jgroups.View
-
Returns the number of members in this view
- size(byte[]) - Static method in class org.jgroups.util.Util
- size(double) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded double
- size(float) - Static method in class org.jgroups.util.Bits
- size(int) - Static method in class org.jgroups.util.Bits
-
Computes the size of a variable-length encoded int
- size(int) - Method in class org.jgroups.util.RTT
- 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(Object) - Static method in class org.jgroups.util.Util
- size(String) - Static method in class org.jgroups.util.Bits
- size(String) - 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(Address[]) - Static method in class org.jgroups.util.Util
- size(Header[]) - Static method in class org.jgroups.util.Headers
- size(Message) - Method in class org.jgroups.protocols.RATE
- size(AsciiString) - Static method in class org.jgroups.util.Bits
-
Measures the number of bytes required to encode an AsciiSring.
- size(MessageBatch) - Method in class org.jgroups.protocols.RATE
- size(SizeStreamable) - 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 - Class in org.jgroups.protocols
-
Protocol which prints out the real size of a message.
- SIZE - Static variable in class org.jgroups.util.UUID
- SIZE() - Constructor for class org.jgroups.protocols.SIZE
- SizeBoundedQueue<T> - Class in org.jgroups.util
-
Blocking FIFO queue bounded by the max number of bytes of all elements.
- SizeBoundedQueue(int) - Constructor for class org.jgroups.util.SizeBoundedQueue
- SizeBoundedQueue(int, Lock) - Constructor for class org.jgroups.util.SizeBoundedQueue
- SizeBoundedQueue.El<T> - Class in org.jgroups.util
- sizeOf(Collection<String>) - Static method in class org.jgroups.protocols.relay.RelayHeader
- sizeOf(AuthToken) - Static method in class org.jgroups.protocols.AuthHeader
- sizeOfAllMessages(Buffer<Message>, boolean) - Static method in class org.jgroups.protocols.ReliableMulticast
- sizeOfAllMessages(Table<Message>, boolean) - Static method in class org.jgroups.protocols.pbcast.NAKACK2
- sizeofHashMap() - Method in class org.jgroups.util.ExtendedUUID
- sizeOfPayload() - Method in class org.jgroups.BytesMessage
- sizeOfPayload() - Method in class org.jgroups.FragmentedMessage
- sizeOfPayload() - Method in class org.jgroups.NioMessage
- sizePrimitive(Object) - Static method in class org.jgroups.util.Util
- 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(long) - Method in class org.jgroups.util.BlockingInputStream
- skip(long) - Method in class org.jgroups.util.InputStreamAdapter
- skip(RequestCorrelator.Header, Address) - Method in class org.jgroups.blocks.RequestCorrelator
- SKIP - org.jgroups.protocols.ASYM_ENCRYPT.Processing
- SKIP_BARRIER - org.jgroups.Message.Flag
- skip_next_resend - Variable in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
- skip_next_send - Variable in class org.jgroups.protocols.ReliableMulticast.LastSeqnoResender
- skip_oob - Variable in class org.jgroups.protocols.MAKE_BATCH
- skip_setting_default_values - Static variable in class org.jgroups.stack.Configurator
- skipBytes(int) - Method in class org.jgroups.util.ByteArrayDataInputStream
- skipBytes(int) - Method in class org.jgroups.util.ByteBufferInputStream
- skipDownMessage(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Processes a message with a GMS header (e.g.
- skipNext() - Method in class org.jgroups.protocols.pbcast.NAKACK2.LastSeqnoResender
- skipNext() - Method in class org.jgroups.protocols.ReliableMulticast.LastSeqnoResender
- skipOOB() - Method in class org.jgroups.protocols.MAKE_BATCH
- skipOOB(boolean) - Method in class org.jgroups.protocols.MAKE_BATCH
- skipSettingDefaultValues() - Static method in class org.jgroups.stack.Configurator
- skipSettingDefaultValues(boolean) - Static method in class org.jgroups.stack.Configurator
- skipUpMessage(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Checks if the message contains a public key (and adds it to pub_map if present) or an encrypted group key (and installs it if present)
- 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 - Static variable in class org.jgroups.util.FileWatcher
- sleep_interval - Variable in class org.jgroups.protocols.FILE_PING.InfoWriter
- sleep_time - Variable in class org.jgroups.protocols.MAKE_BATCH
- 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
- Slf4jLogImpl - Class in org.jgroups.logging
-
Logger that delivers messages to a SLF4J logger
- Slf4jLogImpl(Class<?>) - Constructor for class org.jgroups.logging.Slf4jLogImpl
- Slf4jLogImpl(String) - Constructor for class org.jgroups.logging.Slf4jLogImpl
- Slf4jLogImpl(Locale, Logger) - Constructor for class org.jgroups.logging.Slf4jLogImpl
- SM - org.jgroups.protocols.relay.SiteAddress.Type
- SM_ALL - org.jgroups.protocols.relay.SiteAddress.Type
- sni_matchers - Variable in class org.jgroups.util.TLS
- SNIFF - Class in org.jgroups.protocols
-
Protocol trying to print message payloads as strings
- SNIFF() - Constructor for class org.jgroups.protocols.SNIFF
- SniMatcherConverter() - Constructor for class org.jgroups.util.TLS.SniMatcherConverter
- 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.SimpleTCP.Connection
- 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.protocols.TCPGOSSIP
- sock_conn_timeout - Variable in class org.jgroups.stack.RouterStub
- sockAddress(IpAddress) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- sockConnTimeout() - Method in class org.jgroups.protocols.TCPGOSSIP
- sockConnTimeout(int) - Method in class org.jgroups.protocols.TCPGOSSIP
- socket() - Method in class org.jgroups.nio.MockSocketChannel
- socket_factory - Variable in class org.jgroups.blocks.cs.BaseServer
- socket_factory - Variable in class org.jgroups.client.StompConnection
- socket_factory - Variable in class org.jgroups.protocols.TP
- socket_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
- socket_factory - Variable in class org.jgroups.stack.GossipRouter
- socket_factory - Variable in class org.jgroups.stack.RouterStub
- socket_factory - Variable in class org.jgroups.stack.RouterStubManager
- socket_timeout - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- socketConnectionTimeout() - Method in class org.jgroups.blocks.cs.BaseServer
- socketConnectionTimeout() - Method in class org.jgroups.stack.RouterStub
- socketConnectionTimeout(int) - Method in class org.jgroups.blocks.cs.BaseServer
- socketConnectionTimeout(int) - Method in class org.jgroups.stack.RouterStub
- socketFactory() - Method in class org.jgroups.blocks.cs.BaseServer
- socketFactory() - Method in class org.jgroups.stack.GossipRouter
- socketFactory(SocketFactory) - Method in class org.jgroups.blocks.cs.BaseServer
- socketFactory(SocketFactory) - Method in class org.jgroups.stack.GossipRouter
- socketFactory(SocketFactory) - Method in class org.jgroups.stack.RouterStubManager
- SocketFactory - Interface in org.jgroups.util
-
Factory to create various types of sockets.
- sort() - Method in class org.jgroups.Membership
- sort() - Method in class org.jgroups.util.AverageMinMax
- sorted - Variable in class org.jgroups.util.AverageMinMax
- SOS - Class in org.jgroups.protocols
-
Periodically fetches some attributes and writes them to a file (https://issues.redhat.com/browse/JGRP-2402)
- SOS() - Constructor for class org.jgroups.protocols.SOS
- SOS.DumperTask - Class in org.jgroups.protocols
- spaceAvailable(int) - Method in class org.jgroups.nio.Buffers
- spaceUsed() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- spaceUsed() - Method in class org.jgroups.util.RingBufferSeqnoOld
- span - Variable in class org.jgroups.protocols.RED
- 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 interface org.jgroups.Message
- src(Address) - Method in interface org.jgroups.Message
- srv - Variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- srv - Variable in class org.jgroups.protocols.FD_SOCK2
- srv - Variable in class org.jgroups.protocols.TCP
- SRV - org.jgroups.protocols.dns.DNSResolver.DNSRecordType
- srv_addr - Static variable in class org.jgroups.protocols.ASYM_ENCRYPT
- srv_sock - Variable in class org.jgroups.blocks.cs.TcpServer
- srv_sock - Variable in class org.jgroups.demos.EchoServer
- srv_sock - Variable in class org.jgroups.protocols.FD_SOCK
- srv_sock - Variable in class org.jgroups.protocols.SimpleTCP
- srv_sock - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- srv_sock - Variable in class org.jgroups.protocols.STOMP
- srv_sock - Variable in class org.jgroups.stack.DiagnosticsHandler
- 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_context - Variable in class org.jgroups.util.TLS
- 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.SSLContextReloader - Class in org.jgroups.protocols
-
Helper class that knows how and when to reload the SSLContext.
- SSL_KEY_EXCHANGE.Type - Enum in org.jgroups.protocols
- ssl_protocol - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- ssl_provider - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- sslContext() - Method in class org.jgroups.util.SslContextFactory.Context
- SslContextFactory - Class in org.jgroups.util
-
SslContextFactory.
- SslContextFactory() - Constructor for class org.jgroups.util.SslContextFactory
- SslContextFactory.Context - Class in org.jgroups.util
- SSLContextReloader(long) - Constructor for class org.jgroups.protocols.SSL_KEY_EXCHANGE.SSLContextReloader
- sslParameters - Variable in class org.jgroups.client.StompConnection
- sslProtocol(String) - Method in class org.jgroups.util.SslContextFactory
- STABILITY - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Keeps the last N stability messages
- stability_msgs - Variable in class org.jgroups.protocols.ReliableMulticast
-
Keeps the last N stability messages
- stable(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Nulls elements between low and seqno and forwards low
- stable(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Nulls elements between low and seqno and forwards low
- stable(Digest) - Method in class org.jgroups.protocols.NAKACK4
- stable(Digest) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Garbage collect messages that have been seen by all members.
- stable(Digest) - Method in class org.jgroups.protocols.ReliableMulticast
-
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 - Static variable in class org.jgroups.Event
- STABLE() - Constructor for class org.jgroups.protocols.pbcast.STABLE
- STABLE_GOSSIP - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- stable_task_future - Variable in class org.jgroups.protocols.pbcast.STABLE
- stable_task_lock - Variable in class org.jgroups.protocols.pbcast.STABLE
- stable_xmit_map - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- stable_xmit_map - Variable in class org.jgroups.protocols.ReliableMulticast
- STABLE.ResumeTask - Class in org.jgroups.protocols.pbcast
- STABLE.StableHeader - Class in org.jgroups.protocols.pbcast
- STABLE.StableTask - Class in org.jgroups.protocols.pbcast
-
Mcast periodic STABLE message.
- 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.Configurator
- stack - Variable in class org.jgroups.stack.Protocol
- stack() - Method in class org.jgroups.JChannel
- STACK_DEPENDENT - Static variable in class org.jgroups.Global
- STACK_INDEPENDENT - Static variable in class org.jgroups.Global
- stack_type - Variable in class org.jgroups.protocols.TCPPING
- 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 - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- start() - Method in class org.jgroups.auth.AuthToken
- start() - Method in class org.jgroups.auth.RegexMembership
- start() - Method in class org.jgroups.blocks.Cache
- 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
- 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
- start() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- start() - Method in class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- start() - Method in class org.jgroups.blocks.cs.TcpServer
- start() - Method in class org.jgroups.blocks.MessageDispatcher
- start() - Method in class org.jgroups.blocks.ReplCache
- start() - Method in class org.jgroups.blocks.ReplicatedTree
- start() - Method in class org.jgroups.blocks.RequestCorrelator
- start() - Method in class org.jgroups.demos.StompChat
- start() - Method in class org.jgroups.demos.Topology
- start() - Method in interface org.jgroups.Lifecycle
-
This method is called after an instance has been initialized.
- start() - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- start() - Method in class org.jgroups.protocols.AUTH
- start() - Method in class org.jgroups.protocols.BaseBundler
- start() - Method in class org.jgroups.protocols.BATCH
- start() - Method in class org.jgroups.protocols.BATCH2
- start() - Method in class org.jgroups.protocols.BatchBundler
- start() - Method in class org.jgroups.protocols.BPING
- start() - Method in interface org.jgroups.protocols.Bundler
-
Called after
Bundler.init(TP)
- start() - Method in class org.jgroups.protocols.DISCARD
- start() - Method in class org.jgroups.protocols.Discovery
- start() - Method in class org.jgroups.protocols.FD_ALL3
- 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.FD_SOCK2
- start() - Method in class org.jgroups.protocols.FlowControl
- start() - Method in interface org.jgroups.protocols.LocalTransport
- start() - Method in class org.jgroups.protocols.MAKE_BATCH
- start() - Method in class org.jgroups.protocols.MERGE3
- start() - Method in class org.jgroups.protocols.MFC_NB
- start() - Method in class org.jgroups.protocols.MPING
- start() - Method in class org.jgroups.protocols.NoBundler
- start() - Method in class org.jgroups.protocols.pbcast.GMS
- start() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- start() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- start() - Method in class org.jgroups.protocols.pbcast.STABLE
- start() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- start() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- start() - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- start() - Method in class org.jgroups.protocols.PerDestinationBundler
- start() - Method in class org.jgroups.protocols.RATE_LIMITER
- start() - Method in class org.jgroups.protocols.RATE_LIMITER2
- start() - Method in class org.jgroups.protocols.RATE
- start() - Method in class org.jgroups.protocols.RED
- start() - Method in class org.jgroups.protocols.relay.Bridge
- start() - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
- start() - Method in class org.jgroups.protocols.ReliableMulticast
- start() - Method in class org.jgroups.protocols.RemoveQueueBundler
- 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.SEQUENCER
- start() - Method in class org.jgroups.protocols.SEQUENCER2
- start() - Method in class org.jgroups.protocols.SHUFFLE
- start() - Method in class org.jgroups.protocols.SimpleTCP.Acceptor
- start() - Method in class org.jgroups.protocols.SimpleTCP.Connection
- start() - Method in class org.jgroups.protocols.SimpleTCP
- start() - Method in class org.jgroups.protocols.SOS
- 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_NIO2
- start() - Method in class org.jgroups.protocols.TCP
- 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.TransferQueueBundler2
- start() - Method in class org.jgroups.protocols.TUNNEL
- 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.UFC_NB
- start() - Method in class org.jgroups.protocols.UNICAST3
- start() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- 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
-
This method is called on a
JChannel.connect(String)
; starts work. - start() - Method in class org.jgroups.util.Profiler
- start() - Method in class org.jgroups.util.Runner
- start() - Method in interface org.jgroups.util.TimeScheduler
-
Starts the runner thread
- start() - Method in class org.jgroups.util.TimeScheduler3
- start() - Method in class org.jgroups.util.TimeService
- start(boolean) - Method in class org.jgroups.util.Metrics
- start(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Fetches the state
- start(String, String) - Method in class org.jgroups.demos.RelayDemoRpc
- start(String, String, boolean, boolean, boolean) - Method in class org.jgroups.demos.RelayDemo
- start(InetAddress, int) - Method in class org.jgroups.demos.EchoServer
- start(InetAddress, int, boolean) - Method in class org.jgroups.demos.PubClient
- start(InetAddress, int, boolean, int) - Method in class org.jgroups.demos.PubServer
- start(List<RelayConfig.BridgeConfig>, String, String) - Method in class org.jgroups.protocols.relay.Relayer2
-
Creates all bridges from site_config and connects them (joining the bridge clusters)
- start(Map<Address, View>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
- 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(JChannel) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- start(RelayConfig.SiteConfig, String, String) - Method in class org.jgroups.protocols.relay.Relayer3
-
Creates all bridges from site_config and connects them (joining the bridge clusters)
- start(TimeScheduler, long, long) - Method in class org.jgroups.util.ResponseCollectorTask
- START - org.jgroups.conf.XmlConfigurator.ElementType
- start_down - Variable in class org.jgroups.protocols.ProtPerfHeader
- start_port - Variable in class org.jgroups.protocols.FD_SOCK
- START_RULE - Static variable in class org.jgroups.util.GenerateProfilingScript
- start_time - Variable in class org.jgroups.blocks.Request
- start_time - Variable in class org.jgroups.protocols.PERF.PerfHeader
- start_up - Variable in class org.jgroups.protocols.ProtPerfHeader
- startBatcher() - Method in class org.jgroups.protocols.MAKE_BATCH
- startCacheDissemination(List<Address>, List<Address>, List<Address>) - Method in class org.jgroups.protocols.Discovery
- startDiagnostics() - Method in class org.jgroups.protocols.TP
- startDown() - Method in class org.jgroups.protocols.ProtPerfHeader
- startDown(long) - Method in class org.jgroups.protocols.ProtPerfHeader
- started - Variable in class org.jgroups.blocks.RequestCorrelator
- startFailureDetection() - Method in class org.jgroups.protocols.FailureDetection
- startFlusher(Address) - Method in class org.jgroups.protocols.SEQUENCER
- startFlushTask() - Method in class org.jgroups.protocols.BATCH
- startFlushTask() - Method in class org.jgroups.protocols.BatchBundler
- startGui() - Method in class org.jgroups.protocols.DISCARD
- startHeartbeatSender() - Method in class org.jgroups.protocols.FailureDetection
- startHeartbeatTask() - Method in class org.jgroups.stack.RouterStubManager
- startInfoSender() - Method in class org.jgroups.protocols.MERGE3
- startInfoWriter() - Method in class org.jgroups.protocols.FILE_PING
- startMcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- startMergeKiller() - Method in class org.jgroups.protocols.pbcast.Merger
- 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
- startReceiver() - Method in class org.jgroups.protocols.MPING
- 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(Relayer2, String) - Method in class org.jgroups.protocols.relay.RELAY2
- startRelayer(Relayer3, String) - Method in class org.jgroups.protocols.relay.RELAY3
- 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.ReliableMulticast
- startRetransmitTask() - Method in class org.jgroups.protocols.UNICAST3
- startRunner() - Method in class org.jgroups.client.StompConnection
- startServerSocket() - Method in class org.jgroups.protocols.FD_SOCK
- startStableTask() - Method in class org.jgroups.protocols.pbcast.STABLE
- startStack() - Method in class org.jgroups.fork.ForkProtocolStack
- startStack() - Method in class org.jgroups.stack.ProtocolStack
-
Start all protocols.
- startStack(String) - Method in class org.jgroups.JChannel
- startTask() - Method in class org.jgroups.protocols.FD_SOCK.BroadcastTask
- startTask() - Method in class org.jgroups.protocols.FD_SOCK2.BroadcastTask
- startTask() - Method in class org.jgroups.protocols.SHUFFLE
- startTask() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- startTCP() - Method in class org.jgroups.stack.DiagnosticsHandler
- startThreads() - Method in class org.jgroups.protocols.UDP
- startTimeoutChecker() - Method in class org.jgroups.protocols.FailureDetection
- startTimeoutChecker() - Method in class org.jgroups.stack.RouterStubManager
- startTimer() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- startUcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- startUDP() - Method in class org.jgroups.stack.DiagnosticsHandler
- startUp() - Method in class org.jgroups.protocols.ProtPerfHeader
- startUp(long) - Method in class org.jgroups.protocols.ProtPerfHeader
- startViewConsistencyChecker() - Method in class org.jgroups.protocols.MERGE3
- state - Variable in class org.jgroups.demos.Draw.DrawPanel
- state - Variable in class org.jgroups.JChannel
- state - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- state - Variable in class org.jgroups.protocols.UNICAST3.Entry
- state - Variable in class org.jgroups.stack.StateTransferInfo
- state - Variable in class org.jgroups.util.MyReceiver
- state() - Method in class org.jgroups.util.MyReceiver
- 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_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_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
- STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
-
Wraps data for a state request/response.
- STATE.StateOutputStream - Class in org.jgroups.protocols.pbcast
- StateGetter(Address, OutputStream) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateGetter
- StateHeader() - 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.STATE_TRANSFER.StateHeader
- StateHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- StateHeader(byte, IpAddress, Digest) - Constructor for class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- StateHeader(byte, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- StateHeader(byte, 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
- stats - Variable in class org.jgroups.JChannel
- stats - Variable in class org.jgroups.protocols.relay.Relayer
- stats - Variable in class org.jgroups.protocols.relay.Route
- stats - Variable in class org.jgroups.stack.Protocol
- stats - Variable in class org.jgroups.util.RpcStats
- stats() - Method in class org.jgroups.JChannel
- stats() - Method in class org.jgroups.protocols.relay.Route
- stats(boolean) - Method in class org.jgroups.JChannel
- 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
- 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
- stddev() - Method in class org.jgroups.util.AverageMinMax
- StickySiteMasterPicker - Class in org.jgroups.protocols.relay
-
Picks a local site master or a route based on the sender and caches the decision.
- StickySiteMasterPicker() - Constructor for class org.jgroups.protocols.relay.StickySiteMasterPicker
- STOMP - Class in org.jgroups.protocols
-
Protocol which provides STOMP (https://stomp.github.io/) support.
- STOMP() - Constructor for class org.jgroups.protocols.STOMP
- stomp_client - Variable in class org.jgroups.demos.StompChat
- stomp_client - Variable in class org.jgroups.demos.StompDraw
- 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
- 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(String, String, String, boolean, SSLContext, SSLParameters) - 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 - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- stop() - Method in class org.jgroups.auth.AuthToken
- stop() - Method in class org.jgroups.blocks.Cache
- 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.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.TcpConnectionNonBlocking.Sender
- stop() - Method in class org.jgroups.blocks.cs.TcpServer
- stop() - Method in class org.jgroups.blocks.MessageDispatcher
- 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 interface org.jgroups.Lifecycle
-
Called before an instance is stopped; stops work.
- 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.BATCH
- stop() - Method in class org.jgroups.protocols.BATCH2
- stop() - Method in class org.jgroups.protocols.BatchBundler
- stop() - Method in class org.jgroups.protocols.BPING
- stop() - Method in interface org.jgroups.protocols.Bundler
- stop() - Method in class org.jgroups.protocols.DISCARD
- stop() - Method in class org.jgroups.protocols.Discovery
- stop() - Method in class org.jgroups.protocols.FailureDetection
- stop() - Method in class org.jgroups.protocols.FD_HOST
- stop() - Method in class org.jgroups.protocols.FD_SOCK
- stop() - Method in class org.jgroups.protocols.FD_SOCK2
- stop() - Method in class org.jgroups.protocols.FILE_PING
- stop() - Method in class org.jgroups.protocols.FlowControl
- stop() - Method in class org.jgroups.protocols.LOCAL_PING
- stop() - Method in interface org.jgroups.protocols.LocalTransport
- stop() - Method in class org.jgroups.protocols.MAKE_BATCH
- stop() - Method in class org.jgroups.protocols.MERGE3
- stop() - Method in class org.jgroups.protocols.MFC_NB
- 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.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.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() - 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.PerDestinationBundler.SendBuffer
- stop() - Method in class org.jgroups.protocols.PerDestinationBundler
- stop() - Method in class org.jgroups.protocols.RATE_LIMITER
- stop() - Method in class org.jgroups.protocols.RATE_LIMITER2
- stop() - Method in class org.jgroups.protocols.RATE
- stop() - Method in class org.jgroups.protocols.relay.Bridge
- stop() - Method in class org.jgroups.protocols.relay.RELAY
- stop() - Method in class org.jgroups.protocols.relay.Relayer
- stop() - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
- stop() - Method in class org.jgroups.protocols.relay.Relayer2
-
Disconnects and destroys all bridges
- stop() - Method in class org.jgroups.protocols.relay.Relayer3
-
Disconnects and destroys all bridges
- stop() - Method in class org.jgroups.protocols.ReliableMulticast
- stop() - Method in class org.jgroups.protocols.RemoveQueueBundler
- stop() - Method in class org.jgroups.protocols.REVERSE
- 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.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.SimpleTCP.Acceptor
- stop() - Method in class org.jgroups.protocols.SimpleTCP
- stop() - Method in class org.jgroups.protocols.SOS
- 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_NIO2
- stop() - Method in class org.jgroups.protocols.TCP
- stop() - Method in class org.jgroups.protocols.TCPGOSSIP
- stop() - Method in class org.jgroups.protocols.TP
- stop() - Method in class org.jgroups.protocols.TransferQueueBundler
- stop() - Method in class org.jgroups.protocols.TransferQueueBundler2
- 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_NB
- stop() - Method in class org.jgroups.protocols.UFC
- stop() - Method in class org.jgroups.protocols.UNICAST3
- stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- 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
-
Called on a
JChannel.disconnect()
; stops work (e.g. - stop() - Method in class org.jgroups.util.FileWatcher
- stop() - Method in class org.jgroups.util.Profiler
- 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.TimeScheduler3
-
Stops the timer, cancelling all tasks
- stop() - Method in class org.jgroups.util.TimeService
- stop(boolean) - Method in class org.jgroups.protocols.FD_SOCK.ServerSocketHandler
- stop_function - Variable in class org.jgroups.util.Runner
- STOP_RULE - Static variable in class org.jgroups.util.GenerateProfilingScript
- stopBatcher() - Method in class org.jgroups.protocols.MAKE_BATCH
- stopDiagnostics() - Method in class org.jgroups.protocols.TP
- stopFailureDetection() - Method in class org.jgroups.protocols.FailureDetection
- stopFlusher() - Method in class org.jgroups.protocols.SEQUENCER
- stopFlushTask() - Method in class org.jgroups.protocols.BATCH
- stopFlushTask() - Method in class org.jgroups.protocols.BatchBundler
- stopGui() - Method in class org.jgroups.protocols.DISCARD
- stopHeartbeatSender() - Method in class org.jgroups.protocols.FailureDetection
- stopHeartbeatTask() - Method in class org.jgroups.stack.RouterStubManager
- stopInfoSender() - Method in class org.jgroups.protocols.MERGE3
- stopInfoWriter() - Method in class org.jgroups.protocols.FILE_PING
- stopKeyserver() - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- stopMcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- stopMergeKiller() - Method in class org.jgroups.protocols.pbcast.Merger
- 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
- stopReconciliationTask() - Method in class org.jgroups.protocols.COUNTER
- stopReconnector() - Method in class org.jgroups.stack.RouterStubManager
- 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.ReliableMulticast
- stopRetransmitTask() - Method in class org.jgroups.protocols.UNICAST3
- stopServerSocket(boolean) - Method in class org.jgroups.protocols.FD_SOCK
- stopStableTask() - Method in class org.jgroups.protocols.pbcast.STABLE
- stopStack(boolean, boolean) - Method in class org.jgroups.JChannel
- stopStack(String) - Method in class org.jgroups.fork.ForkProtocolStack
- 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.FD_SOCK2.BroadcastTask
- stopTask() - Method in class org.jgroups.protocols.SHUFFLE
- stopThread(boolean) - Method in class org.jgroups.protocols.FD_SOCK.ClientConnectionHandler
- stopThreadPool() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- stopThreads() - Method in class org.jgroups.protocols.UDP
- stopTimeoutChecker() - Method in class org.jgroups.protocols.FailureDetection
- stopTimeoutChecker() - Method in class org.jgroups.stack.RouterStubManager
- stopTimer() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- stopUcastReceiverThreads() - Method in class org.jgroups.protocols.UDP
- 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
- stream() - Method in class org.jgroups.util.Buffer
- stream() - Method in class org.jgroups.util.DynamicBuffer
- stream() - Method in class org.jgroups.util.FastArray
- stream() - Method in class org.jgroups.util.FixedBuffer
- stream() - Method in class org.jgroups.util.MessageBatch
- stream() - Method in class org.jgroups.util.Table
- stream(long, long) - Method in class org.jgroups.util.Buffer
- stream(long, long) - Method in class org.jgroups.util.DynamicBuffer
- stream(long, long) - Method in class org.jgroups.util.FixedBuffer
- stream(long, long) - Method in class org.jgroups.util.Table
- stream(Predicate<Message>) - Method in class org.jgroups.util.MessageBatch
- stream(Predicate<Message>, boolean) - Method in class org.jgroups.util.MessageBatch
- Streamable - Interface in org.jgroups.util
-
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization
- streamableFromBuffer(Supplier<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
- streamableFromByteBuffer(Class<? extends Streamable>, ByteBuffer) - Static method in class org.jgroups.util.Util
- streamableFromByteBuffer(Supplier<T>, byte[]) - Static method in class org.jgroups.util.Util
- streamableFromByteBuffer(Supplier<T>, 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
-
Thread which invokes
Receiver.getState(java.io.OutputStream)
in the application - StreamingStateTransfer.StateHeader - Class in org.jgroups.protocols.pbcast
- string_version - Static variable in class org.jgroups.Version
- 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(Message, boolean) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- submit(MessageBatch) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- submitted_batches - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- submitted_msgs - Variable in class org.jgroups.util.MaxOneThreadPerSender.Entry
- submitToPool(TimeScheduler3.Task) - Method in class org.jgroups.util.TimeScheduler3
- SubmitToThreadPool - Class in org.jgroups.util
-
Default message processing policy.
- SubmitToThreadPool() - Constructor for class org.jgroups.util.SubmitToThreadPool
- SubmitToThreadPool.BatchHandler - Class in org.jgroups.util
- SubmitToThreadPool.SingleLoopbackHandler - Class in org.jgroups.util
- SubmitToThreadPool.SingleMessageHandler - Class in org.jgroups.util
- SubmitToThreadPool.SingleMessageHandlerWithClusterName - Class in org.jgroups.util
- subscribe(String) - Method in class org.jgroups.client.StompConnection
- SUBSCRIBE - org.jgroups.protocols.STOMP.ClientVerb
- 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).
- substituteVariable(String, Properties) - Static method in class org.jgroups.util.Util
-
Replaces variables in a string.
- substituteVariableOld(String, Properties) - Static method in class org.jgroups.util.Util
-
Replaces variables of ${var:default} with Properties then uses System.getProperty(var, default) if the value was not found.
- substituteVariables() - Method in class org.jgroups.conf.ProtocolConfiguration
- subviews - Variable in class org.jgroups.protocols.pbcast.Merger.MergeTask
- suffix(TimeUnit) - Static method in class org.jgroups.util.Util
- 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
- supplier - Variable in class org.jgroups.util.Metrics.Entry
- supplier() - Method in class org.jgroups.util.Metrics.Entry
- supportedKeys() - Method in class org.jgroups.blocks.RequestCorrelator.MyProbeHandler
- supportedKeys() - Method in class org.jgroups.JChannelProbeHandler
- supportedKeys() - Method in class org.jgroups.protocols.pbcast.GMS
- supportedKeys() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- supportedKeys() - Method in class org.jgroups.protocols.ReliableMulticast
- supportedKeys() - Method in class org.jgroups.protocols.TP
- supportedKeys() - Method in interface org.jgroups.stack.DiagnosticsHandler.ProbeHandler
-
Returns a list of supported keys
- supportedKeys() - Method in class org.jgroups.stack.GossipRouter
- 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.SimpleTCP
- supportsMulticasting() - Method in class org.jgroups.protocols.TP
-
Whether 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_no_route - Variable in class org.jgroups.protocols.relay.RELAY
-
Log to suppress identical errors for messages to non-existing sites ('no route to site X')
- suppress_log_non_member - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Log to suppress identical warnings for messages from non-members
- suppress_log_non_member - Variable in class org.jgroups.protocols.ReliableMulticast
-
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_no_route_errors - Variable in class org.jgroups.protocols.relay.RELAY
- suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- suppress_time_non_member_warnings - Variable in class org.jgroups.protocols.ReliableMulticast
- suppress_time_out_of_buffer_space - Variable in class org.jgroups.protocols.UDP
- suppress_view_size - Static variable in class org.jgroups.View
- SUPPRESS_VIEW_SIZE - Static variable in class org.jgroups.Global
- 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) - Constructor for class org.jgroups.util.SuppressLog
- SuppressLog.Level - Enum in org.jgroups.util
- suspect - Variable in class org.jgroups.protocols.FD_SOCK2.Request
- suspect - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
- suspect - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- suspect(String) - Method in class org.jgroups.protocols.pbcast.GMS
- suspect(InetAddress) - Method in class org.jgroups.protocols.FD_HOST
-
Called by ping task; will result in all members of host getting suspected
- suspect(Collection<Address>) - Method in class org.jgroups.protocols.FD_SOCK2
- suspect(Collection<Address>) - Method in class org.jgroups.util.AckCollector
- suspect(List<Address>) - Method in class org.jgroups.protocols.FailureDetection
- suspect(List<Address>) - Method in class org.jgroups.protocols.FD_HOST
- suspect(Set<Address>) - Method in class org.jgroups.protocols.FD_SOCK
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- suspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- suspect(Address) - Method in class org.jgroups.util.AckCollector
- suspect(Address) - Method in class org.jgroups.util.ResponseCollector
- suspect(Address...) - Method in class org.jgroups.util.AckCollector
- SUSPECT - org.jgroups.stack.GossipType
- SUSPECT - Static variable in class org.jgroups.Event
- SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- SUSPECT - Static variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- suspect_history - Variable in class org.jgroups.protocols.FailureDetection
- suspect_history - Variable in class org.jgroups.protocols.FD_HOST
- suspect_history - Variable in class org.jgroups.protocols.FD_SOCK
- suspect_history - Variable in class org.jgroups.protocols.FD_SOCK2
- suspect_msg_interval - Variable in class org.jgroups.protocols.FD_SOCK
- suspect_msg_interval - Variable in class org.jgroups.protocols.FD_SOCK2
- 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.FailureDetection
- 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.protocols.FD_SOCK2
- suspected_mbrs - Variable in class org.jgroups.protocols.pbcast.GMS
- 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.FD_SOCK.BroadcastTask
- suspects - Variable in class org.jgroups.protocols.FD_SOCK2.BroadcastTask
- suspects - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- suspects - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- suspend() - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
Clears the queue and discards new requests from now on
- suspend(long) - Method in class org.jgroups.protocols.pbcast.STABLE
- 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
- suspended - Variable in class org.jgroups.protocols.pbcast.ViewHandler
- suspended() - Method in class org.jgroups.protocols.pbcast.ViewHandler
- suspendEncoding() - Method in class org.jgroups.util.Base64.OutputStream
-
Suspends encoding of the stream.
- suspendViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
- swap(List<E>, int) - Static method in class org.jgroups.util.Util
- 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, Log) - Constructor for class org.jgroups.protocols.SWIFT_PING.SwiftClient
-
Constructor
- sym_algorithm - Variable in class org.jgroups.protocols.Encrypt
- 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_iv_length - Variable in class org.jgroups.protocols.Encrypt
- sym_keylength - Variable in class org.jgroups.protocols.Encrypt
- sym_version - Variable in class org.jgroups.protocols.Encrypt
- symAlgorithm() - Method in class org.jgroups.protocols.Encrypt
- symAlgorithm(String) - Method in class org.jgroups.protocols.Encrypt
- symIvLength(int) - Method in class org.jgroups.protocols.Encrypt
- symKeyAlgorithm() - Method in class org.jgroups.protocols.Encrypt
- symKeylength() - Method in class org.jgroups.protocols.Encrypt
- symKeylength(int) - Method in class org.jgroups.protocols.Encrypt
- symVersion() - Method in class org.jgroups.protocols.Encrypt
- sync - Variable in class org.jgroups.util.RpcStats.Result
- sync() - Method in interface org.jgroups.blocks.atomic.BaseCounter
-
Returns a
SyncCounter
wrapper for this instance. - sync() - Method in interface org.jgroups.blocks.atomic.SyncCounter
- sync() - Method in class org.jgroups.protocols.COUNTER.CounterImpl
- sync() - Method in class org.jgroups.util.RpcStats.Result
- SYNC() - Static method in class org.jgroups.blocks.RequestOptions
- 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
- SyncCounter - Interface in org.jgroups.blocks.atomic
-
A synchronous counter interface
- synchronizedMap(ReplicatedMap<K, V>) - Static method in class org.jgroups.blocks.ReplicatedHashMap
-
Creates a synchronized facade for a ReplicatedMap.
- systemProperty() - Method in annotation type org.jgroups.annotations.Property
T
- table - Variable in class org.jgroups.util.IntHashMap
- 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(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(long) - Constructor for class org.jgroups.util.Table
- Table.HighestDeliverable - Class in org.jgroups.util
- Table.Missing - Class in org.jgroups.util
- Table.NumDeliverable - Class in org.jgroups.util
- Table.Remover<R> - Class in org.jgroups.util
- Table.TableIterator - Class in org.jgroups.util
-
Iterates through all elements of the matrix.
- Table.Visitor<T> - Interface in org.jgroups.util
- TableIterator() - Constructor for class org.jgroups.util.DynamicBuffer.TableIterator
- TableIterator() - Constructor for class org.jgroups.util.Table.TableIterator
- TableIterator(long, long) - Constructor for class org.jgroups.util.DynamicBuffer.TableIterator
- TableIterator(long, long) - Constructor for class org.jgroups.util.Table.TableIterator
- take() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue
- take() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- take() - Method in class org.jgroups.util.RingBuffer
-
Removes the next available element, blocking until one is available (if needed).
- 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 - Variable in class org.jgroups.stack.StateTransferInfo
- target_dest - Variable in class org.jgroups.protocols.AlternatingBundler
- target_list - Variable in class org.jgroups.protocols.AlternatingBundler
- target_time - Variable in class org.jgroups.protocols.VERIFY_SUSPECT.Entry
- target_time - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2.Entry
- task - Variable in class org.jgroups.protocols.RATE_LIMITER2
- task - Variable in class org.jgroups.protocols.RATE
- task - Variable in class org.jgroups.protocols.SHUFFLE
- task - Variable in class org.jgroups.util.AsyncExecutor.Task
- task - Variable in class org.jgroups.util.TimeService
- Task(Runnable, boolean) - Constructor for class org.jgroups.util.TimeScheduler3.Task
- Task(Runnable, long, TimeUnit, boolean) - Constructor for class org.jgroups.util.TimeScheduler3.Task
- Task(Supplier<T>, CompletableFuture<T>) - Constructor for class org.jgroups.util.AsyncExecutor.Task
- 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_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
- tcp_runner - Variable in class org.jgroups.stack.DiagnosticsHandler
- TCP_THREAD_NAME - Static variable in class org.jgroups.stack.DiagnosticsHandler
- TcpBaseServer - Class in org.jgroups.blocks.cs
-
Common base class for TCP based clients and servers
- TcpBaseServer(ThreadFactory, SocketFactory, int) - Constructor for class org.jgroups.blocks.cs.TcpBaseServer
- TcpClient - Class in org.jgroups.blocks.cs
- 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(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. - TcpConnection - Class in org.jgroups.blocks.cs
-
Blocking IO (BIO) connection.
- TcpConnection(Socket, TcpServer) - Constructor for class org.jgroups.blocks.cs.TcpConnection
-
Called by
TcpServer.Acceptor.handleAccept(Socket)
- TcpConnection(Address, TcpBaseServer) - Constructor for class org.jgroups.blocks.cs.TcpConnection
-
Creates a connection to a remote peer, use
TcpConnection.connect(Address)
to connect - TcpConnection.Receiver - Class in org.jgroups.blocks.cs
- TcpConnectionNonBlocking - Class in org.jgroups.blocks.cs
-
TCP connection which (despite the fancy name) blocks only a single thread at most.
- TcpConnectionNonBlocking(Socket, TcpServer) - Constructor for class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- TcpConnectionNonBlocking(Address, TcpBaseServer) - Constructor for class org.jgroups.blocks.cs.TcpConnectionNonBlocking
- TcpConnectionNonBlocking.Sender - Class in org.jgroups.blocks.cs
- tcpEnabled() - Method in class org.jgroups.stack.DiagnosticsHandler
- TCPGOSSIP - Class in org.jgroups.protocols
-
The TCPGOSSIP protocol layer retrieves the initial membership (used by 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() - Method in class org.jgroups.protocols.BasicTCP
- tcpNodelay(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- tcpNodelay(boolean) - Method in class org.jgroups.protocols.BasicTCP
- 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(ThreadFactory, SocketFactory, InetAddress, int, int, InetAddress, int, int) - Constructor for class org.jgroups.blocks.cs.TcpServer
- TcpServer(ThreadFactory, SocketFactory, InetAddress, int, int, InetAddress, int, int, String) - 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.Acceptor - Class in org.jgroups.blocks.cs
-
Acceptor thread.
- teardownPingSocket() - Method in class org.jgroups.protocols.FD_SOCK
- tenant - Variable in class org.jgroups.protocols.SWIFT_PING
- Tests - Class in org.jgroups.util
-
Common functions for all tests
- Tests() - Constructor for class org.jgroups.util.Tests
- thread - Variable in class org.jgroups.blocks.cs.TcpConnectionNonBlocking.Sender
- thread - Variable in class org.jgroups.protocols.pbcast.Merger.MergeTask
- thread - Variable in class org.jgroups.util.Runner
- THREAD_COUNT - Class in org.jgroups.protocols
-
Maintains averages of up- and down-threads
- THREAD_COUNT() - Constructor for class org.jgroups.protocols.THREAD_COUNT
- thread_dump_path - Variable in class org.jgroups.util.ThreadPool
-
Deprecated.
- thread_dumps_enabled - Variable in class org.jgroups.util.ThreadPool
- thread_dumps_threshold - Variable in class org.jgroups.util.ThreadPool
-
Deprecated.
- thread_factory - Variable in class org.jgroups.protocols.TP
-
Factory which is used by the thread pool
- thread_factory - Variable in class org.jgroups.stack.DiagnosticsHandler
- thread_factory - Variable in class org.jgroups.stack.GossipRouter
- thread_factory - Variable in class org.jgroups.util.ThreadPool
- thread_id - Variable in class org.jgroups.util.Owner
- thread_name - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- thread_name - Variable in class org.jgroups.util.Runner
- THREAD_NAME - Static variable in class org.jgroups.protocols.PerDestinationBundler
- THREAD_NAME - Static variable in class org.jgroups.protocols.RemoveQueueBundler
- 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.protocols.TransferQueueBundler2
- thread_naming_pattern - Variable in class org.jgroups.protocols.TP
- thread_pool - Variable in class org.jgroups.demos.EchoServer
- thread_pool - Variable in class org.jgroups.protocols.AsyncNoBundler
- thread_pool - Variable in class org.jgroups.protocols.pbcast.StreamingStateTransfer
-
Thread pool (configured with
StreamingStateTransfer.max_pool
andStreamingStateTransfer.pool_thread_keep_alive
) to runStreamingStateTransfer.StateGetter
threads on - thread_pool - Variable in class org.jgroups.protocols.TP
-
The thread pool which handles unmarshalling, version checks and dispatching of messages
- thread_pool - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- thread_pool - Variable in class org.jgroups.util.AsyncExecutor
- thread_pool - Variable in class org.jgroups.util.ThreadPool
- thread_pool - Variable in class org.jgroups.util.TimeScheduler3
- thread_pool_full_log - Variable in class org.jgroups.util.ThreadPool
- thread_pool_full_suppress_time - Variable in class org.jgroups.util.ThreadPool
- THREAD_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
- ThreadCreator - Class in org.jgroups.util
- ThreadCreator() - Constructor for class org.jgroups.util.ThreadCreator
- ThreadEntry(Thread.State, String, long, long, double, double, double, double) - Constructor for class org.jgroups.JChannelProbeHandler.ThreadEntry
- ThreadFactory - Interface in org.jgroups.util
- threadId() - Static method in class org.jgroups.protocols.NON_BLOCKING_SENDS
- threadName() - Method in class org.jgroups.util.Runner
- threadName(String) - Method in class org.jgroups.util.Runner
- threadPool() - Method in class org.jgroups.util.AsyncExecutor
- threadPool(ThreadPool) - Method in class org.jgroups.util.AsyncExecutor
- ThreadPool - Class in org.jgroups.util
-
Thread pool based on
ThreadPoolExecutor
- ThreadPool() - Constructor for class org.jgroups.util.ThreadPool
- 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
- threads - Variable in class org.jgroups.protocols.NON_BLOCKING_SENDS
- threads - Variable in class org.jgroups.util.Profiler
- threshold - Variable in class org.jgroups.protocols.SEQUENCER
- throw_exception_on_timeout - Variable in class org.jgroups.protocols.RSVP
- throwExceptionOnTimeout() - Method in class org.jgroups.protocols.RSVP
- throwExceptionOnTimeout(boolean) - Method in class org.jgroups.protocols.RSVP
- TIME - Class in org.jgroups.protocols
-
Protocol measuring delivery times.
- TIME - org.jgroups.conf.AttributeType
- TIME() - Constructor for class org.jgroups.protocols.TIME
- 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
- 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.DH_KEY_EXCHANGE
- timeout - Variable in class org.jgroups.protocols.FailureDetection
- timeout - Variable in class org.jgroups.protocols.FD_HOST
- timeout - Variable in class org.jgroups.protocols.RSVP
- timeout - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- timeout - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- timeout - Variable in class org.jgroups.stack.StateTransferInfo
- timeout - Variable in class org.jgroups.util.Delayer
- timeout - Variable in class org.jgroups.util.ExpiryCache
- timeout - Variable in class org.jgroups.util.RTT
- timeout() - Method in class org.jgroups.blocks.RequestOptions
- timeout() - Method in class org.jgroups.util.Delayer
- timeout() - Method in class org.jgroups.util.RTT
- timeout(long) - Method in class org.jgroups.blocks.RequestOptions
- timeout(long) - Method in class org.jgroups.util.Delayer
- timeout(long) - Method in class org.jgroups.util.RTT
- timeout_check_interval - Variable in class org.jgroups.protocols.FD_ALL
- timeout_checker - Variable in class org.jgroups.protocols.FailureDetection
- timeout_checker_task - Variable in class org.jgroups.stack.RouterStubManager
- timeouterRunning() - Method in class org.jgroups.stack.RouterStubManager
- timer - Variable in class org.jgroups.protocols.BARRIER
- timer - Variable in class org.jgroups.protocols.BATCH
- timer - Variable in class org.jgroups.protocols.BATCH2
- timer - Variable in class org.jgroups.protocols.BatchBundler
- timer - Variable in class org.jgroups.protocols.Discovery
- timer - Variable in class org.jgroups.protocols.FailureDetection
- 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.FD_SOCK2
- timer - Variable in class org.jgroups.protocols.MAKE_BATCH
- 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.RATE_LIMITER2
- timer - Variable in class org.jgroups.protocols.RATE
- timer - Variable in class org.jgroups.protocols.relay.RELAY
- timer - Variable in class org.jgroups.protocols.ReliableMulticast
- timer - Variable in class org.jgroups.protocols.RSVP
- timer - Variable in class org.jgroups.protocols.SHUFFLE
- timer - Variable in class org.jgroups.protocols.TP
- timer - Variable in class org.jgroups.protocols.UNICAST3
- timer - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- timer - Variable in class org.jgroups.stack.RouterStubManager
- timer - Variable in class org.jgroups.util.TimeService
- timer_handle_non_blocking_tasks - Variable in class org.jgroups.protocols.TP
- timer_thread_factory - Variable in class org.jgroups.util.TimeScheduler3
- times - Variable in class org.jgroups.util.RTT
- TimeScheduler - Interface in org.jgroups.util
-
Timer-like interface which allows for execution of tasks.
- TimeScheduler.Task - Interface in org.jgroups.util
-
The interface that dynamic tasks (
TimeScheduler.scheduleWithDynamicInterval(org.jgroups.util.TimeScheduler.Task)
) must implement - TimeScheduler3 - Class in org.jgroups.util
-
Implementation of
TimeScheduler
. - 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(ThreadFactory, int, int, long, BlockingQueue<Runnable>, String, boolean) - Constructor for class org.jgroups.util.TimeScheduler3
- TimeScheduler3(ThreadPool, ThreadFactory, boolean) - 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.UNICAST3.Entry
- timestamp - Variable in class org.jgroups.util.MessageBatch
-
For benchmarking; may get removed without notice
- timestamp - Variable in class org.jgroups.util.SuppressCache.Value
- timestamp - Variable in class org.jgroups.util.TimeService
- timestamp() - Method in class org.jgroups.protocols.TP
- timestamp() - Method in class org.jgroups.protocols.UnicastHeader3
- timestamp() - Method in class org.jgroups.util.MessageBatch
- timestamp() - Method in class org.jgroups.util.TimeService
-
Returns the timestamp (ns).
- timestamp(int) - Method in class org.jgroups.protocols.UnicastHeader3
- timestamp(long) - Method in class org.jgroups.util.MessageBatch
- 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_ALL3
- timestamps - Variable in class org.jgroups.protocols.FD_HOST
- tls - Variable in class org.jgroups.protocols.TCP
- tls - Variable in class org.jgroups.protocols.TUNNEL
- tls - Variable in class org.jgroups.stack.GossipRouter
- tls() - Method in class org.jgroups.protocols.TCP
- tls() - Method in class org.jgroups.protocols.TUNNEL
- tls() - Method in class org.jgroups.stack.GossipRouter
- tls(TLS) - Method in class org.jgroups.protocols.TCP
- tls(TLS) - Method in class org.jgroups.protocols.TUNNEL
- tls(TLS) - Method in class org.jgroups.stack.GossipRouter
- TLS - Class in org.jgroups.util
- TLS() - Constructor for class org.jgroups.util.TLS
- TLS.SniMatcherConverter - Class in org.jgroups.util
- TLSClientAuth - Enum in org.jgroups.util
- 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
- to - Variable in class org.jgroups.protocols.relay.ForwardingRoute
- to - Variable in class org.jgroups.util.DynamicBuffer.TableIterator
- to - Variable in class org.jgroups.util.Table.TableIterator
- to() - Method in class org.jgroups.protocols.relay.config.RelayConfig.ForwardConfig
- to() - Method in class org.jgroups.protocols.relay.ForwardingRoute
- to(String) - Method in class org.jgroups.protocols.relay.ForwardingRoute
- token - Variable in class org.jgroups.protocols.AuthHeader
- token() - Method in class org.jgroups.protocols.AuthHeader
- token(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
- 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
- topo - Variable in class org.jgroups.protocols.relay.RELAY
- topo() - Method in class org.jgroups.protocols.relay.RELAY
- topo_collector - Variable in class org.jgroups.protocols.relay.RELAY2
- TOPO_REQ - Static variable in class org.jgroups.protocols.relay.RelayHeader
- TOPO_RSP - Static variable in class org.jgroups.protocols.relay.RelayHeader
- topo_wait_time - Variable in class org.jgroups.protocols.relay.RELAY2
- Topology - Class in org.jgroups.demos
-
Demonstrates the membership service.
- Topology - Class in org.jgroups.protocols.relay
-
Provides a cache of all sites and their members (addresses, IP addresses, site masters etc) in a network of autonomous sites.
- Topology(String, String) - Constructor for class org.jgroups.demos.Topology
- Topology(RELAY) - Constructor for class org.jgroups.protocols.relay.Topology
- 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.BaseMessage
- toString() - Method in class org.jgroups.BatchMessage
- 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.cs.TcpConnectionNonBlocking
- 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.MethodCall
- 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.CompositeMessage
- toString() - Method in class org.jgroups.conf.ProtocolConfiguration
- toString() - Method in class org.jgroups.conf.XmlNode
- toString() - Method in class org.jgroups.demos.DrawCommand
- toString() - Method in class org.jgroups.demos.JmxDemo.MyNotification
- toString() - Method in class org.jgroups.Event
- toString() - Method in class org.jgroups.FragmentedMessage
- toString() - Method in class org.jgroups.Header
- toString() - Method in class org.jgroups.JChannel
- toString() - Method in class org.jgroups.JChannelProbeHandler.ThreadEntry
- 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.LongMessage
- toString() - Method in class org.jgroups.Membership
- toString() - Method in class org.jgroups.MergeView
- toString() - Method in class org.jgroups.nio.Buffers
- toString() - Method in class org.jgroups.NioMessage
- toString() - Method in class org.jgroups.NullAddress
- toString() - Method in class org.jgroups.ObjectMessage
- toString() - Method in class org.jgroups.protocols.AuthHeader
- toString() - Method in class org.jgroups.protocols.BATCH.BatchHeader
- toString() - Method in class org.jgroups.protocols.BATCH.FlushTask
- toString() - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- toString() - Method in class org.jgroups.protocols.BatchBundler.FlushTask
- toString() - Method in class org.jgroups.protocols.COUNTER.AddAndGetRequest
- 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.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.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.DH_KEY_EXCHANGE.DhHeader
- toString() - Method in class org.jgroups.protocols.EncryptHeader
- toString() - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
- toString() - Method in class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- toString() - Method in class org.jgroups.protocols.FcHeader
- toString() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
- 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.FD_SOCK2.BroadcastTask
- toString() - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- toString() - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- toString() - Method in class org.jgroups.protocols.FD_SOCK2.Request
- toString() - Method in class org.jgroups.protocols.FORK.ForkHeader
- toString() - Method in class org.jgroups.protocols.FRAG2.FragEntry
- toString() - Method in class org.jgroups.protocols.FRAG3.FragEntry
- toString() - Method in class org.jgroups.protocols.Frag3Header
- toString() - Method in class org.jgroups.protocols.FragHeader
- 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.MsgStats
- toString() - Method in class org.jgroups.protocols.NakAckHeader
- toString() - Method in class org.jgroups.protocols.pbcast.DeltaView
- 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.NakAckHeader2
- toString() - Method in class org.jgroups.protocols.pbcast.STABLE.ResumeTask
- 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.pbcast.ViewHandler
- toString() - Method in class org.jgroups.protocols.PDC.Mapping
- toString() - Method in class org.jgroups.protocols.PerDestinationBundler.SendBuffer
- toString() - Method in class org.jgroups.protocols.PingData
- toString() - Method in class org.jgroups.protocols.PingHeader
- toString() - Method in class org.jgroups.protocols.RED
- toString() - Method in class org.jgroups.protocols.relay.Bridge
- 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.DefaultRouteStatusListener
- toString() - Method in class org.jgroups.protocols.relay.ForwardingRoute
- toString() - Method in class org.jgroups.protocols.relay.Relayer
- 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.SiteStatus
- toString() - Method in class org.jgroups.protocols.relay.SiteUUID
- toString() - Method in class org.jgroups.protocols.relay.Topology
- toString() - Method in class org.jgroups.protocols.ReliableMulticast.RetransmitTask
- 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.RTTHeader
- 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.SimpleTCP.Connection
- toString() - Method in class org.jgroups.protocols.SOS.DumperTask
- 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.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.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.UnicastHeader3
- 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.protocols.VERIFY_SUSPECT2.Entry
- toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- toString() - Method in class org.jgroups.stack.Configurator.InetAddressInfo
- 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.Protocol
- toString() - Method in class org.jgroups.stack.RouterStub
- toString() - Method in class org.jgroups.stack.StateTransferInfo
- toString() - Method in exception org.jgroups.SuspectedException
- toString() - Method in exception org.jgroups.UnreachableException
- toString() - Method in class org.jgroups.util.AckCollector
- toString() - Method in class org.jgroups.util.AckTable
- toString() - Method in class org.jgroups.util.AgeOutCache
- toString() - Method in class org.jgroups.util.AsciiString
- toString() - Method in class org.jgroups.util.AsyncExecutor
- toString() - Method in class org.jgroups.util.Average
- toString() - Method in class org.jgroups.util.AverageMinMax
- toString() - Method in class org.jgroups.util.BaseDataOutputStream
- toString() - Method in class org.jgroups.util.BlockingInputStream
- toString() - Method in class org.jgroups.util.Buffer.Options
- toString() - Method in class org.jgroups.util.Buffer
- toString() - Method in class org.jgroups.util.ByteArray
- 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.Credit
- toString() - Method in class org.jgroups.util.CreditMap
- toString() - Method in class org.jgroups.util.Delayer.Entry
- toString() - Method in class org.jgroups.util.Delayer
- toString() - Method in class org.jgroups.util.Digest.Entry
- toString() - 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.FastArray.FastIterator
- toString() - Method in class org.jgroups.util.FastArray
- toString() - Method in class org.jgroups.util.FixedSizeBitSet
-
Returns a string representation of this bit set.
- toString() - Method in class org.jgroups.util.FlagsUUID
- toString() - Method in class org.jgroups.util.IntHashMap
- toString() - Method in class org.jgroups.util.LongTuple
- toString() - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
- toString() - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- toString() - Method in class org.jgroups.util.MergeId
- toString() - Method in class org.jgroups.util.MessageBatch
- toString() - Method in class org.jgroups.util.MessageCache
- toString() - Method in class org.jgroups.util.Metrics.Entry
- toString() - Method in class org.jgroups.util.MyReceiver
- toString() - Method in class org.jgroups.util.NonBlockingCredit
- toString() - Method in class org.jgroups.util.NonBlockingCreditMap
- toString() - Method in class org.jgroups.util.ObjectWrapperPrimitive
- toString() - Method in class org.jgroups.util.ObjectWrapperSerializable
- toString() - Method in class org.jgroups.util.Owner
- toString() - Method in class org.jgroups.util.PartialOutputStream
- toString() - Method in class org.jgroups.util.ProcessingQueue
- toString() - Method in class org.jgroups.util.Profiler
- toString() - Method in class org.jgroups.util.Promise
- toString() - Method in class org.jgroups.util.Range
- toString() - Method in class org.jgroups.util.Ref
- 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.RingBuffer
- toString() - Method in class org.jgroups.util.RingBufferSeqnoLockless
- toString() - Method in class org.jgroups.util.RingBufferSeqnoOld
- toString() - Method in class org.jgroups.util.RpcStats.Result
- toString() - Method in class org.jgroups.util.RpcStats.RTTStat
- 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.SeqnoList
- toString() - Method in class org.jgroups.util.SizeBoundedQueue.El
- toString() - Method in class org.jgroups.util.SizeBoundedQueue
- 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.ThreadPool
- 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
- toString(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- toString(boolean) - Method in class org.jgroups.JChannel
- toString(boolean) - Method in class org.jgroups.protocols.MsgStats
- 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.InitialHosts
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.InitialHosts2
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.NetworkInterfaceList
- toString(Object) - Method in class org.jgroups.conf.PropertyConverters.PolicyConverter
- toString(Object) - Method in class org.jgroups.util.TLS.SniMatcherConverter
- toString(TimeUnit) - Method in class org.jgroups.util.Average
- toString(TimeUnit) - Method in class org.jgroups.util.AverageMinMax
- toString(Function<V, String>) - Method in class org.jgroups.blocks.LazyRemovalCache.Entry
- toString(Address[], boolean) - Method in class org.jgroups.util.Digest
- toString(Digest) - Method in class org.jgroups.util.Digest
- toStringDetailed() - Method in class org.jgroups.protocols.FD_ALL3.Bitmap
- toStringDetails() - Method in class org.jgroups.blocks.MethodCall
- toStringLong() - Method in class org.jgroups.util.UUID
-
Returns a
String
object representing thisUUID
. - total_block_time - Variable in class org.jgroups.protocols.RATE_LIMITER
- total_msgs - Variable in class org.jgroups.protocols.RED
- total_msgs_sent - Variable in class org.jgroups.protocols.PerDestinationBundler
- total_time - Variable in class org.jgroups.util.RpcStats.RTTStat
- 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) - totalTime() - Method in class org.jgroups.protocols.RTTHeader
-
The total time for a round-trip
- toVoidFunction() - Static method in enum org.jgroups.util.CompletableFutures
- tp - Variable in class org.jgroups.util.SubmitToThreadPool
- TP - Class in org.jgroups.protocols
-
Generic transport - specific implementations should extend this abstract class.
- TP() - Constructor for class org.jgroups.protocols.TP
- tp_id - Variable in class org.jgroups.util.RTT
- tp_id - Variable in class org.jgroups.util.SubmitToThreadPool
- TpHeader - Class in org.jgroups.protocols
-
Generic transport header, used by TP.
- TpHeader() - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(byte[]) - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(String) - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(String, byte, int) - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(AsciiString) - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(AsciiString, byte, int) - Constructor for class org.jgroups.protocols.TpHeader
- trace - org.jgroups.util.SuppressLog.Level
- trace(Object) - Method in class org.jgroups.logging.JDKLogImpl
- trace(Object) - Method in interface org.jgroups.logging.Log
- trace(Object) - Method in class org.jgroups.logging.Log4J2LogImpl
- trace(Object) - Method in class org.jgroups.logging.Slf4jLogImpl
- trace(String) - Method in class org.jgroups.logging.JDKLogImpl
- trace(String) - Method in interface org.jgroups.logging.Log
- trace(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- trace(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- trace(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- trace(String, Object...) - Method in interface org.jgroups.logging.Log
- trace(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- trace(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- trace(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
- trace(String, Throwable) - Method in interface org.jgroups.logging.Log
- trace(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
- trace(String, Throwable) - Method in class org.jgroups.logging.Slf4jLogImpl
- TRACE - Class in org.jgroups.protocols
- TRACE() - Constructor for class org.jgroups.protocols.TRACE
- transferFrom(FastArray<T>, boolean) - Method in class org.jgroups.util.FastArray
-
Copies the messages from the other array into this one,
- transferFrom(MessageBatch, boolean) - Method in class org.jgroups.util.MessageBatch
-
Transfers messages from other to this batch.
- 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
- TransferQueueBundler2 - 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.
- TransferQueueBundler2() - Constructor for class org.jgroups.protocols.TransferQueueBundler2
- TransferQueueBundler2(int) - Constructor for class org.jgroups.protocols.TransferQueueBundler2
- TransferQueueBundler2(BlockingQueue<Message>) - Constructor for class org.jgroups.protocols.TransferQueueBundler2
- transient_flags - Variable in class org.jgroups.BaseMessage
- transient_flags - Variable in class org.jgroups.blocks.RequestOptions
- transientFlags() - Method in class org.jgroups.blocks.RequestOptions
- transientFlags(Message.TransientFlag...) - Method in class org.jgroups.blocks.RequestOptions
- transientFlagSet(Message.TransientFlag) - Method in class org.jgroups.blocks.RequestOptions
- transientFlagsToString(short) - Static method in class org.jgroups.util.Util
- transport - Variable in class org.jgroups.protocols.BARRIER
- transport - Variable in class org.jgroups.protocols.BaseBundler
- transport - Variable in class org.jgroups.protocols.DAISYCHAIN
- transport - Variable in class org.jgroups.protocols.Discovery
- transport - Variable in class org.jgroups.protocols.NoBundler
- transport - Variable in class org.jgroups.protocols.PerDestinationBundler
- transport - Variable in class org.jgroups.protocols.TransferQueueBundler2
- transport - Variable in class org.jgroups.util.RTT
- transport_supports_multicasting - Variable in class org.jgroups.protocols.Discovery
- 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
- triggerMemberUnreachableEvent(Address) - Method in class org.jgroups.protocols.relay.RELAY
- triggerMemberUnreachableEvent(Address) - Method in class org.jgroups.protocols.relay.RELAY3
- triggerSiteUnreachableEvent(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY
- triggerSiteUnreachableEvent(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY3
- triggerXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- triggerXmit() - Method in class org.jgroups.protocols.ReliableMulticast
- 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
- trust_store - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- trustManager() - Method in class org.jgroups.util.SslContextFactory.Context
- trustStore(KeyStore) - Method in class org.jgroups.util.SslContextFactory
- truststore_name - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- truststore_password - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- truststore_password - Variable in class org.jgroups.util.TLS
- truststore_path - Variable in class org.jgroups.util.TLS
- truststore_type - Variable in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- truststore_type - Variable in class org.jgroups.util.TLS
- trustStoreFileName(String) - Method in class org.jgroups.util.SslContextFactory
- trustStorePassword(char[]) - Method in class org.jgroups.util.SslContextFactory
- trustStorePassword(String) - Method in class org.jgroups.util.SslContextFactory
- trustStoreType(String) - Method in class org.jgroups.util.SslContextFactory
- 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_policy - Variable in class org.jgroups.protocols.TUNNEL
- TUNNEL.TUNNELPolicy - Interface in org.jgroups.protocols
- 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.blocks.RequestCorrelator.Header
-
Type of header: request or reply
- type - Variable in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- type - Variable in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- type - Variable in class org.jgroups.protocols.EncryptHeader
- type - Variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- type - Variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- type - Variable in class org.jgroups.protocols.FD_SOCK2.Request
- type - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
- type - Variable in class org.jgroups.protocols.NakAckHeader
- type - Variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- type - Variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- 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 - Variable in class org.jgroups.protocols.relay.RelayHeader
- type - Variable in class org.jgroups.protocols.RSVP.RsvpHeader
- 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 - Variable in class org.jgroups.util.Metrics.Entry
- type - Variable in class org.jgroups.util.TimeScheduler3.RecurringTask
- type() - Method in annotation type org.jgroups.annotations.ManagedAttribute
- type() - Method in annotation type org.jgroups.annotations.Property
-
Defines the type, used for pretty printing
- type() - Method in annotation type org.jgroups.annotations.XmlElement
- type() - Method in annotation type org.jgroups.annotations.XmlInclude
- type() - Method in class org.jgroups.Event
- type() - Method in class org.jgroups.jmx.ResourceDMBean.AttributeEntry
- type() - Method in class org.jgroups.protocols.EncryptHeader
- type() - Method in class org.jgroups.protocols.PingHeader
- type() - Method in interface org.jgroups.protocols.relay.SiteAddress
-
Temporary kludge to avoid instanceof
- type() - Method in class org.jgroups.protocols.relay.SiteMaster
- type() - Method in class org.jgroups.protocols.UnicastHeader3
- type() - Method in class org.jgroups.util.Metrics.Entry
- type2Str(byte) - Static method in class org.jgroups.protocols.NakAckHeader
- type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader2
- type2Str(byte) - Static method in class org.jgroups.protocols.UnicastHeader3
- type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK.FdHeader
- type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- type2String(int) - Static method in class org.jgroups.Event
- type2String(int) - Static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- types - Variable in class org.jgroups.blocks.MethodCall
- typeToString() - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- typeToString(byte) - Static method in class org.jgroups.protocols.EncryptHeader
- typeToString(byte) - Static method in class org.jgroups.protocols.relay.RelayHeader
U
- UCAST_NAME - Static variable in class org.jgroups.protocols.UDP
- ucast_queue - Variable in class org.jgroups.protocols.BARRIER
- ucast_receivers - 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
- ucastRetransmissionAvailable(JChannel...) - Static method in class org.jgroups.util.Tests
- ucasts - Variable in class org.jgroups.util.MaxOneThreadPerSender
- UDP - Class in org.jgroups.protocols
-
IP multicast transport based on UDP.
- UDP() - Constructor for class org.jgroups.protocols.UDP
- 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
- udp_mcast_sock - Variable in class org.jgroups.stack.DiagnosticsHandler
- udp_response_sender - Variable in class org.jgroups.stack.DiagnosticsHandler
- udp_runner - Variable in class org.jgroups.stack.DiagnosticsHandler
- UDP_THREAD_NAME - Static variable in class org.jgroups.stack.DiagnosticsHandler
- udp_ucast_sock - Variable in class org.jgroups.stack.DiagnosticsHandler
- UDP.PacketReceiver - Class in org.jgroups.protocols
- udpEnabled() - Method in class org.jgroups.stack.DiagnosticsHandler
- 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_NB - Class in org.jgroups.protocols
-
Non-blocking alternative to
UFC
.
JIRA: https://issues.redhat.com/browse/JGRP-2172 - UFC_NB() - Constructor for class org.jgroups.protocols.UFC_NB
- UFC_REPLENISH_HDR - Static variable in class org.jgroups.protocols.UFC
- UNBATCH - Class in org.jgroups.protocols
-
Intercepts
Protocol.up(MessageBatch)
and passes up each message of a message batch as a single message. - UNBATCH() - Constructor for class org.jgroups.protocols.UNBATCH
- UnbatchOOBBatches - Class in org.jgroups.util
-
Same as
MaxOneThreadPerSender
, but for OOB message batches, every message of the batch is passed to the thread pool separately (https://issues.redhat.com/browse/JGRP-2800). - UnbatchOOBBatches() - Constructor for class org.jgroups.util.UnbatchOOBBatches
- 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(Thread) - Method in class org.jgroups.protocols.BARRIER
- unblockAll() - Method in class org.jgroups.protocols.SEQUENCER
- uncompress(Message, int, boolean) - 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
- UNDEFINED - org.jgroups.conf.AttributeType
- UNDEFINED - org.jgroups.conf.XmlConfigurator.ElementType
- unfragment(Message, Frag3Header) - Method in class org.jgroups.protocols.FRAG3
-
1.
- unfragment(Message, FragHeader) - Method in class org.jgroups.protocols.FRAG2
-
1.
- unicast - Variable in class org.jgroups.protocols.relay.RELAY3
- UNICAST - org.jgroups.protocols.relay.SiteAddress.Type
- UNICAST - org.jgroups.util.RpcStats.Type
- unicast_receiver_threads - Variable in class org.jgroups.protocols.UDP
- UNICAST3 - Class in org.jgroups.protocols
-
Reliable unicast protocol using a combination of positive and negative acks.
- UNICAST3 - Static variable in class org.jgroups.stack.CheckCallerRunsPolicy
- UNICAST3 - Static variable in class org.jgroups.stack.CheckForAbsenceOfRED
- UNICAST3() - Constructor for class org.jgroups.protocols.UNICAST3
- UNICAST3.Entry - Class in org.jgroups.protocols
- 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
- unicastDestMismatch(Address) - Method in class org.jgroups.protocols.TP
- UnicastHeader3 - Class in org.jgroups.protocols
-
Moved out of
UNICAST3
into separate class. - UnicastHeader3() - Constructor for class org.jgroups.protocols.UnicastHeader3
- UnicastHeader3(byte) - Constructor for class org.jgroups.protocols.UnicastHeader3
- UnicastHeader3(byte, long) - Constructor for class org.jgroups.protocols.UnicastHeader3
- UnicastHeader3(byte, long, short, boolean) - Constructor for class org.jgroups.protocols.UnicastHeader3
- 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
- unit - Variable in class org.jgroups.util.Average
- unit() - Method in annotation type org.jgroups.annotations.ManagedAttribute
-
Only used if type is TIME
- unit() - Method in annotation type org.jgroups.annotations.Property
-
Only used if type is TIME
- unit() - Method in class org.jgroups.util.Average
- unit(TimeUnit) - Method in class org.jgroups.util.Average
- 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) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- unknownMember(Address, Object) - Method in class org.jgroups.protocols.ReliableMulticast
- unmarshal(byte[], int, int) - Method in class org.jgroups.protocols.FD_SOCK
- unparkIfNeeded(int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- unparking - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- unparking - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- unreachable(Predicate<SiteAddress>) - Method in class org.jgroups.blocks.GroupRequest
- 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(String, Address) - Constructor for exception org.jgroups.UnreachableException
- UnreachableException(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(AsciiString, Address) - Static method in class org.jgroups.protocols.SHARED_LOOPBACK
- UNREGISTER - org.jgroups.stack.GossipType
- unregisterChannel(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
- unregisterChannel(MBeanServer, ObjectName) - 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
- unregisterChannel(JChannel, MBeanServer, ObjectName, 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(InetSocketAddress) - Method in class org.jgroups.stack.RouterStubManager
- unresolved_hosts - Variable in class org.jgroups.protocols.TCPPING
- unserializeAndInstallKeys(Address, byte[], ByteArrayDataInputStream) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
-
Unserializes public keys and installs them to pub_map, then reads encrypted shared keys and install our own
- unserializeKeys(Address, byte[], int, int) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- unsetThreadNames() - Method in class org.jgroups.protocols.TP
- unsetThreadNames() - Method in class org.jgroups.stack.DiagnosticsHandler
- unsubscribe(String) - Method in class org.jgroups.client.StompConnection
- UNSUBSCRIBE - org.jgroups.protocols.STOMP.ClientVerb
- 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(Address) - Method in class org.jgroups.protocols.FailureDetection
-
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(Address) - Method in class org.jgroups.protocols.FD_SOCK
- unsuspect(Address) - Method in class org.jgroups.protocols.FD_SOCK2
- 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
- unsuspect(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- UNSUSPECT - Static variable in class org.jgroups.Event
- UNSUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- UNSUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK2.FdHeader
- unwatch(Path) - Method in class org.jgroups.util.FileWatcher
- 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 - org.jgroups.protocols.relay.SiteStatus.Status
- up - Variable in class org.jgroups.protocols.DISCARD
- up - Variable in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- up - Variable in class org.jgroups.protocols.SHUFFLE
- up - Variable in class org.jgroups.protocols.SNIFF
- up() - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- up(Event) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
-
Called by channel (we registered before) when event is received.
- up(Event) - 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(Event) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- up(Event) - Method in class org.jgroups.protocols.BARRIER
- up(Event) - Method in class org.jgroups.protocols.BATCH
- up(Event) - Method in class org.jgroups.protocols.BATCH2
- up(Event) - Method in class org.jgroups.protocols.COUNTER
- up(Event) - Method in class org.jgroups.protocols.Discovery
- up(Event) - Method in class org.jgroups.protocols.Encrypt
- up(Event) - Method in class org.jgroups.protocols.FD_SOCK
- up(Event) - Method in class org.jgroups.protocols.FlowControl
- up(Event) - Method in class org.jgroups.protocols.FORK
- 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(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(Event) - Method in class org.jgroups.protocols.FRAG3
-
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
- up(Event) - Method in class org.jgroups.protocols.MPING
- up(Event) - Method in class org.jgroups.protocols.pbcast.GMS
- up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK2
-
Callback.
- up(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
- up(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- up(Event) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- up(Event) - Method in class org.jgroups.protocols.relay.RELAY
- up(Event) - Method in class org.jgroups.protocols.ReliableMulticast
-
Callback.
- up(Event) - Method in class org.jgroups.protocols.RSVP
- up(Event) - Method in class org.jgroups.protocols.SEQUENCER
- up(Event) - Method in class org.jgroups.protocols.SEQUENCER2
- up(Event) - Method in class org.jgroups.protocols.SSL_KEY_EXCHANGE
- up(Event) - Method in class org.jgroups.protocols.STATS
- up(Event) - Method in class org.jgroups.protocols.STOMP
- up(Event) - Method in class org.jgroups.protocols.TRACE
- up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- up(Event) - Method in class org.jgroups.stack.Protocol
-
An event was received from the protocol below.
- up(Event) - Method in class org.jgroups.stack.ProtocolStack
- up(Event) - Method in interface org.jgroups.UpHandler
- up(Message) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- up(Message) - Method in class org.jgroups.fork.ForkProtocolStack
- up(Message) - Method in class org.jgroups.JChannel
- up(Message) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- up(Message) - Method in class org.jgroups.protocols.AUTH
-
An event was received from the layer below.
- up(Message) - Method in class org.jgroups.protocols.BARRIER
- up(Message) - Method in class org.jgroups.protocols.BATCH
- up(Message) - Method in class org.jgroups.protocols.BATCH2
- up(Message) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- up(Message) - Method in class org.jgroups.protocols.COMPRESS
-
If there is no header, we pass the message up.
- up(Message) - Method in class org.jgroups.protocols.COUNTER
- up(Message) - Method in class org.jgroups.protocols.DAISYCHAIN
- up(Message) - Method in class org.jgroups.protocols.DELAY
- up(Message) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- up(Message) - Method in class org.jgroups.protocols.DISCARD
- up(Message) - Method in class org.jgroups.protocols.Discovery
- up(Message) - Method in class org.jgroups.protocols.DROP
- up(Message) - Method in class org.jgroups.protocols.DUPL
- up(Message) - Method in class org.jgroups.protocols.Encrypt
- up(Message) - Method in class org.jgroups.protocols.EXAMPLE
- up(Message) - Method in class org.jgroups.protocols.FailureDetection
- up(Message) - Method in class org.jgroups.protocols.FD_SOCK
- up(Message) - Method in class org.jgroups.protocols.FD_SOCK2
- up(Message) - Method in class org.jgroups.protocols.FlowControl
- up(Message) - Method in class org.jgroups.protocols.FORK
- up(Message) - Method in class org.jgroups.protocols.FRAG
- up(Message) - Method in class org.jgroups.protocols.FRAG2
- up(Message) - Method in class org.jgroups.protocols.FRAG3
- up(Message) - Method in class org.jgroups.protocols.HDRS
- up(Message) - Method in class org.jgroups.protocols.MAKE_BATCH
- up(Message) - Method in class org.jgroups.protocols.MERGE3
- up(Message) - Method in class org.jgroups.protocols.NON_BLOCKING_SENDS
- up(Message) - Method in class org.jgroups.protocols.pbcast.GMS
- up(Message) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- up(Message) - Method in class org.jgroups.protocols.pbcast.STABLE
- up(Message) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- up(Message) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- up(Message) - Method in class org.jgroups.protocols.PERF
- up(Message) - Method in class org.jgroups.protocols.RATE
- up(Message) - Method in class org.jgroups.protocols.relay.RELAY2
- up(Message) - Method in class org.jgroups.protocols.relay.RELAY3
- up(Message) - Method in class org.jgroups.protocols.ReliableMulticast
- up(Message) - Method in class org.jgroups.protocols.REVERSE
- up(Message) - Method in class org.jgroups.protocols.RSVP
- up(Message) - Method in class org.jgroups.protocols.SEQUENCER
- up(Message) - Method in class org.jgroups.protocols.SEQUENCER2
- up(Message) - Method in class org.jgroups.protocols.SERIALIZE
- up(Message) - Method in class org.jgroups.protocols.SHUFFLE
- up(Message) - Method in class org.jgroups.protocols.SIZE
- up(Message) - Method in class org.jgroups.protocols.SNIFF
- up(Message) - Method in class org.jgroups.protocols.STATS
- up(Message) - Method in class org.jgroups.protocols.STOMP
- up(Message) - Method in class org.jgroups.protocols.THREAD_COUNT
- up(Message) - Method in class org.jgroups.protocols.TIME
- up(Message) - Method in class org.jgroups.protocols.UNICAST3
- up(Message) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- up(Message) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- up(Message) - Method in class org.jgroups.stack.Protocol
-
A single message was received.
- up(Message) - Method in class org.jgroups.stack.ProtocolStack
- up(Message) - Method in interface org.jgroups.UpHandler
- up(MessageBatch) - Method in class org.jgroups.blocks.MessageDispatcher.ProtocolAdapter
- up(MessageBatch) - Method in class org.jgroups.fork.ForkProtocolStack
- up(MessageBatch) - Method in class org.jgroups.JChannel
-
Callback invoked by the protocol stack to deliver a message batch
- up(MessageBatch) - Method in class org.jgroups.protocols.ASYM_ENCRYPT
- up(MessageBatch) - Method in class org.jgroups.protocols.AUTH
- up(MessageBatch) - Method in class org.jgroups.protocols.BARRIER
- up(MessageBatch) - Method in class org.jgroups.protocols.BATCH
- up(MessageBatch) - Method in class org.jgroups.protocols.BATCH2
- up(MessageBatch) - Method in class org.jgroups.protocols.CLEAR_FLAGS
- up(MessageBatch) - Method in class org.jgroups.protocols.COMPRESS
- up(MessageBatch) - Method in class org.jgroups.protocols.DELAY
- up(MessageBatch) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE
- up(MessageBatch) - Method in class org.jgroups.protocols.DISCARD
- up(MessageBatch) - Method in class org.jgroups.protocols.Discovery
- up(MessageBatch) - Method in class org.jgroups.protocols.DROP
- up(MessageBatch) - Method in class org.jgroups.protocols.DUPL
- up(MessageBatch) - Method in class org.jgroups.protocols.Encrypt
- up(MessageBatch) - Method in class org.jgroups.protocols.EXAMPLE
- up(MessageBatch) - Method in class org.jgroups.protocols.FailureDetection
- up(MessageBatch) - Method in class org.jgroups.protocols.FD_SOCK2
- up(MessageBatch) - Method in class org.jgroups.protocols.FlowControl
- up(MessageBatch) - Method in class org.jgroups.protocols.FORK
- up(MessageBatch) - Method in class org.jgroups.protocols.FRAG
- up(MessageBatch) - Method in class org.jgroups.protocols.FRAG2
- up(MessageBatch) - Method in class org.jgroups.protocols.FRAG3
- up(MessageBatch) - Method in class org.jgroups.protocols.HDRS
- up(MessageBatch) - Method in class org.jgroups.protocols.MAKE_BATCH
- up(MessageBatch) - Method in class org.jgroups.protocols.MERGE3
- up(MessageBatch) - Method in class org.jgroups.protocols.NON_BLOCKING_SENDS
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.GMS
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.STABLE
- up(MessageBatch) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- up(MessageBatch) - Method in class org.jgroups.protocols.PERF
- up(MessageBatch) - Method in class org.jgroups.protocols.RATE
- up(MessageBatch) - Method in class org.jgroups.protocols.RED
- up(MessageBatch) - Method in class org.jgroups.protocols.relay.RELAY2
- up(MessageBatch) - Method in class org.jgroups.protocols.relay.RELAY3
- up(MessageBatch) - Method in class org.jgroups.protocols.ReliableMulticast
- up(MessageBatch) - Method in class org.jgroups.protocols.REVERSE
- up(MessageBatch) - Method in class org.jgroups.protocols.RSVP
- up(MessageBatch) - Method in class org.jgroups.protocols.SEQUENCER
- up(MessageBatch) - Method in class org.jgroups.protocols.SEQUENCER2
- up(MessageBatch) - Method in class org.jgroups.protocols.SERIALIZE
- up(MessageBatch) - Method in class org.jgroups.protocols.SHUFFLE
- up(MessageBatch) - Method in class org.jgroups.protocols.SIZE
- up(MessageBatch) - Method in class org.jgroups.protocols.SNIFF
- up(MessageBatch) - Method in class org.jgroups.protocols.SOS
- up(MessageBatch) - Method in class org.jgroups.protocols.STATS
- up(MessageBatch) - Method in class org.jgroups.protocols.STOMP
- up(MessageBatch) - Method in class org.jgroups.protocols.THREAD_COUNT
- up(MessageBatch) - Method in class org.jgroups.protocols.TIME
-
Dividing the delivery time for a batch by the batch size is problematic, e.g.
- up(MessageBatch) - Method in class org.jgroups.protocols.TRACE
- up(MessageBatch) - Method in class org.jgroups.protocols.UNBATCH
- up(MessageBatch) - Method in class org.jgroups.protocols.UNICAST3
- up(MessageBatch) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- up(MessageBatch) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
- up(MessageBatch) - Method in class org.jgroups.stack.Protocol
-
Sends up a multiple messages in a
MessageBatch
. - up(MessageBatch) - Method in class org.jgroups.stack.ProtocolStack
- up(MessageBatch) - Method in interface org.jgroups.UpHandler
- UP - org.jgroups.protocols.DUPL.Direction
- up_batches - Variable in class org.jgroups.protocols.TIME
- up_count - Variable in class org.jgroups.protocols.THREAD_COUNT
- up_delivery_batches - Variable in class org.jgroups.protocols.TIME
- up_delivery_msgs - Variable in class org.jgroups.protocols.TIME
- up_filters - Variable in class org.jgroups.protocols.DROP
- up_flags - Variable in class org.jgroups.protocols.CLEAR_FLAGS
- up_handler - Variable in class org.jgroups.JChannel
- up_lock - Variable in class org.jgroups.protocols.SHUFFLE
- up_msgs - Variable in class org.jgroups.protocols.SHUFFLE
- up_msgs - Variable in class org.jgroups.protocols.TIME
- up_prot - Variable in class org.jgroups.stack.Protocol
- up_threads - Variable in class org.jgroups.protocols.THREAD_COUNT
- update - Variable in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- update() - Method in class org.jgroups.util.SuppressCache.Value
- update(Address, boolean, boolean) - Method in class org.jgroups.protocols.FailureDetection
- update(Address, boolean, boolean) - Method in class org.jgroups.protocols.FD_ALL
- update(Address, boolean, boolean) - Method in class org.jgroups.protocols.FD_ALL2
- update(Address, boolean, boolean) - Method in class org.jgroups.protocols.FD_ALL3
- update(CounterFunction<T>) - Method in interface org.jgroups.blocks.atomic.AsyncCounter
-
Atomically updates the counter's value.
- update(CounterFunction<T>) - Method in interface org.jgroups.blocks.atomic.SyncCounter
-
Atomically updates the counter's value.
- update(CounterFunction<T>) - Method in class org.jgroups.protocols.COUNTER.CounterImpl
- update(UNICAST3.Entry, int) - Method in class org.jgroups.protocols.UNICAST3
- update(RpcStats.Type, boolean) - Method in class org.jgroups.util.RpcStats
- UPDATE - org.jgroups.protocols.COUNTER.RequestType
- UPDATE_FUNCTION - org.jgroups.protocols.COUNTER.RequestType
- UPDATE_FUNCTION - org.jgroups.protocols.COUNTER.ResponseType
- update_store_on_view_change - Variable in class org.jgroups.protocols.FILE_PING
- updateBackups(String, 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.Connection
- 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
- updateStoreOnViewChange() - Method in class org.jgroups.protocols.FILE_PING
- updateStoreOnViewChange(boolean) - Method in class org.jgroups.protocols.FILE_PING
- updateTimestampFor(InetAddress) - Method in class org.jgroups.protocols.FD_HOST
- upFlags() - Method in class org.jgroups.protocols.CLEAR_FLAGS
- UpHandler - Interface in org.jgroups
-
Provides a hook to hijack all events received by a certain channel which has installed this UpHandler.
- upReq() - Method in class org.jgroups.protocols.RTTHeader
-
The time after deserializing a request until before it is dispatched to the application
- upRsp() - Method in class org.jgroups.protocols.RTTHeader
-
The time between deserialization of a response and after dispatching to the application
- URL_SAFE - Static variable in class org.jgroups.util.Base64
-
Encode using Base64-like encoding that is URL- and Filename-safe as described in Section 4 of RFC3548: http://www.faqs.org/rfcs/rfc3548.html.
- use_acks - Variable in class org.jgroups.blocks.cs.BaseServer
- use_acks - Variable in class org.jgroups.protocols.BasicTCP
- 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_direct_memory_for_allocations - Variable in class org.jgroups.NioMessage
-
If true, use direct memory when creating
ByteBuffer
payloads, e.g. - use_disk_cache - Variable in class org.jgroups.protocols.Discovery
- use_external_key_exchange - Variable in class org.jgroups.protocols.ASYM_ENCRYPT
- 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.logging.LogFactory
- USE_JDK_LOGGER - Static variable in class org.jgroups.Global
- use_mcast_rsps - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- use_mcast_rsps - Variable in class org.jgroups.protocols.VERIFY_SUSPECT2
- use_mcast_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Retransmit messages using multicast rather than unicast.
- use_mcast_xmit - Variable in class org.jgroups.protocols.ReliableMulticast
-
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_mcast_xmit_req - Variable in class org.jgroups.protocols.ReliableMulticast
-
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_time_service - Variable in class org.jgroups.protocols.FD_ALL
- use_time_service - Variable in class org.jgroups.protocols.FD_HOST
- use_virtual_threads - Variable in class org.jgroups.protocols.TP
- use_virtual_threads - Variable in class org.jgroups.util.DefaultThreadFactory
- use_virtual_threads - Variable in class org.jgroups.util.ThreadPool
- useAcks() - Method in class org.jgroups.blocks.cs.BaseServer
- useAcks() - Method in class org.jgroups.protocols.BasicTCP
- useAcks(boolean) - Method in class org.jgroups.blocks.cs.BaseServer
- useAcks(boolean) - Method in class org.jgroups.protocols.BasicTCP
- useAsyncStateDelivery() - Method in class org.jgroups.protocols.pbcast.STATE
- useAsyncStateDelivery() - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer
- useDeltaViews() - Method in class org.jgroups.protocols.pbcast.GMS
- useDeltaViews(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- useDirectMemory() - Method in class org.jgroups.NioMessage
- useDirectMemory(boolean) - Method in class org.jgroups.NioMessage
- useDiskCache() - Method in class org.jgroups.protocols.Discovery
- useDiskCache(boolean) - Method in class org.jgroups.protocols.Discovery
- useFibers() - Method in class org.jgroups.util.DefaultThreadFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.
- useFibers(boolean) - Method in class org.jgroups.util.DefaultThreadFactory
-
Deprecated, for removal: This API element is subject to removal in a future version.
- useIds() - Method in class org.jgroups.blocks.MethodCall
- useJdkLogger() - Static method in class org.jgroups.logging.LogFactory
- useJdkLogger(boolean) - Static method in class org.jgroups.logging.LogFactory
- useMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- useMcastXmit() - Method in class org.jgroups.protocols.ReliableMulticast
- useMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- useMcastXmit(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- useMcastXmitReq() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- useMcastXmitReq() - Method in class org.jgroups.protocols.ReliableMulticast
- useMcastXmitReq(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- useMcastXmitReq(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- useNio() - Method in class org.jgroups.protocols.TUNNEL
- useNio() - Method in class org.jgroups.stack.GossipRouter
- useNio() - Method in class org.jgroups.stack.RouterStub
- useNio(boolean) - Method in class org.jgroups.protocols.TUNNEL
- useNio(boolean) - Method in class org.jgroups.stack.GossipRouter
- 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
- usePercentiles() - Method in class org.jgroups.util.AverageMinMax
- usePercentiles(int) - Method in class org.jgroups.util.AverageMinMax
- 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
- user_time - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- userid - Variable in class org.jgroups.client.StompConnection
- 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
- useVirtualThreads() - Method in class org.jgroups.protocols.TP
- useVirtualThreads() - Method in class org.jgroups.util.DefaultThreadFactory
- useVirtualThreads() - Method in class org.jgroups.util.ThreadPool
- useVirtualThreads(boolean) - Method in class org.jgroups.protocols.TP
- useVirtualThreads(boolean) - Method in class org.jgroups.util.DefaultThreadFactory
- useVirtualThreads(boolean) - Method in class org.jgroups.util.ThreadPool
- utcEpoch(long) - Static method in class org.jgroups.util.Util
- utcNow() - Static method in class org.jgroups.util.Util
- 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(byte[]) - Constructor for class org.jgroups.util.UUID
-
Private constructor which uses a byte array to construct the new UUID
- UUID(long, long) - Constructor for class org.jgroups.util.UUID
- UUID(UUID) - Constructor for class org.jgroups.util.UUID
- UUID_ADDR - Static variable in interface org.jgroups.Address
- UUID_PREFIX - Static variable in class org.jgroups.util.Util
V
- 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, StackType) - Static method in class org.jgroups.util.Util
-
Method used by PropertyConverters.BindInterface to check that a bind_addr is consistent with a specified interface
- validateProperties() - Method in class org.jgroups.protocols.dns.DNS_PING
- validateSecurityContext(Subject, byte[]) - Static method in class org.jgroups.auth.Krb5TokenUtils
- value - Variable in class org.jgroups.LongMessage
- 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() - Method in annotation type org.jgroups.annotations.GuardedBy
- value() - Method in enum org.jgroups.Message.Flag
- value() - Method in enum org.jgroups.Message.TransientFlag
- Value() - Constructor for class org.jgroups.blocks.Cache.Value
- Value() - Constructor for class org.jgroups.util.SuppressCache.Value
- Value(V, long) - Constructor for class org.jgroups.blocks.Cache.Value
- Value(V, short) - Constructor for class org.jgroups.blocks.ReplCache.Value
- VALUE - org.jgroups.protocols.COUNTER.ResponseType
- 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.ResponseMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.conf.AttributeType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.conf.XmlConfigurator.ElementType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.JChannel.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.ASYM_ENCRYPT.Processing
-
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.DH_KEY_EXCHANGE.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.dns.DNSResolver.DNSRecordType
-
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.FD_SOCK2.Request.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.FD_SOCK2.State
-
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.SiteAddress.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.protocols.relay.SiteStatus.Status
-
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.GossipRouter.DumpMessages
-
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.stack.ProtocolStack.Position
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.jgroups.util.CompletableFutures
-
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.TLSClientAuth
-
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 - Variable in class org.jgroups.protocols.COUNTER.ReconcileRequest
- values - Variable in class org.jgroups.protocols.COUNTER.ReconcileResponse
- values - Variable in class org.jgroups.util.AverageMinMax
- values - Variable in class org.jgroups.util.ExtendedUUID
- 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() - Method in class org.jgroups.blocks.LazyRemovalCache
- 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.conf.AttributeType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.jgroups.conf.XmlConfigurator.ElementType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.jgroups.JChannel.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.ASYM_ENCRYPT.Processing
-
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.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.DH_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.dns.DNSResolver.DNSRecordType
-
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.FD_SOCK2.Request.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.FD_SOCK2.State
-
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.SiteAddress.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.SiteStatus.Status
-
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.GossipRouter.DumpMessages
-
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() - Static method in enum org.jgroups.stack.ProtocolStack.Position
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.jgroups.util.AverageMinMax
- values() - Static method in enum org.jgroups.util.CompletableFutures
-
Returns an array containing the constants of this enum type, in the order they are declared.
- 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() - 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() - 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.TLSClientAuth
-
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.protocols.NON_BLOCKING_SENDS
- verbose - Variable in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- verbose - Variable in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- verbose - Variable in class org.jgroups.util.MyReceiver
- verbose() - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- verbose() - Method in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- verbose(boolean) - Method in class org.jgroups.protocols.relay.DefaultRouteStatusListener
- verbose(boolean) - Method in class org.jgroups.protocols.relay.RandomSiteMasterPicker
- 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
- VERIFY_SUSPECT2 - Class in org.jgroups.protocols
-
Double-checks that a suspected member is really dead.
Details: https://issues.redhat.com/browse/JGRP-2558
Design: https://github.com/belaban/JGroups/blob/master/doc/design/VERIFY_SUSPECT2.txt - VERIFY_SUSPECT2() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT2
- VERIFY_SUSPECT2.Entry - Class in org.jgroups.protocols
- VERIFY_SUSPECT2.VerifyHeader - Class in org.jgroups.protocols
- verifyArray(byte[]) - Static method in class org.jgroups.util.Util
- verifyByteBuffer(ByteBuffer) - Static method in class org.jgroups.util.Util
- verifyConfigurationParameters() - Method in class org.jgroups.protocols.JDBC_PING
- VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- verifySuspect(Collection<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
-
Sends ARE_YOU_DEAD message to suspected_mbr, wait for return or timeout
- verifySuspect(Collection<Address>) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2
-
Sends ARE_YOU_DEAD message to suspected_mbr, wait for return or timeout
- verifySuspectWithICMP(Address) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- version - Variable in class org.jgroups.protocols.COUNTER.UpdateRequest
- version - Variable in class org.jgroups.protocols.COUNTER.ValueResponse
- version - Variable in class org.jgroups.protocols.COUNTER.VersionedValue
- version - Variable in class org.jgroups.protocols.EncryptHeader
- version - Static variable in class org.jgroups.Version
- version() - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- version() - Method in class org.jgroups.protocols.Encrypt
- 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_CHECK - Static variable in class org.jgroups.Global
- VERSION_CHECK_MICRO - Static variable in class org.jgroups.Global
- 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 - Variable in class org.jgroups.JChannel
- view - Variable in class org.jgroups.protocols.COUNTER
- view - Variable in class org.jgroups.protocols.DAISYCHAIN
- view - Variable in class org.jgroups.protocols.Discovery
- view - Variable in class org.jgroups.protocols.Encrypt
- view - Variable in class org.jgroups.protocols.MERGE3
- view - Variable 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.Bridge
- view - Variable in class org.jgroups.protocols.relay.RELAY
- view - Variable in class org.jgroups.protocols.relay.Relayer2.Bridge
- view - Variable in class org.jgroups.protocols.ReliableMulticast
- view - Variable in class org.jgroups.protocols.SEQUENCER
- view - Variable in class org.jgroups.protocols.SEQUENCER2
- 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.JChannel
- view() - Method in class org.jgroups.protocols.pbcast.GMS
- view() - Method in class org.jgroups.protocols.relay.RELAY
- 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(Address, long, List<Address>) - Constructor for class org.jgroups.View
-
Creates a new view
- 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 - Static variable in class org.jgroups.demos.StompChat
- VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- 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_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_handler - Variable in class org.jgroups.protocols.relay.Topology
- view_id - Variable in class org.jgroups.protocols.MERGE3.MergeHeader
- 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_REQ - org.jgroups.protocols.MERGE3.MergeHeader.Type
- VIEW_RSP - org.jgroups.protocols.MERGE3.MergeHeader.Type
- view_rsps - Variable in class org.jgroups.protocols.MERGE3
- VIEW_SEPARATOR - Static variable in class org.jgroups.protocols.INJECT_VIEW
- 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.RelayDemo
- viewAccepted(View) - Method in class org.jgroups.demos.RelayDemoRpc
- viewAccepted(View) - Method in class org.jgroups.protocols.relay.Bridge
-
The view contains a list of SiteUUIDs.
- viewAccepted(View) - Method in class org.jgroups.protocols.relay.Relayer2.Bridge
-
The view contains a list of SiteUUIDs.
- viewAccepted(View) - Method in interface org.jgroups.Receiver
-
Called when a change in membership has occurred.
- viewAccepted(View) - Method in class org.jgroups.util.MyReceiver
- viewChange(List<Address>) - Method in class org.jgroups.util.MaxOneThreadPerSender.MessageTable
- viewChange(List<Address>) - Method in class org.jgroups.util.MaxOneThreadPerSender
- viewChange(View) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- viewChange(View) - Method in class org.jgroups.protocols.BaseBundler
- viewChange(View) - Method in class org.jgroups.protocols.BatchBundler
- viewChange(View) - Method in interface org.jgroups.protocols.Bundler
- viewChange(View) - Method in interface org.jgroups.protocols.LocalTransport
- viewChange(View) - Method in class org.jgroups.protocols.PerDestinationBundler
- viewChange(View) - Method in class org.jgroups.protocols.TransferQueueBundler2
- viewChange(View, boolean) - Method in class org.jgroups.blocks.GroupRequest
-
Any member of 'membership' that is not in the new view is flagged as SUSPECTED.
- viewChange(View, boolean) - Method in class org.jgroups.blocks.Request
- viewChange(View, boolean) - 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 suspected and unblock the caller of execute()
- viewChange(View, List<Address>, List<Address>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- viewChange(View, List<Address>, List<Address>) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- ViewConsistencyChecker() - Constructor for class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
- ViewHandler<R> - Class in org.jgroups.protocols.pbcast
-
Responsible for dispatching JOIN/LEAVE/MERGE requests to the GMS protocol.
- ViewHandler(GMS, Consumer<Collection<R>>, BiPredicate<R, R>) - Constructor for class org.jgroups.protocols.pbcast.ViewHandler
-
Constructor
- 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.MERGE3
- views - Variable in class org.jgroups.protocols.pbcast.GmsImpl.Request
- virtualThreadsAvailable() - Static method in class org.jgroups.util.Util
- visit(long, T) - Method in class org.jgroups.util.Buffer.HighestDeliverable
- visit(long, T) - Method in class org.jgroups.util.Buffer.Missing
- visit(long, T) - Method in class org.jgroups.util.Buffer.NumDeliverable
- visit(long, T) - Method in class org.jgroups.util.Buffer.Remover
- visit(long, T) - Method in interface org.jgroups.util.Buffer.Visitor
-
Iteration over the table, used by
DynamicBuffer.forEach(long, long, Buffer.Visitor, boolean)
. - 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.NumDeliverable
- visit(long, T, int, int) - Method in class org.jgroups.util.Table.Remover
- visit(long, T, int, int) - Method in interface org.jgroups.util.Table.Visitor
-
Iteration over the table, used by
Table.forEach(long,long,org.jgroups.util.Table.Visitor)
. - visit(T) - Method in interface org.jgroups.util.RequestTable.Visitor
- visited_sites - Variable in class org.jgroups.protocols.relay.RelayHeader
- voidConsumer() - Static method in enum org.jgroups.util.CompletableFutures
-
Consumes any value and return a
Void
. - votes - Variable in class org.jgroups.protocols.pbcast.STABLE
-
Keeps track of who we already heard from (STABLE_GOSSIP msgs).
W
- wait_strategy - Variable in class org.jgroups.protocols.RingBufferBundler
- wait_time - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- waiters - Variable in class org.jgroups.util.SizeBoundedQueue
- waitFor(long) - Method in class org.jgroups.util.Responses
- waitFor(BooleanSupplier) - Method in class org.jgroups.util.CondVar
-
Blocks until condition is true.
- waitFor(BooleanSupplier, long, TimeUnit) - Method in class org.jgroups.util.CondVar
-
Blocks until condition is true or the time elapsed
- waitForAllAcks() - Method in class org.jgroups.util.AckCollector
- waitForAllAcks(long) - Method in class org.jgroups.util.AckCollector
- waitForAllResponses(long) - Method in class org.jgroups.util.ResponseCollector
-
Waits until all responses have been received, or until a timeout has elapsed.
- waitForCompletion() - Method in class org.jgroups.blocks.GroupRequest
- waitForCompletion() - Method in class org.jgroups.blocks.Request
- waitForCompletion() - Method in class org.jgroups.blocks.UnicastRequest
- waitForCompletion(long, TimeUnit) - Method in class org.jgroups.blocks.GroupRequest
- waitForCompletion(long, TimeUnit) - Method in class org.jgroups.blocks.Request
-
Blocks until all responses have been received and returns result or throws exception
- waitForCompletion(long, TimeUnit) - Method in class org.jgroups.blocks.UnicastRequest
- waitForConnect(long) - Method in class org.jgroups.protocols.FD_SOCK2.PingDest
- waitForMessages() - Method in class org.jgroups.util.RingBuffer
-
Blocks until messages are available
- waitForMessages(int, BiConsumer<Integer, Integer>) - Method in class org.jgroups.util.RingBuffer
-
Blocks until messages are available
- waitForNotEmpty() - Method in class org.jgroups.util.ConcurrentLinkedBlockingQueue2
- waiting_for_state_response - Variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
set to true while waiting for a STATE_RSP
- waits - Variable in class org.jgroups.JChannelProbeHandler.ThreadEntry
- waitStrategy() - Method in class org.jgroups.protocols.RingBufferBundler
- waitStrategy(String) - Method in class org.jgroups.protocols.RingBufferBundler
- waitUntil(long, long, BooleanSupplier) - Static method in class org.jgroups.util.Util
- waitUntil(long, long, BooleanSupplier, Supplier<String>) - Static method in class org.jgroups.util.Util
- waitUntilAllChannelsHaveSameView(long, long, Collection<JChannel>) - Static method in class org.jgroups.util.Util
- waitUntilAllChannelsHaveSameView(long, long, JChannel...) - Static method in class org.jgroups.util.Util
-
Blocks until all channels have the same view
- waitUntilComplete() - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
Blocks the caller until the current set of requests being processed have been completed.
- waitUntilComplete(long) - Method in class org.jgroups.protocols.pbcast.ViewHandler
-
Blocks the caller until the current set of requests being processed have been completed, or the timeout elapsed.
Returns immediately if no requests are currently being processed - waitUntilListHasSize(List<T>, int, long, long) - Static method in class org.jgroups.util.Util
-
Waits until a list has the expected number of elements.
- waitUntilNoX(long, long, BooleanSupplier) - Static method in class org.jgroups.util.Util
- waitUntilTrue(long, long, BooleanSupplier) - Static method in class org.jgroups.util.Util
- WANT - org.jgroups.util.TLSClientAuth
- warn - org.jgroups.util.SuppressLog.Level
- warn(String) - Method in class org.jgroups.logging.JDKLogImpl
- warn(String) - Method in interface org.jgroups.logging.Log
- warn(String) - Method in class org.jgroups.logging.Log4J2LogImpl
- warn(String) - Method in class org.jgroups.logging.Slf4jLogImpl
- warn(String, Object...) - Method in class org.jgroups.logging.JDKLogImpl
- warn(String, Object...) - Method in interface org.jgroups.logging.Log
- warn(String, Object...) - Method in class org.jgroups.logging.Log4J2LogImpl
- warn(String, Object...) - Method in class org.jgroups.logging.Slf4jLogImpl
- warn(String, Throwable) - Method in class org.jgroups.logging.JDKLogImpl
- warn(String, Throwable) - Method in interface org.jgroups.logging.Log
- warn(String, Throwable) - Method in class org.jgroups.logging.Log4J2LogImpl
- warn(String, Throwable) - Method in class org.jgroups.logging.Slf4jLogImpl
- wasReceived() - Method in class org.jgroups.util.Rsp
- wasSuspected() - Method in class org.jgroups.util.Rsp
- wasUnreachable() - Method in class org.jgroups.util.Rsp
- watch(Path, Consumer<Path>) - Method in class org.jgroups.util.FileWatcher
- watcher - Variable in class org.jgroups.util.TLS
- watcher(FileWatcher) - Method in class org.jgroups.util.SslContextFactory
- weedOutCompletedDiscoveryResponses() - Method in class org.jgroups.protocols.Discovery
-
Removes responses which are done or whose timeout has expired (in the latter case, an expired response is marked as done)
- weight - Variable in class org.jgroups.protocols.RED
- weight_factor - Variable in class org.jgroups.protocols.RED
- WHITESPACE - Static variable in class org.jgroups.protocols.Discovery
- who_has_cache - Variable in class org.jgroups.protocols.TP
-
Cache keeping track of WHO_HAS requests for physical addresses (given a logical address) and expiring them after who_has_cache_timeout ms
- who_has_cache_timeout - Variable in class org.jgroups.protocols.TP
- WHO_HAS_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- wi - Variable in class org.jgroups.util.RingBuffer
- windowActivated(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowActivated(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowClosed(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowClosed(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowClosing(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowClosing(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowDeactivated(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowDeactivated(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowDeiconified(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowDeiconified(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowIconified(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowIconified(WindowEvent) - Method in class org.jgroups.demos.Topology
- windowOpened(WindowEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- windowOpened(WindowEvent) - Method in class org.jgroups.demos.Topology
- WORD_MASK - Static variable in class org.jgroups.util.FixedSizeBitSet
- wordIndex(int) - Static method in class org.jgroups.util.FixedSizeBitSet
- words - Variable in class org.jgroups.util.FixedSizeBitSet
- workAvailable(MessageBatch) - Method in class org.jgroups.util.MaxOneThreadPerSender.Entry
-
Called by
MaxOneThreadPerSender.BatchHandlerLoop
. - wouldBeNewCoordinator(Address) - Method in class org.jgroups.protocols.pbcast.GMS
-
Checks whether the potential_new_coord would be the new coordinator (2nd in line)
- wouldIBeCoordinator(Collection<Address>) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
Determines whether this member is the new coordinator given a list of suspected members.
- wrap(JChannel) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Wrap JChannel with DynamicMBean interface.
- wrap(Protocol) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Wrap Protocol with DynamicMBean interface.
- wrap_exceptions - Variable in class org.jgroups.blocks.MessageDispatcher
- wrap_exceptions - Variable in class org.jgroups.blocks.RequestCorrelator
- wrapAsCompletionException(Throwable) - Static method in enum org.jgroups.util.CompletableFutures
-
Wraps the
throwable
intoCompletionException
. - wrapDirect(byte[]) - Static method in class org.jgroups.util.Util
- wrapDirect(byte[], int, int) - Static method in class org.jgroups.util.Util
- wrapExceptions() - Method in class org.jgroups.blocks.MessageDispatcher
- wrapExceptions() - Method in class org.jgroups.blocks.RequestCorrelator
- wrapExceptions(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- wrapExceptions(boolean) - Method in class org.jgroups.blocks.RequestCorrelator
- WRAPPED_BCAST - Static variable in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- writable() - Method in annotation type org.jgroups.annotations.ManagedAttribute
- writable() - Method in annotation type org.jgroups.annotations.Property
- write(byte[]) - Method in class org.jgroups.blocks.GridOutputStream
- write(byte[]) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- write(byte[]) - Method in class org.jgroups.util.BaseDataOutputStream
- write(byte[]) - Method in class org.jgroups.util.BlockingInputStream
-
Appends bytes to the end of the stream
- write(byte[]) - Method in class org.jgroups.util.ByteArrayDataOutputStream
- write(byte[]) - Method in class org.jgroups.util.ByteBufferOutputStream
- write(byte[]) - Method in class org.jgroups.util.OutputStreamAdapter
- write(byte[], int, int) - Method in class org.jgroups.blocks.GridOutputStream
- write(byte[], int, int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- write(byte[], int, int) - Method in class org.jgroups.util.Base64.OutputStream
-
Calls
Base64.OutputStream.write(int)
repeatedly until len bytes are written. - write(byte[], int, int) - Method in class org.jgroups.util.BaseDataOutputStream
- write(byte[], int, int) - Method in class org.jgroups.util.BlockingInputStream
-
Appends bytes to the end of the stream.
- write(byte[], int, int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
- write(byte[], int, int) - Method in class org.jgroups.util.ByteBufferOutputStream
- write(byte[], int, int) - Method in class org.jgroups.util.OutputStreamAdapter
- write(byte[], int, int) - Method in class org.jgroups.util.PartialOutputStream
- write(int) - Method in class org.jgroups.blocks.GridOutputStream
- write(int) - Method in class org.jgroups.protocols.pbcast.STATE.StateOutputStream
- write(int) - Method in class org.jgroups.util.Base64.OutputStream
-
Writes the byte to the output stream after converting to/from Base64 notation.
- write(int) - Method in class org.jgroups.util.BaseDataOutputStream
- write(int) - Method in class org.jgroups.util.ByteArrayDataOutputStream
- write(int) - Method in class org.jgroups.util.ByteBufferOutputStream
- write(int) - Method in class org.jgroups.util.OutputStreamAdapter
- write(int) - Method in class org.jgroups.util.PartialOutputStream
- write(DataOutput) - Method in class org.jgroups.util.ExtendedUUID
- write(ByteBuffer) - Method in class org.jgroups.nio.MockSocketChannel
- write(ByteBuffer[], int, int) - Method in class org.jgroups.nio.MockSocketChannel
- write(GatheringByteChannel) - Method in class org.jgroups.nio.Buffers
-
Writes the buffers from position to limit to the given channel.
- write(GatheringByteChannel, ByteBuffer...) - Method in class org.jgroups.nio.Buffers
-
Helper method which adds the buffers passed as arguments and then calls write()
- write(List<PingData>, OutputStream) - Method in class org.jgroups.protocols.Discovery
- write(List<PingData>, OutputStream) - Method in class org.jgroups.protocols.FILE_PING
- write(List<PingData>, String) - Method in class org.jgroups.protocols.FILE_PING
- write(List<PingData>, String) - Method in class org.jgroups.protocols.JDBC_PING
- write(List<PingData>, String) - Method in class org.jgroups.protocols.JDBC_PING2
- write(List<PingData>, String) - Method in class org.jgroups.protocols.RACKSPACE_PING
- write(List<PingData>, String) - Method in class org.jgroups.protocols.SWIFT_PING
- write(T[], DataOutput) - Static method in class org.jgroups.util.Util
- write_data_on_find - Variable in class org.jgroups.protocols.FILE_PING
- write_index - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- write_index - Variable in class org.jgroups.protocols.RingBufferBundlerLockless2
- write_permits - Variable in class org.jgroups.protocols.RingBufferBundlerLockless
- write_pos - Variable in class org.jgroups.util.BlockingInputStream
-
Index into buf at which bytes will be written.
- writeAddress(Address, DataOutput) - Static method in class org.jgroups.util.Util
- writeAddresses(Collection<? extends Address>, DataOutput) - Static method in class org.jgroups.util.Util
-
Writes a list of Addresses.
- writeAddresses(Address[], DataOutput) - Static method in class org.jgroups.util.Util
- writeAddresses(View, Digest) - Static method in class org.jgroups.protocols.pbcast.GMS
- writeAll() - Method in class org.jgroups.protocols.FILE_PING
-
Write information about all of the member to file (only if I'm the coord)
- writeAll(Address[]) - Method in class org.jgroups.protocols.FILE_PING
- writeArg(DataOutput, Object) - Method in class org.jgroups.blocks.MethodCall
- writeArgs(DataOutput) - Method in class org.jgroups.blocks.MethodCall
- writeAsciiString(AsciiString, DataOutput) - Static method in class org.jgroups.util.Bits
-
Writes an AsciiString to buf.
- writeAsciiString(AsciiString, ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Writes an AsciiString to buf.
- writeAuthToken(DataOutput, AuthToken) - Static method in class org.jgroups.protocols.AuthHeader
- writeBoolean(boolean) - Method in class org.jgroups.util.BaseDataOutputStream
- writeBoolean(boolean) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeByte(int) - Method in class org.jgroups.util.BaseDataOutputStream
- writeByte(int) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeByteBuffer(byte[], int, int, DataOutput) - Static method in class org.jgroups.util.Util
- writeByteBuffer(byte[], DataOutput) - Static method in class org.jgroups.util.Util
- writeBytes(String) - Method in class org.jgroups.util.BaseDataOutputStream
- writeBytes(String) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeChar(char, byte[], int) - Static method in class org.jgroups.util.Bits
- writeChar(int) - Method in class org.jgroups.util.BaseDataOutputStream
- writeChar(int) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeChars(String) - Method in class org.jgroups.util.BaseDataOutputStream
- writeChars(String) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeDataOnFind() - Method in class org.jgroups.protocols.FILE_PING
- writeDataOnFind(boolean) - Method in class org.jgroups.protocols.FILE_PING
- writeDouble(double) - Method in class org.jgroups.util.BaseDataOutputStream
- writeDouble(double) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeDouble(double, byte[], int) - Static method in class org.jgroups.util.Bits
- writeDouble(double, DataOutput) - Static method in class org.jgroups.util.Bits
- writeDouble(double, ByteBuffer) - Static method in class org.jgroups.util.Bits
- writeException(Set<Throwable>, Throwable, DataOutput) - Static method in class org.jgroups.util.Util
- writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.Cache.Value
- writeFloat(float) - Method in class org.jgroups.util.BaseDataOutputStream
- writeFloat(float) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeFloat(float, byte[], int) - Static method in class org.jgroups.util.Bits
- writeFloat(float, DataOutput) - Static method in class org.jgroups.util.Bits
- writeFloat(float, ByteBuffer) - Static method in class org.jgroups.util.Bits
- writeGenericStreamable(Streamable, DataOutput) - Static method in class org.jgroups.util.Util
- writeHeaders(Header[], DataOutput) - Static method in class org.jgroups.util.Headers
- writeIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- writeIndex() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- writeIndex() - Method in class org.jgroups.util.RingBuffer
- writeInfo() - Method in class org.jgroups.protocols.FILE_PING
- writeInt(int) - Method in class org.jgroups.util.BaseDataOutputStream
- writeInt(int) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeInt(int, byte[], int) - Static method in class org.jgroups.util.Bits
- writeIntCompressed(int, byte[], int) - Static method in class org.jgroups.util.Bits
- writeIntCompressed(int, DataOutput) - Static method in class org.jgroups.util.Bits
- writeIntCompressed(int, ByteBuffer) - Static method in class org.jgroups.util.Bits
- writeLong(long) - Method in class org.jgroups.util.BaseDataOutputStream
- writeLong(long) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeLong(long, byte[], int) - Static method in class org.jgroups.util.Bits
- writeLongCompressed(long, byte[], int) - Static method in class org.jgroups.util.Bits
- writeLongCompressed(long, DataOutput) - Static method in class org.jgroups.util.Bits
-
Writes a long to out in variable-length encoding
- writeLongCompressed(long, ByteBuffer) - Static method in class org.jgroups.util.Bits
- writeLongSequence(long, long, DataOutput) - Static method in class org.jgroups.util.Bits
-
Writes 2 sequence numbers (seqnos) in compressed format to an output stream.
- writeLongSequence(long, long, ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Writes 2 sequence numbers (seqnos) in compressed format to buf.
- writeMessage(Message, DataOutput, boolean) - Static method in class org.jgroups.util.Util
- writeMessageList(Address, Address, byte[], List<Message>, DataOutput, boolean) - Static method in class org.jgroups.util.Util
-
Write a list of messages with the *same* destination and src addresses.
- writeMessageList(Address, Address, byte[], Message[], int, int, DataOutput, boolean) - Static method in class org.jgroups.util.Util
- writeMessageList(Address, Address, byte[], FastArray<Message>, DataOutput, boolean) - Static method in class org.jgroups.util.Util
- writeMessageListHeader(Address, Address, byte[], int, DataOutput, boolean) - Static method in class org.jgroups.util.Util
- writeMethod(DataOutput) - Method in class org.jgroups.blocks.MethodCall
- writeNodeToDisk(Address, PhysicalAddress) - Method in class org.jgroups.protocols.PDC
- writePayload(DataOutput) - Method in class org.jgroups.BatchMessage
- writePayload(DataOutput) - Method in class org.jgroups.BytesMessage
- writePayload(DataOutput) - Method in class org.jgroups.CompositeMessage
- writePayload(DataOutput) - Method in class org.jgroups.EmptyMessage
- writePayload(DataOutput) - Method in class org.jgroups.FragmentedMessage
- writePayload(DataOutput) - Method in class org.jgroups.LongMessage
- writePayload(DataOutput) - Method in interface org.jgroups.Message
- writePayload(DataOutput) - Method in class org.jgroups.NioMessage
- writePayload(DataOutput) - Method in class org.jgroups.ObjectMessage
- writePayloadAsBytes(DataOutput) - Method in class org.jgroups.CompositeMessage
- writeReconciliation(DataOutput, String[], long[], long[]) - Static method in class org.jgroups.protocols.COUNTER
- writeRequest(GossipData) - Method in class org.jgroups.stack.RouterStub
- writers - Variable in class org.jgroups.blocks.cs.TcpConnection
- writers - Variable in class org.jgroups.protocols.SimpleTCP.Connection
- writes - Variable in class org.jgroups.protocols.FILE_PING
- writeSerializable(Object) - Static method in class org.jgroups.util.Util
- writeShort(int) - Method in class org.jgroups.util.BaseDataOutputStream
- writeShort(int) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeShort(short, byte[], int) - Static method in class org.jgroups.util.Bits
- writeState(OutputStream) - Method in class org.jgroups.demos.Draw.DrawPanel
- writeStreamable(Streamable) - Static method in class org.jgroups.util.Util
- writeStreamable(Streamable, DataOutput) - Static method in class org.jgroups.util.Util
- writeString(String, DataOutput) - Static method in class org.jgroups.util.Bits
-
Writes a string to buf.
- writeString(String, DataOutput) - Static method in class org.jgroups.util.Util
- writeString(String, ByteBuffer) - Static method in class org.jgroups.util.Bits
-
Writes a string to buf.
- writeTo(DataOutput) - Method in class org.jgroups.auth.FixedMembershipToken
- writeTo(DataOutput) - Method in class org.jgroups.auth.Krb5Token
- writeTo(DataOutput) - Method in class org.jgroups.auth.RegexMembership
- writeTo(DataOutput) - Method in class org.jgroups.auth.X509Token
- writeTo(DataOutput) - Method in class org.jgroups.BaseMessage
- writeTo(DataOutput) - Method in class org.jgroups.blocks.GridFile.Metadata
- writeTo(DataOutput) - Method in class org.jgroups.blocks.MethodCall
- writeTo(DataOutput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- writeTo(DataOutput) - Method in class org.jgroups.blocks.RequestCorrelator.MultiDestinationHeader
- writeTo(DataOutput) - Method in class org.jgroups.demos.DrawCommand
- writeTo(DataOutput) - Method in class org.jgroups.MergeView
- writeTo(DataOutput) - Method in class org.jgroups.NullAddress
- writeTo(DataOutput) - Method in class org.jgroups.protocols.AuthHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.BATCH.BatchHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.BATCH2.Batch2Header
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.CompareAndSetRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.CounterHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ExceptionResponse
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.GetOrCreateRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ReconcileRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ReconcileResponse
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ResendPendingRequests
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.SetRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.SimpleRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.UpdateRequest
- writeTo(DataOutput) - Method in class org.jgroups.protocols.COUNTER.ValueResponse
- writeTo(DataOutput) - Method in class org.jgroups.protocols.DAISYCHAIN.DaisyHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.DH_KEY_EXCHANGE.DhHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.EncryptHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.EXAMPLE.ExampleHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FailureDetection.HeartbeatHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FcHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FD_SOCK2.FdHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FORK.ForkHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.Frag3Header
- writeTo(DataOutput) - Method in class org.jgroups.protocols.FragHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.MERGE3.MergeHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.NakAckHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.DeltaView
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.JoinRsp
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.NakAckHeader2
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.pbcast.StreamingStateTransfer.StateHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.PDC.Mapping
- writeTo(DataOutput) - Method in class org.jgroups.protocols.PERF.PerfHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.PingData
- writeTo(DataOutput) - Method in class org.jgroups.protocols.PingHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.ProtPerfHeader
-
The contents of this header is not serialized
- writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.RelayHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.relay.SiteUUID
- writeTo(DataOutput) - Method in class org.jgroups.protocols.RSVP.RsvpHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.RTTHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.SEQUENCER2.SequencerHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.STOMP.StompHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.TpHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.UnicastHeader3
-
The following types and fields are serialized:
- writeTo(DataOutput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- writeTo(DataOutput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT2.VerifyHeader
- writeTo(DataOutput) - Method in class org.jgroups.stack.GossipData
- writeTo(DataOutput) - Method in class org.jgroups.stack.IpAddress
- writeTo(DataOutput) - Method in class org.jgroups.util.Average
- writeTo(DataOutput) - Method in class org.jgroups.util.AverageMinMax
- writeTo(DataOutput) - Method in class org.jgroups.util.ByteArray
- writeTo(DataOutput) - Method in class org.jgroups.util.Digest
- writeTo(DataOutput) - Method in class org.jgroups.util.ExtendedUUID
- writeTo(DataOutput) - Method in class org.jgroups.util.FlagsUUID
- writeTo(DataOutput) - Method in class org.jgroups.util.LongSizeStreamable
- writeTo(DataOutput) - Method in class org.jgroups.util.MergeId
- writeTo(DataOutput) - Method in class org.jgroups.util.ObjectWrapperPrimitive
- writeTo(DataOutput) - Method in class org.jgroups.util.ObjectWrapperSerializable
- writeTo(DataOutput) - Method in class org.jgroups.util.Owner
- writeTo(DataOutput) - Method in class org.jgroups.util.Range
- writeTo(DataOutput) - Method in class org.jgroups.util.SeqnoList
- writeTo(DataOutput) - Method in interface org.jgroups.util.Streamable
-
Write the entire state of the current object (including superclasses) to outstream.
- writeTo(DataOutput) - Method in class org.jgroups.util.UUID
- writeTo(DataOutput) - Method in class org.jgroups.View
- writeTo(DataOutput) - Method in class org.jgroups.ViewId
- writeTo(DataOutput, boolean) - Method in class org.jgroups.util.Digest
- writeToDB(PingData, String) - Method in class org.jgroups.protocols.JDBC_PING2
- writeToDB(PingData, String, boolean) - Method in class org.jgroups.protocols.JDBC_PING
- writeToNoAddrs(Address, DataOutput) - Method in class org.jgroups.BaseMessage
- writeToNoAddrs(Address, DataOutput) - Method in interface org.jgroups.Message
-
Writes the message to an output stream excluding the destination (and possibly source) address
- writeToTempFile(File, Address, Address, String) - Method in class org.jgroups.protocols.PDC
-
Writes the data to a temporary file.
The file is stored in the same directory as the other cluster files but is given the .tmp suffix - writeTypes(DataOutput) - Method in class org.jgroups.blocks.MethodCall
- writeTypeStreamable(Streamable, DataOutput) - Static method in class org.jgroups.util.Util
- writeUTF(String) - Method in class org.jgroups.util.BaseDataOutputStream
- writeUTF(String) - Method in class org.jgroups.util.ByteBufferOutputStream
- writeVarToStream(String, Properties, OutputStream) - Static method in class org.jgroups.util.PropertiesToAsciidoc
- WriteVersionTo - Class in org.jgroups.util
-
Extracts version and codename from pom.xml and writes them to ./classes/JGROUPS_VERSION.properties
- WriteVersionTo() - Constructor for class org.jgroups.util.WriteVersionTo
- writeView(View, DataOutput) - Static method in class org.jgroups.util.Util
- writeViewId(ViewId, DataOutput) - Static method in class org.jgroups.util.Util
- wrongMethod(String) - Method in class org.jgroups.protocols.pbcast.GmsImpl
X
- X509Token - Class in org.jgroups.auth
-
This is an example of using a preshared token that is encrypted using an X509 certificate for authentication purposes.
- X509Token() - Constructor for class org.jgroups.auth.X509Token
- xmit_from_random_member - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Ask a random member for retransmission of a missing message.
- xmit_from_random_member - Variable in class org.jgroups.protocols.ReliableMulticast
-
Ask a random member for retransmission of a missing message.
- xmit_interval - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_interval - Variable in class org.jgroups.protocols.ReliableMulticast
- xmit_interval - Variable in class org.jgroups.protocols.UNICAST3
- XMIT_REQ - Static variable in class org.jgroups.protocols.NakAckHeader
- XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
- XMIT_REQ - Static variable in class org.jgroups.protocols.UnicastHeader3
- xmit_reqs_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_reqs_received - Variable in class org.jgroups.protocols.ReliableMulticast
- xmit_reqs_received - Variable in class org.jgroups.protocols.UNICAST3
- xmit_reqs_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_reqs_sent - Variable in class org.jgroups.protocols.ReliableMulticast
- xmit_reqs_sent - Variable in class org.jgroups.protocols.UNICAST3
- XMIT_RSP - Static variable in class org.jgroups.protocols.NakAckHeader
- XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader2
- xmit_rsps_received - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_rsps_received - Variable in class org.jgroups.protocols.ReliableMulticast
- xmit_rsps_sent - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_rsps_sent - Variable in class org.jgroups.protocols.ReliableMulticast
- xmit_rsps_sent - Variable in class org.jgroups.protocols.UNICAST3
- xmit_table - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Map to store sent and received messages (keyed by sender)
- xmit_table - Variable in class org.jgroups.protocols.ReliableMulticast
-
Map to store sent and received messages (keyed by sender)
- xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.NAKACK3
- xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_table_max_compaction_time - Variable in class org.jgroups.protocols.UNICAST3
- xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.NAKACK3
- xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_table_msgs_per_row - Variable in class org.jgroups.protocols.UNICAST3
- xmit_table_num_rows - Variable in class org.jgroups.protocols.NAKACK3
- xmit_table_num_rows - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_table_num_rows - Variable in class org.jgroups.protocols.UNICAST3
- xmit_table_resize_factor - Variable in class org.jgroups.protocols.NAKACK3
- xmit_table_resize_factor - Variable in class org.jgroups.protocols.pbcast.NAKACK2
- xmit_table_resize_factor - Variable in class org.jgroups.protocols.UNICAST3
- xmit_task - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
RetransmitTask running every xmit_interval ms
- xmit_task - Variable in class org.jgroups.protocols.ReliableMulticast
-
RetransmitTask running every xmit_interval ms
- xmit_task - Variable in class org.jgroups.protocols.UNICAST3
-
RetransmitTask running every xmit_interval ms
- xmit_task_map - Variable in class org.jgroups.protocols.pbcast.NAKACK2
-
Used by the retransmit task to keep the last retransmitted seqno per sender (https://issues.redhat.com/browse/JGRP-1539)
- xmit_task_map - Variable in class org.jgroups.protocols.ReliableMulticast
-
Used by the retransmit task to keep the last retransmitted seqno per sender (https://issues.redhat.com/browse/JGRP-1539)
- xmit_task_map - Variable in class org.jgroups.protocols.UNICAST3
-
Used by the retransmit task to keep the last retransmitted seqno per member (applicable only for received messages (ReceiverEntry)): https://issues.redhat.com/browse/JGRP-1539
- xmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK2
- xmitFromRandomMember() - Method in class org.jgroups.protocols.ReliableMulticast
- xmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK2
- xmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.ReliableMulticast
- xmits_enabled - Variable in class org.jgroups.protocols.UNICAST3
- XmlAttribute - Annotation Type in org.jgroups.annotations
-
Annotation to add attributes to the schema created by
XMLSchemaGenerator
. - XmlConfigurator - Class in org.jgroups.conf
-
Uses XML to configure a protocol stack
- XmlConfigurator(List<ProtocolConfiguration>) - Constructor for class org.jgroups.conf.XmlConfigurator
- XmlConfigurator.ElementType - Enum in org.jgroups.conf
- XmlElement - Annotation Type in org.jgroups.annotations
-
Annotation to generate an element in the schema created by
XMLSchemaGenerator
. - XmlInclude - Annotation Type in org.jgroups.annotations
-
Used to include other schemas by
XMLSchemaGenerator
. - XmlInclude.Type - Enum in org.jgroups.annotations
- XmlNode - Class in org.jgroups.conf
-
A simple replacement for a W3C DOM node.
- XmlNode(String) - Constructor for class org.jgroups.conf.XmlNode
- XMLSchemaGenerator - Class in org.jgroups.util
-
Iterates over all concrete Protocol classes and creates XML schema used for validation of configuration files.
- XMLSchemaGenerator() - Constructor for class org.jgroups.util.XMLSchemaGenerator
Y
- YIELD - Static variable in class org.jgroups.protocols.RingBufferBundler
_
- _add(long, T, boolean, Predicate<T>) - Method in class org.jgroups.util.Table
- _add(Collection<R>) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- _add(R) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- _add(R...) - Method in class org.jgroups.protocols.pbcast.ViewHandler
- _clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
- _clear() - Method in interface org.jgroups.blocks.ReplicatedMap
- _close(boolean) - Method in class org.jgroups.JChannel
- _compact() - Method in class org.jgroups.util.DynamicBuffer
-
Moves the contents of matrix down by the number of purged rows and resizes the matrix accordingly.
- _compact() - Method in class org.jgroups.util.RequestTable
-
Shrinks the array to half of its current size if the current number of elements fit into half of the capacity.
- _compact() - Method in class org.jgroups.util.Table
-
Moves the contents of matrix down by the number of purged rows and resizes the matrix accordingly.
- _connect(Event) - Method in class org.jgroups.JChannel
- _contiguousSpaceAvailable(int) - Method in class org.jgroups.util.RequestTable
-
Check if we have at least space_needed contiguous free slots available in range [low+1 ..
- _copy(int) - Method in class org.jgroups.util.RequestTable
-
Copies elements from old into new array
- _decrypt(Cipher, Key, Message, EncryptHeader) - Method in class org.jgroups.protocols.Encrypt
- _doConnect() - Method in class org.jgroups.stack.RouterStub
- _done() - Method in class org.jgroups.util.Responses
- _down(Message) - Method in class org.jgroups.protocols.BATCH2
- _down(Message) - Method in class org.jgroups.protocols.SimpleTCP
- _get(long) - Method in class org.jgroups.util.Buffer
- _get(long) - Method in class org.jgroups.util.DynamicBuffer
-
To be used only for testing; doesn't do any index or sanity checks
- _get(long) - Method in class org.jgroups.util.FixedBuffer
-
Only used for testing !!
- _get(long) - Method in class org.jgroups.util.RingBufferSeqnoLockless
-
Only used for testing !!
- _get(long) - Method in class org.jgroups.util.RingBufferSeqnoOld
-
Only used for testing !!
- _get(long) - Method in class org.jgroups.util.Table
-
To be used only for testing; doesn't do any index or sanity checks
- _get(K) - Method in class org.jgroups.blocks.ReplCache
- _getMergeId() - Method in class org.jgroups.protocols.pbcast.GMS
- _getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
-
Blocks until a result is available, or timeout milliseconds have elapsed.
- _grow(long) - Method in class org.jgroups.util.RequestTable
- _handleAttrWrite(Object, String, String) - Static method in class org.jgroups.jmx.ReflectUtils
- _handleMergeRequest(Address, MergeId, Collection<? extends Address>) - Method in class org.jgroups.protocols.pbcast.Merger
- _list(Object) - Method in class org.jgroups.blocks.GridFile
- _listFiles(Object) - Method in class org.jgroups.blocks.GridFile
- _preConnect(String) - Method in class org.jgroups.JChannel
- _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_ALL3
- _printTimestamps() - Method in class org.jgroups.protocols.FD_HOST
- _printTopology(Relayer) - Method in class org.jgroups.protocols.relay.RELAY2
- _put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
- _put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
- _put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _put(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _put(K, V, short, long) - Method in class org.jgroups.blocks.ReplCache
- _put(K, V, short, long, boolean) - Method in class org.jgroups.blocks.ReplCache
- _putAll(Map<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _putAll(Map<? extends K, ? extends V>) - Method in interface org.jgroups.blocks.ReplicatedMap
- _putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _putIfAbsent(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _read() - Method in class org.jgroups.blocks.cs.NioConnection
- _readMessages() - Method in class org.jgroups.protocols.RingBufferBundlerLockless
- _readMessages() - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- _readViewAndDigest(byte[], int, int) - Static method in class org.jgroups.protocols.pbcast.GMS
- _remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
- _remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
- _remove(K) - Method in class org.jgroups.blocks.ReplCache
- _remove(K) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _remove(K) - Method in interface org.jgroups.blocks.ReplicatedMap
- _remove(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _remove(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _removeData(String) - Method in class org.jgroups.blocks.ReplicatedTree
- _removeMany(Set<K>) - Method in class org.jgroups.blocks.ReplCache
- _replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _replace(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _replace(K, V, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _rtt(int, int, boolean) - Method in class org.jgroups.util.RTT
- _run() - Method in class org.jgroups.demos.EchoServer.ConnectionHandler
- _run() - Method in class org.jgroups.protocols.COUNTER.ReconciliationTask
- _run() - Method in class org.jgroups.protocols.MERGE3.ViewConsistencyChecker
- _run(MergeId, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.Merger.MergeTask
-
Runs the merge protocol as a leader
- _send(InetAddress, int, byte[], int, int) - Method in class org.jgroups.protocols.UDP
- _send(Message, Address) - Method in class org.jgroups.protocols.TP
- _send(Message, ByteArrayDataOutputStream) - Method in class org.jgroups.protocols.BatchBundler
- _sendBundledMessages() - Method in class org.jgroups.protocols.AlternatingBundler
- _sendBundledMessages() - Method in class org.jgroups.protocols.SimplifiedTransferQueueBundler
- _sendMessage(Message, RequestOptions) - Method in class org.jgroups.blocks.MessageDispatcher
- _size(int, int) - Method in class org.jgroups.protocols.RingBufferBundlerLockless2
- _triggerSiteUnreachableEvent(SiteAddress) - Method in class org.jgroups.protocols.relay.RELAY3
- _waitForMessages() - Method in class org.jgroups.util.RingBuffer
- _write(byte[], int, int) - Method in class org.jgroups.util.PartialOutputStream
- _write(int) - Method in class org.jgroups.util.PartialOutputStream
All Classes All Packages