A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
All Classes All Packages

A

accept(ClusterNode) - Method in interface io.hekate.cluster.ClusterNodeFilter
Returns true if this filter accepts the specified node.
acceptAll() - Static method in interface io.hekate.messaging.retry.RetryErrorPredicate
Always retry.
acceptJoin(ClusterNode, Hekate) - Method in interface io.hekate.cluster.ClusterAcceptor
Called when a new node tries to join the cluster.
acceptJoinRequest(GossipProtocol.JoinRequest) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
AckMode - Enum in io.hekate.messaging.operation
Acknowledgement mode.
activeNetworks() - Static method in class io.hekate.core.internal.util.AddressUtils
Returns an immutable list of all active network interfaces.
added() - Method in class io.hekate.cluster.event.ClusterChangeEvent
Returns the list of new nodes that joined the cluster.
added() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
Returns the list of new nodes that joined the cluster.
addHandler(NetworkServerHandlerConfig<?>) - Method in interface io.hekate.network.NetworkServer
Registers the specified handler to this server.
addListener(ClusterEventListener) - Method in interface io.hekate.cluster.ClusterView
Registers the cluster event listener.
addListener(ClusterEventListener) - Method in class io.hekate.cluster.UpdatableClusterView
addListener(ClusterEventListener) - Method in interface io.hekate.core.service.ClusterContext
Synchronously registers the specified cluster event listener.
addListener(ClusterEventListener, ClusterEventType...) - Method in interface io.hekate.cluster.ClusterView
Registers the cluster event listener that will be notified only on events of the specified event types.
addListener(ClusterEventListener, ClusterEventType...) - Method in class io.hekate.cluster.UpdatableClusterView
addListener(ClusterEventListener, ClusterEventType...) - Method in interface io.hekate.core.service.ClusterContext
Synchronously registers the specified cluster event listener.
addListener(Hekate.LifecycleListener) - Method in interface io.hekate.core.Hekate
Adds lifecycle listener.
addListener(LeaderChangeListener) - Method in interface io.hekate.election.FollowerContext
Registers the leader change event listener.
addListenerAsync(ClusterEventListener) - Method in interface io.hekate.core.service.ClusterContext
Asynchronously registers the specified cluster event listener without waiting registration to be completed.
addListenerAsync(ClusterEventListener, ClusterEventType...) - Method in interface io.hekate.core.service.ClusterContext
Asynchronously registers the specified cluster event listener without waiting for registration to be completed.
address() - Method in interface io.hekate.cluster.ClusterNode
Returns the network address of this node.
address() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
address() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
address() - Method in class io.hekate.cluster.split.AddressReachabilityDetector
Address to check.
address() - Method in interface io.hekate.network.NetworkServer
Returns bind address or null if server is not started.
AddressPattern - Class in io.hekate.network.address
Pattern-based implementation of AddressSelector interface.
AddressPattern() - Constructor for class io.hekate.network.address.AddressPattern
Constructs a new instance with 'any' pattern.
AddressPattern(String) - Constructor for class io.hekate.network.address.AddressPattern
Constructs a new instance.
AddressReachabilityDetector - Class in io.hekate.cluster.split
Socket address connectivity-based detector.
AddressReachabilityDetector(String) - Constructor for class io.hekate.cluster.split.AddressReachabilityDetector
Constructs new instance with the default timeout value (=3000).
AddressReachabilityDetector(String, int) - Constructor for class io.hekate.cluster.split.AddressReachabilityDetector
Constructs new instance.
AddressReachabilityDetector(InetSocketAddress, int) - Constructor for class io.hekate.cluster.split.AddressReachabilityDetector
Constructs new instance.
AddressSelector - Interface in io.hekate.network.address
Network host address selector.
AddressUtils - Class in io.hekate.core.internal.util
Network-related utilities.
affinity() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the hash code of affinity key or a synthetically generated value if affinity key was not specified for the messaging operation.
affinity() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns the hash code of affinity key or a synthetically generated value if affinity key was not specified for the messaging operation.
affinityArg() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the zero-based index of an argument that is annotated with RpcAffinityKey (if presents).
affinityKey() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the affinity key of the messaging operation or null if the affinity key wasn't specified.
affinityKey() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns the affinity key of the messaging operation or null if the affinity key wasn't specified.
affinityRoute(T, LoadBalancerContext) - Method in class io.hekate.messaging.loadbalance.DefaultLoadBalancer
Selects a node based on the partition mapping of the operation's affinity key.
AFTER - io.hekate.cluster.internal.gossip.GossipPrecedence
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.lock.LockBean
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.lock.LockRegionBean
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.messaging.MessagingChannelBean
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.network.NetworkConnectorBean
 
afterPropertiesSet() - Method in class io.hekate.spring.bean.rpc.RpcClientBean
 
aggregate() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the RpcAggregate annotation that is declared on this method (if presents).
aggregate(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously submits the specified aggregation request.
aggregate(T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously submits the specified aggregation request.
Aggregate<T> - Interface in io.hekate.messaging.operation
Aggregate operation.
aggregateAsync(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously submits the specified aggregation request.
aggregateAsync(T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously submits the specified aggregation request.
AggregateCallback<T> - Interface in io.hekate.messaging.operation
Callback for an Aggregate operation.
AggregateFuture<T> - Class in io.hekate.messaging.operation
Asynchronous result of an Aggregate operation.
AggregateFuture() - Constructor for class io.hekate.messaging.operation.AggregateFuture
 
AggregateRepeatCondition<T> - Interface in io.hekate.messaging.operation
Condition to repeat an Aggregate operation.
AggregateResult<T> - Interface in io.hekate.messaging.operation
Result of an Aggregate operation.
AggregateRetryConfigurer<T> - Interface in io.hekate.messaging.operation
Configurer of AggregateRetryPolicy.
AggregateRetryPolicy<T> - Interface in io.hekate.messaging.operation
Retry policy for an Aggregate operation.
ALL_VALID - io.hekate.cluster.split.SplitBrainDetectorGroup.GroupPolicy
If at least one of detectors reported failure then the whole group check is considered to be failed.
allChannels() - Method in interface io.hekate.messaging.MessagingService
Returns all channels that are registered within this service.
AllMessageInterceptor<T> - Interface in io.hekate.messaging.intercept
allOf(Collection<CompletableFuture<?>>) - Static method in class io.hekate.util.async.AsyncUtils
Version of CompletableFuture.allOf(CompletableFuture[]) that works with a collection instead of an array.
allProcesses() - Method in interface io.hekate.coordinate.CoordinationService
Returns all processes that are registered within this service.
allProviders() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
Returns an immutable list of all providers that are configured for this group.
allRegions() - Method in interface io.hekate.lock.LockService
Returns all lock regions that are LockServiceFactory.setRegions(List) registered within this service.
allSuspected() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
allTriedNodes() - Method in interface io.hekate.messaging.retry.Attempt
Returns an immutable set of all tried nodes.
alwaysReRoute() - Method in interface io.hekate.messaging.retry.RetryRoutingSupport
Instructs to apply the RetryRoutingPolicy.RE_ROUTE policy.
alwaysTrySameNode() - Method in interface io.hekate.messaging.retry.RetryRoutingSupport
Instructs to apply the RetryRoutingPolicy.RETRY_SAME_NODE policy.
ANY_VALID - io.hekate.cluster.split.SplitBrainDetectorGroup.GroupPolicy
If at least one of detectors reported success then the whole group check is considered to be successful.
apply(DataReader) - Method in interface io.hekate.network.NetworkMessage.Preview
Applies this function.
apply(DataReader) - Method in interface io.hekate.network.NetworkMessage.PreviewBoolean
Applies this function.
apply(DataReader) - Method in interface io.hekate.network.NetworkMessage.PreviewDouble
Applies this function.
apply(DataReader) - Method in interface io.hekate.network.NetworkMessage.PreviewInt
Applies this function.
apply(DataReader) - Method in interface io.hekate.network.NetworkMessage.PreviewLong
Applies this function.
apply(List<ClusterNode>) - Method in interface io.hekate.cluster.ClusterFilter
Applies this filter to the specified group of cluster nodes and returns a new set of only those nodes that were accepted by this filter.
ArgAssert - Class in io.hekate.core.internal.util
 
args() - Method in interface io.hekate.rpc.RpcRequest
Returns arguments of this RPC request.
asAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
asAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
asAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReply
 
asChange() - Method in class io.hekate.cluster.event.ClusterChangeEvent
Returns this instance.
asChange() - Method in interface io.hekate.cluster.event.ClusterEvent
Casts this instance to the ClusterChangeEvent type or returns null if this instance can't be cast to that type.
asChange() - Method in class io.hekate.cluster.event.ClusterEventBase
 
asError(ClusterNode) - Method in interface io.hekate.messaging.operation.FailureResponse
Converts this reply to an error.
asJoin() - Method in interface io.hekate.cluster.event.ClusterEvent
Casts this instance to the ClusterJoinEvent type or returns null if this instance can't be cast to that type.
asJoin() - Method in class io.hekate.cluster.event.ClusterEventBase
 
asJoin() - Method in class io.hekate.cluster.event.ClusterJoinEvent
Returns this instance.
asLeave() - Method in interface io.hekate.cluster.event.ClusterEvent
Casts this instance to the ClusterLeaveEvent type or returns null if this instance can't be cast to that type.
asLeave() - Method in class io.hekate.cluster.event.ClusterEventBase
 
asLeave() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
Returns this instance.
asReject() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
asReject() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
asReject() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReply
 
asStream() - Method in interface io.hekate.codec.DataReader
Casts this writer to the InputStream interface.
asStream() - Method in interface io.hekate.codec.DataWriter
Casts this writer to the OutputStream interface.
asStream() - Method in class io.hekate.codec.StreamDataReader
 
asStream() - Method in class io.hekate.codec.StreamDataWriter
 
asUpdate() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.Update
 
asUpdate() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateBase
 
asUpdate() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateDigest
 
AsyncLockCallback - Interface in io.hekate.lock
Callback for asynchronous locking operations.
AsyncUtils - Class in io.hekate.util.async
Set of utility methods for asynchronous tasks processing.
attach(CompletableFuture<?>) - Method in interface io.hekate.cluster.event.ClusterEvent
Attaches an arbitrary asynchronous task to this event.
attach(CompletableFuture<?>) - Method in class io.hekate.cluster.event.ClusterEventBase
 
attempt() - Method in interface io.hekate.messaging.retry.Attempt
Returns the current attempts (starting with zero for the first attempt).
attempt() - Method in interface io.hekate.network.NetworkServerFailure
Returns the current failover attempt (starting with 0).
Attempt - Interface in io.hekate.messaging.retry
Attempt.
AUTO - io.hekate.network.NetworkSslConfig.Provider
Automatically select provider depending on what is available on the classpath.
AUTO - io.hekate.network.NetworkTransportType
Try to autodetect which implementation to use depending on the runtime environment.
AutoSelectCodecFactory<T> - Class in io.hekate.codec
Codec factory that automatically selects an underlying implementation based on what is available on the classpath.
AutoSelectCodecFactory() - Constructor for class io.hekate.codec.AutoSelectCodecFactory
Constructs a new instance.
await() - Method in interface io.hekate.util.async.Waiting
Waits for this task to complete.
awaitAll(Collection<Waiting>) - Static method in interface io.hekate.util.async.Waiting
Returns a single Waiting that will await for all of the specified tasks to complete.
awaitFor(Predicate<ClusterTopology>) - Method in interface io.hekate.cluster.ClusterView
Awaits for this cluster view to match the specified predicate.
awaitFor(Predicate<ClusterTopology>) - Method in class io.hekate.cluster.UpdatableClusterView
awaitFor(Predicate<ClusterTopology>, long, TimeUnit) - Method in interface io.hekate.cluster.ClusterView
Awaits for this cluster view to match the specified predicate up to the specified timeout.
awaitFor(Predicate<ClusterTopology>, long, TimeUnit) - Method in class io.hekate.cluster.UpdatableClusterView
awaitForNodes() - Method in interface io.hekate.cluster.ClusterView
Awaits for this cluster view to contain at least one node.
awaitForNodes(long, TimeUnit) - Method in interface io.hekate.cluster.ClusterView
Awaits for this cluster view to contain at least one node.
awaitUninterruptedly() - Method in interface io.hekate.util.async.Waiting
Uninterruptedly waits for this task to complete.
AwsCredentialsSupplier - Class in io.hekate.cluster.seed.jclouds.aws
AWS credentials supplier for Apache JClouds-based seed node providers.
AwsCredentialsSupplier() - Constructor for class io.hekate.cluster.seed.jclouds.aws.AwsCredentialsSupplier
 

B

backupNodes() - Method in class io.hekate.partition.DefaultPartition
 
backupNodes() - Method in interface io.hekate.partition.Partition
Returns the backup node set of this partition.
backupNodes() - Method in interface io.hekate.partition.PartitionMapper
Returns the amount of backup nodes that should be assigned to each partition.
backupNodes() - Method in class io.hekate.partition.PartitionMapperBase
 
baseDelay() - Method in class io.hekate.messaging.retry.ExponentialBackoffPolicy
Returns the base delay of this policy in milliseconds.
basePath() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Returns the base path for storing seed nodes information in Consul Key-Value storage.
basePath() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
Returns the base path for storing seed nodes information in Etcd.
basePath() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
Returns the base path for storing seed nodes information in ZooKeeper.
baseType() - Method in class io.hekate.cluster.internal.gossip.GossipProtocolCodec
 
baseType() - Method in interface io.hekate.codec.Codec
Returns the base data type that is supported by this codec.
baseType() - Method in interface io.hekate.messaging.MessagingChannel
Returns the base type of messages that can be transferred through this channel.
BasicCredentialsSupplier - Class in io.hekate.cluster.seed.jclouds
Basic credentials supplier for Apache JClouds-based seed node providers.
BasicCredentialsSupplier() - Constructor for class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
 
batchGossip(GossipPolicy) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
becomeFollower(FollowerContext) - Method in interface io.hekate.election.Candidate
Gets called when this candidate couldn't win elections and switched to the follower state.
becomeInitialized() - Method in class io.hekate.util.StampedStateGuard
Switches this guard to StampedStateGuard.State.INITIALIZED state.
becomeInitialized() - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.INITIALIZED state.
becomeInitialized(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.INITIALIZED state and executes the specified task.
becomeInitializing() - Method in class io.hekate.util.StampedStateGuard
Switches this guard to StampedStateGuard.State.INITIALIZING state.
becomeInitializing() - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.INITIALIZING state.
becomeLeader(LeaderContext) - Method in interface io.hekate.election.Candidate
Gets called when this candidate becomes a group leader.
becomeTerminated() - Method in class io.hekate.util.StampedStateGuard
Switches this guard to StampedStateGuard.State.TERMINATED state if guard is currently in any other state besides StampedStateGuard.State.TERMINATED.
becomeTerminated() - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.TERMINATED state if guard is currently in any other state besides StateGuard.State.TERMINATED.
becomeTerminated(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.TERMINATED state and executes the specified task.
becomeTerminated(StateGuard.GuardedSupplier<List<Waiting>, E>) - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.TERMINATED state and executes the specified task.
becomeTerminating() - Method in class io.hekate.util.StampedStateGuard
becomeTerminating() - Method in class io.hekate.util.StateGuard
Switches this guard to StateGuard.State.TERMINATING state if guard is currently in StateGuard.State.INITIALIZING or StateGuard.State.INITIALIZED state.
becomeTerminating(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Tries to switch this guard to StateGuard.State.TERMINATING state and executes the specified task if switch happened.
becomeTerminating(StateGuard.GuardedSupplier<List<Waiting>, E>) - Method in class io.hekate.util.StateGuard
Tries to switch this guard to StateGuard.State.TERMINATING state and executes the specified task if switch happened.
BEFORE - io.hekate.cluster.internal.gossip.GossipPrecedence
 
bind(NetworkBindCallback) - Method in interface io.hekate.core.service.NetworkServiceManager
Binds the NetworkService to its network address.
BLOCK - io.hekate.messaging.MessagingOverflowPolicy
Block the caller thread unless the MessagingChannel's outbound queue goes down to its low watermark or unless the caller thread gets interrupted.
BLOCK_UNINTERRUPTEDLY - io.hekate.messaging.MessagingOverflowPolicy
Blocks the caller thread unless the MessagingChannel's outbound queue goes down to its low watermark.
BOOLEAN - io.hekate.core.ServiceProperty.Type
For Boolean type.
boolProperty(String) - Method in interface io.hekate.core.ServiceInfo
Returns the property value or null if there is no such property or if property is not of ServiceProperty.Type.BOOLEAN type.
broadcast() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the RpcBroadcast annotation that is declared on this method (if presents).
broadcast(Object, CoordinationBroadcastCallback) - Method in interface io.hekate.coordinate.CoordinationContext
Asynchronously sends the specified request to all members of this coordination process.
broadcast(Object, BooleanSupplier, Predicate<CoordinationMember>, CoordinationBroadcastCallback) - Method in interface io.hekate.coordinate.CoordinationContext
Asynchronously sends the specified request to those members that do match the specified filter and only if the specified precondition is true.
broadcast(Object, Predicate<CoordinationMember>, CoordinationBroadcastCallback) - Method in interface io.hekate.coordinate.CoordinationContext
Asynchronously sends the specified request to those members that do match the specified filter.
broadcast(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously broadcasts the specified message with a mandatory acknowledgement.
broadcast(Object, T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously broadcasts the specified message with the specified acknowledgement mode.
broadcast(T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously broadcasts the specified message with a mandatory acknowledgement.
broadcast(T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously broadcasts the specified message with the specified acknowledgement mode.
Broadcast<T> - Interface in io.hekate.messaging.operation
Broadcast operation.
broadcastAsync(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously broadcasts the specified message with a mandatory acknowledgement.
broadcastAsync(Object, T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously broadcasts the specified message with the specified acknowledgement mode.
broadcastAsync(T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously broadcasts the specified message with a mandatory acknowledgement.
broadcastAsync(T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously broadcasts the specified message with the specified acknowledgement mode.
BroadcastCallback<T> - Interface in io.hekate.messaging.operation
Callback for a Broadcast operation.
BroadcastFuture<T> - Class in io.hekate.messaging.operation
Asynchronous result of Broadcast operation.
BroadcastFuture() - Constructor for class io.hekate.messaging.operation.BroadcastFuture
 
BroadcastRepeatCondition<T> - Interface in io.hekate.messaging.operation
Condition to repeat an Broadcast operation.
BroadcastResult<T> - Interface in io.hekate.messaging.operation
Result of a Broadcast operation.
BroadcastRetryConfigurer - Interface in io.hekate.messaging.operation
Configurer of BroadcastRetryPolicy.
BroadcastRetryPolicy - Interface in io.hekate.messaging.operation
Retry policy for Broadcast operations.
build() - Method in class io.hekate.partition.RendezvousHashMapper.Builder
Constructs a new mapper.
build() - Method in interface io.hekate.rpc.RpcClientBuilder
Constructs a new RPC client proxy.
buildBaseProperties() - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
Converts this configuration to jClouds-compliant properties.
bytes() - Method in interface io.hekate.cluster.ClusterHash
Returns a copy of the bytes of this hash.
BYTES - Static variable in interface io.hekate.messaging.MessageMetaData.MetaDataCodec
Codec for values of byte[] type.
byteSizeFormat(long) - Static method in class io.hekate.core.internal.util.Utils
 

C

camelCase(CharSequence) - Static method in class io.hekate.core.internal.util.Utils
 
cancel(CoordinationContext) - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called if current coordination process gets cancelled.
cancelledFuture() - Static method in class io.hekate.util.async.AsyncUtils
Returns a cancelled Future.
Candidate - Interface in io.hekate.election
Leader election candidate.
CandidateConfig - Class in io.hekate.election
Configuration for Candidate.
CandidateConfig() - Constructor for class io.hekate.election.CandidateConfig
Default constructor.
CandidateConfig(String) - Constructor for class io.hekate.election.CandidateConfig
Constructs new instance.
CandidateConfigProvider - Interface in io.hekate.election
Provider of custom leader election configurations for ElectionService.
CandidateJmx - Interface in io.hekate.election
JMX interface for Candidate.
cause() - Method in interface io.hekate.network.NetworkServerFailure
Returns the cause of this failure.
CHANGE - io.hekate.cluster.event.ClusterEventType
Event is of ClusterChangeEvent type.
channel() - Method in interface io.hekate.messaging.MessageBase
Returns the messaging channel of this message.
channel() - Method in interface io.hekate.messaging.MessagingEndpoint
Returns the messaging channel of this endpoint.
channel(String) - Method in interface io.hekate.messaging.MessagingService
Returns an unchecked messaging channel for the specified name.
channel(String, Class<T>) - Method in interface io.hekate.messaging.MessagingService
Returns a type-safe messaging channel for the specified name.
channelName() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the channel name (see MessagingChannel.name()).
channelName() - Method in interface io.hekate.messaging.intercept.ServerInboundContext
Returns the channel name (see MessagingChannel.name()).
check(boolean, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
checkAliveness() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
cleanupInterval() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
cleanupInterval() - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Returns the time interval in milliseconds for the cluster service to perform the stale data cleaning.
cleanupInterval() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
cleanupInterval() - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
cleanupInterval() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
clientFor(Class<T>) - Method in interface io.hekate.rpc.RpcService
Constructs a new RPC client proxy builder for the specified Java interface.
clientFor(Class<T>, String) - Method in interface io.hekate.rpc.RpcService
Constructs a new RPC client proxy builder for the specified Java interface and tag.
ClientMessageInterceptor<T> - Interface in io.hekate.messaging.intercept
Client-side message interceptor.
ClientOutboundContext<T> - Interface in io.hekate.messaging.intercept
Client's outbound message context.
ClientReceiveContext<T> - Interface in io.hekate.messaging.intercept
Client's receive context.
clients(String) - Method in interface io.hekate.network.NetworkServer
Returns the list of network endpoints that are currently connected to this server with the specified protocol.
ClientSendContext<T> - Interface in io.hekate.messaging.intercept
Client's send context.
close() - Method in interface io.hekate.network.NetworkClient
Support method for Closeable interface (equivalent of calling NetworkEndpoint.disconnect() and CompletableFuture.join()).
cloudCredentialsSupplier(String) - Method in class io.hekate.spring.boot.cluster.HekateCloudSeedNodeProviderConfigurer
Conditionally constructs a new credentials supplier based on the provider name.
CloudPropertiesBase<T extends CloudPropertiesBase<T>> - Class in io.hekate.cluster.seed.jclouds
Abstract base class for jClouds configuration properties.
CloudPropertiesBase() - Constructor for class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
 
cloudSeedNodeProvider(CloudSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateCloudSeedNodeProviderConfigurer
Constructs new CloudSeedNodeProvider.
CloudSeedNodeProvider - Class in io.hekate.cluster.seed.jclouds
Cloud instance-based implementation of SeedNodeProvider interface.
CloudSeedNodeProvider(CloudSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
Constructs new instance.
cloudSeedNodeProviderConfig(CredentialsSupplier) - Method in class io.hekate.spring.boot.cluster.HekateCloudSeedNodeProviderConfigurer
Conditionally constructs a new configuration for CloudSeedNodeProvider if application doesn't provide its own Bean of CloudSeedNodeProviderConfig type.
CloudSeedNodeProviderConfig - Class in io.hekate.cluster.seed.jclouds
Configuration for CloudSeedNodeProvider.
CloudSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
 
cloudStoreCredentialsSupplier(String) - Method in class io.hekate.spring.boot.cluster.HekateCloudStoreSeedNodeProviderConfigurer
Conditionally constructs a new credentials supplier based on the provider name.
cloudStoreSeedNodeProvider(CloudStoreSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateCloudStoreSeedNodeProviderConfigurer
CloudStoreSeedNodeProvider - Class in io.hekate.cluster.seed.jclouds
Cloud store-based implementation of SeedNodeProvider interface.
CloudStoreSeedNodeProvider(CloudStoreSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
Constructs new instance.
cloudStoreSeedNodeProviderConfig(CredentialsSupplier) - Method in class io.hekate.spring.boot.cluster.HekateCloudStoreSeedNodeProviderConfigurer
Conditionally constructs a new configuration for CloudStoreSeedNodeProvider if application doesn't provide its own Bean of CloudStoreSeedNodeProviderConfig type.
CloudStoreSeedNodeProviderConfig - Class in io.hekate.cluster.seed.jclouds
Configuration for CloudStoreSeedNodeProvider.
CloudStoreSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
 
cluster() - Method in interface io.hekate.core.Hekate
Returns the ClusterService.
cluster() - Method in interface io.hekate.core.service.InitializationContext
Returns cluster context.
cluster() - Method in interface io.hekate.lock.LockRegion
Returns the cluster view of this region.
cluster() - Method in interface io.hekate.messaging.MessagingChannel
Returns the cluster view of this channel.
cluster() - Method in interface io.hekate.rpc.RpcClientBuilder
Returns the cluster view of this builder.
ClusterAcceptor - Interface in io.hekate.cluster
Cluster join acceptor.
ClusterAddress - Class in io.hekate.cluster
Address of the ClusterNode.
ClusterAddress(InetSocketAddress, ClusterNodeId) - Constructor for class io.hekate.cluster.ClusterAddress
Constructs new instance with the specified network address and node identifier.
ClusterChangeEvent - Class in io.hekate.cluster.event
Cluster topology change event.
ClusterChangeEvent(ClusterTopology, ClusterTopology, Set<ClusterNode>, HekateSupport) - Constructor for class io.hekate.cluster.event.ClusterChangeEvent
Constructs a new instance by comparing old and new cluster topologies.
ClusterChangeEvent(ClusterTopology, List<ClusterNode>, List<ClusterNode>, List<ClusterNode>, HekateSupport) - Constructor for class io.hekate.cluster.event.ClusterChangeEvent
Constructs a new instance.
ClusterContext - Interface in io.hekate.core.service
Context for ClusterService.
ClusterEvent - Interface in io.hekate.cluster.event
Cluster event.
ClusterEventBase - Class in io.hekate.cluster.event
Abstract base class for ClusterEvent implementations.
ClusterEventBase(ClusterTopology, HekateSupport) - Constructor for class io.hekate.cluster.event.ClusterEventBase
Constructs a new instance with the specified topology snapshot.
ClusterEventListener - Interface in io.hekate.cluster.event
« start hereCluster event listener.
ClusterEventType - Enum in io.hekate.cluster.event
Contains types of ClusterEvent.
ClusterException - Exception in io.hekate.cluster
Error in ClusterService.
ClusterException(String) - Constructor for exception io.hekate.cluster.ClusterException
Constructs a new instance.
ClusterException(String, Throwable) - Constructor for exception io.hekate.cluster.ClusterException
Constructs a new instance.
ClusterFilter - Interface in io.hekate.cluster
Interface for filtering groups of cluster nodes.
ClusterFilters - Class in io.hekate.cluster
Predefined cluster filters.
ClusterFilterSupport<T extends ClusterFilterSupport<T>> - Interface in io.hekate.cluster
Base interface for types that support cluster topology filtering.
ClusterHash - Interface in io.hekate.cluster
Cryptographic hash of the ClusterTopology.
ClusterJoinEvent - Class in io.hekate.cluster.event
Cluster join event.
ClusterJoinEvent(ClusterTopology, HekateSupport) - Constructor for class io.hekate.cluster.event.ClusterJoinEvent
Constructs a new instance.
ClusterLeaveEvent - Class in io.hekate.cluster.event
Cluster leave event.
ClusterLeaveEvent(ClusterLeaveReason, ClusterTopology, List<ClusterNode>, List<ClusterNode>, HekateSupport) - Constructor for class io.hekate.cluster.event.ClusterLeaveEvent
Constructs a new instance.
ClusterLeaveReason - Enum in io.hekate.cluster.event
Reason of a ClusterLeaveEvent.
ClusterNode - Interface in io.hekate.cluster
Provides information about a single cluster node.
ClusterNodeFilter - Interface in io.hekate.cluster
Interface for cluster nodes filtering.
ClusterNodeId - Class in io.hekate.cluster
Universally unique identifier of the ClusterNode.
ClusterNodeId() - Constructor for class io.hekate.cluster.ClusterNodeId
Constructs new random identifier.
ClusterNodeId(long, long) - Constructor for class io.hekate.cluster.ClusterNodeId
Constructs new instance from the specified higher/lower bits.
ClusterNodeId(String) - Constructor for class io.hekate.cluster.ClusterNodeId
Creates new identifier from the specified string.
ClusterNodeIdSupport - Interface in io.hekate.cluster
Marker interface for objects that have (or are) ClusterNodeId.
ClusterNodeJmx - Class in io.hekate.cluster
Information about a ClusterNode that is exposed to JMX.
ClusterNodeJmx(String, String, int, String, Set<String>, Map<String, String>) - Constructor for class io.hekate.cluster.ClusterNodeJmx
Constructs a new instance.
ClusterNodeRuntime - Interface in io.hekate.cluster
Information about the JVM process of the ClusterNode.
clusterOf(Class<?>) - Method in interface io.hekate.rpc.RpcService
Returns the cluster view that includes only those nodes that have a server for the specified Rpc-annotated Java interface.
clusterOf(Class<?>, String) - Method in interface io.hekate.rpc.RpcService
Returns the cluster view that includes only those nodes that have a server for the specified Rpc-annotated Java interface and tag.
ClusterRejectedJoinException - Exception in io.hekate.cluster
Signals that the joining node has been rejected by ClusterAcceptor.
ClusterRejectedJoinException(String, ClusterAddress) - Constructor for exception io.hekate.cluster.ClusterRejectedJoinException
Constructs new instance with the specified reject reason and address of the node that rejected this node joining.
clusterService() - Method in class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Returns the factory bean that makes it possible to inject ClusterService directly into other beans instead of accessing it via Hekate.cluster() method.
ClusterService - Interface in io.hekate.cluster
« start hereMain entry point to clustering API.
ClusterServiceBean - Class in io.hekate.spring.bean.cluster
Imports ClusterService into a Spring context.
ClusterServiceBean() - Constructor for class io.hekate.spring.bean.cluster.ClusterServiceBean
 
clusterServiceFactory(Optional<FailureDetector>) - Method in class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Constructs the ClusterServiceFactory.
ClusterServiceFactory - Class in io.hekate.cluster
Factory for ClusterService.
ClusterServiceFactory() - Constructor for class io.hekate.cluster.ClusterServiceFactory
 
ClusterServiceJmx - Interface in io.hekate.cluster
JMX interface for ClusterService.
ClusterServiceManager - Interface in io.hekate.core.service
Cluster service manager.
ClusterSplitBrainException - Exception in io.hekate.cluster
Signals that cluster is in split-brain state.
ClusterSplitBrainException(String) - Constructor for exception io.hekate.cluster.ClusterSplitBrainException
Constructs a new instance.
ClusterSplitBrainException(String, Throwable) - Constructor for exception io.hekate.cluster.ClusterSplitBrainException
Constructs a new instance.
ClusterTopology - Interface in io.hekate.cluster
Immutable snapshot of the cluster topology.
ClusterTopologySupport - Interface in io.hekate.cluster
Marker interface for objects that have (or are) ClusterTopology.
ClusterView - Interface in io.hekate.cluster
Filtered view of ClusterService.
codec() - Method in interface io.hekate.core.Hekate
Returns the CodecService.
Codec<T> - Interface in io.hekate.codec
Data serialization codec.
CodecException - Exception in io.hekate.codec
Generic data encoding/decoding error.
CodecException(String) - Constructor for exception io.hekate.codec.CodecException
Constructs new instance.
CodecException(String, Throwable) - Constructor for exception io.hekate.codec.CodecException
Constructs new instance.
codecFactory() - Method in interface io.hekate.codec.CodecService
Returns an underlying codec factory (see HekateBootstrap.setDefaultCodec(CodecFactory)).
CodecFactory<T> - Interface in io.hekate.codec
Factory for Codec.
codecService() - Method in class io.hekate.spring.boot.HekateConfigurer
Exports CodecService bean.
CodecService - Interface in io.hekate.codec
« start hereMain entry point to data serialization API.
CodecServiceBean - Class in io.hekate.spring.bean.codec
Imports CodecService into a Spring context.
CodecServiceBean() - Constructor for class io.hekate.spring.bean.codec.CodecServiceBean
 
CodecUtils - Class in io.hekate.codec
Utilities for data encoding/decoding.
compare(GossipBase) - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
compare(GossipNodeInfoBase) - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfoBase
 
compareTo(ClusterAddress) - Method in class io.hekate.cluster.ClusterAddress
Compares this address with the specified one by comparing ClusterAddress.id()s of both addresses.
compareTo(ClusterNode) - Method in interface io.hekate.cluster.ClusterNode
Compares this node with the specified one based on ClusterNode.id() value.
compareTo(GossipNodeState) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
compareTo(Partition) - Method in interface io.hekate.partition.Partition
Compares this partition with the specified one based on Partition.id() value.
compareTo(T) - Method in class io.hekate.util.UuidBase
 
complete() - Method in interface io.hekate.coordinate.CoordinatorContext
Completes this coordination process.
complete(CoordinationContext) - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called when coordination process gets completed successfully.
completed(Hekate) - Static method in class io.hekate.core.LeaveFuture
Creates a future object that is already completed.
completed(Hekate) - Static method in class io.hekate.core.TerminateFuture
Creates a future object that is already completed.
completed(NetworkEndpoint<T>) - Static method in class io.hekate.network.NetworkFuture
Returns completed future.
completed(NetworkServer) - Static method in class io.hekate.network.NetworkServerFuture
Returns the completed future.
CONCURRENT - io.hekate.cluster.internal.gossip.GossipPrecedence
 
ConditionalOnHekateEnabled - Annotation Type in io.hekate.spring.boot
Conditional annotation that can be placed on auto-configuration classes in order to activate them only if HekateConfigurer is enabled.
ConfigCheck - Class in io.hekate.core.internal.util
 
ConfigReporter - Interface in io.hekate.core.report
Helper class to build configuration reports.
ConfigReportSupport - Interface in io.hekate.core.report
Base interface for components that support configuration reports via ConfigReporter.
ConfigurableService - Interface in io.hekate.core.service
Lifecycle interface for services that require a one time configuration pre-processing.
ConfigurationContext - Interface in io.hekate.core.service
Context for ConfigurableService.
configure(ConfigurationContext) - Method in interface io.hekate.core.service.ConfigurableService
Configures this service.
configure(AggregateRetryPolicy<T>) - Method in interface io.hekate.messaging.operation.AggregateRetryConfigurer
Configures the retry policy.
configure(BroadcastRetryPolicy) - Method in interface io.hekate.messaging.operation.BroadcastRetryConfigurer
Configures the retry policy.
configure(RequestRetryPolicy<T>) - Method in interface io.hekate.messaging.operation.RequestRetryConfigurer
Configures the retry policy.
configure(SendRetryPolicy) - Method in interface io.hekate.messaging.operation.SendRetryConfigurer
Configures the retry policy.
configure(RetryPolicy<?>) - Method in interface io.hekate.messaging.retry.GenericRetryConfigurer
Configures the retry policy.
configure(RetryPolicy<?>) - Method in class io.hekate.rpc.RpcRetryInfo
 
configureCoordination() - Method in interface io.hekate.coordinate.CoordinationConfigProvider
Returns a collection of coordination processes configuration that should be registered within the CoordinationService.
configureElection() - Method in interface io.hekate.election.CandidateConfigProvider
Returns a collection of leader election configurations that should be registered within the ElectionService.
configureLocking() - Method in interface io.hekate.lock.LockConfigProvider
Returns a collection of lock region configurations that should be registered within the LockService.
configureMessaging() - Method in interface io.hekate.messaging.MessagingConfigProvider
Returns a collection of channel configurations that should be registered within the MessagingService.
configureNetwork() - Method in interface io.hekate.network.NetworkConfigProvider
Returns a collection of connector configurations that should be registered within the NetworkService.
configureRpcClients() - Method in interface io.hekate.rpc.RpcClientConfigProvider
Returns a collection of RPC client configurations that should be registered within the RpcService.
configureRpcServers() - Method in interface io.hekate.rpc.RpcServerConfigProvider
Returns a collection of RPC server configurations that should be registered within the RpcService.
conflict(ClusterAddress, ClusterAddress, InetSocketAddress) - Static method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
CONFLICT - io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
 
connect(InetSocketAddress, NetworkClientCallback<T>) - Method in interface io.hekate.network.NetworkClient
Asynchronously established a new socket connection to a NetworkService at the specified address.
connect(InetSocketAddress, T, NetworkClientCallback<T>) - Method in interface io.hekate.network.NetworkClient
Asynchronously established a new socket connection to a NetworkService at the specified address and submits an optional login message.
CONNECTED - io.hekate.network.NetworkClient.State
Client is connected.
CONNECTING - io.hekate.network.NetworkClient.State
Connection establishment is in process.
connectionString() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
Returns the ZooKeeper connection string.
connector(String) - Method in interface io.hekate.network.NetworkService
Returns a connector instance for the specified protocol name.
connectTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Returns the Consul connect timeout in milliseconds.
connectTimeout() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
Zookeeper connect timeout.
consulSeedNodeProvider(ConsulSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateConsulSeedNodeProviderConfigurer
Constructs new ConsulSeedNodeProvider.
ConsulSeedNodeProvider - Class in io.hekate.cluster.seed.consul
Implementation of SeedNodeProvider interface with usage of Consul's Key-Value store.
ConsulSeedNodeProvider(ConsulSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Initializes new consul seed node provider.
consulSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateConsulSeedNodeProviderConfigurer
Conditionally constructs a new configuration for ConsulSeedNodeProvider if application doesn't provide its own Bean of ConsulSeedNodeProviderConfig type.
ConsulSeedNodeProviderConfig - Class in io.hekate.cluster.seed.consul
Configuration for ConsulSeedNodeProvider.
ConsulSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
 
container() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
Cloud store container.
containerPortName() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
Container port name.
contains(ClusterNode) - Method in interface io.hekate.cluster.ClusterTopology
Returns true if this topology contains the specified node.
contains(ClusterNodeId) - Method in interface io.hekate.cluster.ClusterTopology
Returns true if this topology contains a node with the specified identifier.
coordinate(CoordinatorContext) - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called when local node is selected to be the coordinator.
coordination() - Method in interface io.hekate.core.Hekate
Returns the CoordinationService.
CoordinationBroadcastCallback - Interface in io.hekate.coordinate
Callback for coordination broadcast requests.
CoordinationConfigProvider - Interface in io.hekate.coordinate
Provider of CoordinationProcess configurations.
CoordinationContext - Interface in io.hekate.coordinate
Coordination context for CoordinationHandler.
CoordinationFuture - Class in io.hekate.coordinate
Coordination future.
CoordinationFuture() - Constructor for class io.hekate.coordinate.CoordinationFuture
 
CoordinationHandler - Interface in io.hekate.coordinate
Handler for CoordinationProcess.
CoordinationMember - Interface in io.hekate.coordinate
Member of a coordination process.
CoordinationProcess - Interface in io.hekate.coordinate
Provided information about the coordination process.
CoordinationProcessConfig - Class in io.hekate.coordinate
Configuration for CoordinationProcess.
CoordinationProcessConfig() - Constructor for class io.hekate.coordinate.CoordinationProcessConfig
Default constructor.
CoordinationProcessConfig(String) - Constructor for class io.hekate.coordinate.CoordinationProcessConfig
Constructs new instance.
CoordinationRequest - Interface in io.hekate.coordinate
Request from a CoordinationMember.
CoordinationRequestCallback - Interface in io.hekate.coordinate
Callback for coordination requests.
coordinationService() - Method in class io.hekate.spring.boot.coordination.HekateCoordinationServiceConfigurer
Returns the factory bean that makes it possible to inject CoordinationService directly into other beans instead of accessing it via Hekate.coordination() method.
CoordinationService - Interface in io.hekate.coordinate
« start hereMain entry point to distributed coordination API.
CoordinationServiceBean - Class in io.hekate.spring.bean.coordinate
Imports CoordinationService into a Spring context.
CoordinationServiceBean() - Constructor for class io.hekate.spring.bean.coordinate.CoordinationServiceBean
 
coordinationServiceFactory() - Method in class io.hekate.spring.boot.coordination.HekateCoordinationServiceConfigurer
CoordinationServiceFactory - Class in io.hekate.coordinate
Factory for CoordinationService.
CoordinationServiceFactory() - Constructor for class io.hekate.coordinate.CoordinationServiceFactory
 
coordinator() - Method in interface io.hekate.coordinate.CoordinationContext
Returns the coordinator.
coordinator(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
CoordinatorContext - Interface in io.hekate.coordinate
Coordinator context.
copy(ClusterTopologySupport) - Method in interface io.hekate.partition.PartitionMapper
Returns a copy of this mapper that will use the specified cluster topology and will inherit the mapping logic and all the configuration options from this instance.
copy(ClusterTopologySupport) - Method in class io.hekate.partition.RendezvousHashMapper
 
copy(ClusterTopologySupport) - Method in class io.hekate.partition.UpdatablePartitionMapper
 
CoreService - Interface in io.hekate.core.service
Combination of commonly used service lifecycle interfaces.
cpus() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the number of CPUs that are available to the Java virtual machine.
create() - Method in class io.hekate.core.HekateBootstrap
Creates a new Hekate instance.
createCodec() - Method in class io.hekate.codec.AutoSelectCodecFactory
 
createCodec() - Method in interface io.hekate.codec.CodecFactory
Creates codec.
createCodec() - Method in class io.hekate.codec.fst.FstCodecFactory
 
createCodec() - Method in class io.hekate.codec.JdkCodecFactory
 
createCodec() - Method in class io.hekate.codec.kryo.KryoCodecFactory
 
createCodec() - Method in class io.hekate.codec.SingletonCodecFactory
 
createCodec() - Method in class io.hekate.codec.ThreadLocalCodecFactory
 
createServer() - Method in class io.hekate.network.netty.NettyServerFactory
 
createServer() - Method in class io.hekate.network.NetworkServerFactoryBase
Creates a new network server based on the configuration options of this factory.
createService() - Method in class io.hekate.cluster.ClusterServiceFactory
 
createService() - Method in class io.hekate.coordinate.CoordinationServiceFactory
 
createService() - Method in class io.hekate.core.jmx.JmxServiceFactory
 
createService() - Method in class io.hekate.core.resource.ResourceServiceFactory
 
createService() - Method in interface io.hekate.core.service.ServiceFactory
Constructs a new service instance based on the configuration options of this factory.
createService() - Method in class io.hekate.election.ElectionServiceFactory
 
createService() - Method in class io.hekate.lock.LockServiceFactory
 
createService() - Method in class io.hekate.messaging.MessagingServiceFactory
 
createService() - Method in class io.hekate.network.NetworkServiceFactory
 
createService() - Method in class io.hekate.rpc.RpcServiceFactory
 
createSink(String) - Method in interface io.hekate.network.netty.NettyMetricsFactory
Creates a new sink for the specified protocol.
CredentialsSupplier - Interface in io.hekate.cluster.seed.jclouds
Credentials supplier for Apache JClouds-based seed node providers.

D

DataReader - Interface in io.hekate.codec
Data reader.
datasource() - Method in class io.hekate.cluster.split.JdbcConnectivityDetector
Datasource to check.
dataSource() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Returns the data source of this provider.
DataWriter - Interface in io.hekate.codec
Data writer.
date() - Static method in class io.hekate.core.HekateVersion
Returns the build date string (dd.MM.yyyy).
decode() - Method in interface io.hekate.network.NetworkMessage
Decodes this message by applying an underlying Codec.
decode(byte[]) - Method in interface io.hekate.codec.CodecService
Decodes an object from the specified array of bytes.
decode(byte[]) - Method in interface io.hekate.codec.EncoderDecoder
Decodes an object from the specified array of bytes.
decode(byte[]) - Method in interface io.hekate.messaging.MessageMetaData.MetaDataCodec
Decodes value.
decode(byte[], int, int) - Method in interface io.hekate.codec.CodecService
Decodes an object from the specified array of bytes.
decode(byte[], int, int) - Method in interface io.hekate.codec.EncoderDecoder
Decodes an object from the specified array of bytes.
decode(byte[], int, int, DecodeFunction<T>) - Method in interface io.hekate.codec.CodecService
Decodes an object from the specified byte array by using the supplied decode function.
decode(byte[], DecodeFunction<T>) - Method in interface io.hekate.codec.CodecService
Decodes an object from the specified byte array by using the supplied decode function.
decode(DataReader) - Method in class io.hekate.cluster.internal.gossip.GossipProtocolCodec
 
decode(DataReader) - Method in interface io.hekate.codec.DecodeFunction
Decodes object from the provided reader.
decode(DataReader) - Method in interface io.hekate.codec.EncoderDecoder
Decodes an object from the specified reader.
decode(InputStream) - Method in interface io.hekate.codec.EncoderDecoder
Decodes an object from the specified stream.
DecodeFunction<T> - Interface in io.hekate.codec
Functional interface for decoding data from binary format.
decodeUnchecked(DataReader) - Method in interface io.hekate.codec.DecodeFunction
Same as DecodeFunction.decode(DataReader) but throws an unchecked exception.
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class io.hekate.util.async.ExtendedScheduledExecutor
 
DEFAULT - Static variable in interface io.hekate.util.time.SystemTimeSupplier
 
DEFAULT_ACCEPT_RETRY_INTERVAL - Static variable in class io.hekate.network.NetworkServiceFactory
DEFAULT_AUTO_ACCEPT - Static variable in class io.hekate.network.NetworkServerFactoryBase
DEFAULT_BASE_DELAY - Static variable in class io.hekate.messaging.retry.ExponentialBackoffPolicy
Default base delay (=50L) in milliseconds.
DEFAULT_BASE_PATH - Static variable in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Default value (="/hekate/cluster") for ConsulSeedNodeProviderConfig.setBasePath(String).
DEFAULT_BASE_PATH - Static variable in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Default value (="/hekate/cluster") for EtcdSeedNodeProviderConfig.setBasePath(String).
DEFAULT_BASE_PATH - Static variable in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Default value (="/hekate/cluster") for ZooKeeperSeedNodeProviderConfig.setBasePath(String).
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
DEFAULT_CLEANUP_INTERVAL - Static variable in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
DEFAULT_CONNECT_TIMEOUT - Static variable in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
DEFAULT_CONNECT_TIMEOUT - Static variable in class io.hekate.network.NetworkServiceFactory
DEFAULT_CONTAINER_PORT_NAME - Static variable in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
DEFAULT_DELAY - Static variable in class io.hekate.messaging.retry.FixedBackoffPolicy
Default delay (=100L) in milliseconds (see FixedBackoffPolicy.defaultPolicy()).
DEFAULT_DOMAIN - Static variable in class io.hekate.core.jmx.JmxServiceFactory
Default value ("io.hekate") for JmxServiceFactory.setDomain(String).
DEFAULT_FAILURE_DETECTION_QUORUM - Static variable in class io.hekate.cluster.health.DefaultFailureDetectorConfig
DEFAULT_GOSSIP_INTERVAL - Static variable in class io.hekate.cluster.ClusterServiceFactory
Default value (=1000L) in milliseconds for ClusterServiceFactory.setGossipInterval(long).
DEFAULT_GROUP - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Default value (="224.1.2.12") for MulticastSeedNodeProviderConfig.setGroup(String).
DEFAULT_HB_INTERVAL - Static variable in class io.hekate.network.NetworkServerFactoryBase
DEFAULT_HB_INTERVAL - Static variable in class io.hekate.network.NetworkServiceFactory
DEFAULT_HB_LOSS_THRESHOLD - Static variable in class io.hekate.network.NetworkServerFactoryBase
DEFAULT_HB_LOSS_THRESHOLD - Static variable in class io.hekate.network.NetworkServiceFactory
DEFAULT_HEARTBEAT_INTERVAL - Static variable in class io.hekate.cluster.health.DefaultFailureDetectorConfig
DEFAULT_HEARTBEAT_LOSS_THRESHOLD - Static variable in class io.hekate.cluster.health.DefaultFailureDetectorConfig
DEFAULT_HOST_COLUMN - Static variable in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
DEFAULT_IDLE_SOCKET_TIMEOUT - Static variable in class io.hekate.coordinate.CoordinationServiceFactory
Default value in milliseconds (=60000L) for CoordinationServiceFactory.setIdleSocketTimeout(long).
DEFAULT_INTERVAL - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
DEFAULT_LOOP_BACK_DISABLED - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
DEFAULT_MAX_DELAY - Static variable in class io.hekate.messaging.retry.ExponentialBackoffPolicy
Default maximum delay (=3000L) in milliseconds.
DEFAULT_NAMESPACE - Static variable in class io.hekate.cluster.ClusterServiceFactory
Default value (="default") for ClusterServiceFactory.setNamespace(String).
DEFAULT_NAMESPACE_COLUMN - Static variable in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Default value (="cluster_namespace") for JdbcSeedNodeProviderConfig.setNamespaceColumn(String).
DEFAULT_PARTITIONS - Static variable in class io.hekate.partition.RendezvousHashMapper
DEFAULT_PORT - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
DEFAULT_PORT - Static variable in class io.hekate.network.NetworkServiceFactory
Default value (=10012) for NetworkServiceFactory.setPort(int).
DEFAULT_PORT_COLUMN - Static variable in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
DEFAULT_PORT_RANGE - Static variable in class io.hekate.network.NetworkServiceFactory
Default value (=100) for NetworkServiceFactory.setPortRange(int).
DEFAULT_RETRY_INTERVAL - Static variable in class io.hekate.coordinate.CoordinationServiceFactory
Default value in milliseconds (=50) for CoordinationServiceFactory.setRetryInterval(long).
DEFAULT_RETRY_INTERVAL - Static variable in class io.hekate.lock.LockServiceFactory
Default value in milliseconds (=50) for LockServiceFactory.setRetryInterval(long).
DEFAULT_SESSION_TIMEOUT - Static variable in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
DEFAULT_SPEED_UP_SIZE - Static variable in class io.hekate.cluster.ClusterServiceFactory
DEFAULT_TABLE - Static variable in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Default value (="cluster_nodes") for JdbcSeedNodeProviderConfig.setTable(String).
DEFAULT_TCP_NO_DELAY - Static variable in class io.hekate.network.NetworkServerFactoryBase
DEFAULT_TCP_NO_DELAY - Static variable in class io.hekate.network.NetworkServiceFactory
DEFAULT_TIMEOUT - Static variable in class io.hekate.cluster.split.AddressReachabilityDetector
Default value (=3000) in milliseconds for the timeout parameter of AddressReachabilityDetector(String, int).
DEFAULT_TIMEOUT - Static variable in class io.hekate.cluster.split.HostReachabilityDetector
Default value (=3000) in milliseconds for the timeout parameter of HostReachabilityDetector(String, int).
DEFAULT_TTL - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
DEFAULT_WAIT_TIME - Static variable in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
DEFAULT_WORKER_THREADS - Static variable in class io.hekate.lock.LockServiceFactory
DefaultConfigReporter - Class in io.hekate.core.report
Default implementation of interface.
DefaultConfigReporter() - Constructor for class io.hekate.core.report.DefaultConfigReporter
Constructs a new instance.
defaultFailureDetector(DefaultFailureDetectorConfig) - Method in class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Conditionally constructs the default failure detector if application doesn't provide its own Bean of FailureDetector type.
DefaultFailureDetector - Class in io.hekate.cluster.health
Default implementation of FailureDetector interface.
DefaultFailureDetector() - Constructor for class io.hekate.cluster.health.DefaultFailureDetector
Constructs a new instance with the default configuration options.
DefaultFailureDetector(DefaultFailureDetectorConfig) - Constructor for class io.hekate.cluster.health.DefaultFailureDetector
Constructs a new instance using the specified configuration.
defaultFailureDetectorConfig() - Method in class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Conditionally constructs the configuration for a default failure detector if application doesn't provide its own Bean of FailureDetector type.
DefaultFailureDetectorConfig - Class in io.hekate.cluster.health
Configuration for DefaultFailureDetector.
DefaultFailureDetectorConfig() - Constructor for class io.hekate.cluster.health.DefaultFailureDetectorConfig
 
DefaultFailureDetectorJmx - Interface in io.hekate.cluster.health
JMX interface for DefaultFailureDetector.
DefaultLoadBalancer<T> - Class in io.hekate.messaging.loadbalance
Default implementation of the LoadBalancer interface.
DefaultLoadBalancer() - Constructor for class io.hekate.messaging.loadbalance.DefaultLoadBalancer
 
DefaultPartition - Class in io.hekate.partition
Default implementation of PartitionMapper interface.
DefaultPartition(int, ClusterNode, List<ClusterNode>, ClusterTopology) - Constructor for class io.hekate.partition.DefaultPartition
Constructs a new instance.
defaultPolicy() - Static method in class io.hekate.messaging.retry.FixedBackoffPolicy
Returns the default policy with 100Lms interval.
defaultPolicy() - Static method in enum io.hekate.messaging.retry.RetryRoutingPolicy
Returns the default policy.
DefaultRpcLoadBalancer - Class in io.hekate.rpc
Default implementation of RpcLoadBalancer interface.
DefaultRpcLoadBalancer() - Constructor for class io.hekate.rpc.DefaultRpcLoadBalancer
 
DefaultServiceFactory - Annotation Type in io.hekate.core.service
Specifies the default factory for a Service interface.
delay() - Method in annotation type io.hekate.rpc.RpcRetry
Delay in milliseconds between attempts.
delay() - Method in class io.hekate.rpc.RpcRetryInfo
Returns the parsed value of RpcRetry.delay().
delayBeforeRetry(int) - Method in class io.hekate.messaging.retry.ExponentialBackoffPolicy
 
delayBeforeRetry(int) - Method in class io.hekate.messaging.retry.FixedBackoffPolicy
 
delayBeforeRetry(int) - Method in interface io.hekate.messaging.retry.RetryBackoffPolicy
Returns a delay in milliseconds before the next retry attempt.
deleteSql() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Returns the SQL string for inserting new records into the seed nodes table.
DependencyContext - Interface in io.hekate.core.service
Context for DependentService.
DependentService - Interface in io.hekate.core.service
Lifecycle interface for services that depend on some other services.
destroy() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
digest() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateDigest
 
disconnect() - Method in interface io.hekate.network.NetworkEndpoint
Asynchronously disconnects this endpoint.
DISCONNECTED - io.hekate.network.NetworkClient.State
Client is disconnected.
DISCONNECTING - io.hekate.network.NetworkClient.State
Client is disconnecting.
DistributedLock - Interface in io.hekate.lock
Distributed lock.
domain() - Method in interface io.hekate.core.jmx.JmxService
Returns the JMX domain of this service.
DOWN - io.hekate.cluster.internal.gossip.GossipNodeStatus
 
DOWN - io.hekate.core.Hekate.State
Initial state.

E

election() - Method in interface io.hekate.core.Hekate
Returns the ElectionService.
electionService() - Method in class io.hekate.spring.boot.election.HekateElectionServiceConfigurer
Returns the factory bean that makes it possible to inject ElectionService directly into other beans instead of accessing it via Hekate.election() method.
ElectionService - Interface in io.hekate.election
« start hereMain entry point to leader election API.
ElectionServiceBean - Class in io.hekate.spring.bean.election
Imports ElectionService into a Spring context.
ElectionServiceBean() - Constructor for class io.hekate.spring.bean.election.ElectionServiceBean
 
electionServiceFactory() - Method in class io.hekate.spring.boot.election.HekateElectionServiceConfigurer
Constructs the ElectionServiceFactory.
ElectionServiceFactory - Class in io.hekate.election
Factory for ElectionService.
ElectionServiceFactory() - Constructor for class io.hekate.election.ElectionServiceFactory
 
empty() - Static method in interface io.hekate.cluster.ClusterTopology
Return an empty cluster topology.
empty() - Static method in class io.hekate.cluster.UpdatableClusterView
Constructs a new empty cluster view.
empty(int) - Static method in class io.hekate.partition.DefaultPartition
Returns a new instance that represents an empty partition.
EMPTY - Static variable in class io.hekate.cluster.internal.gossip.GossipSuspectView
 
EmptyTopologyException - Exception in io.hekate.messaging.loadbalance
Signals that there are no suitable cluster nodes to perform load balancing.
EmptyTopologyException(String) - Constructor for exception io.hekate.messaging.loadbalance.EmptyTopologyException
Constructs a new instance.
EmptyTopologyException(String, Throwable) - Constructor for exception io.hekate.messaging.loadbalance.EmptyTopologyException
Constructs new instance.
EnableHekate - Annotation Type in io.hekate.spring.boot
Enables Hekate auto-configuration on Spring Boot application.
encode(GossipProtocol, DataWriter) - Method in class io.hekate.cluster.internal.gossip.GossipProtocolCodec
 
encode(Object) - Method in interface io.hekate.codec.CodecService
Encodes the specified object into an array of bytes.
encode(T) - Method in interface io.hekate.codec.EncoderDecoder
Encodes the specified object into an array of bytes.
encode(T) - Method in interface io.hekate.messaging.MessageMetaData.MetaDataCodec
Encodes value.
encode(T, DataWriter) - Method in interface io.hekate.codec.EncodeFunction
Encodes object into the provided writer.
encode(T, DataWriter) - Method in interface io.hekate.codec.EncoderDecoder
Encodes the specified object into the specified writer.
encode(T, EncodeFunction<T>) - Method in interface io.hekate.codec.CodecService
Encodes the specified object via the specified function and returns a byte array of encoded data.
encode(T, OutputStream) - Method in interface io.hekate.codec.EncoderDecoder
Encodes the specified object into the specified stream.
EncodeFunction<T> - Interface in io.hekate.codec
Functional interface for data encoding into a binary format.
EncoderDecoder<T> - Interface in io.hekate.codec
Interface for components that can perform encoding/decoding operations.
encodeUnchecked(T, DataWriter) - Method in interface io.hekate.codec.EncodeFunction
Same as EncodeFunction.encode(Object, DataWriter) but throws an unchecked exception.
endpoint() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
Cloud endpoint.
endpoint() - Method in interface io.hekate.messaging.MessageBase
Returns the messaging endpoint of this message..
endpoints() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
Returns an immutable list of Etcd endpoints.
epoch() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
epoch() - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
epoch() - Method in class io.hekate.cluster.internal.gossip.GossipDigest
 
EPOLL - io.hekate.network.NetworkTransportType
Use the optimized Epoll-based transport (for Linux environments only).
equals(Object) - Method in class io.hekate.cluster.ClusterAddress
Returns true if the specified object is of ClusterAddress type and has the same ClusterAddress.id() as this object.
equals(Object) - Method in class io.hekate.cluster.ClusterNodeJmx
 
equals(Object) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
equals(Object) - Method in class io.hekate.partition.DefaultPartition
 
equals(Object) - Method in class io.hekate.util.UuidBase
 
error() - Method in interface io.hekate.messaging.retry.FailedAttempt
Returns the cause of ths failure.
errorOf(ClusterNode) - Method in interface io.hekate.messaging.operation.AggregateResult
Returns an error for the specified node or null if there was no failure on that node.
errorOf(ClusterNode) - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns a communication error for the specified node or null if there was no communication failure with that node.
errors() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the map of cluster nodes and errors that happened while trying to communicate with those nodes.
errors() - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns the map of cluster nodes and errors that happened while trying to communicate with these nodes.
errors() - Method in exception io.hekate.rpc.RpcAggregateException
Returns the map of failed nodes and their corresponding errors.
errors() - Method in annotation type io.hekate.rpc.RpcRetry
Base types of errors that can be retried.
errors() - Method in class io.hekate.rpc.RpcRetryInfo
Returns the parsed value of RpcRetry.errors().
ErrorUtils - Class in io.hekate.core.internal.util
Utilities for working with Exceptions.
etcdSeedNodeProvider(EtcdSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateEtcdSeedNodeProviderConfigurer
Constructs new EtcdSeedNodeProvider.
EtcdSeedNodeProvider - Class in io.hekate.cluster.seed.etcd
Etcd-based implementation of SeedNodeProvider interface.
EtcdSeedNodeProvider(EtcdSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
Constructs new instance.
etcdSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateEtcdSeedNodeProviderConfigurer
Conditionally constructs a new configuration for EtcdSeedNodeProvider if application doesn't provide its own Bean of EtcdSeedNodeProviderConfig type.
EtcdSeedNodeProviderConfig - Class in io.hekate.cluster.seed.etcd
Configuration for EtcdSeedNodeProvider.
EtcdSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
 
executor() - Method in interface io.hekate.messaging.MessagingChannel
Returns the executor of this channel.
exit(int) - Static method in class io.hekate.core.internal.util.Jvm
Exits the JVM by calling the pre-configured Jvm.ExitHandler or by calling the System.exit(int) method (if handler is not defined).
exit(int) - Method in interface io.hekate.core.internal.util.Jvm.ExitHandler
Exits the JVM.
exitHandler() - Static method in class io.hekate.core.internal.util.Jvm
Returns an instance of Jvm.ExitHandler if it was defined via Jvm.setExitHandler(ExitHandler).
exitJvm() - Static method in interface io.hekate.core.HekateFatalErrorPolicy
Call System.exit(int) with 250 exit code upon any fatal error.
exitJvm(int) - Static method in interface io.hekate.core.HekateFatalErrorPolicy
Call System.exit(int) with the specified exit code upon any fatal error.
ExponentialBackoffPolicy - Class in io.hekate.messaging.retry
A backoff policy that waits exponentially longer between each attempt (but keeps a constant delay once a maximum delay is reached).
ExponentialBackoffPolicy() - Constructor for class io.hekate.messaging.retry.ExponentialBackoffPolicy
Constructs a new instance with default values.
ExponentialBackoffPolicy(long, long) - Constructor for class io.hekate.messaging.retry.ExponentialBackoffPolicy
Constructs a new instance.
ExtendedScheduledExecutor - Class in io.hekate.util.async
Extended version of ScheduledThreadPoolExecutor.
ExtendedScheduledExecutor(int) - Constructor for class io.hekate.util.async.ExtendedScheduledExecutor
Constructs a new instance.
ExtendedScheduledExecutor(int, RejectedExecutionHandler) - Constructor for class io.hekate.util.async.ExtendedScheduledExecutor
Constructs a new instance.
ExtendedScheduledExecutor(int, ThreadFactory) - Constructor for class io.hekate.util.async.ExtendedScheduledExecutor
Constructs a new instance.
ExtendedScheduledExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class io.hekate.util.async.ExtendedScheduledExecutor
Constructs a new instance.
extract(Object) - Static method in class io.hekate.util.trace.TraceInfo
Tries to extract TraceInfo from the specified object.

F

fail() - Method in interface io.hekate.network.NetworkServerFailure
Resolves this failure to be unrecoverable.
fail(String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
fail(Throwable) - Method in class io.hekate.core.internal.util.ConfigCheck
 
FAIL - io.hekate.messaging.MessagingOverflowPolicy
Rejects operation with MessageQueueOverflowException error.
FAIL - io.hekate.rpc.RpcAggregate.RemoteErrors
In case of any error fail the whole aggregation with RpcAggregateException.
FAIL - io.hekate.rpc.RpcBroadcast.RemoteErrors
In case of any error fail the whole aggregation with RpcAggregateException.
FAIL_ON_FIRST_ERROR - io.hekate.cluster.seed.SeedNodeProviderGroupPolicy
Fail if at least one SeedNodeProvider fails.
failed() - Method in class io.hekate.cluster.event.ClusterChangeEvent
Returns the list of failed nodes.
FAILED - io.hekate.cluster.internal.gossip.GossipNodeStatus
 
FailedAttempt - Interface in io.hekate.messaging.retry
Failed attempt.
failure() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns information about a failure if this context represents a retry attempts.
FAILURE - io.hekate.network.NetworkPingResult
Ping operation failed.
FailureDetector - Interface in io.hekate.cluster.health
« start hereCluster nodes failure detector.
FailureDetectorContext - Interface in io.hekate.cluster.health
Runtime context for FailureDetector implementations.
failureQuorum() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
failureQuorum() - Method in interface io.hekate.cluster.health.FailureDetector
Return the amount of nodes that should agree on some particular node failure before removing such node from the cluster.
FailureResponse - Interface in io.hekate.messaging.operation
Marker interface for application-specific error responses.
fallbackExecutor() - Static method in class io.hekate.util.async.AsyncUtils
Fallback executor.
fatal(ClusterAddress, ClusterAddress, InetSocketAddress, String) - Static method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
FATAL - io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
 
FATAL_ERROR - io.hekate.cluster.event.ClusterLeaveReason
Leaving because of an unrecoverable error.
fatalError(Throwable) - Method in interface io.hekate.core.Hekate
Signals a fatal error.
FILE_PREFIX - Static variable in class io.hekate.core.internal.util.AddressUtils
Prefix for the file name of AddressUtils.toFileName(InetSocketAddress).
filter(ClusterNodeFilter) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use the specified filter along with all the filter criteria that were inherited from this instance.
filter(ClusterNodeFilter) - Method in interface io.hekate.cluster.ClusterTopology
Returns a copy of this topology containing only those nodes that match the specified filter.
filterAll(ClusterFilter) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use the specified filter along with all the filter criteria that were inherited from this instance.
filterAll(ClusterFilter) - Method in interface io.hekate.cluster.ClusterTopology
Returns a copy of this topology that contains only those nodes that match the specified filter.
filterAll(ClusterFilter) - Method in class io.hekate.cluster.UpdatableClusterView
 
FINAL_RESPONSE - io.hekate.messaging.intercept.InboundType
findCause(Class<T>) - Method in exception io.hekate.core.HekateException
Searches for an error cause of the specified type.
findCause(Class<T>, Throwable) - Static method in class io.hekate.core.internal.util.ErrorUtils
Returns an error instance of the specified type by scanning the cause tree.
findComponents(Class<T>) - Method in interface io.hekate.core.service.ConfigurationContext
Searches for all components of the specified type.
findProvider(Class<T>) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
Searches for a seed node provider of the specified type.
findSeedNodes(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
findSeedNodes(String) - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Returns the list of known seed node addresses.
findSeedNodes(String) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
findSeedNodes(String) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
first() - Method in interface io.hekate.cluster.ClusterTopology
Returns the first node of the ClusterTopology.nodes() list or null if this topology is empty.
FixedBackoffPolicy - Class in io.hekate.messaging.retry
Fixed delay policy.
FixedBackoffPolicy() - Constructor for class io.hekate.messaging.retry.FixedBackoffPolicy
Constructs a new instance with the default delay (=100L).
FixedBackoffPolicy(long) - Constructor for class io.hekate.messaging.retry.FixedBackoffPolicy
Constructs a new instance.
FollowerContext - Interface in io.hekate.election
Follower state context for Candidate.
forBoolean(String, boolean) - Static method in class io.hekate.core.ServiceProperty
Constructs a new property of ServiceProperty.Type.BOOLEAN type.
forEach(Consumer<ClusterNode>) - Method in interface io.hekate.cluster.ClusterView
Performs the given action for each node of this view.
forFactory(CodecFactory<T>) - Method in interface io.hekate.codec.CodecService
Returns encoder/decoder for the codec factory.
forFilter(ClusterNodeFilter) - Static method in class io.hekate.cluster.ClusterFilters
Wraps the specified filter with ClusterFilter.
forInteger(String, int) - Static method in class io.hekate.core.ServiceProperty
Constructs a new property of ServiceProperty.Type.INTEGER type.
fork() - Method in class io.hekate.util.HekateFuture
Returns a new future instance who's lifecycle depends on this instance but not vice versa.
forkFromAsync() - Method in exception io.hekate.cluster.ClusterException
 
forkFromAsync() - Method in exception io.hekate.cluster.ClusterRejectedJoinException
 
forkFromAsync() - Method in exception io.hekate.cluster.ClusterSplitBrainException
 
forkFromAsync() - Method in exception io.hekate.codec.CodecException
 
forkFromAsync() - Method in exception io.hekate.core.HekateException
Forks this exception by creating a new exception that has this instance as its cause.
forkFromAsync() - Method in exception io.hekate.core.HekateExecutionException
 
forkFromAsync() - Method in exception io.hekate.core.HekateInterruptedException
 
forkFromAsync() - Method in exception io.hekate.core.HekateIoException
 
forkFromAsync() - Method in exception io.hekate.core.HekateTimeoutException
 
forkFromAsync() - Method in exception io.hekate.core.jmx.JmxServiceException
 
forkFromAsync() - Method in exception io.hekate.core.resource.ResourceLoadException
 
forkFromAsync() - Method in exception io.hekate.election.LeaderException
 
forkFromAsync() - Method in exception io.hekate.messaging.loadbalance.EmptyTopologyException
 
forkFromAsync() - Method in exception io.hekate.messaging.loadbalance.LoadBalancerException
 
forkFromAsync() - Method in exception io.hekate.messaging.loadbalance.UnknownRouteException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessageQueueOverflowException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessageQueueTimeoutException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessageTimeoutException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessagingChannelClosedException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessagingException
 
forkFromAsync() - Method in exception io.hekate.messaging.MessagingRemoteException
 
forkFromAsync() - Method in exception io.hekate.messaging.operation.RejectedResponseException
 
forkFromAsync() - Method in exception io.hekate.network.NetworkConnectException
 
forkFromAsync() - Method in exception io.hekate.network.NetworkConnectTimeoutException
 
forkFromAsync() - Method in exception io.hekate.network.NetworkEndpointClosedException
 
forkFromAsync() - Method in exception io.hekate.network.NetworkException
 
forkFromAsync() - Method in exception io.hekate.network.NetworkTimeoutException
 
forkFromAsync() - Method in exception io.hekate.rpc.RpcAggregateException
 
forkFromAsync() - Method in exception io.hekate.rpc.RpcException
 
forLong(String, long) - Static method in class io.hekate.core.ServiceProperty
Constructs a new property of ServiceProperty.Type.LONG type.
format(Class<?>, Object) - Static method in class io.hekate.util.format.ToString
Formats the specified object to string by prefixing it with the specified type name instead of the original object type.
format(Object) - Static method in class io.hekate.util.format.ToString
Formats the specified object to string including the object's type information.
format(Object) - Method in interface io.hekate.util.format.ToStringFormat.Formatter
Converts field value to string.
formatProperties(Object) - Static method in class io.hekate.util.format.ToString
Returns the comma-separated list of object's fields and values.
forNext() - Static method in class io.hekate.cluster.ClusterFilters
Filters nodes using a ring structure based on natural nodes ordering.
forNextInJoinOrder() - Static method in class io.hekate.cluster.ClusterFilters
Filters nodes using a ring structure based on nodes join order.
forNode(ClusterNode) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all nodes but the specified one.
forNode(ClusterNode) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forNode(ClusterNode) filter along with all the filter criteria that were inherited from this instance.
forNode(ClusterNodeId) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all nodes but the specified one.
forNode(ClusterNodeId) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forNode(ClusterNodeId) filter along with all the filter criteria that were inherited from this instance.
forOldest() - Static method in class io.hekate.cluster.ClusterFilters
Filters out all nodes but the oldest one (with the smallest ClusterNode.joinOrder()).
forOldest() - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forOldest() filter along with all the filter criteria that were inherited from this instance.
forProperty(String) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all but nodes with the specified property.
forProperty(String) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forProperty(String) filter along with all the filter criteria that were inherited from this instance.
forProperty(String, String) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all but nodes with the specified property value.
forProperty(String, String) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forProperty(String, String) filter along with all the filter criteria that were inherited from this instance.
forRemotes() - Static method in class io.hekate.cluster.ClusterFilters
Filters out all but remote nodes.
forRemotes() - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forRemotes() filter along with all the filter criteria that were inherited from this instance.
forRole(String) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all but nodes with the specified role.
forRole(String) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forRole(String) filter along with all the filter criteria that were inherited from this instance.
forService(Class<? extends Service>) - Static method in class io.hekate.cluster.ClusterFilters
Filters out all but nodes with the specified ClusterNode.services() service}.
forService(Class<? extends Service>) - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forService(Class) filter along with all the filter criteria that were inherited from this instance.
forString(String, String) - Static method in class io.hekate.core.ServiceProperty
Constructs a new property of ServiceProperty.Type.STRING type.
forType(Class<T>) - Method in interface io.hekate.codec.CodecService
Returns encoder/decoder for the specified type.
forType(Class<T>, EncodeFunction<T>, DecodeFunction<T>) - Method in interface io.hekate.codec.CodecService
Returns encoder/decoder for the specified type and encoding/decoding functions.
forYoungest() - Static method in class io.hekate.cluster.ClusterFilters
Filters out all nodes but the youngest one (with the largest ClusterNode.joinOrder()).
forYoungest() - Method in interface io.hekate.cluster.ClusterFilterSupport
Returns a copy of this instance that will use ClusterFilters.forYoungest() filter along with all the filter criteria that were inherited from this instance.
from() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol
 
from() - Method in interface io.hekate.coordinate.CoordinationRequest
Returns the member who sent this request.
from() - Method in interface io.hekate.messaging.intercept.ServerInboundContext
Address of a remote node.
from() - Method in interface io.hekate.messaging.MessageBase
Returns the universally unique identifier of the remote cluster node.
fromFileName(String, Logger) - Static method in class io.hekate.core.internal.util.AddressUtils
Parses an address from the specified file name which was constructed via AddressUtils.toFileName(InetSocketAddress).
fromNode() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinRequest
 
fsSeedNodeProvider(FsSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateFsSeedNodeProviderConfigurer
Constructs new FsSeedNodeProvider.
FsSeedNodeProvider - Class in io.hekate.cluster.seed.fs
File system-based implementation of SeedNodeProvider interface.
FsSeedNodeProvider(FsSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.fs.FsSeedNodeProvider
Constructs new instance.
fsSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateFsSeedNodeProviderConfigurer
Conditionally constructs a new configuration for FsSeedNodeProvider if application doesn't provide its own Bean of FsSeedNodeProviderConfig type.
FsSeedNodeProviderConfig - Class in io.hekate.cluster.seed.fs
Configuration for FsSeedNodeProvider.
FsSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
 
FsSeedNodeProviderJmx - Interface in io.hekate.cluster.seed.fs
JMX interface for FsSeedNodeProvider.
fstCodecFactory() - Method in class io.hekate.spring.boot.codec.HekateFstCodecConfigurer
Constructs a new instance of FstCodecFactory.
FstCodecFactory<T> - Class in io.hekate.codec.fst
« start hereFST -based implementation of CodecFactory interface.
FstCodecFactory() - Constructor for class io.hekate.codec.fst.FstCodecFactory
 
fullVersion() - Static method in class io.hekate.core.HekateVersion
Returns the full version number including the product name.
future() - Method in interface io.hekate.cluster.event.ClusterEvent
Returns a future object that represents all the attached futures of this event.
future() - Method in class io.hekate.cluster.event.ClusterEventBase
 
future() - Method in interface io.hekate.coordinate.CoordinationProcess
Returns the initial coordination future of this process.
futureOf(String) - Method in interface io.hekate.coordinate.CoordinationService
Returns an initial coordination future for the specified process name.
futureOf(Predicate<ClusterTopology>) - Method in interface io.hekate.cluster.ClusterView
Returns a future object that will be completed once the cluster topology matches the specified predicate.
futureOf(Predicate<ClusterTopology>) - Method in class io.hekate.cluster.UpdatableClusterView

G

GenericRetryConfigurer - Interface in io.hekate.messaging.retry
Generic retry policy for a messaging channel.
get() - Method in class io.hekate.cluster.seed.jclouds.aws.AwsCredentialsSupplier
 
get() - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
get() - Static method in class io.hekate.codec.HekateSerializableClasses
Returns a sorted set of serializable Hekate-internal classes.
get() - Method in interface io.hekate.coordinate.CoordinationRequest
Returns the request message.
get() - Method in interface io.hekate.messaging.operation.Aggregate
Synchronously executes this operation and returns the result.
get() - Method in interface io.hekate.messaging.operation.Request
Synchronously executes this operation and returns the response.
get() - Method in interface io.hekate.util.StateGuard.GuardedSupplier
Returns a value.
get(ClusterNodeId) - Method in interface io.hekate.cluster.ClusterTopology
Returns the node for the specified identifier or null if there is no such node within this topology.
get(MessageMetaData.Key<T>) - Method in class io.hekate.messaging.MessageMetaData
Returns the value of the specified key.
get(Class<?>) - Static method in class io.hekate.core.internal.util.ConfigCheck
 
get(Class<T>) - Method in interface io.hekate.coordinate.CoordinationRequest
Returns the request message.
get(Class<T>) - Method in interface io.hekate.core.Hekate
Returns the service of the specified type (f.e.
get(String) - Method in interface io.hekate.lock.LockRegion
Returns the distributed lock for the specified name.
getAcceptorEventLoop() - Method in class io.hekate.network.netty.NettyServerFactory
Returns the event loop group that is responsible for accepting new connections (see NettyServerFactory.setAcceptorEventLoop(EventLoopGroup)).
getAcceptors() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns a list of the cluster join acceptors (see ClusterServiceFactory.setAcceptors(List)).
getAcceptRetryInterval() - Method in class io.hekate.network.NetworkServiceFactory
Returns the number of milliseconds to wait before trying to re-create a TCP socket acceptor in case of a failure (see NetworkServiceFactory.setAcceptRetryInterval(long)).
getAclToken() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the ACL token to access Consul (see ConsulSeedNodeProviderConfig.setAclToken(String)).
getAddresses() - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
Returns the unmodifiable list of seed node addresses (see StaticSeedNodeProviderConfig.setAddresses(List)).
getAddresses() - Method in class io.hekate.cluster.seed.StaticSeedNodeProviderConfig
Returns the list of configured addresses (see StaticSeedNodeProviderConfig.setAddresses(List)).
getAttachment() - Method in interface io.hekate.coordinate.CoordinationContext
Returns a user-defined object that is attached to this context (see CoordinationContext.setAttachment(Object)).
getAttribute(String) - Method in interface io.hekate.core.Hekate
Returns an attribute that was set via Hekate.setAttribute(String, Object) method.
getAttribute(String) - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the attribute for the specified name.
getAttribute(String) - Method in interface io.hekate.messaging.intercept.ServerInboundContext
Returns the attribute for the specified name.
getBackPressure() - Method in class io.hekate.messaging.MessagingConfigBase
Returns the back pressure configuration (see MessagingConfigBase.setBackPressure(MessagingBackPressureConfig)).
getBackPressureInHighWatermark() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the value of the channel's MessagingBackPressureConfig.setInHighWatermark(int) or null if inbound back pressure is disabled.
getBackPressureInLowWatermark() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the value of the channel's MessagingBackPressureConfig.setInLowWatermark(int) or null if inbound back pressure is disabled.
getBackPressureOutHighWatermark() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the value of the channel's MessagingBackPressureConfig.setOutHighWatermark(int) or null if outbound back pressure is disabled.
getBackPressureOutLowWatermark() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the value of the channel's MessagingBackPressureConfig.setOutLowWatermark(int) or null if outbound back pressure is disabled.
getBackPressureOutOverflowPolicy() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the value of the channel's MessagingBackPressureConfig.setOutOverflowPolicy(MessagingOverflowPolicy) or null if outbound back pressure is disabled.
getBackupNodes() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the amount of backup nodes that should be assigned to each partition by the the channel's partition mapper (see MessagingChannelConfig.setBackupNodes(int)).
getBackupNodes() - Method in interface io.hekate.messaging.MessagingChannelJmx
getBackupNodes() - Method in class io.hekate.rpc.RpcClientConfig
Returns the amount of backup nodes that should be assigned to each partition by the the RPC client's partition mapper (see RpcClientConfig.setBackupNodes(int)).
getBasePath() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the base path to store seed nodes information in Consul (see ConsulSeedNodeProviderConfig.setBasePath(String)).
getBasePath() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Returns the base path to store seed nodes information in Etcd (see EtcdSeedNodeProviderConfig.setBasePath(String)).
getBasePath() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Returns the base path to store seed nodes information in ZooKeeper (see ZooKeeperSeedNodeProviderConfig.setBasePath(String)).
getBaseType() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the base type of messages that can be transferred over this channel (see MessagingChannelConfig(Class)).
getBaseType() - Method in interface io.hekate.messaging.MessagingChannelJmx
getCandidate() - Method in class io.hekate.election.CandidateConfig
Returns the leader election candidate (see CandidateConfig.setCandidate(Candidate)).
getCandidates() - Method in class io.hekate.election.ElectionServiceFactory
Returns the list of election candidate configurations that should be automatically registered during the leader election service startup (see ElectionServiceFactory.setCandidates(List)).
getCandidateType() - Method in interface io.hekate.election.CandidateJmx
Returns the class name of CandidateConfig.setCandidate(Candidate).
getChannel() - Method in class io.hekate.spring.bean.messaging.MessagingChannelBean
Returns the channel name (see MessagingChannelBean.setChannel(String)).
getChannels() - Method in class io.hekate.messaging.MessagingServiceFactory
Returns the list of Channel configurations (see MessagingServiceFactory.setChannels(List)).
getCleanupInterval() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see ConsulSeedNodeProviderConfig.setCleanupInterval(long)).
getCleanupInterval() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see EtcdSeedNodeProviderConfig.setCleanupInterval(int)).
getCleanupInterval() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see FsSeedNodeProviderConfig.setCleanupInterval(long)).
getCleanupInterval() - Method in interface io.hekate.cluster.seed.fs.FsSeedNodeProviderJmx
Returns the string representation of FsSeedNodeProviderConfig.setCleanupInterval(long).
getCleanupInterval() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see CloudStoreSeedNodeProviderConfig.setCleanupInterval(long)).
getCleanupInterval() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see JdbcSeedNodeProviderConfig.setCleanupInterval(long)).
getCleanupInterval() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
getCleanupInterval() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Returns the time interval in milliseconds between stale node cleanup runs (see ZooKeeperSeedNodeProviderConfig.setCleanupInterval(int)).
getClientProviders() - Method in class io.hekate.rpc.RpcServiceFactory
Returns the list of RPC client configuration providers (see RpcServiceFactory.setClientProviders(List)).
getClients() - Method in class io.hekate.rpc.RpcServiceFactory
Returns the list of RPC client configurations (see RpcServiceFactory.setClients(List)).
getClusterFilter() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the cluster node filter for this channel (see MessagingChannelConfig.setClusterFilter(ClusterNodeFilter)).
getClusterListeners() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns a list of cluster event listeners (see ClusterServiceFactory.setClusterListeners(List)).
getCodecFactory() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the CodecFactory that should be used for messages serialization (see NettyClientFactory.setCodecFactory(CodecFactory)).
getCodecFactory() - Method in class io.hekate.network.NetworkServerHandlerConfig
Returns the codec factory that should be used for messages serialization (see NetworkServerHandlerConfig.setCodecFactory(CodecFactory)).
getConfigProviders() - Method in class io.hekate.coordinate.CoordinationServiceFactory
Returns the list of coordination process configuration providers (see CoordinationServiceFactory.setConfigProviders(List)).
getConfigProviders() - Method in class io.hekate.election.ElectionServiceFactory
Returns the list of leader election configuration providers (see ElectionServiceFactory.setConfigProviders(List)).
getConfigProviders() - Method in class io.hekate.lock.LockServiceFactory
Returns the list of lock region configuration providers (see LockServiceFactory.setConfigProviders(List)).
getConfigProviders() - Method in class io.hekate.messaging.MessagingServiceFactory
Returns the list of channel configuration providers (see MessagingServiceFactory.setConfigProviders(List)).
getConfigProviders() - Method in class io.hekate.network.NetworkServiceFactory
Returns the list of connector configuration providers (see NetworkServiceFactory.setConfigProviders(List)).
getConnectionString() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Returns the list of ZooKeeper servers to connect to (see ZooKeeperSeedNodeProviderConfig.setConnectionString(String)).
getConnectors() - Method in class io.hekate.network.NetworkServiceFactory
Returns the list of connector configurations (see NetworkServiceFactory.setConnectors(List)).
getConnectTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the connect timeout value in milliseconds (see ConsulSeedNodeProviderConfig.setConnectTimeout(Long)).
getConnectTimeout() - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
Returns the connect timeout in milliseconds (see CloudPropertiesBase.setConnectTimeout(Integer)).
getConnectTimeout() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Returns the ZooKeeper connection timeout in milliseconds (see ZooKeeperSeedNodeProviderConfig.setConnectTimeout(int)).
getConnectTimeout() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the TCP connect timeout in milliseconds (see NettyClientFactory.setConnectTimeout(Integer)).
getConnectTimeout() - Method in class io.hekate.network.NetworkServiceFactory
Returns the TCP connect timeout in milliseconds (see NetworkServiceFactory.setConnectTimeout(int)).
getConnectTimeout() - Method in interface io.hekate.network.NetworkServiceJmx
getContainer() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the name of a BlobStore container (see CloudStoreSeedNodeProviderConfig.setContainer(String)).
getContainerPortName() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Returns the port name of a Pod's container (see KubernetesSeedNodeProviderConfig.setContainerPortName(String)).
getContext() - Method in interface io.hekate.messaging.MessagingEndpoint
Returns the custom context object that was set via MessagingEndpoint.setContext(Object).
getContext() - Method in interface io.hekate.network.NetworkEndpoint
Returns the custom user context object that was set via NetworkEndpoint.setContext(Object).
getCredential() - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
getCredentials() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns the supplier of credentials for ComputeService.
getCredentials() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the supplier of BlobStore credentials (see CloudStoreSeedNodeProviderConfig.setCredentials(CredentialsSupplier)).
getDataSource() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
getDataSourceInfo() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
Returns the string representation of JdbcSeedNodeProviderConfig.setDataSource(DataSource).
getDefaultCodec() - Method in class io.hekate.core.HekateBootstrap
Returns the default codec factory (see HekateBootstrap.setDefaultCodec(CodecFactory)).
getDefaultSerializers() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the map of default serializers (see KryoCodecFactory.setSerializers(Map)).
getDeleteSql() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
Returns the SQL statement for deleting data from the seed nodes table.
getDetectors() - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
Returns the list of registered detectors (see SplitBrainDetectorGroup.setDetectors(List)).
getDomain() - Method in class io.hekate.core.jmx.JmxServiceFactory
Returns the JMX domain (see JmxServiceFactory.setDomain(String)).
getEndpoint() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns the ComputeService provider endpoint (see CloudSeedNodeProviderConfig.setEndpoint(String)).
getEndpoints() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Returns the list of Etcd endpoint addresses (see EtcdSeedNodeProviderConfig.setEndpoints(List)).
getEventLoop() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the event loop group (see NettyClientFactory.setEventLoop(EventLoopGroup)).
getEventLoop() - Method in class io.hekate.network.netty.NettyServerHandlerConfig
Returns the event loop of this handler (see NettyServerHandlerConfig.setEventLoop(EventLoopGroup)).
getFailureDetectionQuorum() - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Returns the amount of nodes that should agree on some particular node failure before removing such a suspected node from the cluster (see DefaultFailureDetectorConfig.setFailureDetectionQuorum(int)).
getFailureDetectionQuorum() - Method in interface io.hekate.cluster.health.DefaultFailureDetectorJmx
getFailureDetector() - Method in class io.hekate.cluster.ClusterServiceFactory
getFatalErrorPolicy() - Method in class io.hekate.core.HekateBootstrap
Returns fatal error handling policy (see HekateBootstrap.setFatalErrorPolicy(HekateFatalErrorPolicy)).
getGlobalInterceptors() - Method in class io.hekate.messaging.MessagingServiceFactory
Returns the list of message interceptors that should be applied to all channels (see MessagingServiceFactory.setGlobalInterceptors(List)).
getGossipInterval() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns the time interval in millisecond between gossip rounds (see ClusterServiceFactory.setGossipInterval(long)).
getGroup() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns the multicast group address (see MulticastSeedNodeProviderConfig.setGroup(String)).
getGroup() - Method in interface io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderJmx
Returns the string value of MulticastSeedNodeProvider.group().
getGroup() - Method in class io.hekate.election.CandidateConfig
Returns the election group name (see CandidateConfig.setGroup(String)).
getGroup() - Method in interface io.hekate.election.CandidateJmx
Returns the value of CandidateConfig.setGroup(String).
getGroupPolicy() - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
Returns the policy of this group (see SplitBrainDetectorGroup.setGroupPolicy(GroupPolicy)).
getHandler() - Method in class io.hekate.coordinate.CoordinationProcessConfig
Returns the coordination process handler (see CoordinationProcessConfig.setHandler(CoordinationHandler)).
getHandler() - Method in class io.hekate.network.NetworkServerHandlerConfig
getHandler() - Method in class io.hekate.rpc.RpcServerConfig
Returns the RPC handler (see RpcServerConfig.setHandler(Object)).
getHandlers() - Method in class io.hekate.network.netty.NettyServerFactory
Returns the list of server connection handlers (see NettyServerFactory.setHandlers(List)).
getHandlerType() - Method in interface io.hekate.rpc.RpcServerJmx
Returns the class name of the servers's handler (see RpcServerConfig.setHandler(Object)).
getHeartbeatInterval() - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Returns the heartbeat sending interval in milliseconds (see DefaultFailureDetectorConfig.setHeartbeatInterval(long)).
getHeartbeatInterval() - Method in interface io.hekate.cluster.health.DefaultFailureDetectorJmx
getHeartbeatInterval() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns the heartbeat sending interval in milliseconds (see NetworkServerFactoryBase.setHeartbeatInterval(int)).
getHeartbeatInterval() - Method in class io.hekate.network.NetworkServiceFactory
Returns the heartbeat sending interval in milliseconds (see NetworkServiceFactory.setHeartbeatInterval(int)).
getHeartbeatInterval() - Method in interface io.hekate.network.NetworkServiceJmx
getHeartbeatLossThreshold() - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Returns the amount of heartbeats that can be lost before considering a node failure (see DefaultFailureDetectorConfig.setHeartbeatLossThreshold(int)).
getHeartbeatLossThreshold() - Method in interface io.hekate.cluster.health.DefaultFailureDetectorJmx
getHeartbeatLossThreshold() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns the maximum number of lost heartbeats (see NetworkServerFactoryBase.setHeartbeatLossThreshold(int)).
getHeartbeatLossThreshold() - Method in class io.hekate.network.NetworkServiceFactory
Returns the maximum number of lost heartbeats (see NetworkServiceFactory.setHeartbeatLossThreshold(int)).
getHeartbeatLossThreshold() - Method in interface io.hekate.network.NetworkServiceJmx
getHost() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the host address.
getHost() - Method in interface io.hekate.core.HekateJmx
Returns the local node's host address.
getHost() - Method in class io.hekate.network.NetworkServiceFactory
Supplementary getter for NetworkServiceFactory.setHost(String).
getHostColumn() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the host column name (see JdbcSeedNodeProviderConfig.setHostColumn(String)).
getHostSelector() - Method in class io.hekate.network.NetworkServiceFactory
Returns host address selector of the local node (see NetworkServiceFactory.setHostSelector(AddressSelector)).
getId() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the node identifier.
getId() - Method in interface io.hekate.messaging.MessagingChannelJmx
getIdentity() - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
getIdleSocketTimeout() - Method in class io.hekate.coordinate.CoordinationServiceFactory
Returns the idle socket timeout in milliseconds (see CoordinationServiceFactory.setIdleSocketTimeout(long)).
getIdleSocketTimeout() - Method in interface io.hekate.messaging.MessagingChannelJmx
getIdleSocketTimeout() - Method in class io.hekate.messaging.MessagingConfigBase
Returns the idle socket timeout in milliseconds (see MessagingConfigBase.setIdleSocketTimeout(long)).
getIdleSocketTimeout() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the timeout in milliseconds for NetworkClients to stay idle before being automatically disconnected (see NetworkConnectorConfig.setIdleSocketTimeout(long)).
getIdleSocketTimeout() - Method in interface io.hekate.network.NetworkConnectorJmx
getIdleTimeout() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the timeout in milliseconds for NetworkClients to stay idle before being automatically disconnected (see NettyClientFactory.setIdleTimeout(long)).
getInHighWatermark() - Method in class io.hekate.messaging.MessagingBackPressureConfig
Returns the high watermark of inbound (receiving) queue size (see MessagingBackPressureConfig.setOutHighWatermark(int)).
getInLowWatermark() - Method in class io.hekate.messaging.MessagingBackPressureConfig
Returns the low watermark of inbound (receiving) queue size (see MessagingBackPressureConfig.setInLowWatermark(int)).
getInsertSql() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
Returns the SQL statement for inserting data into the seed nodes table.
getInstantiatorStrategy() - Method in class io.hekate.codec.kryo.KryoCodecFactory
getInterceptors() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns a list of message interceptors that should be used by the channel (see MessagingChannelConfig.setInterceptors(List)).
getInterfaceMinClientVersion() - Method in interface io.hekate.rpc.RpcServerJmx
getInterfaceType() - Method in interface io.hekate.rpc.RpcServerJmx
Returns the class name of the server's RPC interface.
getInterfaceVersion() - Method in interface io.hekate.rpc.RpcServerJmx
Returns the value of RpcInterfaceInfo.version().
getInterval() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns the time interval in milliseconds between discovery messages multicasting (see MulticastSeedNodeProviderConfig.setInterval(long)).
getInterval() - Method in interface io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderJmx
getKeyStoreAlgorithm() - Method in class io.hekate.network.NetworkSslConfig
Returns the keystore algorithm (see NetworkSslConfig.setKeyStoreAlgorithm(String)).
getKeyStorePassword() - Method in class io.hekate.network.NetworkSslConfig
Returns the keystore password (see NetworkSslConfig.setKeyStorePassword(String)).
getKeyStorePath() - Method in class io.hekate.network.NetworkSslConfig
Returns the keystore path (see NetworkSslConfig.setKeyStorePath(String)).
getKeyStoreType() - Method in class io.hekate.network.NetworkSslConfig
Returns the keystore type (see NetworkSslConfig.setKeyStoreType(String)).
getKnownTypes() - Method in class io.hekate.codec.fst.FstCodecFactory
Returns the list of known Java types (see FstCodecFactory.setKnownTypes(List)).
getKnownTypes() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the list of known java types (see KryoCodecFactory.setKnownTypes(List)).
getLeaderNode() - Method in interface io.hekate.election.CandidateJmx
Returns the leader node or null if leader is not elected yet.
getLifecycleListeners() - Method in class io.hekate.core.HekateBootstrap
Returns the list of instance lifecycle listeners (see HekateBootstrap.setLifecycleListeners(List)).
getLoadBalancer() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the unicast load balancer that should be used by the channel (see MessagingChannelConfig.setLoadBalancer(LoadBalancer)).
getLoadBalancer() - Method in class io.hekate.rpc.RpcClientConfig
Returns the RPC load balancer (see RpcClientConfig.setLoadBalancer(RpcLoadBalancer)).
getLocalNode() - Method in interface io.hekate.cluster.ClusterServiceJmx
Returns the local node.
getLogCategory() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the logging category that should be used by the channel (see MessagingChannelConfig.setLogCategory(String)).
getLogCategory() - Method in interface io.hekate.messaging.MessagingChannelJmx
getLogCategory() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the log category that should be used by the connector (see NetworkConnectorConfig.setLogCategory(String)).
getLogCategory() - Method in interface io.hekate.network.NetworkConnectorJmx
getLoggerCategory() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the logger category that should be used by NetworkClients (see NettyClientFactory.setLoggerCategory(String)).
getLoggerCategory() - Method in class io.hekate.network.NetworkServerHandlerConfig
Returns the logger category that should be used by NetworkServerHandler (see NetworkServerHandlerConfig.setLoggerCategory(String)).
getMasterUrl() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Returns the URL of Kubernetes API server.
getMessage() - Method in exception io.hekate.messaging.operation.RejectedResponseException
 
getMessageCodec() - Method in class io.hekate.coordinate.CoordinationProcessConfig
Returns the codec that should be used for messages serialization (see CoordinationProcessConfig.setMessageCodec(CodecFactory)).
getMessageCodec() - Method in class io.hekate.messaging.MessagingChannelConfig
getMessageCodec() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the CodecFactory that should be used for messages serialization (see NetworkConnectorConfig.setMessageCodec(CodecFactory)).
getMessagingTimeout() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the timeout in milliseconds that should be applied to all messaging operations within this channel (see MessagingChannelConfig.setMessagingTimeout(long)).
getMetrics() - Method in class io.hekate.core.HekateBootstrap
Returns the metrics registry.
getMetrics() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the metrics sink (see NettyClientFactory.setMetrics(NettyMetricsSink)).
getMetrics() - Method in class io.hekate.network.netty.NettyServerFactory
Returns the metrics factory (see NettyServerFactory.setMetrics(NettyMetricsFactory)).
getMonitoredAddresses() - Method in interface io.hekate.cluster.health.DefaultFailureDetectorJmx
Returns the value of DefaultFailureDetector.monitored() as a list of strings.
getName() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the node name.
getName() - Method in class io.hekate.coordinate.CoordinationProcessConfig
Returns the coordination process name (see CoordinationProcessConfig.setName(String)).
getName() - Method in class io.hekate.lock.LockRegionConfig
Returns the lock region name (see LockRegionConfig.setName(String)).
getName() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the channel name (see MessagingChannelConfig.setName(String)).
getName() - Method in interface io.hekate.messaging.MessagingChannelJmx
getName() - Method in class io.hekate.spring.bean.lock.LockBean
Returns the lock name (see LockBean.setName(String)).
getNamespace() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns the cluster namespace (see ClusterServiceFactory.setNamespace(String)).
getNamespace() - Method in interface io.hekate.cluster.ClusterServiceJmx
Returns the namespace.
getNamespace() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Returns the Kubernetes namespace (see KubernetesSeedNodeProviderConfig.setNamespace(String)).
getNamespaceColumn() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the cluster column name (see JdbcSeedNodeProviderConfig.setNamespaceColumn(String)).
getNioThreads() - Method in class io.hekate.coordinate.CoordinationServiceFactory
Returns the size of a thread pool for handling NIO-based socket connections.
getNioThreads() - Method in class io.hekate.lock.LockServiceFactory
Returns the size of a thread pool for handling NIO-based network communications (see LockServiceFactory.setNioThreads(int)).
getNioThreads() - Method in interface io.hekate.messaging.MessagingChannelJmx
getNioThreads() - Method in class io.hekate.messaging.MessagingConfigBase
Returns the size of a thread pool for handling NIO-based socket connections (see MessagingConfigBase.setNioThreads(int)).
getNioThreads() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the thread pool size that should be used for NIO events processing (see NetworkConnectorConfig.setNioThreads(int)).
getNioThreads() - Method in interface io.hekate.network.NetworkConnectorJmx
getNioThreads() - Method in class io.hekate.network.NetworkServiceFactory
Returns the number of threads to be used for NIO event processing (see NetworkServiceFactory.setNioThreads(int)).
getNioThreads() - Method in interface io.hekate.network.NetworkServiceJmx
getNodeId() - Method in interface io.hekate.core.HekateJmx
Returns the string representation of the local node's ClusterNodeId.
getNodeName() - Method in class io.hekate.core.HekateBootstrap
Returns the node name (see HekateBootstrap.setNodeName(String)).
getNodeName() - Method in interface io.hekate.core.HekateJmx
Returns the local node's name.
getObject() - Method in class io.hekate.spring.bean.cluster.ClusterServiceBean
 
getObject() - Method in class io.hekate.spring.bean.codec.CodecServiceBean
 
getObject() - Method in class io.hekate.spring.bean.coordinate.CoordinationServiceBean
 
getObject() - Method in class io.hekate.spring.bean.election.ElectionServiceBean
 
getObject() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
getObject() - Method in class io.hekate.spring.bean.lock.LockBean
 
getObject() - Method in class io.hekate.spring.bean.lock.LockRegionBean
 
getObject() - Method in class io.hekate.spring.bean.lock.LockServiceBean
 
getObject() - Method in class io.hekate.spring.bean.messaging.MessagingChannelBean
 
getObject() - Method in class io.hekate.spring.bean.messaging.MessagingServiceBean
 
getObject() - Method in class io.hekate.spring.bean.network.NetworkConnectorBean
 
getObject() - Method in class io.hekate.spring.bean.network.NetworkServiceBean
 
getObject() - Method in class io.hekate.spring.bean.rpc.RpcClientBean
 
getObject() - Method in class io.hekate.spring.bean.rpc.RpcServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.cluster.ClusterServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.codec.CodecServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.coordinate.CoordinationServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.election.ElectionServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
getObjectType() - Method in class io.hekate.spring.bean.lock.LockBean
 
getObjectType() - Method in class io.hekate.spring.bean.lock.LockRegionBean
 
getObjectType() - Method in class io.hekate.spring.bean.lock.LockServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.messaging.MessagingChannelBean
 
getObjectType() - Method in class io.hekate.spring.bean.messaging.MessagingServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.network.NetworkConnectorBean
 
getObjectType() - Method in class io.hekate.spring.bean.network.NetworkServiceBean
 
getObjectType() - Method in class io.hekate.spring.bean.rpc.RpcClientBean
 
getObjectType() - Method in class io.hekate.spring.bean.rpc.RpcServiceBean
 
getOutHighWatermark() - Method in class io.hekate.messaging.MessagingBackPressureConfig
Returns the high watermark of outbound (sending) queue size (see MessagingBackPressureConfig.setOutHighWatermark(int)).
getOutLowWatermark() - Method in class io.hekate.messaging.MessagingBackPressureConfig
Returns the low watermark of outbound (sending) queue size (see MessagingBackPressureConfig.setOutLowWatermark(int)).
getOutOverflowPolicy() - Method in class io.hekate.messaging.MessagingBackPressureConfig
Returns the policy that should be applied when MessagingChannel's outbound (sending) queue size exceeds the limit (see MessagingBackPressureConfig.setOutOverflowPolicy(MessagingOverflowPolicy)).
getPartitions() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the total amount of partitions that should be managed by the channel's partition mapper (see MessagingChannelConfig.setPartitions(int)).
getPartitions() - Method in interface io.hekate.messaging.MessagingChannelJmx
getPartitions() - Method in class io.hekate.rpc.RpcClientConfig
Returns the total amount of partitions that should be managed by the RPC client's partition mapper (see RpcClientConfig.setPartitions(int)).
getPassword() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Returns the Etcd password (see EtcdSeedNodeProviderConfig.setPassword(String)).
getPlugins() - Method in class io.hekate.core.HekateBootstrap
Returns the list of plugins that should run within the local node (see HekateBootstrap.setPlugins(List)).
getPolicy() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
Returns the error handling policy of this group (see SeedNodeProviderGroupConfig.setPolicy(SeedNodeProviderGroupPolicy)).
getPort() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the network port.
getPort() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns the multicast port (see MulticastSeedNodeProviderConfig.setPort(int)).
getPort() - Method in interface io.hekate.core.HekateJmx
Returns the local node's TCP port.
getPort() - Method in class io.hekate.network.NetworkServiceFactory
Returns communications port of the local node (see NetworkServiceFactory.setPort(int)).
getPortColumn() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the port column name (see JdbcSeedNodeProviderConfig.setPortColumn(String)).
getPortRange() - Method in class io.hekate.network.NetworkServiceFactory
Returns the port range (see NetworkServiceFactory.setPortRange(int)).
getProcesses() - Method in class io.hekate.coordinate.CoordinationServiceFactory
Returns the list of coordination process configurations that should be automatically registered during the coordination service startup (see CoordinationServiceFactory.setProcesses(List)).
getProperties() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the node's properties.
getProperties() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns the ComputeService provider-specific properties (see CloudSeedNodeProviderConfig.setProperties(Properties)).
getProperties() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the BlobStore provider-specific properties (see CloudStoreSeedNodeProviderConfig.setProperties(Properties)).
getProperties() - Method in class io.hekate.core.HekateBootstrap
Returns a map of local node properties (see HekateBootstrap.setProperties(Map)).
getProperties() - Method in interface io.hekate.core.PropertyProvider
Returns a map of node properties that should become a part of node properties.
getPropertyProviders() - Method in class io.hekate.core.HekateBootstrap
Returns a list of node property providers (see HekateBootstrap.setPropertyProviders(List)).
getProtocol() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the protocol identifier (see NettyClientFactory.setProtocol(String)).
getProtocol() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the connector's protocol identifier (see NetworkConnectorConfig.setProtocol(String)).
getProtocol() - Method in interface io.hekate.network.NetworkConnectorJmx
getProtocol() - Method in class io.hekate.network.NetworkServerHandlerConfig
Returns the protocol identifier (see NetworkServerHandlerConfig.setProtocol(String)).
getProtocol() - Method in class io.hekate.spring.bean.network.NetworkConnectorBean
Returns the protocol name.
getProvider() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns the name of a ComputeService provider (see CloudSeedNodeProviderConfig.setProvider(String)).
getProvider() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the name of a BlobStore provider (see CloudStoreSeedNodeProviderConfig.setProvider(String)).
getProvider() - Method in class io.hekate.network.NetworkSslConfig
Returns the SSL provider (see NetworkSslConfig.setProvider(Provider)).
getProviders() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
Returns the list of providers of this group (see SeedNodeProviderGroupConfig.setProviders(List)).
getQueryTimeout() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the JDBC query timeout (see JdbcSeedNodeProviderConfig.setQueryTimeout(int)).
getQueryTimeout() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
getReadTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the read timeout value in milliseconds (see ConsulSeedNodeProviderConfig.setReadTimeout(Long)).
getReceiver() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the message receiver that should be used to handle incoming messages (see MessagingChannelConfig.setReceiver(MessageReceiver)).
getReferences() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the value that should override Kryo.setReferences(boolean) flag (see KryoCodecFactory.setReferences(Boolean)).
getRegion() - Method in class io.hekate.spring.bean.lock.LockBean
Returns the lock region name (see LockBean.setRegion(String)).
getRegion() - Method in class io.hekate.spring.bean.lock.LockRegionBean
Returns the lock region name (see LockRegionBean.setRegion(String)).
getRegions() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns a set of regions to search for seed nodes (see @CloudSeedNodeProviderConfig.setRegions(Set)).
getRegions() - Method in class io.hekate.lock.LockServiceFactory
Returns the list of lock region configurations (see LockServiceFactory.setRegions(List)).
getRetryInterval() - Method in class io.hekate.coordinate.CoordinationServiceFactory
Returns the time interval in milliseconds between retry attempts in case of network communication failures (see CoordinationServiceFactory.setRetryInterval(long)).
getRetryInterval() - Method in class io.hekate.lock.LockServiceFactory
Returns the time interval in milliseconds between retry attempts in case of network communication failures (see LockServiceFactory.setRetryInterval(long)).
getRetryPolicy() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the generic retry policy to be applied to all messaging operations of this channel.
getRetryPolicy() - Method in class io.hekate.rpc.RpcClientConfig
Returns the generic retry policy (see RpcClientConfig.setRetryPolicy(GenericRetryConfigurer)).
getRoles() - Method in class io.hekate.cluster.ClusterNodeJmx
Returns the node's roles.
getRoles() - Method in class io.hekate.core.HekateBootstrap
Returns a list of the local node's roles (see HekateBootstrap.setRoles(List)).
getRpcInterface() - Method in class io.hekate.rpc.RpcClientConfig
Returns the RPC interface (see RpcClientConfig.setRpcInterface(Class)).
getRpcInterface() - Method in class io.hekate.spring.bean.rpc.RpcClientBean
Returns the RPC service interface (see RpcClientBean.setRpcInterface(Class)).
getSeedNodeProvider() - Method in class io.hekate.cluster.ClusterServiceFactory
getSelectSql() - Method in interface io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderJmx
Returns the SQL statement for selecting data from the seed nodes table.
getSerializers() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the map of custom serializer (see KryoCodecFactory.setSerializers(Map)).
getServer() - Method in class io.hekate.core.jmx.JmxServiceFactory
Returns the MBean server (see MBeanServer).
getServerHandler() - Method in class io.hekate.network.NetworkConnectorConfig
Returns the handler that should be used to accept connections and process messages from remote connectors (see NetworkConnectorConfig.setServerHandler(NetworkServerHandler)).
getServerProviders() - Method in class io.hekate.rpc.RpcServiceFactory
Returns the list of RPC server configuration providers (see RpcServiceFactory.setServerProviders(List)).
getServers() - Method in class io.hekate.rpc.RpcServiceFactory
Returns the list of RPC server configurations (see RpcServiceFactory.setServers(List)).
getServices() - Method in class io.hekate.core.HekateBootstrap
Returns services of the local node (see HekateBootstrap.setServices(List)).
getSessionTimeout() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Returns the ZooKeeper session timeout in milliseconds (see ZooKeeperSeedNodeProviderConfig.setSessionTimeout(int)).
getSharedReferences() - Method in class io.hekate.codec.fst.FstCodecFactory
Returns the value that should override the FSTConfiguration.setShareReferences(boolean) flag (see FstCodecFactory.setSharedReferences(Boolean)).
getSoBacklog() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns the maximum number of pending connections that can be queued on the server socket channel (see NetworkServerFactoryBase.setSoBacklog(Integer)).
getSocketAddress() - Method in interface io.hekate.core.HekateJmx
Returns the string representation of the local node's SocketAddress.
getSoReceiveBufferSize() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the size of the socket receive buffer in bytes (see NettyClientFactory.setSoReceiveBufferSize(Integer)).
getSoReceiveBufferSize() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns the size of the socket receive buffer in bytes (see NetworkServerFactoryBase.setSoReceiveBufferSize(Integer)).
getSoReuseAddress() - Method in class io.hekate.network.netty.NettyClientFactory
Sets flag indicating that socket addresses should be re-used (see NettyClientFactory.setSoReuseAddress(Boolean)).
getSoReuseAddress() - Method in class io.hekate.network.NetworkServerFactoryBase
Sets flag indicating that socket addresses should be re-used (see NetworkServerFactoryBase.setSoReuseAddress(Boolean)).
getSoSendBufferSize() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the size of the socket send buffer in bytes (see NettyClientFactory.setSoSendBufferSize(Integer)).
getSoSendBufferSize() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns the size of the socket send buffer in bytes (see NetworkServerFactoryBase.setSoSendBufferSize(Integer)).
getSoTimeout() - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
Returns the response read timeout in milliseconds (see CloudPropertiesBase.setSoTimeout(Integer)).
getSource() - Method in class io.hekate.spring.bean.HekateBaseBean
Return the Hekate instance that will be used as a source of imported components and services (see HekateBaseBean.setSource(Hekate)).
getSpeedUpGossipSize() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns the maximum amount of nodes in the cluster for the gossip protocol to speeded up by sending messages at a higher rate so that the cluster could converge faster (see ClusterServiceFactory.setSpeedUpGossipSize(int)).
getSplitBrainCheckInterval() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns the time interval in milliseconds for split-brain checking (see ClusterServiceFactory.setSplitBrainCheckInterval(long)).
getSplitBrainDetector() - Method in class io.hekate.cluster.ClusterServiceFactory
Returns the cluster split-brain detector (see ClusterServiceFactory.setSplitBrainDetector(SplitBrainDetector)).
getSsl() - Method in class io.hekate.network.netty.NettyClientFactory
Returns the SSL context (see NettyClientFactory.setSsl(SslContext)).
getSsl() - Method in class io.hekate.network.netty.NettyServerFactory
Returns the SSL context (see NettyServerFactory.setSsl(SslContext)).
getSsl() - Method in class io.hekate.network.NetworkServiceFactory
Returns the SSL configuration (see NetworkServiceFactory.setSsl(NetworkSslConfig)).
getSslSessionCacheSize() - Method in class io.hekate.network.NetworkSslConfig
Returns the size of the cache used for storing SSL session objects (see NetworkSslConfig.setSslSessionCacheSize(int)).
getSslSessionCacheTimeout() - Method in class io.hekate.network.NetworkSslConfig
Returns the timeout in seconds for the cached SSL session objects.
getState() - Method in interface io.hekate.core.HekateJmx
Returns the local node's state.
getTable() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Returns the table name (see JdbcSeedNodeProviderConfig.setTable(String)).
getTag() - Method in class io.hekate.rpc.RpcClientConfig
Returns the RPC interface tag (see RpcClientConfig.setTag(String)).
getTag() - Method in interface io.hekate.rpc.RpcServerJmx
Returns the tag of this server or null if server doesn't have tags.
getTag() - Method in class io.hekate.spring.bean.rpc.RpcClientBean
Returns the RPC service tag.
getTags() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns a map of compute instance's tag names/values to search for seed nodes (see @CloudSeedNodeProviderConfig.setTags(Map)).
getTags() - Method in class io.hekate.rpc.RpcServerConfig
Returns the set of tags of this server (see RpcServerConfig.setTags(Set)).
getTcpBacklog() - Method in class io.hekate.network.NetworkServiceFactory
Returns the maximum number of pending connections that can be queued on the server socket channel (see NetworkServiceFactory.setTcpBacklog(Integer)).
getTcpReceiveBufferSize() - Method in class io.hekate.network.NetworkServiceFactory
Returns the size of the socket receive buffer in bytes (see NetworkServiceFactory.setTcpReceiveBufferSize(Integer)).
getTcpReceiveBufferSize() - Method in interface io.hekate.network.NetworkServiceJmx
getTcpReuseAddress() - Method in class io.hekate.network.NetworkServiceFactory
Sets flag indicating that socket addresses should be re-used (see NetworkServiceFactory.setTcpReuseAddress(Boolean)).
getTcpReuseAddress() - Method in interface io.hekate.network.NetworkServiceJmx
getTcpSendBufferSize() - Method in class io.hekate.network.NetworkServiceFactory
Returns the size of the socket send buffer in bytes (see NetworkServiceFactory.setTcpSendBufferSize(Integer)).
getTcpSendBufferSize() - Method in interface io.hekate.network.NetworkServiceJmx
getTimeout() - Method in class io.hekate.rpc.RpcClientConfig
Returns the timeout in milliseconds (see RpcClientConfig.setTimeout(long)).
getTopology() - Method in interface io.hekate.cluster.ClusterServiceJmx
Returns the current topology.
getTopology() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns the cluster topology of this channel (see MessagingChannel.cluster()).
getTopology() - Method in interface io.hekate.rpc.RpcServerJmx
Returns the cluster topology of this server (i.e. all nodes that have a server for the same combination of RpcInterfaceInfo and RpcServerJmx.getTag())
getTopologySize() - Method in interface io.hekate.cluster.ClusterServiceJmx
Returns the current topology size.
getTopologyVersion() - Method in interface io.hekate.cluster.ClusterServiceJmx
Returns the current topology version.
getTransport() - Method in class io.hekate.network.NetworkServiceFactory
getTransport() - Method in interface io.hekate.network.NetworkServiceJmx
getTrustCertificates() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Returns the flag indicating that Kubernetes API must have a trusted certificate (see KubernetesSeedNodeProviderConfig.setTrustCertificates(Boolean)).
getTrustStoreAlgorithm() - Method in class io.hekate.network.NetworkSslConfig
Returns the trust store algorithm (see NetworkSslConfig.setTrustStoreAlgorithm(String)).
getTrustStorePassword() - Method in class io.hekate.network.NetworkSslConfig
Returns the trust store password (see NetworkSslConfig.setTrustStorePassword(String)).
getTrustStorePath() - Method in class io.hekate.network.NetworkSslConfig
Returns the trust store path (see NetworkSslConfig.setKeyStorePath(String)).
getTrustStoreType() - Method in class io.hekate.network.NetworkSslConfig
Returns the trust store type (see NetworkSslConfig.setTrustStoreType(String)).
getTtl() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns the multicast TTL (see MulticastSeedNodeProviderConfig.setTtl(int)).
getTtl() - Method in interface io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderJmx
Returns the value of MulticastSeedNodeProvider.ttl().
getUninterruptedly(Future<T>) - Static method in class io.hekate.util.async.AsyncUtils
Uninterruptedly waits for the specified Future to complete, and then returns its result.
getUpTime() - Method in interface io.hekate.core.HekateJmx
Returns the formatted value of HekateJmx.getUpTimeMillis().
getUpTimeMillis() - Method in interface io.hekate.core.HekateJmx
Returns the number of milliseconds since the local node switched to the Hekate.State.UP state.
getUrl() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns url of the Consul (see ConsulSeedNodeProviderConfig.setUrl(String) (String)}).
getUsername() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Returns the Etcd username (see EtcdSeedNodeProviderConfig.setUsername(String)).
getVersion() - Method in interface io.hekate.core.HekateJmx
Returns the HekateVersion.fullVersion() string.
getWaitTime() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns the timeout in milliseconds to await for responses from remote nodes (see MulticastSeedNodeProviderConfig.setWaitTime(long)).
getWaitTime() - Method in interface io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderJmx
getWarnOnRetry() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the amount of retry attempts to skip before logging a warn message (see MessagingChannelConfig.setWarnOnRetry(int)).
getWorkDir() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
Returns the work directory where seed node addresses are stored (see FsSeedNodeProviderConfig.setWorkDir(File)).
getWorkDir() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
Returns the work directory for seed node provider to store its files (see FsSeedNodeProviderConfig.setWorkDir(File)).
getWorkDir() - Method in interface io.hekate.cluster.seed.fs.FsSeedNodeProviderJmx
Returns the string representation of FsSeedNodeProviderConfig.setWorkDir(File).
getWorkerEventLoop() - Method in class io.hekate.network.netty.NettyServerFactory
Returns the event loop group that is responsible for handling messaging operations (see NettyServerFactory.setWorkerEventLoop(EventLoopGroup)).
getWorkerThreads() - Method in class io.hekate.lock.LockServiceFactory
Returns the size of a thread pool that will perform locks management operations (see LockServiceFactory.setWorkerThreads(int)).
getWorkerThreads() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns the worker thread pool size (see MessagingChannelConfig.setWorkerThreads(int)).
getWorkerThreads() - Method in interface io.hekate.messaging.MessagingChannelJmx
getWorkerThreads() - Method in class io.hekate.rpc.RpcServiceFactory
Returns the worker thread pool size (see RpcServiceFactory.setWorkerThreads(int)).
getWriteTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Returns the write timeout value in milliseconds (see ConsulSeedNodeProviderConfig.setWriteTimeout(Long)).
getZones() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Returns a set of availability zones to search for seed nodes (see CloudSeedNodeProviderConfig.setZones(Set)).
gossip() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
gossip() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
gossip() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.Update
 
Gossip - Class in io.hekate.cluster.internal.gossip
 
Gossip() - Constructor for class io.hekate.cluster.internal.gossip.Gossip
 
Gossip(long, Map<ClusterNodeId, GossipNodeState>, Set<ClusterNodeId>, Set<ClusterNodeId>, int) - Constructor for class io.hekate.cluster.internal.gossip.Gossip
 
GOSSIP_FANOUT_SIZE - Static variable in class io.hekate.cluster.internal.gossip.GossipManager
 
GOSSIP_UPDATE - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
GOSSIP_UPDATE_DIGEST - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
gossipBase() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.Update
 
gossipBase() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateBase
 
gossipBase() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateDigest
 
GossipBase - Class in io.hekate.cluster.internal.gossip
 
GossipBase() - Constructor for class io.hekate.cluster.internal.gossip.GossipBase
 
GossipCommListener - Interface in io.hekate.cluster.internal.gossip
 
GossipCommManager - Class in io.hekate.cluster.internal.gossip
 
GossipCommManager(NetworkConnector<GossipProtocol>, ClusterAddress, GossipCommListener) - Constructor for class io.hekate.cluster.internal.gossip.GossipCommManager
 
GossipDigest - Class in io.hekate.cluster.internal.gossip
 
GossipDigest(long, Map<ClusterNodeId, GossipNodeInfo>, Set<ClusterNodeId>, Set<ClusterNodeId>) - Constructor for class io.hekate.cluster.internal.gossip.GossipDigest
 
GossipDigest(Gossip) - Constructor for class io.hekate.cluster.internal.gossip.GossipDigest
 
GossipListener - Interface in io.hekate.cluster.internal.gossip
 
GossipManager - Class in io.hekate.cluster.internal.gossip
 
GossipManager(String, ClusterNode, int, FailureDetector, GossipListener) - Constructor for class io.hekate.cluster.internal.gossip.GossipManager
 
GossipMessage(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.GossipMessage
 
GossipNodeInfo - Class in io.hekate.cluster.internal.gossip
 
GossipNodeInfo(ClusterNodeId, GossipNodeStatus, long) - Constructor for class io.hekate.cluster.internal.gossip.GossipNodeInfo
 
GossipNodeInfoBase - Class in io.hekate.cluster.internal.gossip
 
GossipNodeInfoBase() - Constructor for class io.hekate.cluster.internal.gossip.GossipNodeInfoBase
 
GossipNodesDeathWatch - Class in io.hekate.cluster.internal.gossip
 
GossipNodesDeathWatch(ClusterNodeId, int, long) - Constructor for class io.hekate.cluster.internal.gossip.GossipNodesDeathWatch
 
GossipNodeState - Class in io.hekate.cluster.internal.gossip
 
GossipNodeState(ClusterNode, GossipNodeStatus) - Constructor for class io.hekate.cluster.internal.gossip.GossipNodeState
 
GossipNodeState(ClusterNode, GossipNodeStatus, long, Set<ClusterNodeId>) - Constructor for class io.hekate.cluster.internal.gossip.GossipNodeState
 
GossipNodeStatus - Enum in io.hekate.cluster.internal.gossip
 
GossipPolicy - Interface in io.hekate.cluster.internal.gossip
 
GossipPrecedence - Enum in io.hekate.cluster.internal.gossip
 
GossipProtocol - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol(ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol
 
GossipProtocol.GossipMessage - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.HeartbeatReply - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.HeartbeatRequest - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.JoinAccept - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.JoinReject - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.JoinReject.RejectType - Enum in io.hekate.cluster.internal.gossip
 
GossipProtocol.JoinReply - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.JoinRequest - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.LongTermConnect - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.Type - Enum in io.hekate.cluster.internal.gossip
 
GossipProtocol.Update - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.UpdateBase - Class in io.hekate.cluster.internal.gossip
 
GossipProtocol.UpdateDigest - Class in io.hekate.cluster.internal.gossip
 
GossipProtocolCodec - Class in io.hekate.cluster.internal.gossip
 
GossipProtocolCodec(AtomicReference<ClusterNodeId>) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocolCodec
 
GossipSuspectView - Class in io.hekate.cluster.internal.gossip
 
GossipSuspectView(Map<ClusterNodeId, Set<ClusterNodeId>>) - Constructor for class io.hekate.cluster.internal.gossip.GossipSuspectView
 
greater(int, int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
greater(long, long, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
greaterOrEquals(int, int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
group() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Returns the multicast group (see MulticastSeedNodeProviderConfig.setGroup(String)).

H

handleAsync(Executor, Consumer<NetworkMessage<T>>) - Method in interface io.hekate.network.NetworkMessage
Asynchronously this message on a thread of the specified executor.
handleFatalError(Throwable, HekateFatalErrorContext) - Method in interface io.hekate.core.HekateFatalErrorPolicy
Handles the fatal error.
handler() - Method in interface io.hekate.coordinate.CoordinationProcess
Returns the handler of this process (see CoordinationProcessConfig.setHandler(CoordinationHandler)).
has(Class<T>) - Method in interface io.hekate.core.Hekate
Checks if the service of the specified type is registered within this instance.
hasAffinity() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns true if the messaging operation has an affinity key (see ClientOutboundContext.affinityKey()).
hasAffinity() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns true if the messaging operation has an affinity key (see LoadBalancerContext.affinityKey()).
hasArgs() - Method in interface io.hekate.rpc.RpcRequest
Returns true if RPC request has arguments.
hasBackupNodes() - Method in interface io.hekate.partition.Partition
Returns true if this partition has Partition.backupNodes().
hasChannel(String) - Method in interface io.hekate.messaging.MessagingService
Returns true if this service has a messaging channel with the specified name.
hasConnector(String) - Method in interface io.hekate.network.NetworkService
Returns true if this service has a connector with the specified protocol name.
hash() - Method in interface io.hekate.cluster.ClusterTopology
Returns the SHA-256 hash of all cluster node identifiers of this topology.
hash(int, int) - Static method in class io.hekate.core.internal.util.Murmur3
 
hashCode() - Method in class io.hekate.cluster.ClusterAddress
Returns the hash code of ClusterAddress.id().
hashCode() - Method in class io.hekate.cluster.ClusterNodeJmx
 
hashCode() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
hashCode() - Method in class io.hekate.partition.DefaultPartition
 
hashCode() - Method in class io.hekate.util.UuidBase
 
hasMember(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
hasMembers() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
hasMetaData() - Method in interface io.hekate.messaging.intercept.ClientSendContext
Returns true if message has a non-empty ClientSendContext.metaData().
hasMetaData() - Method in interface io.hekate.messaging.intercept.ServerSendContext
Returns true if this message has meta-data.
hasProcess(String) - Method in interface io.hekate.coordinate.CoordinationService
Returns true if this service has a coordination process with the specified name.
hasProperty(String) - Method in interface io.hekate.cluster.ClusterNode
Returns true if this node has a property with the specified name (see ClusterNode.properties()).
hasProviders() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
Returns true if this configuration has at least one provider (see SeedNodeProviderGroupConfig.setProviders(List)).
hasReceiver() - Method in class io.hekate.messaging.MessagingChannelConfig
Returns true if receiver is specified.
hasRegion(String) - Method in interface io.hekate.lock.LockService
Returns true if this service has a lock region with the specified name.
hasRole(String) - Method in interface io.hekate.cluster.ClusterNode
Returns true if this node has the specified role (see ClusterNode.roles()).
hasSeen(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
hasSeenAll(Set<ClusterNodeId>) - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
hasService(Class<? extends Service>) - Method in interface io.hekate.cluster.ClusterNode
Returns true if this node has a service of the specified type.
hasSuspected() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
hasTriedNode(ClusterNode) - Method in interface io.hekate.messaging.retry.Attempt
Returns true if the specified node is in the Attempt.allTriedNodes() set.
HEARTBEAT_REPLY - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
HEARTBEAT_REQUEST - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
heartbeatInterval() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
heartbeatInterval() - Method in interface io.hekate.cluster.health.FailureDetector
Returns the time interval in milliseconds between heartbeat sending rounds (see FailureDetector.heartbeatTick()).
heartbeatLossThreshold() - Method in class io.hekate.cluster.health.DefaultFailureDetector
Returns the amount of heartbeats that can be lost before considering a node failure.
HeartbeatReply(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.HeartbeatReply
 
HeartbeatRequest(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.HeartbeatRequest
 
heartbeatTick() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
heartbeatTick() - Method in interface io.hekate.cluster.health.FailureDetector
Runs a heartbeat tick and returns a set of cluster node addresses that should received a heartbeat request message.
hekate() - Method in class io.hekate.cluster.event.ClusterEventBase
 
hekate() - Method in interface io.hekate.core.HekateSupport
Returns the Hekate instance.
hekate() - Method in interface io.hekate.core.service.DependencyContext
Returns the Hekate instance that manages this service.
hekate() - Method in interface io.hekate.core.service.InitializationContext
Returns the Hekate instance that this service belongs to.
hekate() - Method in class io.hekate.spring.boot.HekateConfigurer
Constructs the Hekate factory bean.
Hekate - Interface in io.hekate.core
« start hereMain entry point to Hekate services.
Hekate.LifecycleListener - Interface in io.hekate.core
Listener of Hekate.State changes.
Hekate.State - Enum in io.hekate.core
State of the Hekate instance life cycle.
HekateBaseBean<T> - Class in io.hekate.spring.bean
Base class for beans that provide support for importing Hekate components and services into a Spring context.
HekateBaseBean() - Constructor for class io.hekate.spring.bean.HekateBaseBean
 
HekateBootstrap - Class in io.hekate.core
Main configuration and factory for Hekate instances.
HekateBootstrap() - Constructor for class io.hekate.core.HekateBootstrap
 
HekateCloudSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for CloudSeedNodeProvider.
HekateCloudSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateCloudSeedNodeProviderConfigurer
 
HekateCloudStoreSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for CloudStoreSeedNodeProvider.
HekateCloudStoreSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateCloudStoreSeedNodeProviderConfigurer
 
HekateClusterServiceConfigurer - Class in io.hekate.spring.boot.cluster
« start hereAuto-configuration for ClusterService.
HekateClusterServiceConfigurer(Optional<List<SeedNodeProvider>>, Optional<List<ClusterEventListener>>, Optional<List<ClusterAcceptor>>, Optional<SplitBrainDetector>) - Constructor for class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Constructs new instance.
HekateConfigurationException - Exception in io.hekate.core
Configuration error.
HekateConfigurationException(String) - Constructor for exception io.hekate.core.HekateConfigurationException
Constructs new instance with the specified error message.
HekateConfigurationException(String, Throwable) - Constructor for exception io.hekate.core.HekateConfigurationException
Constructs new instance with the specified error message and cause.
HekateConfigurer - Class in io.hekate.spring.boot
« start hereAuto-configuration for Hekate instances.
HekateConfigurer(Optional<List<PropertyProvider>>, Optional<List<ServiceFactory<?>>>, Optional<List<Plugin>>, Optional<List<Hekate.LifecycleListener>>, Optional<MeterRegistry>, Optional<HekateFatalErrorPolicy>, Optional<CodecFactory<Object>>) - Constructor for class io.hekate.spring.boot.HekateConfigurer
Constructs new instance with autowired dependencies.
HekateConsulSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for ConsulSeedNodeProvider.
HekateConsulSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateConsulSeedNodeProviderConfigurer
 
HekateCoordinationServiceConfigurer - Class in io.hekate.spring.boot.coordination
« start hereAuto-configuration for CoordinationService.
HekateCoordinationServiceConfigurer(Optional<List<CoordinationProcessConfig>>) - Constructor for class io.hekate.spring.boot.coordination.HekateCoordinationServiceConfigurer
Constructs new instance.
HekateElectionServiceConfigurer - Class in io.hekate.spring.boot.election
« start hereAuto-configuration for ElectionService.
HekateElectionServiceConfigurer(Optional<List<CandidateConfig>>) - Constructor for class io.hekate.spring.boot.election.HekateElectionServiceConfigurer
Constructs new instance.
HekateEtcdSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for EtcdSeedNodeProvider.
HekateEtcdSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateEtcdSeedNodeProviderConfigurer
 
HekateException - Exception in io.hekate.core
Generic base class for Hekate errors.
HekateException(String) - Constructor for exception io.hekate.core.HekateException
Constructs a new instance.
HekateException(String, Throwable) - Constructor for exception io.hekate.core.HekateException
Constructs a new instance.
HekateException(String, Throwable, boolean, boolean) - Constructor for exception io.hekate.core.HekateException
Constructs a new instance.
HekateExecutionException - Exception in io.hekate.core
Unchecked version of ExecutionException.
HekateExecutionException(String) - Constructor for exception io.hekate.core.HekateExecutionException
Constructs a new instance.
HekateExecutionException(String, Throwable) - Constructor for exception io.hekate.core.HekateExecutionException
Constructs a new instance.
HekateFatalErrorContext - Interface in io.hekate.core
HekateFatalErrorPolicy - Interface in io.hekate.core
Fatal error handling policy.
HekateFsSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for FsSeedNodeProvider.
HekateFsSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateFsSeedNodeProviderConfigurer
 
HekateFstCodecConfigurer - Class in io.hekate.spring.boot.codec
Auto-configuration for FstCodecFactory.
HekateFstCodecConfigurer() - Constructor for class io.hekate.spring.boot.codec.HekateFstCodecConfigurer
 
HekateFuture<T,​F extends HekateFuture<T,​F>> - Class in io.hekate.util
Base class for asynchronous operation results.
HekateFuture() - Constructor for class io.hekate.util.HekateFuture
 
HekateInject - Annotation Type in io.hekate.core.inject
Annotation to be placed on classes that should be processed by InjectionService.
HekateInterruptedException - Exception in io.hekate.core
Unchecked version of InterruptedException.
HekateInterruptedException(String) - Constructor for exception io.hekate.core.HekateInterruptedException
Constructs a new instance.
HekateInterruptedException(String, Throwable) - Constructor for exception io.hekate.core.HekateInterruptedException
Constructs a new instance.
HekateIoException - Exception in io.hekate.core
Unchecked version of IOException.
HekateIoException(String) - Constructor for exception io.hekate.core.HekateIoException
Constructs a new instance.
HekateIoException(String, Throwable) - Constructor for exception io.hekate.core.HekateIoException
Constructs a new instance.
HekateJdbcSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for JdbcSeedNodeProvider.
HekateJdbcSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateJdbcSeedNodeProviderConfigurer
 
HekateJdkCodecConfigurer - Class in io.hekate.spring.boot.codec
Auto-configuration for JdkCodecFactory.
HekateJdkCodecConfigurer() - Constructor for class io.hekate.spring.boot.codec.HekateJdkCodecConfigurer
 
HekateJmx - Interface in io.hekate.core
JMX interface for Hekate instance.
HekateJmxServiceConfigurer - Class in io.hekate.spring.boot.core.jmx
« start hereAuto-configuration for JmxService.
HekateJmxServiceConfigurer() - Constructor for class io.hekate.spring.boot.core.jmx.HekateJmxServiceConfigurer
 
HekateKryoCodecConfigurer - Class in io.hekate.spring.boot.codec
Auto-configuration for KryoCodecFactory.
HekateKryoCodecConfigurer() - Constructor for class io.hekate.spring.boot.codec.HekateKryoCodecConfigurer
 
HekateKubernetesSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for KubernetesSeedNodeProvider.
HekateKubernetesSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateKubernetesSeedNodeProviderConfigurer
 
HekateLockServiceConfigurer - Class in io.hekate.spring.boot.lock
« start hereAuto-configuration for LockService.
HekateLockServiceConfigurer(Optional<List<LockRegionConfig>>) - Constructor for class io.hekate.spring.boot.lock.HekateLockServiceConfigurer
Constructs new instance.
HekateMessagingServiceConfigurer - Class in io.hekate.spring.boot.messaging
« start hereAuto-configuration for MessagingService.
HekateMessagingServiceConfigurer(Optional<List<MessagingChannelConfig<?>>>) - Constructor for class io.hekate.spring.boot.messaging.HekateMessagingServiceConfigurer
Constructs new instance.
HekateMulticastSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for MulticastSeedNodeProvider.
HekateMulticastSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateMulticastSeedNodeProviderConfigurer
 
HekateNetworkServiceConfigurer - Class in io.hekate.spring.boot.network
« start hereAuto-configuration for NetworkService.
HekateNetworkServiceConfigurer(Optional<List<NetworkConnectorConfig<?>>>) - Constructor for class io.hekate.spring.boot.network.HekateNetworkServiceConfigurer
Constructs new instance.
HekateRpcServiceConfigurer - Class in io.hekate.spring.boot.rpc
« start hereAuto-configuration for RpcService.
HekateRpcServiceConfigurer(Optional<List<RpcClientConfig>>, Optional<List<RpcServerConfig>>) - Constructor for class io.hekate.spring.boot.rpc.HekateRpcServiceConfigurer
Constructs a new instance.
HekateSerializableClasses - Class in io.hekate.codec
Registry of serializable Hekate-internal classes that are automatically registered to KryoCodecFactory and FstCodecFactory.
HekateSpringBootstrap - Class in io.hekate.spring.bean
« start hereMain entry point to Spring Framework integration.
HekateSpringBootstrap() - Constructor for class io.hekate.spring.bean.HekateSpringBootstrap
 
HekateStaticSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for StaticSeedNodeProvider.
HekateStaticSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateStaticSeedNodeProviderConfigurer
 
HekateSupport - Interface in io.hekate.core
Marker interface for components that can provide a reference to the Hekate instance that those components belong to.
HekateThreadFactory - Class in io.hekate.core.internal.util
 
HekateThreadFactory(String) - Constructor for class io.hekate.core.internal.util.HekateThreadFactory
 
HekateThreadFactory(String, String) - Constructor for class io.hekate.core.internal.util.HekateThreadFactory
 
HekateThreadFactory(String, String, boolean) - Constructor for class io.hekate.core.internal.util.HekateThreadFactory
 
HekateTimeoutException - Exception in io.hekate.core
Unchecked version of TimeoutException.
HekateTimeoutException(String) - Constructor for exception io.hekate.core.HekateTimeoutException
Constructs a new instance.
HekateTimeoutException(String, Throwable) - Constructor for exception io.hekate.core.HekateTimeoutException
Constructs a new instance.
HekateVersion - Class in io.hekate.core
Build version.
HekateZooKeeperSeedNodeProviderConfigurer - Class in io.hekate.spring.boot.cluster
Auto-configuration for ZooKeeperSeedNodeProvider.
HekateZooKeeperSeedNodeProviderConfigurer() - Constructor for class io.hekate.spring.boot.cluster.HekateZooKeeperSeedNodeProviderConfigurer
 
hiBits() - Method in class io.hekate.util.UuidBase
Returns higher bits of this identifier.
holdCount() - Method in interface io.hekate.lock.DistributedLock
Returns the number of holds on this lock by the current thread.
host() - Method in class io.hekate.cluster.ClusterAddress
Returns the host address.
host() - Method in class io.hekate.cluster.split.HostReachabilityDetector
Host to check.
host(InetSocketAddress) - Static method in class io.hekate.core.internal.util.AddressUtils
Returns the host address of a socket address.
HostReachabilityDetector - Class in io.hekate.cluster.split
Host reachability-based detector.
HostReachabilityDetector(String) - Constructor for class io.hekate.cluster.split.HostReachabilityDetector
Constructs new instance with the default timeout value (=3000).
HostReachabilityDetector(String, int) - Constructor for class io.hekate.cluster.split.HostReachabilityDetector
Constructs new instance.

I

id() - Method in class io.hekate.cluster.ClusterAddress
Returns the unique identifier of the ClusterNode.
id() - Method in interface io.hekate.cluster.ClusterNode
Returns the universally unique identifier of this node.
id() - Method in class io.hekate.cluster.ClusterNodeId
Returns self (inherited from ClusterNodeIdSupport).
id() - Method in interface io.hekate.cluster.ClusterNodeIdSupport
Converts this object to ClusterNodeId.
id() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
id() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfo
 
id() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfoBase
 
id() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
id() - Method in interface io.hekate.messaging.MessagingChannel
Returns the universally unique identifier of this channel.
id() - Method in class io.hekate.partition.DefaultPartition
 
id() - Method in interface io.hekate.partition.Partition
Returns the partition identifier.
IGNORE - io.hekate.messaging.MessagingOverflowPolicy
Completely ignore queue size restrictions.
IGNORE - io.hekate.rpc.RpcAggregate.RemoteErrors
Ignore all remote errors and return whatever results were successfully aggregated or an empty result if RPC failed on all nodes.
IGNORE - io.hekate.rpc.RpcBroadcast.RemoteErrors
Ignore all remote errors.
IGNORE_PARTIAL_ERRORS - io.hekate.cluster.seed.SeedNodeProviderGroupPolicy
Do not fail if at least one SeedNodeProvider succeeds.
inboundContext() - Method in interface io.hekate.messaging.intercept.ServerSendContext
Returns the inbound context.
InboundType - Enum in io.hekate.messaging.intercept
Type of an inbound message.
info() - Static method in class io.hekate.core.HekateVersion
Returns detailed information about this version.
inheritSeen(ClusterNodeId, GossipBase) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
InitializationContext - Interface in io.hekate.core.service
Context for InitializingService.
InitializationFuture - Class in io.hekate.core
Asynchronous result of Hekate.initializeAsync() operation.
InitializationFuture() - Constructor for class io.hekate.core.InitializationFuture
 
initialize() - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called during the CoordinationService initialization.
initialize() - Method in interface io.hekate.core.Hekate
Synchronously initializes this instance without joining to the cluster..
initialize() - Method in class io.hekate.core.HekateBootstrap
Constructs a new Hekate instance and synchronously initializes it without joining the cluster.
initialize(FailureDetectorContext) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
initialize(FailureDetectorContext) - Method in interface io.hekate.cluster.health.FailureDetector
Initialized this failure detector with the runtime context.
initialize(InitializationContext) - Method in interface io.hekate.core.service.InitializingService
Initializes this service.
initializeAsync() - Method in interface io.hekate.core.Hekate
Asynchronously initializes this instance without joining to the cluster.
INITIALIZED - io.hekate.core.Hekate.State
Initialized and ready to start Hekate.State.JOINING.
INITIALIZED - io.hekate.util.StampedStateGuard.State
INITIALIZED - io.hekate.util.StateGuard.State
INITIALIZING - io.hekate.core.Hekate.State
Initializing services and starting seed nodes discovery .
INITIALIZING - io.hekate.util.StampedStateGuard.State
INITIALIZING - io.hekate.util.StateGuard.State
InitializingService - Interface in io.hekate.core.service
Lifecycle interface for services that require initialization.
inject(Object) - Method in interface io.hekate.core.inject.InjectionService
Injects dependencies into the specified object.
InjectChannel - Annotation Type in io.hekate.spring.boot.messaging
Provides support for MessagingChannels autowiring.
InjectConnector - Annotation Type in io.hekate.spring.boot.network
Provides support for NetworkConnectors autowiring.
InjectionService - Interface in io.hekate.core.inject
Dependency injection service.
InjectLock - Annotation Type in io.hekate.spring.boot.lock
Provides support for DistributedLocks autowiring.
InjectLockRegion - Annotation Type in io.hekate.spring.boot.lock
Provides support for LockRegions autowiring.
InjectRpcClient - Annotation Type in io.hekate.spring.boot.rpc
Provides support for RPC clients autowiring.
insertSql() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Returns the SQL string for deleting records from the seed nodes table.
install(HekateBootstrap) - Method in interface io.hekate.core.plugin.Plugin
Gets called when Hekate instance is constructed.
INTEGER - io.hekate.core.ServiceProperty.Type
For Integer type.
interceptClientReceiveAck(ClientOutboundContext<T>) - Method in interface io.hekate.messaging.intercept.ClientMessageInterceptor
Notifies on an acknowledgement from a server.
interceptClientReceiveError(ClientOutboundContext<T>, Throwable) - Method in interface io.hekate.messaging.intercept.ClientMessageInterceptor
Notifies on a failure to receive a response from server.
interceptClientReceiveResponse(ClientReceiveContext<T>) - Method in interface io.hekate.messaging.intercept.ClientMessageInterceptor
Intercepts a response from a server.
interceptClientSend(ClientSendContext<T>) - Method in interface io.hekate.messaging.intercept.ClientMessageInterceptor
Intercepts a message right before sending it to a server.
interceptServerReceive(ServerReceiveContext<T>) - Method in interface io.hekate.messaging.intercept.ServerMessageInterceptor
Intercepts an incoming message from a remote client.
interceptServerReceiveComplete(ServerInboundContext<T>) - Method in interface io.hekate.messaging.intercept.ServerMessageInterceptor
Notifies on server completes processing of a message.
interceptServerSend(ServerSendContext<T>) - Method in interface io.hekate.messaging.intercept.ServerMessageInterceptor
Intercepts a response right before sending it back to a client.
interfaces() - Method in class io.hekate.rpc.RpcServerInfo
Returns the list of RPC interfaces that are supported by this RPC server.
interval() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Returns the multicast interval (see MulticastSeedNodeProviderConfig.setInterval(long)).
intProperty(String) - Method in interface io.hekate.core.ServiceInfo
Returns the property value or null if there is no such property or if property is not of ServiceProperty.Type.INTEGER type.
io.hekate.cluster - package io.hekate.cluster
io.hekate.cluster.event - package io.hekate.cluster.event
API for handling cluster events.
io.hekate.cluster.health - package io.hekate.cluster.health
Cluster node failure detection API.
io.hekate.cluster.internal.gossip - package io.hekate.cluster.internal.gossip
 
io.hekate.cluster.seed - package io.hekate.cluster.seed
Seed node provider API.
io.hekate.cluster.seed.consul - package io.hekate.cluster.seed.consul
Consul key value store based seed node provider.
io.hekate.cluster.seed.etcd - package io.hekate.cluster.seed.etcd
Etcd-based seed node provider.
io.hekate.cluster.seed.fs - package io.hekate.cluster.seed.fs
Filesystem-based seed node provider.
io.hekate.cluster.seed.jclouds - package io.hekate.cluster.seed.jclouds
JClouds-based seed node provider.
io.hekate.cluster.seed.jclouds.aws - package io.hekate.cluster.seed.jclouds.aws
AWS-specific extensions of the seed node provider API.
io.hekate.cluster.seed.jdbc - package io.hekate.cluster.seed.jdbc
JDBC-based seed node provider.
io.hekate.cluster.seed.kubernetes - package io.hekate.cluster.seed.kubernetes
Kubernetes-based seed node provider.
io.hekate.cluster.seed.multicast - package io.hekate.cluster.seed.multicast
Multicast-based seed node provider.
io.hekate.cluster.seed.zookeeper - package io.hekate.cluster.seed.zookeeper
ZooKeeper-based seed node provider.
io.hekate.cluster.split - package io.hekate.cluster.split
Cluster split-brain detection API.
io.hekate.codec - package io.hekate.codec
io.hekate.codec.fst - package io.hekate.codec.fst
Integration with Fast-serialization framework.
io.hekate.codec.kryo - package io.hekate.codec.kryo
Integration with Kryo serialization framework.
io.hekate.coordinate - package io.hekate.coordinate
io.hekate.core - package io.hekate.core
« start hereMain entry point to Hekate API.
io.hekate.core.inject - package io.hekate.core.inject
io.hekate.core.internal.util - package io.hekate.core.internal.util
 
io.hekate.core.jmx - package io.hekate.core.jmx
io.hekate.core.plugin - package io.hekate.core.plugin
Plugins API.
io.hekate.core.report - package io.hekate.core.report
Reporting API.
io.hekate.core.resource - package io.hekate.core.resource
io.hekate.core.service - package io.hekate.core.service
io.hekate.election - package io.hekate.election
io.hekate.lock - package io.hekate.lock
io.hekate.messaging - package io.hekate.messaging
io.hekate.messaging.intercept - package io.hekate.messaging.intercept
Message interception API.
io.hekate.messaging.loadbalance - package io.hekate.messaging.loadbalance
Load balancer API.
io.hekate.messaging.operation - package io.hekate.messaging.operation
Message operation API.
io.hekate.messaging.retry - package io.hekate.messaging.retry
Retry API.
io.hekate.network - package io.hekate.network
io.hekate.network.address - package io.hekate.network.address
Network address resolution API.
io.hekate.network.netty - package io.hekate.network.netty
Netty-based implementation of networking API.
io.hekate.partition - package io.hekate.partition
Partitions mapping API.
io.hekate.rpc - package io.hekate.rpc
io.hekate.spring.bean - package io.hekate.spring.bean
Spring Framework integration.
io.hekate.spring.bean.cluster - package io.hekate.spring.bean.cluster
Support for importing the ClusterService into the Spring context.
io.hekate.spring.bean.codec - package io.hekate.spring.bean.codec
Support for importing the CodecService into the Spring context.
io.hekate.spring.bean.coordinate - package io.hekate.spring.bean.coordinate
Support for importing the CoordinationService into the Spring context.
io.hekate.spring.bean.election - package io.hekate.spring.bean.election
Support for importing the ElectionService into the Spring context.
io.hekate.spring.bean.lock - package io.hekate.spring.bean.lock
Support for importing the LockService into the Spring context.
io.hekate.spring.bean.messaging - package io.hekate.spring.bean.messaging
Support for importing the MessagingService into the Spring context.
io.hekate.spring.bean.network - package io.hekate.spring.bean.network
Support for importing the NetworkService into the Spring context.
io.hekate.spring.bean.rpc - package io.hekate.spring.bean.rpc
Support for importing the RpcService into the Spring context.
io.hekate.spring.boot - package io.hekate.spring.boot
Spring Boot integration.
io.hekate.spring.boot.cluster - package io.hekate.spring.boot.cluster
Auto-configuration for ClusterService.
io.hekate.spring.boot.codec - package io.hekate.spring.boot.codec
Auto-configuration for CodecService.
io.hekate.spring.boot.coordination - package io.hekate.spring.boot.coordination
Auto-configuration for CoordinationService.
io.hekate.spring.boot.core.jmx - package io.hekate.spring.boot.core.jmx
Auto-configuration for JmxService.
io.hekate.spring.boot.election - package io.hekate.spring.boot.election
Auto-configuration for ElectionService.
io.hekate.spring.boot.lock - package io.hekate.spring.boot.lock
Auto-configuration for LockService.
io.hekate.spring.boot.messaging - package io.hekate.spring.boot.messaging
Auto-configuration for MessagingService.
io.hekate.spring.boot.network - package io.hekate.spring.boot.network
Auto-configuration for NetworkService.
io.hekate.spring.boot.rpc - package io.hekate.spring.boot.rpc
Auto-configuration for RpcService.
io.hekate.util - package io.hekate.util
Common helpers and utilities.
io.hekate.util.async - package io.hekate.util.async
Utilities for asynchronous tasks.
io.hekate.util.format - package io.hekate.util.format
Objects formatting utilities.
io.hekate.util.time - package io.hekate.util.time
Time-related utilities.
io.hekate.util.trace - package io.hekate.util.trace
Utilities for tracing.
is(Class<?>) - Method in interface io.hekate.coordinate.CoordinationRequest
Returns true if the request message if of the specified type.
is(Class<? extends T>) - Method in interface io.hekate.messaging.MessageBase
Returns true if this message has a payload of the specified type.
isAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
isAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
isAccept() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReply
 
isAlive(ClusterAddress) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
isAlive(ClusterAddress) - Method in interface io.hekate.cluster.health.FailureDetector
Returns true if cluster node at the specified address is known to be alive.
isAsync() - Method in class io.hekate.rpc.RpcMethodInfo
Returns true if this is an asynchronous method.
isAsyncInit() - Method in class io.hekate.coordinate.CoordinationProcessConfig
Returns the flag that controls the timing of initial coordination (see CoordinationProcessConfig.setAsyncInit(boolean)).
isAutoAccept() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns true if server should automatically start accepting client connections (see NetworkServerFactoryBase.setAutoAccept(boolean)).
isCacheUnknownTypes() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the flag that controls whether class-to-identifiers mapping should be cached (see KryoCodecFactory.setCacheUnknownTypes(boolean)).
isCancelled() - Method in interface io.hekate.coordinate.CoordinationContext
Returns true if this coordination process was cancelled.
isCausedBy(Class<? extends Throwable>) - Method in exception io.hekate.core.HekateException
Returns true if this exception is caused by an error of the specified type.
isCausedBy(Class<? extends Throwable>) - Method in interface io.hekate.messaging.retry.FailedAttempt
Returns true if this failure is caused by an error of the specified type.
isCausedBy(Class<? extends Throwable>, Throwable) - Static method in class io.hekate.core.internal.util.ErrorUtils
Returns true if the specified exception is an error of the specified type or is caused by an error of the specified type.
isCausedBy(Class<T>, Predicate<T>) - Method in interface io.hekate.messaging.retry.FailedAttempt
Returns true if this failure is caused by an error of the specified type.
isConfigReport() - Method in class io.hekate.core.HekateBootstrap
true if the configuration report should be logged during node initialization.
isConvergent() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
isCoordinator() - Method in interface io.hekate.coordinate.CoordinationContext
Returns true if local node is the coordinator.
isCoordinator() - Method in interface io.hekate.coordinate.CoordinationMember
Returns true if this member was selected to be the coordinator.
isCoordinator(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
isDeferredJoin() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
the flag indicating that Hekate node should not join the cluster during the Spring context initialization (see setDeferredJoin(boolean)).
isDisableHeartbeats() - Method in class io.hekate.network.netty.NettyServerFactory
Returns true if heartbeats are disabled (see NettyServerFactory.setDisableHeartbeats(boolean)).
isDone() - Method in interface io.hekate.coordinate.CoordinationContext
Returns true if this coordination process is complete (either successfully or by CoordinationHandler.cancel(CoordinationContext) cancellation).
isDown(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
isEmpty() - Method in interface io.hekate.cluster.ClusterTopology
Returns true if this topology doesn't have any nodes.
isEmpty() - Method in class io.hekate.cluster.internal.gossip.GossipSuspectView
 
isEmpty() - Method in class io.hekate.messaging.MessageMetaData
Returns true if this instance doesn't hold any key/value pairs.
isFailFast() - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Sets the flag that controls the failure detection behavior in case of network connectivity issues between the cluster nodes (see DefaultFailureDetectorConfig.setFailFast(boolean).
isFailure() - Method in interface io.hekate.network.NetworkServerFailure.Resolution
Returns true if failure is unrecoverable and false if error is recoverable and failover actions should be performed by the server.
isFalse(boolean, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
isFalse(boolean, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
isFirstAttempt() - Method in interface io.hekate.messaging.retry.Attempt
Returns true if this is the first attempt (Attempt.attempt() == 0).
isFstAvailable() - Static method in class io.hekate.codec.AutoSelectCodecFactory
Returns true if FST is available on the classpath.
isHeldByCurrentThread() - Method in interface io.hekate.lock.DistributedLock
Returns true if this lock is held by the current thread.
isInitialized() - Method in class io.hekate.util.StampedStateGuard
Returns true if this guard is in StampedStateGuard.State.INITIALIZED state.
isInitialized() - Method in class io.hekate.util.StateGuard
Returns true if this guard is in StateGuard.State.INITIALIZED state.
isInitializing() - Method in class io.hekate.util.StampedStateGuard
Returns true if this guard is in StampedStateGuard.State.INITIALIZING state.
isInitializing() - Method in class io.hekate.util.StateGuard
Returns true if this guard is in StateGuard.State.INITIALIZING state.
isKryoAvailable() - Static method in class io.hekate.codec.AutoSelectCodecFactory
Returns true if Kryo is available on the classpath.
isLastPart() - Method in interface io.hekate.messaging.operation.ResponsePart
Returns true if this is the final part of a response.
isLeader() - Method in interface io.hekate.election.CandidateJmx
Returns true if local node is the leader of this group.
isLocal() - Method in interface io.hekate.cluster.ClusterNode
Returns true if this is a local node.
isLoopBackDisabled() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Returns true if receiving of multicast messages on the loopback address is disabled (see MulticastSeedNodeProviderConfig.setLoopBackDisabled(boolean)).
isLoopBackDisabled() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Returns true if receiving of multicast messages on the loopback address should be disabled (see MulticastSeedNodeProviderConfig.setLoopBackDisabled(boolean)).
isMonitored(ClusterAddress) - Method in class io.hekate.cluster.health.DefaultFailureDetector
Returns true if the specified node is in the list of DefaultFailureDetector.monitored() nodes.
isPowerOfTwo(int) - Static method in class io.hekate.core.internal.util.Utils
Returns true if the specified value is a power of two.
isPowerOfTwo(int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
isPrimary(ClusterNode) - Method in interface io.hekate.partition.Partition
Returns true if the specified node is primary for this partition (see Partition.primaryNode()).
isPrimary(ClusterNodeId) - Method in interface io.hekate.partition.Partition
Returns true if the specified node is primary for this partition (see Partition.primaryNode()).
isReceiver() - Method in interface io.hekate.messaging.MessagingChannelJmx
Returns true if this channel has a MessageReceiver.
isReceiving() - Method in interface io.hekate.network.NetworkEndpoint
Returns false if receiving of messages from a remote peer is NetworkEndpoint.pauseReceiving(Consumer) paused} or if this endpoint is disconnected.
isRegistrationRequired() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns the flag indicating if registration is required for all serializable classes (see KryoCodecFactory.setRegistrationRequired(boolean)).
isRemote() - Method in interface io.hekate.cluster.ClusterNode
Returns true if this is a remote node.
isRequest() - Method in interface io.hekate.messaging.Message
Returns true if this message represents a request/subscription and can be replied.
isRetransmit() - Method in interface io.hekate.messaging.Message
Returns true if this message is a possible duplicate of another message that was received earlier and then was retransmitted based on retry logic.
isSecure() - Method in interface io.hekate.network.NetworkEndpoint
Returns true if SSL is enabled (see NetworkServiceFactory.setSsl(NetworkSslConfig)).
isServer() - Method in interface io.hekate.network.NetworkConnectorJmx
Returns true if this connector has a server handler (see NetworkConnectorConfig.setServerHandler(NetworkServerHandler)).
isSingleton() - Method in class io.hekate.spring.bean.HekateBaseBean
Returns true.
isSingleton() - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
isSnapshot() - Method in interface io.hekate.partition.PartitionMapper
Returns true if this instance is a snapshot.
isSnapshot() - Method in class io.hekate.partition.RendezvousHashMapper
 
isSnapshot() - Method in class io.hekate.partition.UpdatablePartitionMapper
 
isSplit() - Method in interface io.hekate.rpc.RpcRequest
Returns true if this is an RpcAggregate request with RpcSplit of an argument.
isSsl() - Method in interface io.hekate.network.NetworkServiceJmx
Returns true if SSL is enabled.
isStateful() - Method in class io.hekate.cluster.internal.gossip.GossipProtocolCodec
 
isStateful() - Method in interface io.hekate.codec.Codec
Returns true if this codec maintains an internal state and can't be shared among multiple threads or network connections.
isSubscription() - Method in interface io.hekate.messaging.Message
Returns true if this message represents a subscription request and supports partial responses.
isSuccess() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns true if aggregation completed successfully without any errors.
isSuccess() - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns true if broadcast completed successfully without any errors.
isSuccess() - Method in class io.hekate.util.HekateFuture
Returns true if this future completed successfully without an error.
isSuccess(ClusterNode) - Method in interface io.hekate.messaging.operation.AggregateResult
Returns true if there was no failure during the aggregation request processing on the specified cluster node.
isSuccess(ClusterNode) - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns true if there was no communication failure with the specified cluster node..
isSuspected(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
isSuspected(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
isTcpNoDelay() - Method in class io.hekate.network.netty.NettyClientFactory
Returns true if TCP_NODELAY option must be set on TCP socket connections (see NettyClientFactory.setTcpNoDelay(boolean)).
isTcpNoDelay() - Method in class io.hekate.network.NetworkServerFactoryBase
Returns true if TCP_NODELAY option must be set on TCP socket connections (see NetworkServerFactoryBase.setTcpNoDelay(boolean)).
isTcpNoDelay() - Method in class io.hekate.network.NetworkServiceFactory
Returns true if TCP_NODELAY option must be set on TCP socket connections (see NetworkServiceFactory.setTcpNoDelay(boolean)).
isTcpNoDelay() - Method in interface io.hekate.network.NetworkServiceJmx
isTerminated() - Method in enum io.hekate.cluster.internal.gossip.GossipNodeStatus
 
isTrue(boolean, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
isTrue(boolean, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
isUnsafeIo() - Method in class io.hekate.codec.kryo.KryoCodecFactory
Returns true if Unsafe-based IO should be used by Kryo (see KryoCodecFactory.setUnsafeIo(boolean)).
isUseUnsafe() - Method in class io.hekate.codec.fst.FstCodecFactory
Returns the flag that indicates which implementation of FSTCoder should be used (see FstCodecFactory.setUseUnsafe(boolean)).
isValid(ClusterNode) - Method in class io.hekate.cluster.split.AddressReachabilityDetector
 
isValid(ClusterNode) - Method in class io.hekate.cluster.split.HostReachabilityDetector
 
isValid(ClusterNode) - Method in class io.hekate.cluster.split.JdbcConnectivityDetector
 
isValid(ClusterNode) - Method in interface io.hekate.cluster.split.SplitBrainDetector
Performs a split-brain check and returns true if local node can reach other members of the cluster.
isValid(ClusterNode) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
 
isWriteLocked() - Method in class io.hekate.util.StampedStateGuard
Returns true if current thread hold the write lock.
isWriteLocked() - Method in class io.hekate.util.StateGuard
Returns true if the current thread holds a write lock.
iterator() - Method in interface io.hekate.messaging.operation.AggregateResult
 

J

javaMethod() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the Java method.
javaType() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the Java type of this RPC interface.
JdbcConnectivityDetector - Class in io.hekate.cluster.split
JDBC connectivity-based detector.
JdbcConnectivityDetector(DataSource, int) - Constructor for class io.hekate.cluster.split.JdbcConnectivityDetector
Constructs a new instance.
jdbcSeedNodeProvider(JdbcSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateJdbcSeedNodeProviderConfigurer
Constructs new JdbcSeedNodeProvider.
JdbcSeedNodeProvider - Class in io.hekate.cluster.seed.jdbc
JDBC-based implementation of SeedNodeProvider interface.
JdbcSeedNodeProvider(JdbcSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Constructs new instance.
jdbcSeedNodeProviderConfig(DataSource) - Method in class io.hekate.spring.boot.cluster.HekateJdbcSeedNodeProviderConfigurer
Conditionally constructs a new configuration for JdbcSeedNodeProvider if application doesn't provide its own Bean of JdbcSeedNodeProviderConfig type.
JdbcSeedNodeProviderConfig - Class in io.hekate.cluster.seed.jdbc
Configuration for JdbcSeedNodeProvider.
JdbcSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
 
JdbcSeedNodeProviderJmx - Interface in io.hekate.cluster.seed.jdbc
JMX interface for JdbcSeedNodeProvider.
JDK - io.hekate.network.NetworkSslConfig.Provider
JDK default SSL provider.
jdkCodecFactory() - Method in class io.hekate.spring.boot.codec.HekateJdkCodecConfigurer
Constructs a new instance of JdkCodecFactory.
JdkCodecFactory<T> - Class in io.hekate.codec
Codec factory that uses the standard Java Serialization API for data encoding/decoding.
JdkCodecFactory() - Constructor for class io.hekate.codec.JdkCodecFactory
 
jmx() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
jmx() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
jmx() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
jmx() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
jmx() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
jmx() - Method in interface io.hekate.core.jmx.JmxSupport
Creates a JMX object.
JmxService - Interface in io.hekate.core.jmx
« start hereJava Management Extensions service.
JmxServiceException - Exception in io.hekate.core.jmx
Signals an error within the JmxService.
JmxServiceException(String) - Constructor for exception io.hekate.core.jmx.JmxServiceException
Constructs a new instance with the specified error message.
JmxServiceException(String, Throwable) - Constructor for exception io.hekate.core.jmx.JmxServiceException
Constructs a new instance with the specified error message and cause.
jmxServiceFactory() - Method in class io.hekate.spring.boot.core.jmx.HekateJmxServiceConfigurer
Constructs the JmxServiceFactory.
JmxServiceFactory - Class in io.hekate.core.jmx
Factory for JmxService.
JmxServiceFactory() - Constructor for class io.hekate.core.jmx.JmxServiceFactory
 
JmxSupport<T> - Interface in io.hekate.core.jmx
Adaptor interface that can be implemented by any object that indirectly provides JMX support.
JmxTypeName - Annotation Type in io.hekate.core.jmx
Provides a custom value for the 'type' attribute of an ObjectName.
join() - Method in interface io.hekate.core.Hekate
Synchronously initializes this instance and joins the cluster.
join() - Method in class io.hekate.core.HekateBootstrap
Constructs a new Hekate instance and synchronously joins the cluster.
join(List<InetSocketAddress>) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
JOIN - io.hekate.cluster.event.ClusterEventType
Event is of ClusterJoinEvent type.
JOIN_ACCEPT - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
JOIN_REJECT - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
JOIN_REQUEST - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
JoinAccept(ClusterAddress, ClusterAddress, Gossip) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
joinAsync() - Method in interface io.hekate.core.Hekate
Asynchronously initializes this instance and joins the cluster.
joinAsync() - Method in class io.hekate.core.HekateBootstrap
Constructs a new Hekate instance and asynchronously joins the cluster.
joinAsync() - Method in interface io.hekate.core.service.ClusterServiceManager
Asynchronously starts joining the cluster.
JoinFuture - Class in io.hekate.core
Asynchronous result of Hekate.joinAsync() operation.
JoinFuture() - Constructor for class io.hekate.core.JoinFuture
 
JOINING - io.hekate.cluster.internal.gossip.GossipNodeStatus
 
JOINING - io.hekate.core.Hekate.State
Initiated the cluster joining with one of the seed nodes.
joinOrder() - Method in interface io.hekate.cluster.ClusterNode
Returns the cluster join order.
joinOrder() - Method in interface io.hekate.cluster.ClusterTopology
Returns an immutable set of all nodes ordered by their join order.
JoinReject(ClusterAddress, ClusterAddress, InetSocketAddress, GossipProtocol.JoinReject.RejectType, String) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
JoinReply(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReply
 
JoinRequest(ClusterNode, String, InetSocketAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.JoinRequest
 
Jvm - Class in io.hekate.core.internal.util
JVM utilities.
JVM_EXIT_CODE - Static variable in interface io.hekate.core.HekateFatalErrorPolicy
JVM exit code (=250) for HekateFatalErrorPolicy.exitJvm() policy.
Jvm.ExitHandler - Interface in io.hekate.core.internal.util
JVM exit handler.
jvmName() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the Java virtual machine implementation name ('java.vm.name' system property).
jvmVendor() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the Java virtual machine implementation vendor ('java.vm.vendor' system property).
jvmVersion() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the Java runtime environment version ('java.version' system property).

K

kryoCodecFactory() - Method in class io.hekate.spring.boot.codec.HekateKryoCodecConfigurer
Constructs a new instance of KryoCodecFactory.
KryoCodecFactory<T> - Class in io.hekate.codec.kryo
« start hereKryo-based implementation of CodecFactory interface.
KryoCodecFactory() - Constructor for class io.hekate.codec.kryo.KryoCodecFactory
 
kubernetesSeedNodeProvider(KubernetesSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateKubernetesSeedNodeProviderConfigurer
KubernetesSeedNodeProvider - Class in io.hekate.cluster.seed.kubernetes
Kubernetes-based implementation of SeedNodeProvider interface.
KubernetesSeedNodeProvider(KubernetesSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
Constructs new instance.
kubernetesSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateKubernetesSeedNodeProviderConfigurer
Conditionally constructs a new configuration for KubernetesSeedNodeProvider if application doesn't provide its own Bean of KubernetesSeedNodeProviderConfig type.
KubernetesSeedNodeProviderConfig - Class in io.hekate.cluster.seed.kubernetes
Configuration for KubernetesSeedNodeProvider.
KubernetesSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
 

L

last() - Method in interface io.hekate.cluster.ClusterTopology
Returns the last node of the ClusterTopology.nodes() list or null if this topology is empty.
lastTriedAddress() - Method in interface io.hekate.network.NetworkServerFailure
Returns the last address that was tried by the server.
lastTriedNode() - Method in interface io.hekate.messaging.retry.Attempt
Returns the last tried node.
leader() - Method in interface io.hekate.election.FollowerContext
Returns a node that is currently holding the leadership.
leader(String) - Method in interface io.hekate.election.ElectionService
Returns a future object that can be used to get the current leader of the specified group.
LeaderChangeListener - Interface in io.hekate.election
Listener of leader change events.
LeaderContext - Interface in io.hekate.election
Leader state context for Candidate.
LeaderException - Exception in io.hekate.election
Failure of a leader election.
LeaderException(String, Throwable) - Constructor for exception io.hekate.election.LeaderException
Constructs new instance.
LeaderFuture - Class in io.hekate.election
Asynchronous result of leader election.
LeaderFuture() - Constructor for class io.hekate.election.LeaderFuture
 
leave() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
leave() - Method in interface io.hekate.core.Hekate
Synchronously leaves the cluster and terminates this instance.
LEAVE - io.hekate.cluster.event.ClusterEventType
Event is of ClusterLeaveEvent type.
LEAVE - io.hekate.cluster.event.ClusterLeaveReason
Leaving because of the Hekate.leave() method call.
leaveAsync() - Method in interface io.hekate.core.Hekate
Asynchronously leaves the cluster and terminates this instance.
leaveAsync() - Method in interface io.hekate.core.service.ClusterServiceManager
Asynchronously starts leaving the cluster.
LeaveFuture - Class in io.hekate.core
Asynchronous result of Hekate.leaveAsync() operation.
LeaveFuture() - Constructor for class io.hekate.core.LeaveFuture
 
LEAVING - io.hekate.cluster.internal.gossip.GossipNodeStatus
 
LEAVING - io.hekate.core.Hekate.State
Started leaving the cluster.
liveProviders() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
Returns a copy of a list of all providers that were successfully started.
load(String) - Method in interface io.hekate.core.resource.ResourceService
Loads a resource from the specified location.
LoadBalancer<T> - Interface in io.hekate.messaging.loadbalance
Load balancer for unicast messaging.
LoadBalancerContext - Interface in io.hekate.messaging.loadbalance
Context for LoadBalancer.
LoadBalancerException - Exception in io.hekate.messaging.loadbalance
Message load balancing failure.
LoadBalancerException(String) - Constructor for exception io.hekate.messaging.loadbalance.LoadBalancerException
Constructs new instance.
LoadBalancerException(String, Throwable) - Constructor for exception io.hekate.messaging.loadbalance.LoadBalancerException
Constructs new instance.
LoadBalancers - Class in io.hekate.messaging.loadbalance
Common load balancers.
loBits() - Method in class io.hekate.util.UuidBase
Returns lower bits of this identifier.
localAddress() - Method in interface io.hekate.cluster.health.FailureDetectorContext
Returns the local node address.
localAddress() - Method in interface io.hekate.network.NetworkEndpoint
Returns the local address of this endpoint.
localGossip() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
localMember() - Method in interface io.hekate.coordinate.CoordinationContext
Returns the local node member.
localNode() - Method in interface io.hekate.cluster.ClusterService
Returns the local cluster node.
localNode() - Method in interface io.hekate.cluster.ClusterTopology
Returns local node or null if local node is not within this topology.
localNode() - Method in interface io.hekate.core.Hekate
Returns the local cluster node.
localNode() - Method in interface io.hekate.core.service.InitializationContext
Returns the cluster node.
localNode() - Method in interface io.hekate.election.FollowerContext
Returns the local node where the Candidate is running.
localNode() - Method in interface io.hekate.election.LeaderContext
Returns the local node where the Candidate is running.
lockAsync(Executor, AsyncLockCallback) - Method in interface io.hekate.lock.DistributedLock
Performs asynchronous locking and notifies the specified callback upon the lock status changes.
LockBean - Class in io.hekate.spring.bean.lock
Imports DistributedLock into a Spring context.
LockBean() - Constructor for class io.hekate.spring.bean.lock.LockBean
 
LockConfigProvider - Interface in io.hekate.lock
Provider of LockRegion configurations.
LockOwnerInfo - Interface in io.hekate.lock
Provides information about DistributedLock owner.
lockRead() - Method in class io.hekate.util.StampedStateGuard
Acquires the read lock.
lockRead() - Method in class io.hekate.util.StateGuard
Acquires the read lock.
lockReadWithStateCheck() - Method in class io.hekate.util.StampedStateGuard
Acquires the read lock on this guard and checks its current state.
lockReadWithStateCheck() - Method in class io.hekate.util.StateGuard
Acquires the read lock on this guard and checks its current state.
lockReadWithStateCheck(StateGuard.State) - Method in class io.hekate.util.StateGuard
Acquires the read lock on this guard and checks its current state.
LockRegion - Interface in io.hekate.lock
Lock region.
LockRegionBean - Class in io.hekate.spring.bean.lock
Imports LockRegion into a Spring context.
LockRegionBean() - Constructor for class io.hekate.spring.bean.lock.LockRegionBean
 
LockRegionConfig - Class in io.hekate.lock
Configuration for LockRegion.
LockRegionConfig() - Constructor for class io.hekate.lock.LockRegionConfig
Constructs new instance.
LockRegionConfig(String) - Constructor for class io.hekate.lock.LockRegionConfig
Constructs new instance with the specified name.
locks() - Method in interface io.hekate.core.Hekate
Returns the LockService.
lockService() - Method in class io.hekate.spring.boot.lock.HekateLockServiceConfigurer
Returns the factory bean that makes it possible to inject LockService directly into other beans instead of accessing it via Hekate.locks() method.
LockService - Interface in io.hekate.lock
« start hereMain entry point to distributed locks API.
LockServiceBean - Class in io.hekate.spring.bean.lock
Imports LockService into a Spring context.
LockServiceBean() - Constructor for class io.hekate.spring.bean.lock.LockServiceBean
 
lockServiceFactory() - Method in class io.hekate.spring.boot.lock.HekateLockServiceConfigurer
Constructs the LockServiceFactory.
LockServiceFactory - Class in io.hekate.lock
Factory for LockService.
LockServiceFactory() - Constructor for class io.hekate.lock.LockServiceFactory
 
lockWrite() - Method in class io.hekate.util.StampedStateGuard
Acquires the write lock.
lockWrite() - Method in class io.hekate.util.StateGuard
Acquires the write lock.
lockWriteWithStateCheck() - Method in class io.hekate.util.StampedStateGuard
Acquires the write lock on this guard and checks its current state.
lockWriteWithStateCheck() - Method in class io.hekate.util.StateGuard
Acquires the write lock on this guard and checks its current state.
LONG - io.hekate.core.ServiceProperty.Type
For Long type.
LONG_TERM_CONNECT - io.hekate.cluster.internal.gossip.GossipProtocol.Type
 
longProperty(String) - Method in interface io.hekate.core.ServiceInfo
Returns the property value or null if there is no such property or if property is not of ServiceProperty.Type.LONG type.
LongTermConnect(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.LongTermConnect
 

M

MAGIC_BYTES - Static variable in class io.hekate.core.internal.util.Utils
Magic bytes that should be appended to the first packet of a network connection.
MAJORITY_VALID - io.hekate.cluster.split.SplitBrainDetectorGroup.GroupPolicy
If the majority of detectors reported success then the whole group check is considered to be successful.
map(Object) - Method in interface io.hekate.partition.PartitionMapper
Maps the specified key to a Partition.
map(Object) - Method in class io.hekate.partition.PartitionMapperBase
 
map(Object) - Method in class io.hekate.partition.RendezvousHashMapper
 
mapInt(int) - Method in interface io.hekate.partition.PartitionMapper
Maps the specified key of Integer type to a Partition.
mapInt(int) - Method in class io.hekate.partition.PartitionMapperBase
 
mapInt(int) - Method in class io.hekate.partition.RendezvousHashMapper
 
masterUrl() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
Kubernetes master URL.
maxAttempts() - Method in annotation type io.hekate.rpc.RpcRetry
Maximum amount of attempts.
maxAttempts() - Method in class io.hekate.rpc.RpcRetryInfo
Returns the parsed value of RpcRetry.maxAttempts().
maxAttempts(int) - Method in interface io.hekate.messaging.retry.RetryPolicy
Sets the maximum number of retry attempts.
maxDelay() - Method in class io.hekate.messaging.retry.ExponentialBackoffPolicy
Returns the maximum delay of this policy in milliseconds.
maxDelay() - Method in annotation type io.hekate.rpc.RpcRetry
Maximum delay in milliseconds between attempts.
maxDelay() - Method in class io.hekate.rpc.RpcRetryInfo
Returns the parsed value of RpcRetry.maxDelay().
maxJoinOrder() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
maxJoinOrder(int) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
maxMemory() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the maximum amount of memory as provided by Runtime.maxMemory().
member(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
memberOf(ClusterNode) - Method in interface io.hekate.coordinate.CoordinationContext
Returns member by its cluster node.
memberOf(ClusterNodeId) - Method in interface io.hekate.coordinate.CoordinationContext
Returns member by its cluster node identifier.
members() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
members() - Method in interface io.hekate.coordinate.CoordinationContext
Returns all members of this coordination process.
membersInfo() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
membersInfo() - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
membersInfo() - Method in class io.hekate.cluster.internal.gossip.GossipDigest
 
merge(ClusterNodeId, Gossip) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
merge(GossipNodeState) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
message() - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns the original message object that was submitted to the cluster.
Message<T> - Interface in io.hekate.messaging
Message with arbitrary payload.
MessageBase<T> - Interface in io.hekate.messaging
Base interface for messages.
MessageInterceptor - Interface in io.hekate.messaging.intercept
« start hereMessage interceptor.
MessageMetaData - Class in io.hekate.messaging
Message meta-data.
MessageMetaData() - Constructor for class io.hekate.messaging.MessageMetaData
Constructs a new instance.
MessageMetaData.Key<T> - Class in io.hekate.messaging
Key of a MessageMetaData's attribute.
MessageMetaData.MetaDataCodec<T> - Interface in io.hekate.messaging
Codec for MessageMetaData values.
MessageQueueOverflowException - Exception in io.hekate.messaging
Signals MessagingChannel's send queue overflow.
MessageQueueOverflowException(String) - Constructor for exception io.hekate.messaging.MessageQueueOverflowException
Constructs a new instance with the specified error message.
MessageQueueTimeoutException - Exception in io.hekate.messaging
Signals MessagingChannel's send queue timeout.
MessageQueueTimeoutException(String) - Constructor for exception io.hekate.messaging.MessageQueueTimeoutException
Constructs a new instance with the specified error message.
MessageReceiver<T> - Interface in io.hekate.messaging
Message receiver.
MessageTimeoutException - Exception in io.hekate.messaging
Signals that messaging operation timed out.
MessageTimeoutException(MessageTimeoutException) - Constructor for exception io.hekate.messaging.MessageTimeoutException
MessageTimeoutException(String) - Constructor for exception io.hekate.messaging.MessageTimeoutException
Constructs new instance.
messaging() - Method in interface io.hekate.core.Hekate
Returns the MessagingService.
MessagingBackPressureConfig - Class in io.hekate.messaging
Back pressure configuration of a MessagingChannel.
MessagingBackPressureConfig() - Constructor for class io.hekate.messaging.MessagingBackPressureConfig
Constructs a new instance.
MessagingBackPressureConfig(MessagingBackPressureConfig) - Constructor for class io.hekate.messaging.MessagingBackPressureConfig
Copy constructor.
MessagingChannel<T> - Interface in io.hekate.messaging
Messaging channel.
MessagingChannelBean - Class in io.hekate.spring.bean.messaging
Imports MessagingChannel into a Spring context.
MessagingChannelBean() - Constructor for class io.hekate.spring.bean.messaging.MessagingChannelBean
 
MessagingChannelClosedException - Exception in io.hekate.messaging
Signals that messaging operation can't be completed since messaging channel is already closed.
MessagingChannelClosedException(String, Throwable) - Constructor for exception io.hekate.messaging.MessagingChannelClosedException
Constructs new instance.
MessagingChannelConfig<T> - Class in io.hekate.messaging
Configuration options for a MessagingChannel.
MessagingChannelConfig() - Constructor for class io.hekate.messaging.MessagingChannelConfig
Deprecated.
Not really deprecated, but set so in order to produce warnings when this constructor is used instead of the recommended one.
MessagingChannelConfig(Class<T>) - Constructor for class io.hekate.messaging.MessagingChannelConfig
Type safe constructor.
MessagingChannelId - Class in io.hekate.messaging
Universally unique identifier of a messaging channel.
MessagingChannelId() - Constructor for class io.hekate.messaging.MessagingChannelId
Constructs new random identifier.
MessagingChannelId(long, long) - Constructor for class io.hekate.messaging.MessagingChannelId
Constructs new instance from the specified higher/lower bits.
MessagingChannelId(String) - Constructor for class io.hekate.messaging.MessagingChannelId
Creates new identifier from the specified string.
MessagingChannelJmx - Interface in io.hekate.messaging
JMX interface for MessagingChannel.
MessagingConfigBase<T extends MessagingConfigBase<T>> - Class in io.hekate.messaging
Common configuration options for components that provide messaging support.
MessagingConfigBase() - Constructor for class io.hekate.messaging.MessagingConfigBase
 
MessagingConfigProvider - Interface in io.hekate.messaging
Provider of messaging channels configuration.
MessagingEndpoint<T> - Interface in io.hekate.messaging
Remote messaging endpoint.
MessagingException - Exception in io.hekate.messaging
Failure of a messaging operation.
MessagingException(String) - Constructor for exception io.hekate.messaging.MessagingException
Constructs new instance.
MessagingException(String, Throwable) - Constructor for exception io.hekate.messaging.MessagingException
Constructs new instance.
MessagingException(String, Throwable, boolean, boolean) - Constructor for exception io.hekate.messaging.MessagingException
Constructs a new instance.
MessagingFuture<T> - Class in io.hekate.messaging
Asynchronous result of a messaging operation.
MessagingFuture() - Constructor for class io.hekate.messaging.MessagingFuture
 
MessagingOverflowPolicy - Enum in io.hekate.messaging
Policy that defines how MessagingChannel should behave in case of its send queue overflow.
MessagingRemoteException - Exception in io.hekate.messaging
Signals that response message couldn't be received due to an error on a remote node.
MessagingRemoteException(String, String) - Constructor for exception io.hekate.messaging.MessagingRemoteException
Constructs new instance.
messagingService() - Method in class io.hekate.spring.boot.messaging.HekateMessagingServiceConfigurer
Returns the factory bean that makes it possible to inject MessagingService directly into other beans instead of accessing it via Hekate.messaging() method.
MessagingService - Interface in io.hekate.messaging
« start hereMain entry point to messaging API.
MessagingServiceBean - Class in io.hekate.spring.bean.messaging
Imports MessagingService into a Spring context.
MessagingServiceBean() - Constructor for class io.hekate.spring.bean.messaging.MessagingServiceBean
 
messagingServiceFactory() - Method in class io.hekate.spring.boot.messaging.HekateMessagingServiceConfigurer
Constructs the MessagingServiceFactory.
MessagingServiceFactory - Class in io.hekate.messaging
Factory for MessagingService.
MessagingServiceFactory() - Constructor for class io.hekate.messaging.MessagingServiceFactory
 
metaData() - Method in interface io.hekate.messaging.intercept.ClientSendContext
Returns the message's meta-data.
metaData() - Method in interface io.hekate.messaging.intercept.ServerSendContext
Returns the message's meta-data.
method() - Method in interface io.hekate.rpc.RpcRequest
Returns the RPC method.
methods() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the meta-information about this RPC interface's methods.
metrics() - Method in interface io.hekate.core.service.DependencyContext
Returns metrics registry.
metrics() - Method in interface io.hekate.core.service.InitializationContext
Returns metrics registry.
minClientVersion() - Method in annotation type io.hekate.rpc.Rpc
Minimum version of a client interface that is supported by this RPC interface.
minClientVersion() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the minimum client version that is supported by this RPC interface.
mod(int, int) - Static method in class io.hekate.core.internal.util.Utils
 
monitored() - Method in class io.hekate.cluster.health.DefaultFailureDetector
Returns addresses of all nodes that are monitored by this failure detector.
multicastSeedNodeProvider(MulticastSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateMulticastSeedNodeProviderConfigurer
MulticastSeedNodeProvider - Class in io.hekate.cluster.seed.multicast
Multicast-based seed node provider.
MulticastSeedNodeProvider() - Constructor for class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Constructs a new instance with all configuration options set to their default values (see MulticastSeedNodeProviderConfig).
MulticastSeedNodeProvider(MulticastSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Constructs a new instance.
multicastSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateMulticastSeedNodeProviderConfigurer
Conditionally constructs a new configuration for MulticastSeedNodeProvider if application doesn't provide its own Bean of MulticastSeedNodeProviderConfig type.
MulticastSeedNodeProviderConfig - Class in io.hekate.cluster.seed.multicast
Configuration for MulticastSeedNodeProvider.
MulticastSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
 
MulticastSeedNodeProviderJmx - Interface in io.hekate.cluster.seed.multicast
JMX interface for MulticastSeedNodeProvider.
Murmur3 - Class in io.hekate.core.internal.util
Copy of MurmurHash3 code from Google Guava library (Licensed under the Apache License, Version 2.0).
mustReply() - Method in interface io.hekate.messaging.Message
Returns true if the sender is waiting for a response message.

N

name() - Method in interface io.hekate.cluster.ClusterNode
Returns the name of this node.
name() - Method in interface io.hekate.coordinate.CoordinationProcess
Returns the process name (see CoordinationProcessConfig.setName(String)).
name() - Method in class io.hekate.core.ServiceProperty
Returns the property name.
name() - Method in interface io.hekate.lock.DistributedLock
Returns the name of this lock.
name() - Method in interface io.hekate.lock.LockRegion
Returns the name of this region.
name() - Method in class io.hekate.messaging.MessageMetaData.Key
Returns the name of this key.
name() - Method in interface io.hekate.messaging.MessagingChannel
Returns the channel name.
name() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the RPC interface name.
name() - Method in annotation type io.hekate.spring.boot.lock.InjectLock
Specifies the name of a DistributedLock that should be used to get the lock (see LockRegion.get(String)).
name() - Method in class io.hekate.util.trace.TraceInfo
Name of this trace.
nameFor(Class<?>) - Method in interface io.hekate.core.jmx.JmxService
Constructs a new object name for the specified JMX interface.
nameFor(Class<?>, String) - Method in interface io.hekate.core.jmx.JmxService
Constructs a new object name for the specified JMX interface and an additional 'name' attribute.
names() - Method in interface io.hekate.core.jmx.JmxService
Returns the list of names of all MBeans that are registered to this service.
namespace() - Method in interface io.hekate.cluster.ClusterService
Returns the namespace of this cluster.
namespace() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinRequest
 
namespace() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
Kubernetes namespace.
nanoTime() - Method in interface io.hekate.util.time.SystemTimeSupplier
NettyClientFactory<T> - Class in io.hekate.network.netty
Configurable factory for Netty-based NetworkClients.
NettyClientFactory() - Constructor for class io.hekate.network.netty.NettyClientFactory
 
NettyMetricsFactory - Interface in io.hekate.network.netty
Factory for NettyMetricsSink.
NettyMetricsSink - Interface in io.hekate.network.netty
Sink for metrics of a Netty-based network endpoint.
NettyServerFactory - Class in io.hekate.network.netty
Configurable factory for Netty-based NetworkServers.
NettyServerFactory() - Constructor for class io.hekate.network.netty.NettyServerFactory
 
NettyServerHandlerConfig<T> - Class in io.hekate.network.netty
Netty-specific extension of NetworkServerHandlerConfig.
NettyServerHandlerConfig() - Constructor for class io.hekate.network.netty.NettyServerHandlerConfig
 
NettyUtils - Class in io.hekate.network.netty
Netty-related utilities.
network() - Method in interface io.hekate.core.Hekate
Returns the NetworkService.
NetworkBindCallback - Interface in io.hekate.core.service
Callback for NetworkServiceManager.
NetworkClient<T> - Interface in io.hekate.network
Asynchronous network client connection.
NetworkClient.State - Enum in io.hekate.network
State of NetworkClient connection lifecycle.
NetworkClientCallback<T> - Interface in io.hekate.network
Callback for receiving messages and tracking state changes in NetworkClient.
NetworkConfigProvider - Interface in io.hekate.network
Provider of NetworkConnector configurations.
NetworkConnectException - Exception in io.hekate.network
Signals that an error occurred while attempting to establish a network connection.
NetworkConnectException(String, Throwable) - Constructor for exception io.hekate.network.NetworkConnectException
Constructs a new instance.
NetworkConnector<T> - Interface in io.hekate.network
Network connector.
NetworkConnectorBean - Class in io.hekate.spring.bean.network
Imports NetworkConnector into a Spring context.
NetworkConnectorBean() - Constructor for class io.hekate.spring.bean.network.NetworkConnectorBean
 
NetworkConnectorConfig<T> - Class in io.hekate.network
Configuration for NetworkConnector.
NetworkConnectorConfig() - Constructor for class io.hekate.network.NetworkConnectorConfig
 
NetworkConnectorJmx - Interface in io.hekate.network
JMX interface for NetworkConnector.
NetworkConnectTimeoutException - Exception in io.hekate.network
Signals a timeout while trying to connect to a remote host.
NetworkConnectTimeoutException(String) - Constructor for exception io.hekate.network.NetworkConnectTimeoutException
Constructs a new instance.
NetworkConnectTimeoutException(String, Throwable) - Constructor for exception io.hekate.network.NetworkConnectTimeoutException
Constructs a new instance.
NetworkEndpoint<T> - Interface in io.hekate.network
Base interface for network communication endpoints.
NetworkEndpointClosedException - Exception in io.hekate.network
Signals an attempt to perform a networking operation on a NetworkEndpoint that is closed.
NetworkEndpointClosedException(String) - Constructor for exception io.hekate.network.NetworkEndpointClosedException
Constructs a new instance.
NetworkEndpointClosedException(String, Throwable) - Constructor for exception io.hekate.network.NetworkEndpointClosedException
Constructs a new instance.
NetworkException - Exception in io.hekate.network
General networking error.
NetworkException(String) - Constructor for exception io.hekate.network.NetworkException
Constructs a new instance.
NetworkException(String, Throwable) - Constructor for exception io.hekate.network.NetworkException
Constructs a new instance.
NetworkFuture<T> - Class in io.hekate.network
Result of an asynchronous operation in NetworkEndpoint.
NetworkFuture() - Constructor for class io.hekate.network.NetworkFuture
 
NetworkMessage<T> - Interface in io.hekate.network
Buffered message.
NetworkMessage.Preview<V> - Interface in io.hekate.network
Preview function for NetworkMessage.preview(Preview).
NetworkMessage.PreviewBoolean - Interface in io.hekate.network
NetworkMessage.PreviewDouble - Interface in io.hekate.network
NetworkMessage.PreviewInt - Interface in io.hekate.network
NetworkMessage.PreviewLong - Interface in io.hekate.network
NetworkPingCallback - Interface in io.hekate.network
Callback for ping(...) operation.
NetworkPingResult - Enum in io.hekate.network
Enumeration with possible outcome of ping(...) operation.
NetworkSendCallback<T> - Interface in io.hekate.network
Callback for getting results of an asynchronous messages sending operation in NetworkEndpoint.
NetworkServer - Interface in io.hekate.network
Standalone TCP server.
NetworkServer.State - Enum in io.hekate.network
State of NetworkServer lifecycle.
NetworkServerCallback - Interface in io.hekate.network
Lifecycle callback for NetworkServer.
NetworkServerFactoryBase - Class in io.hekate.network
Abstract base class for configurable NetworkServer factories.
NetworkServerFactoryBase() - Constructor for class io.hekate.network.NetworkServerFactoryBase
 
NetworkServerFailure - Interface in io.hekate.network
Failure in NetworkServer.
NetworkServerFailure.Resolution - Interface in io.hekate.network
Resolution of NetworkServerFailure.
NetworkServerFuture - Class in io.hekate.network
Result of an asynchronous operation in NetworkServer.
NetworkServerFuture() - Constructor for class io.hekate.network.NetworkServerFuture
 
NetworkServerHandler<T> - Interface in io.hekate.network
Handler for processing connections from NetworkClients.
NetworkServerHandlerConfig<T> - Class in io.hekate.network
Configuration for NetworkServerHandler.
NetworkServerHandlerConfig() - Constructor for class io.hekate.network.NetworkServerHandlerConfig
 
networkService() - Method in class io.hekate.spring.boot.network.HekateNetworkServiceConfigurer
Returns a factory bean that makes it possible to inject NetworkService directly into other beans instead of accessing it via Hekate.network() method.
NetworkService - Interface in io.hekate.network
« start hereEntry point to TCP-based client/server communication API.
NetworkServiceBean - Class in io.hekate.spring.bean.network
Imports NetworkService into a Spring context.
NetworkServiceBean() - Constructor for class io.hekate.spring.bean.network.NetworkServiceBean
 
networkServiceFactory(Optional<NetworkSslConfig>) - Method in class io.hekate.spring.boot.network.HekateNetworkServiceConfigurer
Constructs the NetworkServiceFactory.
NetworkServiceFactory - Class in io.hekate.network
Factory for NetworkService.
NetworkServiceFactory() - Constructor for class io.hekate.network.NetworkServiceFactory
 
NetworkServiceJmx - Interface in io.hekate.network
JMX interface for NetworkService.
NetworkServiceManager - Interface in io.hekate.core.service
Network service manager.
networkSslConfig() - Method in class io.hekate.spring.boot.network.HekateNetworkServiceConfigurer
Constructs a NetworkSslConfig.
NetworkSslConfig - Class in io.hekate.network
SSL configuration options.
NetworkSslConfig() - Constructor for class io.hekate.network.NetworkSslConfig
 
NetworkSslConfig.Provider - Enum in io.hekate.network
SSL provider type.
NetworkTimeoutException - Exception in io.hekate.network
Signals a network operation timed out.
NetworkTimeoutException(String) - Constructor for exception io.hekate.network.NetworkTimeoutException
Constructs a new instance.
NetworkTimeoutException(String, Throwable) - Constructor for exception io.hekate.network.NetworkTimeoutException
Constructs a new instance.
NetworkTransportType - Enum in io.hekate.network
Network transport type for NetworkServiceFactory.
newAggregate(T) - Method in interface io.hekate.messaging.MessagingChannel
Creates a new Aggregate operation.
newBroadcast(T) - Method in interface io.hekate.messaging.MessagingChannel
Creates a new Broadcast operation.
newClient() - Method in class io.hekate.network.netty.NettyClientFactory
 
newClient() - Method in interface io.hekate.network.NetworkConnector
Creates a new NetworkClient instance.
newCondition() - Method in interface io.hekate.lock.DistributedLock
Unsupported operation.
newInstance() - Method in class io.hekate.coordinate.CoordinationFuture
 
newInstance() - Method in class io.hekate.core.InitializationFuture
 
newInstance() - Method in class io.hekate.core.JoinFuture
 
newInstance() - Method in class io.hekate.core.LeaveFuture
 
newInstance() - Method in class io.hekate.core.TerminateFuture
 
newInstance() - Method in class io.hekate.election.LeaderFuture
 
newInstance() - Method in class io.hekate.messaging.MessagingFuture
 
newInstance() - Method in class io.hekate.util.HekateFuture
Constructs new future instance of this class.
newRequest(T) - Method in interface io.hekate.messaging.MessagingChannel
Creates a new Request operation.
newRoundRobin() - Static method in class io.hekate.messaging.loadbalance.LoadBalancers
Returns a new load balancer that routes all messages using a round-robin approach.
newSend(T) - Method in interface io.hekate.messaging.MessagingChannel
Creates a new Send operation.
newSubscribe(T) - Method in interface io.hekate.messaging.MessagingChannel
Creates a new Subscribe operation.
newThread(Runnable) - Method in class io.hekate.core.internal.util.HekateThreadFactory
 
newThread(ForkJoinPool) - Method in class io.hekate.core.internal.util.HekateThreadFactory
 
NIO - io.hekate.network.NetworkTransportType
Use the default NIO implementation that is provided by the JVM.
nioThreads() - Method in interface io.hekate.messaging.MessagingChannel
Returns the size of a thread pool for handling NIO-based socket connections (see MessagingConfigBase.setNioThreads(int)).
nioThreads() - Method in interface io.hekate.rpc.RpcService
Returns the size of a thread pool for handling NIO-based socket connections (see MessagingConfigBase.setNioThreads(int)).
NL - Static variable in class io.hekate.core.internal.util.Utils
NO_WAIT - Static variable in interface io.hekate.util.async.Waiting
Do not wait.
node() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
node() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
node() - Method in interface io.hekate.coordinate.CoordinationMember
Returns the cluster node of this member.
node() - Method in interface io.hekate.lock.LockOwnerInfo
Returns a cluster node that currently holds the lock.
nodeName() - Method in interface io.hekate.core.service.DependencyContext
Returns the node node.
nodes() - Method in interface io.hekate.cluster.ClusterTopology
Returns an immutable list of all nodes with consistent ordering based on ClusterNode.compareTo(ClusterNode) method.
nodes() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the aggregation participants.
nodes() - Method in interface io.hekate.messaging.operation.BroadcastResult
Returns the broadcast operation participants.
nodes() - Method in class io.hekate.partition.DefaultPartition
 
nodes() - Method in interface io.hekate.partition.Partition
Returns the set of all nodes that are mapped to this partition (including primary and backup).
nodeSet() - Method in interface io.hekate.cluster.ClusterTopology
Returns an immutable set of all nodes within this topology.
nonAffinityRoute(T, LoadBalancerContext) - Method in class io.hekate.messaging.loadbalance.DefaultLoadBalancer
Selects a random node from the load balancer context.
nonNegative(int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
noRetries() - Static method in interface io.hekate.messaging.retry.GenericRetryConfigurer
Do not retry.
NOT_NEEDED - io.hekate.messaging.operation.AckMode
Do not require an acknowledgement.
notEmpty(String, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
notEmpty(String, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
notEmpty(Stream<?>, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
notNull(Object, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
notNull(Object, String, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
notNull(T, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
nullOrTrim(String) - Static method in class io.hekate.core.internal.util.Utils
Returns null if the specified string is null or is an empty string after trimming; returns a trimmed string otherwise.
nullOrTrim(String, String) - Static method in class io.hekate.core.internal.util.Utils
Returns defaultVal if the specified string is null or is an empty string after trimming; returns a trimmed string otherwise.
nullSafe(Collection<T>) - Static method in class io.hekate.core.internal.util.StreamUtils
Returns a Stream that filters out all null values.
nullSafeImmutableCopy(List<T>) - Static method in class io.hekate.core.internal.util.Utils
Returns an immutable copy of the specified list by filtering out all null elements.
numberFormat(String, Number) - Static method in class io.hekate.core.internal.util.Utils
 

O

of(int, ClusterNode) - Static method in class io.hekate.cluster.UpdatableClusterView
Constructs a new view.
of(int, Set<ClusterNode>) - Static method in class io.hekate.cluster.UpdatableClusterView
Constructs a new view.
of(long, Set<ClusterNode>) - Static method in interface io.hekate.cluster.ClusterTopology
Constructs a new cluster topology.
of(ClusterNode) - Static method in class io.hekate.cluster.ClusterNodeJmx
Constructs a new ClusterNodeJmx instance from the specified node.
of(ClusterTopology) - Static method in class io.hekate.cluster.UpdatableClusterView
Constructs a new view.
of(ClusterTopologySupport) - Static method in class io.hekate.partition.RendezvousHashMapper
Constructs a new builder that can be used to configure RendezvousHashMapper.
of(ClusterTopologySupport, int, int) - Static method in class io.hekate.partition.RendezvousHashMapper
Constructs a new mapper.
of(Class<T>) - Static method in class io.hekate.messaging.MessagingChannelConfig
Shortcut method for MessagingChannelConfig(Class) constructor.
of(String) - Static method in class io.hekate.util.trace.TraceInfo
Constructs a new instance.
of(String, MessageMetaData.MetaDataCodec<T>) - Static method in class io.hekate.messaging.MessageMetaData.Key
Constructs a new key.
oldest() - Method in interface io.hekate.cluster.ClusterTopology
Returns the oldest node of this topology.
ON_DOWN - Static variable in interface io.hekate.cluster.internal.gossip.GossipPolicy
 
onApplicationEvent(ContextRefreshedEvent) - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
onBeforeSend(GossipProtocol) - Method in interface io.hekate.cluster.internal.gossip.GossipCommListener
 
onBeforeSend(GossipProtocol) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onBind(InetSocketAddress) - Method in interface io.hekate.core.service.NetworkBindCallback
Successfully bound to the provided address.
onBytesReceived(long) - Method in interface io.hekate.network.netty.NettyMetricsSink
Bytes received.
onBytesSent(long) - Method in interface io.hekate.network.netty.NettyMetricsSink
Bytes sent.
onCancel() - Method in interface io.hekate.coordinate.CoordinationRequestCallback
Gets called if coordination process was cancelled before the response could be received.
onCancel(Map<CoordinationMember, Object>) - Method in interface io.hekate.coordinate.CoordinationBroadcastCallback
Gets called if coordination processes is cancelled.
onComplete(Throwable) - Method in interface io.hekate.messaging.operation.SendCallback
Called when the request operation gets completed either successfully or with an error.
onComplete(Throwable, AggregateResult<T>) - Method in interface io.hekate.messaging.operation.AggregateCallback
Called when the aggregation operation gets completed either successfully or with an error.
onComplete(Throwable, BroadcastResult<T>) - Method in interface io.hekate.messaging.operation.BroadcastCallback
Called when the broadcast operation gets completed either successfully or with an error.
onComplete(Throwable, Response<T>) - Method in interface io.hekate.messaging.operation.RequestCallback
Called when a request operation gets completed either successfully or with an error.
onComplete(Throwable, ResponsePart<T>) - Method in interface io.hekate.messaging.operation.SubscribeCallback
Called when a request operation gets completed either successfully or with an error.
onComplete(T, Throwable) - Method in interface io.hekate.network.NetworkSendCallback
Called when message sending completes either successfully or with an error.
onConnect() - Method in interface io.hekate.network.netty.NettyMetricsSink
Connected.
onConnect(GossipProtocol, NetworkEndpoint<GossipProtocol>) - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
onConnect(MessagingEndpoint<T>) - Method in interface io.hekate.messaging.MessageReceiver
Called when a remote node connects to this channel.
onConnect(NetworkClient<T>) - Method in interface io.hekate.network.NetworkClientCallback
Called upon successful completion of connect operation right after client switches to the CONNECTED state.
onConnect(T, NetworkEndpoint<T>) - Method in interface io.hekate.network.NetworkServerHandler
Called when NetworkClient connects to the server.
onConnectFailure(ClusterAddress) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
onConnectFailure(ClusterAddress) - Method in interface io.hekate.cluster.health.FailureDetector
Notifies this failure detector upon failure while trying to connect to a remote node.
onConnectFailure(ClusterAddress) - Method in interface io.hekate.cluster.internal.gossip.GossipCommListener
 
onDisconnect() - Method in interface io.hekate.network.netty.NettyMetricsSink
Disconnect.
onDisconnect(MessagingEndpoint<T>) - Method in interface io.hekate.messaging.MessageReceiver
Called when a remote node disconnects from this channel.
onDisconnect(NetworkClient<T>, Optional<Throwable>) - Method in interface io.hekate.network.NetworkClientCallback
Called right after NetworkClient gets disconnected and switched to the DISCONNECTED state either by explicit call of NetworkEndpoint.disconnect() method or if connection was closed due to an error.
onDisconnect(NetworkEndpoint<GossipProtocol>) - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
onDisconnect(NetworkEndpoint<T>) - Method in interface io.hekate.network.NetworkServerHandler
Called when client connection is closed.
onEvent(ClusterEvent) - Method in interface io.hekate.cluster.event.ClusterEventListener
Processes the cluster event.
onFailure(NetworkEndpoint<T>, Throwable) - Method in interface io.hekate.network.NetworkServerHandler
Called if error happened while communicating with the client.
onFailure(NetworkServerFailure) - Method in interface io.hekate.core.service.NetworkBindCallback
Network service failure.
onFailure(NetworkServer, NetworkServerFailure) - Method in interface io.hekate.network.NetworkServerCallback
Called if there is an error either when the server is staring or already started.
onHeartbeatReply(ClusterAddress) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
onHeartbeatReply(ClusterAddress) - Method in interface io.hekate.cluster.health.FailureDetector
Notifies this failure detector on heartbeat reply message from a remote node.
onHeartbeatRequest(ClusterAddress) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
onHeartbeatRequest(ClusterAddress) - Method in interface io.hekate.cluster.health.FailureDetector
Notifies this failure detector on heartbeat request message form a remote node.
onJoin(int, Set<ClusterNode>) - Method in interface io.hekate.core.service.ClusterContext
Asynchronously notifies this context that ClusterService has successfully joined the cluster.
onJoinReject(ClusterAddress, String) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onKnownAddressesChange(Set<ClusterAddress>, Set<ClusterAddress>) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onLeaderChange(FollowerContext) - Method in interface io.hekate.election.LeaderChangeListener
Called every time when some other node wins elections and takes a group leadership.
onLeave() - Method in interface io.hekate.core.service.ClusterContext
Asynchronously notifies on ClusterService successfully left the cluster.
onLockAcquire(DistributedLock) - Method in interface io.hekate.lock.AsyncLockCallback
Gets called when lock was successfully acquired.
onLockBusy(LockOwnerInfo) - Method in interface io.hekate.lock.AsyncLockCallback
Gets called when initial attempt to acquire the lock failed because of the lock is being held by some other node or thread.
onLockOwnerChange(LockOwnerInfo) - Method in interface io.hekate.lock.AsyncLockCallback
Gets called when lock owner changes while the callback is still waiting for the lock to be acquired.
onLockRelease(DistributedLock) - Method in interface io.hekate.lock.AsyncLockCallback
Gets called after lock has been released.
onMessage(NetworkMessage<GossipProtocol>, NetworkEndpoint<GossipProtocol>) - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
onMessage(NetworkMessage<T>, NetworkClient<T>) - Method in interface io.hekate.network.NetworkClientCallback
Called when a new message is received from the server.
onMessage(NetworkMessage<T>, NetworkEndpoint<T>) - Method in interface io.hekate.network.NetworkServerHandler
Called when new message is received from the client.
onMessageDequeue() - Method in interface io.hekate.network.netty.NettyMetricsSink
Message removed from the queue.
onMessageEnqueue() - Method in interface io.hekate.network.netty.NettyMetricsSink
Message added to the queue.
onMessageReceived() - Method in interface io.hekate.network.netty.NettyMetricsSink
Message received.
onMessageSent() - Method in interface io.hekate.network.netty.NettyMetricsSink
Message sent.
onNodeFailure(ClusterNode, GossipNodeStatus) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onNodeFailureSuspected(ClusterNode, GossipNodeStatus) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onNodeFailureUnsuspected(ClusterNode, GossipNodeStatus) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onNodeInconsistency(GossipNodeStatus) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onReceive(GossipProtocol) - Method in interface io.hekate.cluster.internal.gossip.GossipCommListener
 
onResponse(Object, CoordinationMember) - Method in interface io.hekate.coordinate.CoordinationRequestCallback
Gets called when a response is received.
onResponses(Map<CoordinationMember, Object>) - Method in interface io.hekate.coordinate.CoordinationBroadcastCallback
Gets called when responses have been received from all coordination participants.
onResult(InetSocketAddress, NetworkPingResult) - Method in interface io.hekate.network.NetworkPingCallback
Called when asynchronous ping operation result is ready.
onRetry(FailedAttempt) - Method in interface io.hekate.messaging.retry.RetryCallback
Gets called when RetryPolicy decides to retry a failed operation.
onRetry(RetryCallback) - Method in interface io.hekate.messaging.retry.RetryPolicy
Registers a callback to be notified when this policy decides to retry a failed operation.
onSendFailure(GossipProtocol, Throwable) - Method in interface io.hekate.cluster.internal.gossip.GossipCommListener
 
onStart(NetworkServer) - Method in interface io.hekate.network.NetworkServerCallback
Called if server started successfully.
onStateChanged(Hekate) - Method in interface io.hekate.core.Hekate.LifecycleListener
Gets called after each change of Hekate.state().
onStatusChange(GossipNodeStatus, GossipNodeStatus, int, Set<ClusterNode>) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
onStop(NetworkServer) - Method in interface io.hekate.network.NetworkServerCallback
Called if server stopped.
onTopologyChange(Set<ClusterNode>, Set<ClusterNode>) - Method in interface io.hekate.core.service.ClusterContext
onTopologyChange(Set<ClusterNode>, Set<ClusterNode>, Set<ClusterNode>) - Method in interface io.hekate.cluster.internal.gossip.GossipListener
 
OPEN_SSL - io.hekate.network.NetworkSslConfig.Provider
OpenSSL provider.
optional(Class<T>) - Method in interface io.hekate.core.service.DependencyContext
Returns a reference to an optional service.
order() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
order(int) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
osArch() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the operating system architecture ('os.arch' system property).
osName() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the name of an operating system ('os.name' system property).
osVersion() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns the operating system version ('os.version' system property).
outboundContext() - Method in interface io.hekate.messaging.intercept.ClientReceiveContext
Returns the outbound context.
OutboundType - Enum in io.hekate.messaging.intercept
Type of an outbound message.
overrideMessage(T) - Method in interface io.hekate.messaging.intercept.ClientReceiveContext
Overrides the received message with the specified one.
overrideMessage(T) - Method in interface io.hekate.messaging.intercept.ClientSendContext
Overrides the message to be sent with the specified one.
overrideMessage(T) - Method in interface io.hekate.messaging.intercept.ServerReceiveContext
Overrides the received message with the specified one.
overrideMessage(T) - Method in interface io.hekate.messaging.intercept.ServerSendContext
Overrides the message to be sent with the specified one.
owner() - Method in interface io.hekate.lock.DistributedLock
Returns an information about the node that is currently holding this lock.
ownerOf(String) - Method in interface io.hekate.lock.LockRegion
Returns information about the node that is currently holding the specified lock.

P

parse(RpcRetry, PlaceholderResolver) - Static method in class io.hekate.rpc.RpcRetryInfo
Parses the specified RpcRetry annotation.
parse(String, ConfigCheck) - Static method in class io.hekate.core.internal.util.AddressUtils
Parses the specified string into an InetSocketAddress.
parseUnresolved(String, ConfigCheck) - Static method in class io.hekate.core.internal.util.AddressUtils
Parses the specified string as an InetSocketAddress with an unresolved host name.
partialReply(T) - Method in interface io.hekate.messaging.Message
Asynchronously sends a partial response for a subscription request.
partialReply(T, SendCallback) - Method in interface io.hekate.messaging.Message
Asynchronously sends a partial reply in response to a subscription request.
partialResults() - Method in exception io.hekate.rpc.RpcAggregateException
Returns the map of successful nodes and their corresponding results.
partition(int) - Method in interface io.hekate.partition.PartitionMapper
Returns a partition for the specified Partition.id().
partition(int) - Method in class io.hekate.partition.RendezvousHashMapper
 
partition(int) - Method in class io.hekate.partition.UpdatablePartitionMapper
 
Partition - Interface in io.hekate.partition
Data partition.
PartitionMapper - Interface in io.hekate.partition
Partition mapper.
PartitionMapperBase - Class in io.hekate.partition
Abstract base class for PartitionMapper implementations.
PartitionMapperBase(int, int) - Constructor for class io.hekate.partition.PartitionMapperBase
Constructs a new instance.
partitions() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns the partition mapper.
partitions() - Method in interface io.hekate.messaging.MessagingChannel
Returns the partition mapper of this channel.
partitions() - Method in interface io.hekate.partition.PartitionMapper
Returns the total amount of partitions.
partitions() - Method in class io.hekate.partition.PartitionMapperBase
 
partitions() - Method in interface io.hekate.rpc.RpcClientBuilder
Returns the partition mapper that RPC client will use to map affinity keys to the cluster nodes.
pattern() - Method in class io.hekate.network.address.AddressPattern
Returns the host pattern as string.
pauseReceiving(Consumer<NetworkEndpoint<T>>) - Method in interface io.hekate.network.NetworkEndpoint
Pauses receiving of messages from a remote peer.
payload() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the outbound message.
payload() - Method in interface io.hekate.messaging.intercept.ClientReceiveContext
Returns the inbound message.
payload() - Method in interface io.hekate.messaging.intercept.ServerInboundContext
Returns the inbound message.
payload() - Method in interface io.hekate.messaging.intercept.ServerSendContext
Returns the outbound message.
payload() - Method in interface io.hekate.messaging.MessageBase
Returns the payload of this message.
payload(Class<P>) - Method in interface io.hekate.messaging.MessageBase
Casts the payload of this message to the specified type.
permanent(ClusterAddress, ClusterAddress, InetSocketAddress) - Static method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
PERMANENT - io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
 
pid() - Method in interface io.hekate.cluster.ClusterNodeRuntime
Returns PID of a Java virtual machine system process.
pid() - Static method in class io.hekate.core.internal.util.Jvm
Returns the PID of the JVM process.
ping(InetSocketAddress, NetworkPingCallback) - Method in interface io.hekate.network.NetworkService
Asynchronously checks if connection can be established with a NetworkService at the specified address and notifies the provided callback on operation result.
PlaceholderResolver - Interface in io.hekate.core.inject
Resolver of property placeholders in String values.
Plugin - Interface in io.hekate.core.plugin
« start hereEntry point to core API of Hekate plugins.
policy() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
Returns the error handling policy of this group.
port() - Method in class io.hekate.cluster.ClusterAddress
Returns the port number.
PORT_SEPARATOR - Static variable in class io.hekate.core.internal.util.AddressUtils
Separator of host and port components for AddressUtils.toFileName(InetSocketAddress).
positive(int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
positive(long, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
positive(long, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
postInitialize(InitializationContext) - Method in interface io.hekate.core.service.InitializingService
Post-initializes this service.
postTerminate() - Method in interface io.hekate.core.service.TerminatingService
Post-terminates this service.
powerOfTwo(int, String) - Static method in class io.hekate.core.internal.util.ArgAssert
 
PREFER_SAME_NODE - io.hekate.messaging.retry.RetryRoutingPolicy
If failed node is still within the cluster topology then try using it.
preferSameNode() - Method in interface io.hekate.messaging.retry.RetryRoutingSupport
Instructs to apply the RetryRoutingPolicy.PREFER_SAME_NODE policy.
preInitialize(InitializationContext) - Method in interface io.hekate.core.service.InitializingService
Pre-initializes this service.
prepare(CoordinationContext) - Method in interface io.hekate.coordinate.CoordinationHandler
Signals the beginning of a new coordination process.
preTerminate() - Method in interface io.hekate.core.service.TerminatingService
Pre-terminates this service.
prevFailure() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the previous failure in case if this is a retry attempt.
preview(NetworkMessage.Preview<V>) - Method in interface io.hekate.network.NetworkMessage
Applies the specified preview function to this message.
previewBoolean(NetworkMessage.PreviewBoolean) - Method in interface io.hekate.network.NetworkMessage
Applies the specified preview function to this message.
previewDouble(NetworkMessage.PreviewDouble) - Method in interface io.hekate.network.NetworkMessage
Applies the specified preview function to this message.
previewInt(NetworkMessage.PreviewInt) - Method in interface io.hekate.network.NetworkMessage
Applies the specified preview function to this message.
previewLong(NetworkMessage.PreviewLong) - Method in interface io.hekate.network.NetworkMessage
Applies the specified preview function to this message.
primaryNode() - Method in class io.hekate.partition.DefaultPartition
 
primaryNode() - Method in interface io.hekate.partition.Partition
Returns the primary node that is assigned to this partition.
process(CoordinationRequest, CoordinationContext) - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called when a new request is received from a coordination member.
process(String) - Method in interface io.hekate.coordinate.CoordinationService
Returns a coordination process for the specified name.
processJoinAccept(GossipProtocol.JoinAccept) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
processJoinFailure(GossipProtocol.JoinRequest, Throwable) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
processJoinReject(GossipProtocol.JoinReject) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
processJoinRequest(GossipProtocol.JoinRequest) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
processUpdate(GossipProtocol.UpdateBase) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
productName() - Static method in class io.hekate.core.HekateVersion
Returns the product name.
properties() - Method in interface io.hekate.cluster.ClusterNode
Returns the immutable map of properties that are configured for this node.
properties() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
Cloud provider properties.
properties() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
Cloud store provider properties.
properties() - Method in interface io.hekate.core.ServiceInfo
Returns an immutable map of service properties.
property(String) - Method in interface io.hekate.cluster.ClusterNode
Returns value for the specified property name (see ClusterNode.properties()).
property(String) - Method in interface io.hekate.core.ServiceInfo
Returns the property value or null if there is no such property.
PropertyProvider - Interface in io.hekate.core
Provider of node properties for HekateBootstrap.
protocol() - Method in class io.hekate.network.netty.NettyClientFactory
 
protocol() - Method in interface io.hekate.network.NetworkConnector
Returns the protocol identifier of this connector.
protocol() - Method in interface io.hekate.network.NetworkEndpoint
Returns the protocol name of this endpoint.
provider() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
Cloud provider.
provider() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
Cloud store provider.
purge(ClusterNodeId, Set<ClusterNodeId>) - Method in class io.hekate.cluster.internal.gossip.Gossip
 

Q

queryTimeout() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Returns the JDBC query timeout in seconds.

R

random() - Method in interface io.hekate.cluster.ClusterTopology
Returns a random node of this topology.
random() - Static method in class io.hekate.messaging.loadbalance.LoadBalancers
Routes each message to a to randomly selected node.
RANDOM_PREFER_UNSEEN - Static variable in interface io.hekate.cluster.internal.gossip.GossipPolicy
 
RANDOM_UNSEEN - Static variable in interface io.hekate.cluster.internal.gossip.GossipPolicy
 
RANDOM_UNSEEN_NON_DOWN - Static variable in interface io.hekate.cluster.internal.gossip.GossipPolicy
 
range(int, int, int, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
RE_ROUTE - io.hekate.messaging.retry.RetryRoutingPolicy
Always preform re-routing.
readAddress(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads InetSocketAddress from the specified data input.
readBigDecimal() - Method in interface io.hekate.codec.DataReader
Reads BigDecimal value that wa written via DataWriter.writeBigDecimal(BigDecimal).
readBigDecimal(DataInput) - Static method in class io.hekate.codec.CodecUtils
readBigInteger() - Method in interface io.hekate.codec.DataReader
Reads BigInteger value that was written via DataWriter.writeBigInteger(BigInteger).
readBigInteger(DataInput) - Static method in class io.hekate.codec.CodecUtils
readClusterAddress(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads ClusterAddress from the specified data input.
readFrom(DataReader) - Static method in class io.hekate.messaging.MessageMetaData
Reads a MessageMetaData from the specified reader.
readMetaData() - Method in interface io.hekate.messaging.intercept.ClientReceiveContext
Reads the message's meta-data.
readMetaData() - Method in interface io.hekate.messaging.intercept.ServerReceiveContext
Reads the message's meta-data.
readNodeId(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads ClusterNodeId from the specified data input.
readTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Returns the Consul read timeout in milliseconds.
readTopologyHash(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads ClusterHash from the specified data input.
readVarInt() - Method in interface io.hekate.codec.DataReader
Reads a variable-length int value that was written via DataWriter.writeVarInt(int).
readVarInt(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads a value that was encoded via CodecUtils.writeVarInt(int, DataOutput).
readVarIntUnsigned() - Method in interface io.hekate.codec.DataReader
Reads an unsigned variable-length int value that was written via DataWriter.writeVarIntUnsigned(int).
readVarIntUnsigned(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads a value that was encoded via CodecUtils.writeVarIntUnsigned(int, DataOutput).
readVarLong() - Method in interface io.hekate.codec.DataReader
Reads a variable-length long value that was written via DataWriter.writeVarLong(long).
readVarLong(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads a value that was encoded via CodecUtils.writeVarLong(long, DataOutput).
readVarLongUnsigned() - Method in interface io.hekate.codec.DataReader
Reads an unsigned variable-length long value that was written via DataWriter.writeVarLongUnsigned(long).
readVarLongUnsigned(DataInput) - Static method in class io.hekate.codec.CodecUtils
Reads a value that was encoded via CodecUtils.writeVarLongUnsigned(long, DataOutput).
realReturnType() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the real return type of this method.
reason() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
Returns the reason of this event.
reason() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
receive(Message<T>) - Method in interface io.hekate.messaging.MessageReceiver
Called when a new message is received by this channel.
receiver() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Target node that was selected by the LoadBalancer.
region() - Method in annotation type io.hekate.spring.boot.lock.InjectLock
Specifies the name of a LockRegion that should be used to get the lock (see LockService.region(String)).
region(String) - Method in interface io.hekate.lock.LockService
Returns a lock region for the specified name.
regionName() - Method in interface io.hekate.lock.DistributedLock
Returns the name of the region this lock belongs to.
register(Object) - Method in interface io.hekate.core.jmx.JmxService
Registers the specified object as MXBean.
register(Object, String) - Method in interface io.hekate.core.jmx.JmxService
Registers the specified object as MXBean.
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Registered the specified addresses within this provider.
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
registerRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
reject(GossipProtocol.JoinRequest, String) - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
rejectAll() - Static method in interface io.hekate.messaging.retry.RetryErrorPredicate
Never retry.
rejectedAddress() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
rejectedBy() - Method in exception io.hekate.cluster.ClusterRejectedJoinException
Returns address of the node that rejected this node joining.
RejectedResponseException - Exception in io.hekate.messaging.operation
Signals that the result of a request operation was rejected by a RetryResponsePredicate.
RejectedResponseException(String, Object) - Constructor for exception io.hekate.messaging.operation.RejectedResponseException
Constructs new instance.
rejectReason() - Method in exception io.hekate.cluster.ClusterRejectedJoinException
Returns reject reason as it was returned by ClusterAcceptor.acceptJoin(ClusterNode, Hekate).
rejectType() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
rejoin() - Method in interface io.hekate.core.HekateFatalErrorContext
Triggers asynchronous termination and rejoining of Hekate node.
rejoin() - Static method in interface io.hekate.core.HekateFatalErrorPolicy
Rejoin upon any fatal error.
rejoin() - Method in interface io.hekate.core.service.InitializationContext
Instructs local node to asynchronously terminate and rejoin to the cluster.
remoteAddress() - Method in interface io.hekate.messaging.MessagingEndpoint
Returns the address of the remote cluster node.
remoteAddress() - Method in interface io.hekate.network.NetworkEndpoint
Returns the remote address of this endpoint.
remoteErrors() - Method in annotation type io.hekate.rpc.RpcAggregate
Remote errors handling policy (see description of RpcAggregate.RemoteErrors's values).
remoteErrors() - Method in annotation type io.hekate.rpc.RpcBroadcast
Remote errors handling policy (see description of RpcBroadcast.RemoteErrors's values).
remoteNodeId() - Method in interface io.hekate.messaging.MessagingEndpoint
Returns the universally unique identifier of the remote cluster node.
remoteNodes() - Method in interface io.hekate.cluster.ClusterTopology
Returns an immutable list of remote nodes within this topology ordered by their identifiers.
remoteStackTrace() - Method in exception io.hekate.messaging.MessagingRemoteException
Returns the stack trace of a remote failure.
removed() - Method in class io.hekate.cluster.event.ClusterChangeEvent
Returns the list of nodes that left the cluster.
removed() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
Returns the list of nodes that left the cluster.
removed() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
removed() - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
removed() - Method in class io.hekate.cluster.internal.gossip.GossipDigest
 
removeHandler(String) - Method in interface io.hekate.network.NetworkServer
Unregisters NetworkServerHandler with the specified protocol identifier and returns a list of NetworkEndpoints that were connected at the time of this operation.
removeListener(ClusterEventListener) - Method in interface io.hekate.cluster.ClusterView
Unregisters the cluster event listener.
removeListener(ClusterEventListener) - Method in class io.hekate.cluster.UpdatableClusterView
removeListener(ClusterEventListener) - Method in interface io.hekate.core.service.ClusterContext
Synchronously removes the specified cluster event listener.
removeListener(Hekate.LifecycleListener) - Method in interface io.hekate.core.Hekate
Removes lifecycle listener.
removeListener(LeaderChangeListener) - Method in interface io.hekate.election.FollowerContext
Unregisters the specified listener if it was previously registered via FollowerContext.addListener(LeaderChangeListener).
RendezvousHashMapper - Class in io.hekate.partition
Implementation of PartitionMapper that uses Rendezvous (aka Highest Random Weight) hashing algorithm for partition mapping.
RendezvousHashMapper.Builder - Class in io.hekate.partition
repeatAtFixedRate(RepeatingRunnable, long, long, TimeUnit) - Method in class io.hekate.util.async.ExtendedScheduledExecutor
Schedules the specified repeating command to be executed at fixed rate.
RepeatingRunnable - Interface in io.hekate.util.async
Repeatable task.
repeatWithFixedDelay(RepeatingRunnable, long, long, TimeUnit) - Method in class io.hekate.util.async.ExtendedScheduledExecutor
Schedules the specified repeating command to be executed with fixed delay.
reply(Object) - Method in interface io.hekate.coordinate.CoordinationRequest
Sends the response.
reply(T) - Method in interface io.hekate.messaging.Message
Asynchronously send back a reply and ignores the operation result.
reply(T, SendCallback) - Method in interface io.hekate.messaging.Message
Asynchronously sends a response and uses the specified callback for notification of the operation result.
report() - Method in class io.hekate.core.report.DefaultConfigReporter
Returns report.
report(ConfigReporter) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
report(ConfigReporter) - Method in class io.hekate.cluster.split.AddressReachabilityDetector
 
report(ConfigReporter) - Method in class io.hekate.cluster.split.HostReachabilityDetector
 
report(ConfigReporter) - Method in class io.hekate.cluster.split.JdbcConnectivityDetector
 
report(ConfigReporter) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
 
report(ConfigReporter) - Method in interface io.hekate.core.report.ConfigReportSupport
Report configuration.
report(ConfigReportSupport) - Static method in class io.hekate.core.report.DefaultConfigReporter
Returns a configuration report for the specified subject.
request() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the original request object that was submitted to the cluster.
request() - Method in interface io.hekate.messaging.operation.Response
Returns the request.
request(Class<P>) - Method in interface io.hekate.messaging.operation.Response
Casts the request of this message to the specified type.
request(Object, CoordinationRequestCallback) - Method in interface io.hekate.coordinate.CoordinationMember
Asynchronously send the specified request to this member.
request(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified request and awaits for a response.
request(T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified request and awaits for a response.
Request<T> - Interface in io.hekate.messaging.operation
Request operation.
REQUEST - io.hekate.messaging.intercept.OutboundType
Message is submitted as a Request operation.
requestAsync(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified request.
requestAsync(T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified request.
RequestCallback<T> - Interface in io.hekate.messaging.operation
Callback for a Request operation.
RequestFuture<T> - Class in io.hekate.messaging.operation
Asynchronous result of Request operation.
RequestFuture() - Constructor for class io.hekate.messaging.operation.RequestFuture
 
RequestRetryConfigurer<T> - Interface in io.hekate.messaging.operation
Configurer of RequestRetryPolicy.
RequestRetryPolicy<T> - Interface in io.hekate.messaging.operation
Retry policy for Request and Subscribe operations.
require(Class<T>) - Method in interface io.hekate.core.service.DependencyContext
Returns a reference to a required service.
REQUIRED - io.hekate.messaging.operation.AckMode
Require an acknowledgement.
resolve(DependencyContext) - Method in interface io.hekate.core.service.DependentService
Resolves dependencies of this service.
resolvePlaceholders(String) - Method in interface io.hekate.core.inject.PlaceholderResolver
Replaces property placeholders with real values in the provided String value.
ResourceLoadException - Exception in io.hekate.core.resource
Signals a resource loading error.
ResourceLoadException(String) - Constructor for exception io.hekate.core.resource.ResourceLoadException
Constructs new instance with the specified error message.
ResourceLoadException(String, Throwable) - Constructor for exception io.hekate.core.resource.ResourceLoadException
Constructs new instance with the specified error message and cause.
ResourceService - Interface in io.hekate.core.resource
Resources loading service.
ResourceServiceFactory - Class in io.hekate.core.resource
Factory for ResourceService.
ResourceServiceFactory() - Constructor for class io.hekate.core.resource.ResourceServiceFactory
 
response() - Method in exception io.hekate.messaging.operation.RejectedResponseException
Returns the rejected reply message.
response() - Method in interface io.hekate.messaging.operation.Request
Synchronously executes this operation and returns the response's payload.
response(Class<R>) - Method in interface io.hekate.messaging.operation.Request
Synchronously executes this operation and returns the response.
Response<T> - Interface in io.hekate.messaging.operation
Response of a Request operation.
RESPONSE_CHUNK - io.hekate.messaging.intercept.InboundType
Chunk of a bigger response (see Message.partialReply(Object, SendCallback)).
ResponsePart<T> - Interface in io.hekate.messaging.operation
Partial response of a Subscribe operation.
responses() - Method in interface io.hekate.messaging.operation.Subscribe
Synchronously collects all response chunks.
result() - Method in class io.hekate.messaging.operation.RequestFuture
Awaits for this operation to complete and returns the payload of the response.
result(Class<V>) - Method in class io.hekate.messaging.operation.RequestFuture
Awaits for this operation to complete and returns the payload of the response.
resultOf(ClusterNode) - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the result for the specified cluster node or null if there was no result from this node.
results() - Method in interface io.hekate.messaging.operation.Aggregate
Synchronously executes this operation and returns the result.
results() - Method in class io.hekate.messaging.operation.AggregateFuture
Awaits for the asynchronous aggregation to complete and returns the AggregateResult.results() result}.
results() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the aggregation results.
results(Class<V>) - Method in class io.hekate.messaging.operation.AggregateFuture
Awaits for the asynchronous aggregation to complete and returns the AggregateResult.results() result}.
resultsByNode() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns a map of cluster nodes and results that were successfully received from these nodes.
resumeReceiving(Consumer<NetworkEndpoint<T>>) - Method in interface io.hekate.network.NetworkEndpoint
Resumes receiving of messages from a remote peer.
retry() - Method in interface io.hekate.network.NetworkServerFailure
Resolves this failure to be recoverable.
retry() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the error retry policy of this method based on the RpcRetry annotation attributes.
RETRY_SAME_NODE - io.hekate.messaging.retry.RetryRoutingPolicy
Do not try to re-route and always use the same node.
retryAddress() - Method in interface io.hekate.network.NetworkServerFailure.Resolution
Returns a new address that the server should try during its failover actions.
RetryBackoffPolicy - Interface in io.hekate.messaging.retry
Backoff policy.
RetryCallback - Interface in io.hekate.messaging.retry
Callback for receiving retry notifications.
RetryCondition - Interface in io.hekate.messaging.retry
Condition to retry an operation.
retryDelay() - Method in interface io.hekate.network.NetworkServerFailure.Resolution
Returns the amount of time in milliseconds for server to wait before performing another failover attempt.
RetryErrorPredicate - Interface in io.hekate.messaging.retry
Predicate to test if particular error should be retried.
retryLater(ClusterAddress, ClusterAddress, InetSocketAddress) - Static method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
RetryPolicy<P extends RetryPolicy<P>> - Interface in io.hekate.messaging.retry
Base interface for retry policies.
RetryResponsePredicate<T> - Interface in io.hekate.messaging.retry
Predicate to test if particular response should be retried.
RetryResponseSupport<T,​P extends RetryResponseSupport<T,​P>> - Interface in io.hekate.messaging.retry
Template interface for policies that can retry upon an unexpected response.
RetryRoutingPolicy - Enum in io.hekate.messaging.retry
Routing behavior in case of a retry action.
RetryRoutingSupport<P extends RetryRoutingSupport<P>> - Interface in io.hekate.messaging.retry
Template interface for policies that can re-route operations upon retry.
revision() - Static method in class io.hekate.core.HekateVersion
Returns GIT commit id.
roles() - Method in interface io.hekate.cluster.ClusterNode
Returns the immutable set of roles that are configured for this node.
route(RetryRoutingPolicy) - Method in interface io.hekate.messaging.retry.RetryRoutingSupport
Routing policy in case of a retry.
route(T, LoadBalancerContext) - Method in class io.hekate.messaging.loadbalance.DefaultLoadBalancer
 
route(T, LoadBalancerContext) - Method in interface io.hekate.messaging.loadbalance.LoadBalancer
Selects one of the cluster nodes from the load balancer context.
routing() - Method in interface io.hekate.messaging.retry.FailedAttempt
Returns the routing policy.
rpc() - Method in interface io.hekate.core.Hekate
Returns the RpcService.
rpc() - Method in class io.hekate.rpc.RpcServerInfo
Returns the RPC server object.
Rpc - Annotation Type in io.hekate.rpc
Marker annotation for RPC interfaces.
RpcAffinityKey - Annotation Type in io.hekate.rpc
Affinity key for RPC operations.
RpcAggregate - Annotation Type in io.hekate.rpc
Enables aggregation on RPC interface's methods.
RpcAggregate.RemoteErrors - Enum in io.hekate.rpc
Remote errors handling policy for RPC aggregation.
RpcAggregateException - Exception in io.hekate.rpc
Signals that there was a failure while performing an RPC aggregation request.
RpcAggregateException(String, Map<ClusterNode, Throwable>, Map<ClusterNode, Object>) - Constructor for exception io.hekate.rpc.RpcAggregateException
Constructs a new instance.
RpcBroadcast - Annotation Type in io.hekate.rpc
Enables broadcast on RPC interface's methods.
RpcBroadcast.RemoteErrors - Enum in io.hekate.rpc
Remote errors handling policy for RPC aggregation.
RpcClientBean<T> - Class in io.hekate.spring.bean.rpc
Imports RPC client proxy into the Spring context.
RpcClientBean() - Constructor for class io.hekate.spring.bean.rpc.RpcClientBean
 
RpcClientBuilder<T> - Interface in io.hekate.rpc
Builder for RPC client proxies.
RpcClientConfig - Class in io.hekate.rpc
RPC client configuration.
RpcClientConfig() - Constructor for class io.hekate.rpc.RpcClientConfig
 
RpcClientConfigProvider - Interface in io.hekate.rpc
Provider of RPC clients configuration.
RpcException - Exception in io.hekate.rpc
Generic error that signals an RPC operation failure.
RpcException(String) - Constructor for exception io.hekate.rpc.RpcException
Constructs a new instance.
RpcException(String, Throwable) - Constructor for exception io.hekate.rpc.RpcException
Constructs a new instance.
rpcInterface() - Method in interface io.hekate.rpc.RpcRequest
Returns the RPC interface.
RpcInterfaceInfo<T> - Class in io.hekate.rpc
Meta-information about an Rpc-annotated interface.
RpcInterfaceInfo(Class<T>, int, int, List<RpcMethodInfo>) - Constructor for class io.hekate.rpc.RpcInterfaceInfo
Constructs a new instance.
RpcLoadBalancer - Interface in io.hekate.rpc
Client-side load balancer for RPC requests.
RpcMethodInfo - Class in io.hekate.rpc
Meta-information about RPC method.
RpcMethodInfo(Method, PlaceholderResolver) - Constructor for class io.hekate.rpc.RpcMethodInfo
Constructs a new instance.
RpcRequest - Interface in io.hekate.rpc
RPC request for load balancing.
RpcRetry - Annotation Type in io.hekate.rpc
Marker annotation to enable retrying of failed RPC invocations.
RpcRetryInfo - Class in io.hekate.rpc
Meta-information about RPC retry setting.
RpcServerConfig - Class in io.hekate.rpc
RPC server configuration.
RpcServerConfig() - Constructor for class io.hekate.rpc.RpcServerConfig
 
RpcServerConfigProvider - Interface in io.hekate.rpc
Provider of RPC servers configuration.
RpcServerInfo - Class in io.hekate.rpc
Provides information about the RPC server configuration.
RpcServerInfo(Object, Collection<RpcInterfaceInfo<?>>, Collection<String>) - Constructor for class io.hekate.rpc.RpcServerInfo
Constructs a new instance.
RpcServerJmx - Interface in io.hekate.rpc
JMX interface for RpcServerConfig.
rpcService() - Method in class io.hekate.spring.boot.rpc.HekateRpcServiceConfigurer
Returns the factory bean that makes it possible to inject RpcService directly into other beans instead of accessing it via Hekate.rpc() method.
RpcService - Interface in io.hekate.rpc
« start hereMain entry point to Remote Procedure Call (RPC) API.
RpcServiceBean - Class in io.hekate.spring.bean.rpc
Imports RpcService into the Spring context.
RpcServiceBean() - Constructor for class io.hekate.spring.bean.rpc.RpcServiceBean
 
rpcServiceFactory() - Method in class io.hekate.spring.boot.rpc.HekateRpcServiceConfigurer
Constructs the RpcServiceFactory.
RpcServiceFactory - Class in io.hekate.rpc
Factory for RpcService.
RpcServiceFactory() - Constructor for class io.hekate.rpc.RpcServiceFactory
 
RpcSplit - Annotation Type in io.hekate.rpc
Marks one of an RPC method's parameters as being eligible for splitting and parallel processing.
rpcTag() - Method in interface io.hekate.rpc.RpcRequest
Returns the RPC interface tag.
rpcVersion() - Method in interface io.hekate.rpc.RpcRequest
Returns the RPC interface version.
run() - Method in interface io.hekate.util.async.RepeatingRunnable
Runs this task.
run() - Method in interface io.hekate.util.StateGuard.GuardedRunnable
Runs this task.
runAtAllCost(EventLoop, Runnable) - Static method in class io.hekate.network.netty.NettyUtils
Executes the task using the provided event loop or falls back to AsyncUtils.fallbackExecutor() if event loop is already shut down.
runtime() - Method in interface io.hekate.cluster.ClusterNode
Returns information about the JVM of this node.

S

SAME - io.hekate.cluster.internal.gossip.GossipPrecedence
 
section(String) - Method in interface io.hekate.core.report.ConfigReporter
Creates a new sub-section of this report.
section(String) - Method in class io.hekate.core.report.DefaultConfigReporter
 
section(String, Consumer<ConfigReporter>) - Method in interface io.hekate.core.report.ConfigReporter
Applies the given consumer to a sub-section of this report.
SeedNodeProvider - Interface in io.hekate.cluster.seed
« start hereSeed node provider.
SeedNodeProviderGroup - Class in io.hekate.cluster.seed
Group of SeedNodeProviders.
SeedNodeProviderGroup(SeedNodeProviderGroupConfig) - Constructor for class io.hekate.cluster.seed.SeedNodeProviderGroup
Constructs a new instance.
seedNodeProviderGroupConfig() - Method in class io.hekate.spring.boot.cluster.HekateClusterServiceConfigurer
Constructs a group configuration of all SeedNodeProviders that were found in the application context.
SeedNodeProviderGroupConfig - Class in io.hekate.cluster.seed
Configuration options for SeedNodeProviderGroup.
SeedNodeProviderGroupConfig() - Constructor for class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
 
SeedNodeProviderGroupPolicy - Enum in io.hekate.cluster.seed
Error handling policy for SeedNodeProviderGroup.
seen() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
seen() - Method in class io.hekate.cluster.internal.gossip.GossipBase
 
seen() - Method in class io.hekate.cluster.internal.gossip.GossipDigest
 
seen(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
seen(Collection<ClusterNodeId>) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
select() - Method in class io.hekate.network.address.AddressPattern
 
select() - Method in interface io.hekate.network.address.AddressSelector
Resolves the IP address for the local node.
selected() - Method in class io.hekate.codec.AutoSelectCodecFactory
Returns the selected factory.
selectNodes(int, GossipNodeState, List<GossipNodeState>, Set<ClusterNodeId>) - Method in interface io.hekate.cluster.internal.gossip.GossipPolicy
 
selectSql() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
Returns the SQL string for selecting records from the seed nodes table.
send(GossipProtocol.GossipMessage, Runnable) - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
send(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified message and awaits for an acknowledgement.
send(Object, T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified message with the specified acknowledgement mode.
send(T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified message and awaits for an acknowledgement.
send(T) - Method in interface io.hekate.network.NetworkEndpoint
Asynchronously sends the specified message.
send(T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified message with the specified acknowledgement mode.
send(T, NetworkSendCallback<T>) - Method in interface io.hekate.network.NetworkEndpoint
Asynchronously sends the specified message and notifies the specified callback on operation result.
Send<T> - Interface in io.hekate.messaging.operation
Send operation.
SEND_NO_ACK - io.hekate.messaging.intercept.OutboundType
Message is submitted as a Send operation with Send.withAckMode(AckMode) set to AckMode.NOT_NEEDED.
SEND_WITH_ACK - io.hekate.messaging.intercept.OutboundType
Message is submitted as a Send operation with Send.withAckMode(AckMode) set to AckMode.REQUIRED.
sendAndDisconnect(GossipProtocol) - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
sendAsync(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified message with a mandatory acknowledgement.
sendAsync(Object, T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified message with the specified acknowledgement mode.
sendAsync(T) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified message with a mandatory acknowledgement.
sendAsync(T, AckMode) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified message with the specified acknowledgement mode.
SendCallback - Interface in io.hekate.messaging.operation
Callback for a Send operation.
SendFuture - Class in io.hekate.messaging.operation
Asynchronous result of Send operation.
SendFuture() - Constructor for class io.hekate.messaging.operation.SendFuture
 
SendRetryConfigurer - Interface in io.hekate.messaging.operation
Configurer of SendRetryPolicy.
SendRetryPolicy - Interface in io.hekate.messaging.operation
Retry policy for Send operations.
server() - Method in interface io.hekate.core.jmx.JmxService
Returns the MBean server.
ServerInboundContext<T> - Interface in io.hekate.messaging.intercept
Server's inbound message context.
ServerMessageInterceptor<T> - Interface in io.hekate.messaging.intercept
Server-side message interceptor.
ServerReceiveContext<T> - Interface in io.hekate.messaging.intercept
Server's receive context.
servers() - Method in interface io.hekate.rpc.RpcService
Returns an immutable list of all RPC servers registered on this node.
ServerSendContext<T> - Interface in io.hekate.messaging.intercept
Server's outbound message context.
service(Class<? extends Service>) - Method in interface io.hekate.cluster.ClusterNode
Returns the service information for the specified type.
service(Class<T>) - Method in class io.hekate.core.HekateBootstrap
Finds a service factory of the specified type (see HekateBootstrap.setServices(List)).
Service - Interface in io.hekate.core.service
« start hereEntry point to core API of Hekate services.
ServiceDependencyException - Exception in io.hekate.core.service
Signals a dependency resolution failure in DependentService.
ServiceDependencyException(String) - Constructor for exception io.hekate.core.service.ServiceDependencyException
Constructs new instance with the specified error message.
ServiceFactory<T extends Service> - Interface in io.hekate.core.service
Factory for services.
ServiceInfo - Interface in io.hekate.core
Provides information about a service.
ServiceProperty<T> - Class in io.hekate.core
Property of ServiceInfo.
ServiceProperty.Type - Enum in io.hekate.core
Service property type.
services() - Method in interface io.hekate.cluster.ClusterNode
Returns the immutable map of services that are provided by this node, with the service type as the key.
services() - Method in interface io.hekate.core.Hekate
Returns types of all registered services.
sessionTimeout() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
Zookeeper session timeout.
set(MessageMetaData.Key<T>, T) - Method in class io.hekate.messaging.MessageMetaData
Sets the key/value pair.
setAcceptorEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerFactory
Sets the event loop group that will be responsible for accepting new connections.
setAcceptors(List<ClusterAcceptor>) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the list of the cluster join acceptors.
setAcceptRetryInterval(long) - Method in class io.hekate.network.NetworkServiceFactory
Sets the number of milliseconds to wait before trying to re-create a TCP socket acceptor in case of its failure.
setAclToken(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Sets ACL token to access Consul.
setAddresses(List<String>) - Method in class io.hekate.cluster.seed.StaticSeedNodeProviderConfig
Sets the list of addresses.
setApplicationContext(ApplicationContext) - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
setAsyncInit(boolean) - Method in class io.hekate.coordinate.CoordinationProcessConfig
Sets the flag that controls the timing of initial coordination.
setAttachment(Object) - Method in interface io.hekate.coordinate.CoordinationContext
Sets the user-defined object that should be attached to this context.
setAttribute(String, Object) - Method in interface io.hekate.core.Hekate
Sets the attribute that should be associated with this Hekate instance.
setAttribute(String, Object) - Method in interface io.hekate.messaging.intercept.ClientSendContext
Sets an attribute of this context.
setAttribute(String, Object) - Method in interface io.hekate.messaging.intercept.ServerReceiveContext
Sets an attribute of this context.
setAutoAccept(boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the flag indicating whether server should automatically start accepting client connections or if it should be done manually.
setBackPressure(MessagingBackPressureConfig) - Method in class io.hekate.messaging.MessagingConfigBase
Sets the back pressure configuration.
setBackupNodes(int) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the amount of backup nodes that should be assigned to each partition by the the channel's partition mapper.
setBackupNodes(int) - Method in class io.hekate.rpc.RpcClientConfig
Sets the amount of backup nodes that should be assigned to each partition by the the RPC client's partition mapper.
setBasePath(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Sets the base path to store seed nodes information in Consul.
setBasePath(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Sets the base path to store seed nodes information in Etcd.
setBasePath(String) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Sets the base path to store seed nodes information in ZooKeeper.
setBeanFactory(BeanFactory) - Method in class io.hekate.spring.bean.HekateBaseBean
 
setBoolProperty(String, boolean) - Method in interface io.hekate.core.service.ConfigurationContext
Adds the specified service property.
setCacheUnknownTypes(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the flag that controls the behavior of unmapped classes caching.
setCandidate(Candidate) - Method in class io.hekate.election.CandidateConfig
Sets the leader election candidate that should be notified upon group leader election results.
setCandidates(List<CandidateConfig>) - Method in class io.hekate.election.ElectionServiceFactory
Sets the list of election candidate configurations that should be automatically registered during the leader election service startup.
setChannel(String) - Method in class io.hekate.spring.bean.messaging.MessagingChannelBean
Sets the channel name.
setChannels(List<MessagingChannelConfig<?>>) - Method in class io.hekate.messaging.MessagingServiceFactory
Sets the list of channel configurations that should be registered to the MessagingService.
setCleanupInterval(int) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setCleanupInterval(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setCleanupInterval(long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setCleanupInterval(long) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setCleanupInterval(long) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setCleanupInterval(long) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the time interval in milliseconds between stale node cleanup runs.
setClientProviders(List<RpcClientConfigProvider>) - Method in class io.hekate.rpc.RpcServiceFactory
Sets the list of RPC client configuration providers.
setClients(List<RpcClientConfig>) - Method in class io.hekate.rpc.RpcServiceFactory
Sets the list of RPC client configurations.
setClusterFilter(ClusterNodeFilter) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the cluster node filter that should be used to filter nodes during the the message sending.
setClusterListeners(List<ClusterEventListener>) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets a list of cluster event listeners to be notified upon ClusterEvent.
setCodecFactory(CodecFactory<T>) - Method in class io.hekate.network.netty.NettyClientFactory
Sets codec factory that should be used for messages serialization.
setCodecFactory(CodecFactory<T>) - Method in class io.hekate.network.NetworkServerHandlerConfig
Sets the codec factory that should be used for messages serialization.
setConfigProviders(List<CoordinationConfigProvider>) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Sets the list of coordination process configuration providers.
setConfigProviders(List<CandidateConfigProvider>) - Method in class io.hekate.election.ElectionServiceFactory
Sets the list of leader election configuration providers.
setConfigProviders(List<LockConfigProvider>) - Method in class io.hekate.lock.LockServiceFactory
Sets the list of lock region configuration providers.
setConfigProviders(List<MessagingConfigProvider>) - Method in class io.hekate.messaging.MessagingServiceFactory
Sets the list of channel configuration providers.
setConfigProviders(List<NetworkConfigProvider>) - Method in class io.hekate.network.NetworkServiceFactory
Sets the list of connector configuration providers.
setConfigReport(boolean) - Method in class io.hekate.core.HekateBootstrap
true if the configuration report should be logged during node initialization.
setConnectionString(String) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Set the list of ZooKeeper servers to connect to.
setConnectors(List<NetworkConnectorConfig<?>>) - Method in class io.hekate.network.NetworkServiceFactory
Sets the list of connector configurations that should be registered within the NetworkService.
setConnectTimeout(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Sets the ZooKeeper connection timeout in milliseconds.
setConnectTimeout(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets the timeout in milliseconds for establishing a TCP socket connection to a remote node.
setConnectTimeout(Integer) - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
Sets the connect timeout in milliseconds.
setConnectTimeout(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the timeout in milliseconds for establishing a TCP socket connection to a remote node.
setConnectTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Set the connect timeout value in milliseconds.
setContainer(String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Returns the name of a BlobStore container (f.e.
setContainerPortName(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Sets the port name of a Pod's container.
setContext(Object) - Method in interface io.hekate.messaging.MessagingEndpoint
Sets the custom context object that should be associated with this endpoint.
setContext(Object) - Method in interface io.hekate.network.NetworkEndpoint
Sets the custom user context object that should be associated with this endpoint.
setCredential(String) - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
Sets the credential.
setCredentials(CredentialsSupplier) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the supplier of credentials for ComputeService.
setCredentials(CredentialsSupplier) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Sets the supplier of BlobStore credentials.
setDataSource(DataSource) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the data source.
setDefaultCodec(CodecFactory<Object>) - Method in class io.hekate.core.HekateBootstrap
Sets the codec factory that should be used by the CodecService.
setDefaultSerializers(Map<Class<?>, Serializer<?>>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the map of default serializer.
setDeferredJoin(boolean) - Method in class io.hekate.spring.bean.HekateSpringBootstrap
Sets the flag indicating that Hekate node should not join the cluster during the Spring context initialization.
setDetectors(List<SplitBrainDetector>) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
Sets the list of detectors that should be invoked during each SplitBrainDetectorGroup.isValid(ClusterNode) check.
setDisableHeartbeats(boolean) - Method in class io.hekate.network.netty.NettyServerFactory
Enabled/disabled heartbeats support.
setDomain(String) - Method in class io.hekate.core.jmx.JmxServiceFactory
Sets the JMX domain.
setEmbeddedValueResolver(StringValueResolver) - Method in class io.hekate.spring.bean.HekateSpringBootstrap
 
setEndpoint(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the ComputeService endpoint (f.e "https://ec2.us-east-1.amazonaws.com").
setEndpoints(List<String>) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Sets the list of Etcd endpoint addresses.
setEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the event loop group.
setEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerHandlerConfig
Sets the event loop to be used by this handler.
setExitHandler(Jvm.ExitHandler) - Static method in class io.hekate.core.internal.util.Jvm
Configures the exit handler.
setFailFast(boolean) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Sets the flag that controls the failure detection behavior in case of network connectivity issues between the cluster nodes.
setFailureDetectionQuorum(int) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Sets the amount of nodes that should agree on some particular node failure before removing such a suspected node from the cluster.
setFailureDetector(FailureDetector) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the failure detector that should be used for health checking of remote nodes.
setFatalErrorPolicy(HekateFatalErrorPolicy) - Method in class io.hekate.core.HekateBootstrap
Sets the fatal error handling policy.
setGlobalInterceptors(List<MessageInterceptor>) - Method in class io.hekate.messaging.MessagingServiceFactory
Sets the list of message interceptors that should be applied to all channels.
setGossipInterval(long) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the time interval in milliseconds between gossip rounds.
setGroup(String) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the multicast group address.
setGroup(String) - Method in class io.hekate.election.CandidateConfig
Sets the election group name.
setGroupPolicy(SplitBrainDetectorGroup.GroupPolicy) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
Sets the group policy.
setHandler(CoordinationHandler) - Method in class io.hekate.coordinate.CoordinationProcessConfig
Sets the coordination process handler.
setHandler(NetworkServerHandler<T>) - Method in class io.hekate.network.NetworkServerHandlerConfig
Sets the handler.
setHandler(Object) - Method in class io.hekate.rpc.RpcServerConfig
Sets the RPC handler.
setHandlers(List<NettyServerHandlerConfig<?>>) - Method in class io.hekate.network.netty.NettyServerFactory
Sets the list of server connection handlers.
setHeartbeatInterval(int) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the heartbeat sending interval in milliseconds for keeping a TCP socket connection alive.
setHeartbeatInterval(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets the heartbeat sending interval in milliseconds for keeping a TCP socket connection alive.
setHeartbeatInterval(long) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Sets the heartbeat sending interval in milliseconds.
setHeartbeatLossThreshold(int) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
Sets the amount of heartbeats that can be lost before considering a node failure.
setHeartbeatLossThreshold(int) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the maximum number of lost heartbeats before considering a TCP connection to be failed.
setHeartbeatLossThreshold(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets the maximum number of lost heartbeats before considering a TCP connection to be failed.
setHost(String) - Method in class io.hekate.network.NetworkServiceFactory
Sets the host address selection pattern (see AddressPattern).
setHostColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the host column name.
setHostSelector(AddressSelector) - Method in class io.hekate.network.NetworkServiceFactory
Sets the host address selector that will be used to select an address of the local cluster node.
setIdentity(String) - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
Sets the identity.
setIdleSocketTimeout(long) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Sets idle socket timeout in milliseconds.
setIdleSocketTimeout(long) - Method in class io.hekate.messaging.MessagingConfigBase
Sets idle socket timeout in milliseconds.
setIdleSocketTimeout(long) - Method in class io.hekate.network.NetworkConnectorConfig
Sets the timeout in milliseconds for NetworkClients to stay idle before being automatically disconnected.
setIdleTimeout(long) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the timeout in milliseconds for NetworkClients to stay idle before being automatically disconnected.
setInHighWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
Sets the high watermark of inbound (receiving) queue size.
setInLowWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
Sets the low watermark of inbound (receiving) queue size.
setInstantiatorStrategy(InstantiatorStrategy) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets instantiator strategy.
setInterceptors(List<MessageInterceptor>) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the list of message interceptors that should be used by the channel.
setInterval(long) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the time interval in milliseconds between discovery messages multicasting.
setIntProperty(String, int) - Method in interface io.hekate.core.service.ConfigurationContext
Adds the specified service property.
setKeyStoreAlgorithm(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the keystore algorithm.
setKeyStorePassword(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the keystore password.
setKeyStorePath(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the path to the keystore file.
setKeyStoreType(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the keystore type.
setKnownTypes(List<Class<?>>) - Method in class io.hekate.codec.fst.FstCodecFactory
Sets the list of known Java types.
setKnownTypes(List<Class<?>>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the list of known Java types.
setLifecycleListeners(List<Hekate.LifecycleListener>) - Method in class io.hekate.core.HekateBootstrap
Sets the list of Hekate lifecycle listeners.
setLoadBalancer(LoadBalancer<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the load balancer that should be used by the MessagingChannel.
setLoadBalancer(RpcLoadBalancer) - Method in class io.hekate.rpc.RpcClientConfig
Sets the RPC load balancer.
setLogCategory(String) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the logging category that should be used by the channel.
setLogCategory(String) - Method in class io.hekate.network.NetworkConnectorConfig
Sets the log category that should be used by the connector.
setLoggerCategory(String) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the log category that should be used by NetworkClients.
setLoggerCategory(String) - Method in class io.hekate.network.NetworkServerHandlerConfig
Sets the logger category that should be used by NetworkServerHandler.
setLongProperty(String, long) - Method in interface io.hekate.core.service.ConfigurationContext
Adds the specified service property.
setLoopBackDisabled(boolean) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the flag indicating whether receiving of multicast messages on the loop back address should be disabled or enabled.
setMasterUrl(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Sets the URL of Kubernetes API server.
setMessageCodec(CodecFactory<Object>) - Method in class io.hekate.coordinate.CoordinationProcessConfig
Sets the codec that should be used for messages serialization.
setMessageCodec(CodecFactory<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the codec factory to be used for messages serialization/deserialization by this channel.
setMessageCodec(CodecFactory<T>) - Method in class io.hekate.network.NetworkConnectorConfig
Sets codec factory that should be used for messages serialization.
setMessagingTimeout(long) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the timeout in milliseconds that should be applied to all messaging operations of this channel.
setMetrics(NettyMetricsFactory) - Method in class io.hekate.network.netty.NettyServerFactory
Sets the metrics factory.
setMetrics(NettyMetricsSink) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the metrics sink.
setMetrics(MeterRegistry) - Method in class io.hekate.core.HekateBootstrap
Sets the metrics registry.
setName(String) - Method in class io.hekate.coordinate.CoordinationProcessConfig
Sets the coordination process name.
setName(String) - Method in class io.hekate.lock.LockRegionConfig
Sets the lock region name.
setName(String) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the channel name.
setName(String) - Method in class io.hekate.spring.bean.lock.LockBean
Sets the lock name.
setNamespace(String) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the cluster namespace.
setNamespace(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Sets the Kubernetes namespace.
setNamespaceColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the cluster column name.
setNioThreads(int) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Sets the size of a thread pool for handling NIO-based socket connections.
setNioThreads(int) - Method in class io.hekate.lock.LockServiceFactory
Sets the size of a thread pool for handling NIO-based network communications.
setNioThreads(int) - Method in class io.hekate.messaging.MessagingConfigBase
Sets the size of a thread pool for handling NIO-based socket connections.
setNioThreads(int) - Method in class io.hekate.network.NetworkConnectorConfig
Sets the thread pool size that should be used for NIO events processing.
setNioThreads(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets the number of threads to be used for NIO event processing.
setNodeName(String) - Method in class io.hekate.core.HekateBootstrap
Sets the node name.
setOutHighWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
Sets the high watermark of outbound (sending) queue size.
setOutLowWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
Sets the low watermark of outbound (sending) queue size.
setOutOverflowPolicy(MessagingOverflowPolicy) - Method in class io.hekate.messaging.MessagingBackPressureConfig
Sets the policy that should be applied when MessagingChannel's outbound (sending) queue size exceeds the limit.
setPartitions(int) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the total amount of partitions that should be managed by the channel's partition mapper.
setPartitions(int) - Method in class io.hekate.rpc.RpcClientConfig
Sets the total amount of partitions that should be managed by the RPC client's partition mapper.
setPassword(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Sets the Etcd password.
setPlugins(List<Plugin>) - Method in class io.hekate.core.HekateBootstrap
Sets the list of plugins that should run within the local node.
setPolicy(SeedNodeProviderGroupPolicy) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
Sets the error handling policy for this group.
setPort(int) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the multicast port.
setPort(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets port number that will be used by the local node to accept network connections.
setPortColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the port column name.
setPortRange(int) - Method in class io.hekate.network.NetworkServiceFactory
Sets maximum value that can be used for port auto-incrementing.
setProcesses(List<CoordinationProcessConfig>) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Sets the list of coordination process configurations that should be automatically registered during the coordination service startup.
setProperties(Map<String, String>) - Method in class io.hekate.core.HekateBootstrap
Sets node's properties.
setProperties(Properties) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the ComputeService provider-specific properties.
setProperties(Properties) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Sets the BlobStore provider-specific properties.
setPropertyProviders(List<PropertyProvider>) - Method in class io.hekate.core.HekateBootstrap
Sets the list of node property providers.
setProtocol(String) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the protocol identifier.
setProtocol(String) - Method in class io.hekate.network.NetworkConnectorConfig
Sets the connector's protocol identifier.
setProtocol(String) - Method in class io.hekate.network.NetworkServerHandlerConfig
Sets the connector protocol identifier.
setProtocol(String) - Method in class io.hekate.spring.bean.network.NetworkConnectorBean
Sets the protocol name.
setProvider(NetworkSslConfig.Provider) - Method in class io.hekate.network.NetworkSslConfig
Sets the SSL provider.
setProvider(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the name of a ComputeService provider (f.e.
setProvider(String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
Sets the name of a BlobStore provider (f.e "aws-s3").
setProviders(List<SeedNodeProvider>) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
Sets the list of providers for this group.
setQueryTimeout(int) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the JDBC query timeout value in seconds.
setReadTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Set the read timeout value in milliseconds.
setReceiver(MessageReceiver<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the message receiver that should be used to handle incoming messages.
setReferences(Boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the value that should override the Kryo.setReferences(boolean) flag.
setRegion(String) - Method in class io.hekate.spring.bean.lock.LockBean
Sets the name of a lock region.
setRegion(String) - Method in class io.hekate.spring.bean.lock.LockRegionBean
Sets the name of a lock region that should imported into a Spring context.
setRegions(List<LockRegionConfig>) - Method in class io.hekate.lock.LockServiceFactory
Sets the list of lock region configurations that should be registered to the LockService.
setRegions(Set<String>) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the set of regions to search for seed nodes (f.e.
setRegistrationRequired(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the flag indicating that all serializable classes must be registered via KryoCodecFactory.setKnownTypes(List).
setRetryInterval(long) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Sets the time interval in milliseconds between retry attempts in case of network communication failures.
setRetryInterval(long) - Method in class io.hekate.lock.LockServiceFactory
Sets the time interval in milliseconds between retry attempts in case of network communication failures.
setRetryPolicy(GenericRetryConfigurer) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the generic retry policy to be applied to all messaging operations of this channel.
setRetryPolicy(GenericRetryConfigurer) - Method in class io.hekate.rpc.RpcClientConfig
Sets the generic retry policy.
setRoles(List<String>) - Method in class io.hekate.core.HekateBootstrap
Sets node's roles.
setRpcInterface(Class<?>) - Method in class io.hekate.rpc.RpcClientConfig
Sets the RPC interface.
setRpcInterface(Class<T>) - Method in class io.hekate.spring.bean.rpc.RpcClientBean
Sets the RPC service interface.
setSeedNodeProvider(SeedNodeProvider) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets seed node provider that should be used to discover existing cluster nodes when local node starts joining to a cluster.
setSerializers(Map<Class<?>, Serializer<?>>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Sets the map of custom serializers.
setServer(MBeanServer) - Method in class io.hekate.core.jmx.JmxServiceFactory
Sets the MBean server that should be used by the JmxService to register JMX beans.
setServerHandler(NetworkServerHandler<T>) - Method in class io.hekate.network.NetworkConnectorConfig
Sets the server handler that should be used to accept connections and process messages from remote connectors.
setServerProviders(List<RpcServerConfigProvider>) - Method in class io.hekate.rpc.RpcServiceFactory
Sets the list of RPC server configuration providers.
setServers(List<RpcServerConfig>) - Method in class io.hekate.rpc.RpcServiceFactory
Sets the list of RPC server configurations.
setServices(List<ServiceFactory<? extends Service>>) - Method in class io.hekate.core.HekateBootstrap
Sets the list of services that should be provided by the local node.
setSessionTimeout(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
Sets the ZooKeeper session timeout in milliseconds.
setSharedReferences(Boolean) - Method in class io.hekate.codec.fst.FstCodecFactory
Sets the value that should override the FSTConfiguration.setShareReferences(boolean) flag.
setSoBacklog(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the maximum number of pending connections that can be queued on the server socket channel (see ServerSocketChannel.bind(SocketAddress, int) for more details).
setSoReceiveBufferSize(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the size of the socket receive buffer in bytes (see StandardSocketOptions.SO_RCVBUF for more details).
setSoReceiveBufferSize(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the size of the socket receive buffer in bytes (see StandardSocketOptions.SO_RCVBUF for more details).
setSoReuseAddress(Boolean) - Method in class io.hekate.network.netty.NettyClientFactory
Sets flag indicating that socket addresses should be re-used (see StandardSocketOptions.SO_REUSEADDR for more details).
setSoReuseAddress(Boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets flag indicating that socket addresses should be re-used (see StandardSocketOptions.SO_REUSEADDR for more details).
setSoSendBufferSize(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the size of the socket send buffer in bytes (see StandardSocketOptions.SO_SNDBUF for more details).
setSoSendBufferSize(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the size of the socket send buffer in bytes (see StandardSocketOptions.SO_SNDBUF for more details).
setSoTimeout(Integer) - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
Sets the response read timeout in milliseconds.
setSource(Hekate) - Method in class io.hekate.spring.bean.HekateBaseBean
Sets the Hekate instance that will be used as a source of imported components and services.
setSpeedUpGossipSize(int) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the maximum amount of nodes in the cluster for the gossip protocol to speed up by sending messages at a higher rate so that the cluster could converge faster.
setSplitBrainCheckInterval(long) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the time interval in milliseconds for split-brain checking.
setSplitBrainDetector(SplitBrainDetector) - Method in class io.hekate.cluster.ClusterServiceFactory
Sets the cluster split-brain detector.
setSsl(NetworkSslConfig) - Method in class io.hekate.network.NetworkServiceFactory
Sets the SSL configuration.
setSsl(SslContext) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the SSL context that should be used to secure all network communications.
setSsl(SslContext) - Method in class io.hekate.network.netty.NettyServerFactory
Sets the SSL context that should be used to secure all network communications.
setSslSessionCacheSize(int) - Method in class io.hekate.network.NetworkSslConfig
Set the size of the cache used for storing SSL session objects (0 to use the JDK default value).
setSslSessionCacheTimeout(int) - Method in class io.hekate.network.NetworkSslConfig
Sets the timeout in seconds for the cached SSL session objects.
setStringProperty(String, String) - Method in interface io.hekate.core.service.ConfigurationContext
Adds the specified service property.
setTable(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
Sets the table name.
setTag(String) - Method in class io.hekate.rpc.RpcClientConfig
Sets the RPC interface tag.
setTag(String) - Method in class io.hekate.spring.bean.rpc.RpcClientBean
Sets the RPC service tag.
setTags(Map<String, String>) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the map of a compute instance's tag names and tag values to search for seed nodes.
setTags(Set<String>) - Method in class io.hekate.rpc.RpcServerConfig
Sets tags that should be attached to this RPC server.
setTcpBacklog(Integer) - Method in class io.hekate.network.NetworkServiceFactory
Sets the maximum number of pending connections that can be queued on the server socket channel (see ServerSocketChannel.bind(SocketAddress, int) for more details).
setTcpNoDelay(boolean) - Method in class io.hekate.network.netty.NettyClientFactory
Sets the flag indicating that TCP_NODELAY option must be set on TCP socket connections.
setTcpNoDelay(boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
Sets the flag indicating that TCP_NODELAY option must be set on TCP socket connections.
setTcpNoDelay(boolean) - Method in class io.hekate.network.NetworkServiceFactory
Sets the flag indicating that TCP_NODELAY option must be set on TCP socket connections.
setTcpReceiveBufferSize(Integer) - Method in class io.hekate.network.NetworkServiceFactory
Sets the size of the socket receive buffer in bytes (see StandardSocketOptions.SO_RCVBUF for more details).
setTcpReuseAddress(Boolean) - Method in class io.hekate.network.NetworkServiceFactory
Sets flag indicating that socket addresses should be re-used (see StandardSocketOptions.SO_REUSEADDR for more details).
setTcpSendBufferSize(Integer) - Method in class io.hekate.network.NetworkServiceFactory
Sets the size of the socket send buffer in bytes (see StandardSocketOptions.SO_SNDBUF for more details).
setTimeout(long) - Method in class io.hekate.rpc.RpcClientConfig
Sets the RPC timeout in milliseconds.
setTransport(NetworkTransportType) - Method in class io.hekate.network.NetworkServiceFactory
Sets the transport type that controls which implementation of NIO API should be used.
setTrustCertificates(Boolean) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
Sets the flag indicating that Kubernetes API must have a trusted certificate.
setTrustStoreAlgorithm(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the trust store algorithm.
setTrustStorePassword(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the trust store password.
setTrustStorePath(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the path to the trust store file.
setTrustStoreType(String) - Method in class io.hekate.network.NetworkSslConfig
Sets the trust store type.
setTtl(int) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the multicast TTL (Time To Live).
setUnsafeIo(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Set to true in order to use UnsafeInput/UnsafeOutput with Kryo.
setUrl(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Sets path to Consul endpoint address.
setUsername(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
Sets the Etcd username.
setUseUnsafe(boolean) - Method in class io.hekate.codec.fst.FstCodecFactory
Sets the flag that indicates which implementation of FSTCoder should be used.
setWaitTime(long) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
Sets the timeout in milliseconds to await for responses from remote nodes.
setWarnOnRetry(int) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the amount of retry attempts to skip before logging a warn message.
setWorkDir(File) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
Sets the work directory for seed node provider to store its files.
setWorkerEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerFactory
Sets the event loop group that will be responsible for handling messaging operations.
setWorkerThreads(int) - Method in class io.hekate.lock.LockServiceFactory
Sets the side of a thread pool that will perform lock management operations.
setWorkerThreads(int) - Method in class io.hekate.messaging.MessagingChannelConfig
Sets the worker thread pool size.
setWorkerThreads(int) - Method in class io.hekate.rpc.RpcServiceFactory
Sets the worker thread pool size for RPCs execution.
setWriteTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
Set the write timeout value in milliseconds.
setZones(Set<String>) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
Sets the set of availability zones to search for seed nodes (f.e.
shortVersion() - Static method in class io.hekate.core.HekateVersion
Returns the short version without the product name (x.y.z).
shouldRepeat(AggregateResult<T>) - Method in interface io.hekate.messaging.operation.AggregateRepeatCondition
Returns true if the whole Aggregate operation should be repeated.
shouldRepeat(BroadcastResult<T>) - Method in interface io.hekate.messaging.operation.BroadcastRepeatCondition
Returns true if the whole Broadcast operation should be repeated.
shouldRetry() - Method in interface io.hekate.messaging.retry.RetryCondition
Returns true if operation should be retried.
shouldRetry(Response<T>) - Method in interface io.hekate.messaging.retry.RetryResponsePredicate
Called upon a request operation completion in order decide on whether the result is acceptable or should the operation be retried.
shouldRetry(FailedAttempt) - Method in interface io.hekate.messaging.retry.RetryErrorPredicate
Decides on whether the specified error should be retried.
shutdown(EventExecutorGroup) - Static method in class io.hekate.network.netty.NettyUtils
Shuts down the specified executor with 0 graceful shutdown period.
shutdown(ExecutorService) - Static method in class io.hekate.util.async.AsyncUtils
Shuts down the specified executor service and returns a Waiting that will await for termination.
signature() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the signature of this method.
SingletonCodecFactory<T> - Class in io.hekate.codec
Singleton codec factory.
SingletonCodecFactory(Codec<T>) - Constructor for class io.hekate.codec.SingletonCodecFactory
Constructs new instance.
size() - Method in interface io.hekate.cluster.ClusterTopology
Returns the number of nodes in this topology.
size() - Method in interface io.hekate.codec.DataWriter
Returns the number of bytes written to this writer so far.
size() - Method in interface io.hekate.coordinate.CoordinationContext
Returns the size of CoordinationContext.members().
size() - Method in class io.hekate.messaging.MessageMetaData
Returns the amount of key/value pairs of this instance.
snapshot() - Method in interface io.hekate.partition.PartitionMapper
Creates a point in time snapshot of this mapper.
snapshot() - Method in class io.hekate.partition.RendezvousHashMapper
 
snapshot() - Method in class io.hekate.partition.UpdatablePartitionMapper
 
socket() - Method in class io.hekate.cluster.ClusterAddress
Returns the network address of the ClusterNode.
socket() - Method in interface io.hekate.cluster.ClusterNode
Returns the network socket address of this node.
splitArg() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the zero-based index of an argument that is annotated with RpcSplit (if presents).
splitArgType() - Method in class io.hekate.rpc.RpcMethodInfo
Returns the type of a RpcMethodInfo.splitArg().
SplitBrainDetector - Interface in io.hekate.cluster.split
Cluster split-brain detector.
SplitBrainDetectorGroup - Class in io.hekate.cluster.split
Combination of multiple split-brain detectors.
SplitBrainDetectorGroup() - Constructor for class io.hekate.cluster.split.SplitBrainDetectorGroup
 
SplitBrainDetectorGroup.GroupPolicy - Enum in io.hekate.cluster.split
Group policy for SplitBrainDetectorGroup.
stackTrace(Throwable) - Static method in class io.hekate.core.internal.util.ErrorUtils
Returns stackt race as string.
StampedStateGuard - Class in io.hekate.util
Helper class that provides support for components lifecycle management and locking.
StampedStateGuard(Class<?>) - Constructor for class io.hekate.util.StampedStateGuard
Constructs new instance.
StampedStateGuard.State - Enum in io.hekate.util
Enumeration of StampedStateGuard states.
start(Hekate) - Method in interface io.hekate.core.plugin.Plugin
Called when Hekate instance is about to start joining the cluster.
start(InetSocketAddress) - Method in interface io.hekate.network.NetworkServer
Asynchronously starts this server and binds it to the specified address.
start(InetSocketAddress, NetworkServerCallback) - Method in interface io.hekate.network.NetworkServer
Asynchronously starts this server and binds it to the specified address.
startAccepting() - Method in interface io.hekate.network.NetworkServer
Starts accepting connection from clients.
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Registers the local node address and starts this provider.
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
startDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
STARTED - io.hekate.network.NetworkServer.State
Server is started.
STARTING - io.hekate.network.NetworkServer.State
Server is starting.
state() - Method in interface io.hekate.core.Hekate
Returns the current state of this instance (see instance lifecycle).
state() - Method in interface io.hekate.core.service.InitializationContext
Returns the current state of Hekate instance that this service belongs to.
state() - Method in interface io.hekate.network.NetworkClient
Returns the connection state.
state() - Method in interface io.hekate.network.NetworkServer
Returns the lifecycle state of this server.
StateGuard - Class in io.hekate.util
Helper class that provides support for components lifecycle management and locking.
StateGuard(Class<?>) - Constructor for class io.hekate.util.StateGuard
Constructs a new instance.
StateGuard.GuardedRunnable<E extends Exception> - Interface in io.hekate.util
Guarded runnable.
StateGuard.GuardedSupplier<T,​E extends Exception> - Interface in io.hekate.util
Guarded supplier.
StateGuard.State - Enum in io.hekate.util
Enumeration of StateGuard states.
staticSeedNodeProvider(StaticSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateStaticSeedNodeProviderConfigurer
Constructs new StaticSeedNodeProvider.
StaticSeedNodeProvider - Class in io.hekate.cluster.seed
Seed node provider with a pre-configured static list of seed node addresses.
StaticSeedNodeProvider(StaticSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.StaticSeedNodeProvider
Constructs new instance.
staticSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateStaticSeedNodeProviderConfigurer
Conditionally constructs a new configuration for StaticSeedNodeProvider if application doesn't provide its own Bean of StaticSeedNodeProviderConfig type.
StaticSeedNodeProviderConfig - Class in io.hekate.cluster.seed
Configuration for StaticSeedNodeProvider.
StaticSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.StaticSeedNodeProviderConfig
 
status() - Method in class io.hekate.cluster.internal.gossip.GossipManager
 
status() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfo
 
status() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfoBase
 
status() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
status(GossipNodeStatus) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
stop() - Method in class io.hekate.cluster.internal.gossip.GossipCommManager
 
stop() - Method in interface io.hekate.core.plugin.Plugin
Called before Hekate instance is about to leave the cluster.
stop() - Method in interface io.hekate.network.NetworkServer
Asynchronously stops this server and closes all active client connections.
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Unregisters the local node address and stops this provider.
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
stopDiscovery(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
STOPPED - io.hekate.network.NetworkServer.State
Server is stopped.
STOPPING - io.hekate.network.NetworkServer.State
Server is stopping.
stream() - Method in interface io.hekate.cluster.ClusterTopology
Returns Stream of all nodes from this topology.
stream() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
stream() - Method in interface io.hekate.messaging.operation.AggregateResult
Returns the aggregation results as Stream.
StreamDataReader - Class in io.hekate.codec
Basic implementation of DataReader that wraps InputStream.
StreamDataReader(InputStream) - Constructor for class io.hekate.codec.StreamDataReader
Creates a data reader that uses the specified underlying input stream.
StreamDataWriter - Class in io.hekate.codec
Basic implementation of DataWriter that wraps OutputStream.
StreamDataWriter(OutputStream) - Constructor for class io.hekate.codec.StreamDataWriter
Creates a new data output stream to write data to the specified underlying output stream.
StreamUtils - Class in io.hekate.core.internal.util
Utilities for working with Streams.
STRING - io.hekate.core.ServiceProperty.Type
For String type.
stringProperty(String) - Method in interface io.hekate.core.ServiceInfo
Returns the property value or null if there is no such property or if property is not of ServiceProperty.Type.STRING type.
submit() - Method in interface io.hekate.messaging.operation.Aggregate
Asynchronously executes this operation.
submit() - Method in interface io.hekate.messaging.operation.Broadcast
Asynchronously executes this operation.
submit() - Method in interface io.hekate.messaging.operation.Request
Asynchronously executes this operation.
submit() - Method in interface io.hekate.messaging.operation.Send
Asynchronously executes this operation.
submit(AggregateCallback<T>) - Method in interface io.hekate.messaging.operation.Aggregate
Asynchronously executes this operation and notifies the specified callback upon completion.
submit(BroadcastCallback<T>) - Method in interface io.hekate.messaging.operation.Broadcast
Asynchronously executes this operation and notifies the specified callback upon completion.
submit(RequestCallback<T>) - Method in interface io.hekate.messaging.operation.Request
Asynchronously executes this operation and notifies the specified callback upon completion.
submit(SendCallback) - Method in interface io.hekate.messaging.operation.Send
Asynchronously executes this operation and notifies the specified callback upon completion.
submit(SubscribeCallback<T>) - Method in interface io.hekate.messaging.operation.Subscribe
Asynchronously executes this operation.
subscribe(Object, T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified subscription request and accumulates all responses.
subscribe(T) - Method in interface io.hekate.messaging.MessagingChannel
Synchronously sends the specified subscription request and accumulates all responses.
Subscribe<T> - Interface in io.hekate.messaging.operation
Subscribe operation.
SUBSCRIBE - io.hekate.messaging.intercept.OutboundType
Message is submitted as a Subscribe operation.
subscribeAsync(Object, T, SubscribeCallback<T>) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified subscription request.
subscribeAsync(T, SubscribeCallback<T>) - Method in interface io.hekate.messaging.MessagingChannel
Asynchronously sends the specified subscription request.
SubscribeCallback<T> - Interface in io.hekate.messaging.operation
Callback for a Subscribe operation.
SubscribeFuture<T> - Class in io.hekate.messaging.operation
Asynchronous result of Subscribe operation.
SubscribeFuture() - Constructor for class io.hekate.messaging.operation.SubscribeFuture
 
SUCCESS - io.hekate.network.NetworkPingResult
Ping operation was successful.
suspect(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
suspect(Set<ClusterNodeId>) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
suspected() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
suspected() - Method in class io.hekate.cluster.internal.gossip.GossipSuspectView
 
suspecting(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipSuspectView
 
suspectView() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
suspendDiscovery() - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Suspends discovery activities.
suspendDiscovery() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
suspendDiscovery() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
sync() - Method in interface io.hekate.messaging.operation.Broadcast
Synchronously executes this operation and returns the result.
sync() - Method in interface io.hekate.messaging.operation.Send
Synchronously executes this operation.
sync() - Method in class io.hekate.util.HekateFuture
Same as CompletableFuture.get() but throws unchecked exceptions.
sync(long, TimeUnit) - Method in class io.hekate.util.HekateFuture
Same as CompletableFuture.get(long, TimeUnit) but throws unchecked exceptions.
SYNCHRONIZING - io.hekate.core.Hekate.State
Synchronizing with remote nodes.
SystemTimeSupplier - Interface in io.hekate.util.time
System time supplier.

T

tag() - Method in interface io.hekate.rpc.RpcClientBuilder
Returns the RPC tag value.
tag() - Method in annotation type io.hekate.spring.boot.rpc.InjectRpcClient
Specifies the RPC tag that should be used for this client (see RpcClientConfig.setTag(String)).
tags() - Method in class io.hekate.rpc.RpcServerInfo
Returns the set of tags that are configured for this RPC server.
tags() - Method in class io.hekate.util.trace.TraceInfo
Tags of this trace.
TEMPORARY - io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
 
terminate() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
terminate() - Method in interface io.hekate.cluster.health.FailureDetector
Terminates this failure detector.
terminate() - Method in interface io.hekate.coordinate.CoordinationHandler
Gets called during the CoordinationService termination.
terminate() - Method in interface io.hekate.core.Hekate
Synchronously terminates this instance.
terminate() - Method in interface io.hekate.core.HekateFatalErrorContext
Triggers asynchronous termination of Hekate node.
terminate() - Static method in interface io.hekate.core.HekateFatalErrorPolicy
Terminate upon any fatal error.
terminate() - Method in interface io.hekate.core.service.InitializationContext
Triggers asynchronous termination of the local node.
terminate() - Method in interface io.hekate.core.service.TerminatingService
Terminates this service.
terminate() - Method in interface io.hekate.election.Candidate
Gets called when candidate must be terminated because of the ElectionService being stopped.
terminate(Throwable) - Method in interface io.hekate.core.service.InitializationContext
Triggers asynchronous termination of the local node with the specified error..
TERMINATE - io.hekate.cluster.event.ClusterLeaveReason
Leaving because of the Hekate.terminate() method call.
terminateAsync() - Method in interface io.hekate.core.Hekate
Asynchronously terminates this instance.
TERMINATED - io.hekate.util.StampedStateGuard.State
TERMINATED - io.hekate.util.StateGuard.State
TerminateFuture - Class in io.hekate.core
Asynchronous result of Hekate.terminateAsync() operation.
TerminateFuture() - Constructor for class io.hekate.core.TerminateFuture
 
terminateNodes() - Method in class io.hekate.cluster.internal.gossip.GossipNodesDeathWatch
 
TERMINATING - io.hekate.core.Hekate.State
Left the cluster and started terminating services.
TERMINATING - io.hekate.util.StampedStateGuard.State
TERMINATING - io.hekate.util.StateGuard.State
TerminatingService - Interface in io.hekate.core.service
Lifecycle interface for services that require termination.
TEXT - Static variable in interface io.hekate.messaging.MessageMetaData.MetaDataCodec
Codec for values of UTF-8-encoded strings.
that(boolean, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
THREAD_COMMON_PREFIX - Static variable in class io.hekate.core.internal.util.HekateThreadFactory
 
threadId() - Method in interface io.hekate.lock.LockOwnerInfo
Returns an identifier of a thread that currently holds the lock.
ThreadLocalCodecFactory<T> - Class in io.hekate.codec
Codec factory that manages a per-thread cache of Codecs.
timeout() - Method in class io.hekate.cluster.split.AddressReachabilityDetector
Check timeout in milliseconds.
timeout() - Method in class io.hekate.cluster.split.HostReachabilityDetector
Check timeout in milliseconds.
timeout() - Method in class io.hekate.cluster.split.JdbcConnectivityDetector
Check timeout in seconds.
timeout() - Method in interface io.hekate.rpc.RpcClientBuilder
Returns the timeout value in milliseconds (see RpcClientBuilder.withTimeout(long, TimeUnit)).
TIMEOUT - io.hekate.network.NetworkPingResult
Ping operation failed due to a timeout.
to() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.GossipMessage
 
toAddress() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.GossipMessage
 
toAddress() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinRequest
 
toAddress() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol
 
toFileName(InetSocketAddress) - Static method in class io.hekate.core.internal.util.AddressUtils
Converts the specified address into a string that is suitable for naming files.
topology() - Method in interface io.hekate.cluster.ClusterTopologySupport
Returns the cluster topology.
topology() - Method in interface io.hekate.cluster.event.ClusterEvent
Returns the cluster topology snapshot of this event.
topology() - Method in class io.hekate.cluster.event.ClusterEventBase
 
topology() - Method in class io.hekate.cluster.UpdatableClusterView
 
topology() - Method in interface io.hekate.coordinate.CoordinationContext
Returns the cluster topology of this coordination process.
topology() - Method in interface io.hekate.core.service.ClusterContext
Returns the current cluster topology.
topology() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Cluster topology that was used by the LoadBalancer.
topology() - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Returns the cluster topology.
topology() - Method in interface io.hekate.messaging.operation.Response
Cluster topology that was used by the LoadBalancer to submit the request.
topology() - Method in class io.hekate.partition.DefaultPartition
 
topology() - Method in interface io.hekate.partition.Partition
Returns the cluster topology that this partition is mapped to.
topology() - Method in interface io.hekate.partition.PartitionMapper
Returns the cluster topology as it is visible to this mapper.
topology() - Method in class io.hekate.partition.RendezvousHashMapper
 
topology() - Method in class io.hekate.partition.UpdatablePartitionMapper
 
topologyContext(Function<ClusterTopology, T>) - Method in interface io.hekate.cluster.ClusterView
Constructs a new context object or returns a cached one, based on the current cluster topology.
topologyContext(Function<ClusterTopology, T>) - Method in class io.hekate.cluster.UpdatableClusterView
 
topologyContext(Function<ClusterTopology, T>) - Method in interface io.hekate.messaging.loadbalance.LoadBalancerContext
Constructs a new context object or returns a cached one, based on the current cluster topology.
toString() - Method in class io.hekate.cluster.ClusterAddress
Returns the string representation of this address formatted as ClusterAddress.socket():ClusterAddress.id().
toString() - Method in class io.hekate.cluster.ClusterNodeJmx
 
toString() - Method in class io.hekate.cluster.ClusterServiceFactory
 
toString() - Method in class io.hekate.cluster.event.ClusterChangeEvent
 
toString() - Method in class io.hekate.cluster.event.ClusterJoinEvent
 
toString() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
 
toString() - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
toString() - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
 
toString() - Method in class io.hekate.cluster.internal.gossip.Gossip
 
toString() - Method in class io.hekate.cluster.internal.gossip.GossipDigest
 
toString() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfo
 
toString() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
toString() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol
 
toString() - Method in class io.hekate.cluster.internal.gossip.GossipSuspectView
 
toString() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
 
toString() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
toString() - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
 
toString() - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.StaticSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
toString() - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
 
toString() - Method in class io.hekate.cluster.split.AddressReachabilityDetector
 
toString() - Method in class io.hekate.cluster.split.HostReachabilityDetector
 
toString() - Method in class io.hekate.cluster.split.JdbcConnectivityDetector
 
toString() - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
 
toString() - Method in class io.hekate.cluster.UpdatableClusterView
 
toString() - Method in class io.hekate.codec.AutoSelectCodecFactory
 
toString() - Method in class io.hekate.codec.fst.FstCodecFactory
 
toString() - Method in class io.hekate.codec.JdkCodecFactory
 
toString() - Method in class io.hekate.codec.kryo.KryoCodecFactory
 
toString() - Method in class io.hekate.codec.SingletonCodecFactory
 
toString() - Method in class io.hekate.codec.ThreadLocalCodecFactory
 
toString() - Method in class io.hekate.coordinate.CoordinationProcessConfig
 
toString() - Method in class io.hekate.core.HekateBootstrap
 
toString() - Method in class io.hekate.core.jmx.JmxServiceFactory
 
toString() - Method in class io.hekate.core.resource.ResourceServiceFactory
 
toString() - Method in class io.hekate.core.ServiceProperty
 
toString() - Method in class io.hekate.election.CandidateConfig
 
toString() - Method in class io.hekate.election.ElectionServiceFactory
 
toString() - Method in class io.hekate.lock.LockRegionConfig
 
toString() - Method in class io.hekate.lock.LockServiceFactory
 
toString() - Method in class io.hekate.messaging.loadbalance.DefaultLoadBalancer
 
toString() - Method in class io.hekate.messaging.MessageMetaData.Key
 
toString() - Method in class io.hekate.messaging.MessageMetaData
 
toString() - Method in class io.hekate.messaging.MessagingBackPressureConfig
 
toString() - Method in class io.hekate.messaging.MessagingChannelConfig
 
toString() - Method in class io.hekate.messaging.MessagingServiceFactory
 
toString() - Method in class io.hekate.messaging.retry.ExponentialBackoffPolicy
 
toString() - Method in class io.hekate.messaging.retry.FixedBackoffPolicy
 
toString() - Method in class io.hekate.network.address.AddressPattern
 
toString() - Method in class io.hekate.network.netty.NettyClientFactory
 
toString() - Method in class io.hekate.network.NetworkConnectorConfig
 
toString() - Method in class io.hekate.network.NetworkServerFactoryBase
 
toString() - Method in class io.hekate.network.NetworkServerHandlerConfig
 
toString() - Method in class io.hekate.network.NetworkServiceFactory
 
toString() - Method in class io.hekate.network.NetworkSslConfig
 
toString() - Method in class io.hekate.partition.DefaultPartition
 
toString() - Method in class io.hekate.partition.RendezvousHashMapper.Builder
 
toString() - Method in class io.hekate.partition.RendezvousHashMapper
 
toString() - Method in class io.hekate.partition.UpdatablePartitionMapper
 
toString() - Method in class io.hekate.rpc.RpcClientConfig
 
toString() - Method in class io.hekate.rpc.RpcInterfaceInfo
 
toString() - Method in class io.hekate.rpc.RpcMethodInfo
 
toString() - Method in class io.hekate.rpc.RpcRetryInfo
 
toString() - Method in class io.hekate.rpc.RpcServerConfig
 
toString() - Method in class io.hekate.rpc.RpcServerInfo
 
toString() - Method in class io.hekate.rpc.RpcServiceFactory
 
toString() - Method in class io.hekate.util.StampedStateGuard
 
toString() - Method in class io.hekate.util.StateGuard
 
toString() - Method in class io.hekate.util.trace.TraceInfo
 
toString() - Method in class io.hekate.util.UuidBase
 
toString(Collection<T>, Function<? super T, String>) - Static method in class io.hekate.core.internal.util.Utils
Converts the specified collection to a comma-separated string by applying the specified mapper to each element and wrapping the resulting string with {...}.
ToString - Class in io.hekate.util.format
Utility for building Object.toString() methods.
ToStringFormat - Annotation Type in io.hekate.util.format
Applies a custom formatter to a field.
ToStringFormat.Formatter - Interface in io.hekate.util.format
Formatter for ToStringFormat.
ToStringIgnore - Annotation Type in io.hekate.util.format
Excludes field from ToString formatting.
Traceable - Interface in io.hekate.util.trace
Generic interface for traceable objects.
traceInfo() - Method in interface io.hekate.util.trace.Traceable
Returns tracing information.
TraceInfo - Class in io.hekate.util.trace
Information about a Traceable object.
trustCertificates() - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
true if Kubernetes API must have a trusted certificate.
tryLock(long, TimeUnit) - Method in interface io.hekate.lock.DistributedLock
Tries to acquire the lock with the given timeout.
tryLockRead(long, TimeUnit) - Method in class io.hekate.util.StateGuard
Tries to acquire the read lock with the specified timeout.
tryLockReadWithStateCheck() - Method in class io.hekate.util.StateGuard
Tries to acquire the read lock on this guard only if current state is StateGuard.State.INITIALIZED.
tryLockReadWithStateCheck(StateGuard.State) - Method in class io.hekate.util.StateGuard
Tries to acquire the read lock on this guard only if current state is the same with the specified one.
tryLockWrite(long, TimeUnit) - Method in class io.hekate.util.StateGuard
Tries to acquire the write lock with the specified timeout.
tryUnwrap(CodecFactory<T>) - Static method in class io.hekate.codec.ThreadLocalCodecFactory
Tries to unwrap the specified factory.
tryWrap(CodecFactory<T>) - Static method in class io.hekate.codec.ThreadLocalCodecFactory
Tries to wrap the specified factory with ThreadLocalCodecFactory.
ttl() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Returns the multicast TTL (see MulticastSeedNodeProviderConfig.setTtl(int)).
type() - Method in class io.hekate.cluster.event.ClusterChangeEvent
type() - Method in interface io.hekate.cluster.event.ClusterEvent
Returns the event type.
type() - Method in class io.hekate.cluster.event.ClusterJoinEvent
type() - Method in class io.hekate.cluster.event.ClusterLeaveEvent
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.HeartbeatReply
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.HeartbeatRequest
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinAccept
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.JoinRequest
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.LongTermConnect
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.Update
 
type() - Method in class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateDigest
 
type() - Method in interface io.hekate.core.ServiceInfo
Returns the service class name.
type() - Method in class io.hekate.core.ServiceProperty
Returns the property type.
type() - Method in interface io.hekate.messaging.intercept.ClientOutboundContext
Returns the type of this message.
type() - Method in interface io.hekate.messaging.intercept.ClientReceiveContext
Type of this response.
type() - Method in interface io.hekate.messaging.intercept.ServerInboundContext
Type of a send operation.
type() - Method in interface io.hekate.messaging.intercept.ServerSendContext
Type of this response.
type() - Method in interface io.hekate.rpc.RpcClientBuilder
Returns the RPC interface type.

U

unchecked() - Static method in class io.hekate.messaging.MessagingChannelConfig
Shortcut method for MessagingChannelConfig(Class) constructor to produce polyglot channels with Object base type.
unique(Object, Set<?>, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
UnknownRouteException - Exception in io.hekate.messaging.loadbalance
Signals that the load balanced node couldn't be found in the cluster topology.
UnknownRouteException(String) - Constructor for exception io.hekate.messaging.loadbalance.UnknownRouteException
Constructs a new instance.
UnknownRouteException(String, Throwable) - Constructor for exception io.hekate.messaging.loadbalance.UnknownRouteException
Constructs a new instance.
unlimitedAttempts() - Method in interface io.hekate.messaging.retry.RetryPolicy
Retry with unlimited number of attempts.
unlock() - Method in interface io.hekate.lock.DistributedLock
Unlocks the lock.
unlockAsync() - Method in interface io.hekate.lock.DistributedLock
Schedules unlock operation for asynchronous processing but doesn't await for its completion.
unlockRead() - Method in class io.hekate.util.StateGuard
Releases the read lock.
unlockRead(long) - Method in class io.hekate.util.StampedStateGuard
Releases the read lock.
unlockWrite() - Method in class io.hekate.util.StateGuard
Releases the write lock.
unlockWrite(long) - Method in class io.hekate.util.StampedStateGuard
Releases the write lock.
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in interface io.hekate.cluster.seed.SeedNodeProvider
Unregisters the specified address from this provider.
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroup
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.StaticSeedNodeProvider
 
unregisterRemote(String, InetSocketAddress) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
 
unsuspect(ClusterNodeId) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
unsuspect(Set<ClusterNodeId>) - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
UP - io.hekate.cluster.internal.gossip.GossipNodeStatus
 
UP - io.hekate.core.Hekate.State
Up and running.
UpdatableClusterView - Class in io.hekate.cluster
Simple updatable version of the ClusterView interface.
UpdatableClusterView(ClusterTopology) - Constructor for class io.hekate.cluster.UpdatableClusterView
Constructs a new instance.
UpdatablePartitionMapper - Class in io.hekate.partition
Updatable implementation of PartitionMapper interface.
UpdatablePartitionMapper(int, int) - Constructor for class io.hekate.partition.UpdatablePartitionMapper
Constructs a new instance.
update(ClusterNodeId, GossipNodeState) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
update(ClusterNodeId, List<GossipNodeState>) - Method in class io.hekate.cluster.internal.gossip.Gossip
 
update(ClusterTopology) - Method in class io.hekate.cluster.UpdatableClusterView
Updates the cluster topology of this view if the specified topology has higher version than the one that is already assigned to this view.
update(ClusterTopology, Function<Partition, Partition>) - Method in class io.hekate.partition.UpdatablePartitionMapper
Updates partitions mapping by applying the specified update function to each partition and using its result as a new mapping.
update(Gossip) - Method in class io.hekate.cluster.internal.gossip.GossipNodesDeathWatch
 
update(Set<ClusterAddress>) - Method in class io.hekate.cluster.health.DefaultFailureDetector
 
update(Set<ClusterAddress>) - Method in interface io.hekate.cluster.health.FailureDetector
Updates this failure detector with the latest information about all known cluster nodes addresses (including local node address).
Update(ClusterAddress, ClusterAddress, Gossip) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.Update
 
UpdateBase(ClusterAddress, ClusterAddress) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateBase
 
UpdateDigest(ClusterAddress, ClusterAddress, GossipDigest) - Constructor for class io.hekate.cluster.internal.gossip.GossipProtocol.UpdateDigest
 
url() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Return URL path to Consul HTTP API.
UTF_8 - Static variable in class io.hekate.core.internal.util.Utils
Charset for UTF-8.
Utils - Class in io.hekate.core.internal.util
Common utilities.
UuidBase<T extends UuidBase<T>> - Class in io.hekate.util
Base class for custom UUID-based identifiers.
UuidBase() - Constructor for class io.hekate.util.UuidBase
Constructs new random identifier.
UuidBase(long, long) - Constructor for class io.hekate.util.UuidBase
Constructs new instance from the specified higher/lower bits.
UuidBase(String) - Constructor for class io.hekate.util.UuidBase
Creates new identifier from the specified string.

V

validSysName(String, String) - Method in class io.hekate.core.internal.util.ConfigCheck
 
value() - Method in annotation type io.hekate.core.jmx.JmxTypeName
Returns the value for the ObjectName's 'type' attribute.
value() - Method in annotation type io.hekate.core.service.DefaultServiceFactory
Service factory class.
value() - Method in class io.hekate.core.ServiceProperty
Returns the property value.
value() - Method in annotation type io.hekate.spring.boot.lock.InjectLockRegion
Specifies the name of a LockRegion that should be injected (see LockService.region(String)).
value() - Method in annotation type io.hekate.spring.boot.messaging.InjectChannel
Specifies the name of a MessagingChannel that should be injected (see MessagingService.channel(String)).
value() - Method in annotation type io.hekate.spring.boot.network.InjectConnector
Specifies the protocol name of a NetworkConnector that should be injected (see NetworkService.connector(String)).
value() - Method in annotation type io.hekate.util.format.ToStringFormat
Formatter type.
value(String, Object) - Method in interface io.hekate.core.report.ConfigReporter
Add the specified value to this report.
value(String, Object) - Method in class io.hekate.core.report.DefaultConfigReporter
 
valueOf(String) - Static method in enum io.hekate.cluster.event.ClusterEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.event.ClusterLeaveReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.internal.gossip.GossipNodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.internal.gossip.GossipPrecedence
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.internal.gossip.GossipProtocol.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.seed.SeedNodeProviderGroupPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.cluster.split.SplitBrainDetectorGroup.GroupPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.core.Hekate.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.core.ServiceProperty.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.messaging.intercept.InboundType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.messaging.intercept.OutboundType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.messaging.MessagingOverflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.messaging.operation.AckMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.messaging.retry.RetryRoutingPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.network.NetworkClient.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.network.NetworkPingResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.network.NetworkServer.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.network.NetworkSslConfig.Provider
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.network.NetworkTransportType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.rpc.RpcAggregate.RemoteErrors
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.rpc.RpcBroadcast.RemoteErrors
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.util.StampedStateGuard.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.hekate.util.StateGuard.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.hekate.cluster.event.ClusterEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.event.ClusterLeaveReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.internal.gossip.GossipNodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.internal.gossip.GossipPrecedence
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.internal.gossip.GossipProtocol.JoinReject.RejectType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.internal.gossip.GossipProtocol.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.seed.SeedNodeProviderGroupPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.cluster.split.SplitBrainDetectorGroup.GroupPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.core.Hekate.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.core.ServiceProperty.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.messaging.intercept.InboundType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.messaging.intercept.OutboundType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.messaging.MessagingOverflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.messaging.operation.AckMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.messaging.retry.RetryRoutingPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.network.NetworkClient.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.network.NetworkPingResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.network.NetworkServer.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.network.NetworkSslConfig.Provider
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.network.NetworkTransportType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.rpc.RpcAggregate.RemoteErrors
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.rpc.RpcBroadcast.RemoteErrors
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.util.StampedStateGuard.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.hekate.util.StateGuard.State
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in interface io.hekate.cluster.ClusterTopology
Returns the version of this topology.
version() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfo
 
version() - Method in class io.hekate.cluster.internal.gossip.GossipNodeInfoBase
 
version() - Method in class io.hekate.cluster.internal.gossip.GossipNodeState
 
version() - Method in annotation type io.hekate.rpc.Rpc
Version of RPC interface.
version() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the version of this RPC interface.
versionedName() - Method in class io.hekate.rpc.RpcInterfaceInfo
Returns the versioned name of this RPC interface.

W

Waiting - Interface in io.hekate.util.async
Interface to await for the completion of an asynchronous task.
waitTime() - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProvider
Returns the time to await for responses from remote nodes (see MulticastSeedNodeProviderConfig.setWaitTime(long)).
WARN - io.hekate.rpc.RpcAggregate.RemoteErrors
Same as RpcAggregate.RemoteErrors.IGNORE but also logs a WARN message for each failure.
WARN - io.hekate.rpc.RpcBroadcast.RemoteErrors
Same as RpcBroadcast.RemoteErrors.IGNORE but also logs a WARN message for each failure.
whileError(RetryErrorPredicate) - Method in interface io.hekate.messaging.retry.RetryPolicy
Registers a predicate to control if the operation should be retried upon an error.
whileResponse(RetryResponsePredicate<T>) - Method in interface io.hekate.messaging.retry.RetryResponseSupport
Registers a predicate to control if the operation should to be repeated upon the response.
whileTrue(RetryCondition) - Method in interface io.hekate.messaging.retry.RetryPolicy
Retry while this condition is true.
withAcceptor(ClusterAcceptor) - Method in class io.hekate.cluster.ClusterServiceFactory
withAcceptorEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerFactory
withAcceptRetryInterval(long) - Method in class io.hekate.network.NetworkServiceFactory
withAck() - Method in interface io.hekate.messaging.operation.Broadcast
Sets acknowledgement mode to AckMode.REQUIRED.
withAck() - Method in interface io.hekate.messaging.operation.Send
Sets acknowledgement mode to AckMode.REQUIRED.
withAckMode(AckMode) - Method in interface io.hekate.messaging.operation.Broadcast
Acknowledgement mode.
withAckMode(AckMode) - Method in interface io.hekate.messaging.operation.Send
Acknowledgement mode.
withAclToken(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withAddress(String) - Method in class io.hekate.cluster.seed.StaticSeedNodeProviderConfig
withAffinity(Object) - Method in interface io.hekate.messaging.operation.Aggregate
Affinity key.
withAffinity(Object) - Method in interface io.hekate.messaging.operation.Broadcast
Affinity key.
withAffinity(Object) - Method in interface io.hekate.messaging.operation.Request
Affinity key.
withAffinity(Object) - Method in interface io.hekate.messaging.operation.Send
Affinity key.
withAffinity(Object) - Method in interface io.hekate.messaging.operation.Subscribe
Affinity key.
withAsyncInit(boolean) - Method in class io.hekate.coordinate.CoordinationProcessConfig
withAutoAccept(boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
withBackoff(RetryBackoffPolicy) - Method in interface io.hekate.messaging.retry.RetryPolicy
Backoff policy.
withBackPressure(MessagingBackPressureConfig) - Method in class io.hekate.messaging.MessagingConfigBase
withBackPressure(Consumer<MessagingBackPressureConfig>) - Method in class io.hekate.messaging.MessagingConfigBase
Applies the specified consumer to the current MessagingConfigBase.getBackPressure() configuration.
withBackupNodes(int) - Method in class io.hekate.messaging.MessagingChannelConfig
withBackupNodes(int) - Method in class io.hekate.partition.RendezvousHashMapper.Builder
Sets the amount of backup nodes that should be assigned to each partition by the mapper.
withBackupNodes(int) - Method in class io.hekate.rpc.RpcClientConfig
Fluent-style version of RpcClientConfig.setBackupNodes(int).
withBasePath(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withBasePath(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withBasePath(String) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
withCacheUnknownTypes(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
withCandidate(Candidate) - Method in class io.hekate.election.CandidateConfig
withCandidate(CandidateConfig) - Method in class io.hekate.election.ElectionServiceFactory
withCandidate(String) - Method in class io.hekate.election.ElectionServiceFactory
Fluent-style shortcut to register a new CandidateConfig with the specified group.
withChannel(MessagingChannelConfig<?>) - Method in class io.hekate.messaging.MessagingServiceFactory
withCleanupInterval(int) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withCleanupInterval(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
withCleanupInterval(long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withCleanupInterval(long) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
withCleanupInterval(long) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
withCleanupInterval(long) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withClient(RpcClientConfig) - Method in class io.hekate.rpc.RpcServiceFactory
Fluent-style version of RpcServiceFactory.setClients(List).
withClientProvider(RpcClientConfigProvider) - Method in class io.hekate.rpc.RpcServiceFactory
withCluster(ClusterView) - Method in interface io.hekate.messaging.MessagingChannel
Returns a copy of this channel that will use the specified cluster view and will inherit all other options from this instance.
withCluster(ClusterView) - Method in interface io.hekate.rpc.RpcClientBuilder
Returns a new builder that will use the specified cluster view with all clients that it produces.
withCluster(Consumer<ClusterServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures ClusterService.
withClusterFilter(ClusterNodeFilter) - Method in class io.hekate.messaging.MessagingChannelConfig
withClusterListener(ClusterEventListener) - Method in class io.hekate.cluster.ClusterServiceFactory
withCodecFactory(CodecFactory<T>) - Method in class io.hekate.network.netty.NettyClientFactory
withCodecFactory(CodecFactory<T>) - Method in class io.hekate.network.NetworkServerHandlerConfig
withConfigProvider(CoordinationConfigProvider) - Method in class io.hekate.coordinate.CoordinationServiceFactory
withConfigProvider(CandidateConfigProvider) - Method in class io.hekate.election.ElectionServiceFactory
withConfigProvider(LockConfigProvider) - Method in class io.hekate.lock.LockServiceFactory
withConfigProvider(MessagingConfigProvider) - Method in class io.hekate.messaging.MessagingServiceFactory
withConfigProvider(NetworkConfigProvider) - Method in class io.hekate.network.NetworkServiceFactory
withConfigReport(boolean) - Method in class io.hekate.core.HekateBootstrap
withConnectionString(String) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
withConnector(NetworkConnectorConfig<?>) - Method in class io.hekate.network.NetworkServiceFactory
withConnectTimeout(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
withConnectTimeout(int) - Method in class io.hekate.network.NetworkServiceFactory
withConnectTimeout(Integer) - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
withConnectTimeout(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
withConnectTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withContainer(String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
withContainerPortName(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
withCoordination(Consumer<CoordinationServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
withCredential(String) - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
withCredentials(CredentialsSupplier) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withCredentials(CredentialsSupplier) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
withDataSource(DataSource) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withDefaultCodec(CodecFactory<Object>) - Method in class io.hekate.core.HekateBootstrap
withDefaultSerializer(Class<V>, Serializer<V>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
withDetector(SplitBrainDetector) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
withDisableHeartbeats(boolean) - Method in class io.hekate.network.netty.NettyServerFactory
withDomain(String) - Method in class io.hekate.core.jmx.JmxServiceFactory
Fluent-style version of JmxServiceFactory.setDomain(String).
withElection(Consumer<ElectionServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures ElectionService.
withEndpoint(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withEndpoint(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withEndpoints(List<String>) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyClientFactory
withEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerHandlerConfig
withExponentialDelay(long, long) - Method in interface io.hekate.messaging.retry.RetryPolicy
Use ExponentialBackoffPolicy with the specified base/max delays (in milliseconds).
withFailFast(boolean) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
withFailureDetectionQuorum(int) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
withFailureDetector(FailureDetector) - Method in class io.hekate.cluster.ClusterServiceFactory
withFatalErrorPolicy(HekateFatalErrorPolicy) - Method in class io.hekate.core.HekateBootstrap
withFixedDelay(long) - Method in interface io.hekate.messaging.retry.RetryPolicy
Use FixedBackoffPolicy with the specified delay (in milliseconds).
withGlobalInterceptor(MessageInterceptor) - Method in class io.hekate.messaging.MessagingServiceFactory
withGossipInterval(long) - Method in class io.hekate.cluster.ClusterServiceFactory
withGroup(String) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withGroup(String) - Method in class io.hekate.election.CandidateConfig
Fluent-style version of CandidateConfig.setGroup(String).
withGroupPolicy(SplitBrainDetectorGroup.GroupPolicy) - Method in class io.hekate.cluster.split.SplitBrainDetectorGroup
withHandler(CoordinationHandler) - Method in class io.hekate.coordinate.CoordinationProcessConfig
withHandler(NettyServerHandlerConfig<?>) - Method in class io.hekate.network.netty.NettyServerFactory
Fluent-style version of NettyServerFactory.setHandlers(List).
withHandler(NetworkServerHandler<T>) - Method in class io.hekate.network.NetworkServerHandlerConfig
withHandler(Object) - Method in class io.hekate.rpc.RpcServerConfig
Fluent-style version of RpcServerConfig.setHandler(Object).
withHeartbeatInterval(int) - Method in class io.hekate.network.NetworkServerFactoryBase
withHeartbeatInterval(int) - Method in class io.hekate.network.NetworkServiceFactory
withHeartbeatInterval(long) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
withHeartbeatLossThreshold(int) - Method in class io.hekate.cluster.health.DefaultFailureDetectorConfig
withHeartbeatLossThreshold(int) - Method in class io.hekate.network.NetworkServerFactoryBase
withHeartbeatLossThreshold(int) - Method in class io.hekate.network.NetworkServiceFactory
withHost(String) - Method in class io.hekate.network.NetworkServiceFactory
Fluent-style version of NetworkServiceFactory.setHost(String).
withHostColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withHostSelector(AddressSelector) - Method in class io.hekate.network.NetworkServiceFactory
withIdentity(String) - Method in class io.hekate.cluster.seed.jclouds.BasicCredentialsSupplier
withIdleSocketTimeout(long) - Method in class io.hekate.coordinate.CoordinationServiceFactory
withIdleSocketTimeout(long) - Method in class io.hekate.messaging.MessagingConfigBase
withIdleSocketTimeout(long) - Method in class io.hekate.network.NetworkConnectorConfig
withIdleTimeout(long) - Method in class io.hekate.network.netty.NettyClientFactory
withInHighWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
withInLowWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
withInstantiatorStrategy(InstantiatorStrategy) - Method in class io.hekate.codec.kryo.KryoCodecFactory
withInterceptor(MessageInterceptor) - Method in class io.hekate.messaging.MessagingChannelConfig
withInterval(long) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withJmx(Consumer<JmxServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures JmxService.
withKeyStoreAlgorithm(String) - Method in class io.hekate.network.NetworkSslConfig
withKeyStorePassword(String) - Method in class io.hekate.network.NetworkSslConfig
withKeyStorePath(String) - Method in class io.hekate.network.NetworkSslConfig
withKeyStoreType(String) - Method in class io.hekate.network.NetworkSslConfig
withKnownType(Class<?>) - Method in class io.hekate.codec.fst.FstCodecFactory
Fluent-style version of FstCodecFactory.setKnownTypes(List).
withKnownType(Class<?>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Fluent-style version of KryoCodecFactory.setKnownTypes(List).
withKnownTypes(List<Class<?>>) - Method in class io.hekate.codec.fst.FstCodecFactory
Fluent-style version of FstCodecFactory.setKnownTypes(List).
withKnownTypes(List<Class<?>>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Fluent-style version of KryoCodecFactory.setKnownTypes(List).
withLifecycleListener(Hekate.LifecycleListener) - Method in class io.hekate.core.HekateBootstrap
withLoadBalancer(LoadBalancer<T>) - Method in interface io.hekate.messaging.MessagingChannel
Returns a copy of this channel that will use the specified load balancer and will inherit all other options from this instance.
withLoadBalancer(LoadBalancer<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
withLoadBalancer(RpcLoadBalancer) - Method in interface io.hekate.rpc.RpcClientBuilder
Returns a new builder that will apply the specifier load balancer to all clients that it produces.
withLoadBalancer(RpcLoadBalancer) - Method in class io.hekate.rpc.RpcClientConfig
withLocks(Consumer<LockServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures LockService.
withLogCategory(String) - Method in class io.hekate.messaging.MessagingChannelConfig
withLogCategory(String) - Method in class io.hekate.network.NetworkConnectorConfig
withLoggerCategory(String) - Method in class io.hekate.network.netty.NettyClientFactory
withLoggerCategory(String) - Method in class io.hekate.network.NetworkServerHandlerConfig
withLoopBackDisabled(boolean) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withMasterUrl(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
withMessageCodec(CodecFactory<Object>) - Method in class io.hekate.coordinate.CoordinationProcessConfig
withMessageCodec(CodecFactory<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
withMessageCodec(CodecFactory<T>) - Method in class io.hekate.network.NetworkConnectorConfig
withMessaging(Consumer<MessagingServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures MessagingService.
withMessagingTimeout(long) - Method in class io.hekate.messaging.MessagingChannelConfig
withMetrics(NettyMetricsFactory) - Method in class io.hekate.network.netty.NettyServerFactory
withMetrics(NettyMetricsSink) - Method in class io.hekate.network.netty.NettyClientFactory
withMetrics(MeterRegistry) - Method in class io.hekate.core.HekateBootstrap
withName(String) - Method in class io.hekate.coordinate.CoordinationProcessConfig
withName(String) - Method in class io.hekate.lock.LockRegionConfig
Fluent-style version of LockRegionConfig.setName(String).
withName(String) - Method in class io.hekate.messaging.MessagingChannelConfig
withNamespace(String) - Method in class io.hekate.cluster.ClusterServiceFactory
withNamespace(String) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
withNamespaceColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withNetwork(Consumer<NetworkServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures NetworkService.
withNioThreads(int) - Method in class io.hekate.coordinate.CoordinationServiceFactory
withNioThreads(int) - Method in class io.hekate.lock.LockServiceFactory
Fluent-style version of LockServiceFactory.setNioThreads(int).
withNioThreads(int) - Method in class io.hekate.messaging.MessagingConfigBase
withNioThreads(int) - Method in class io.hekate.network.NetworkConnectorConfig
withNioThreads(int) - Method in class io.hekate.network.NetworkServiceFactory
withNoAck() - Method in interface io.hekate.messaging.operation.Broadcast
Sets acknowledgement mode to AckMode.NOT_NEEDED.
withNoAck() - Method in interface io.hekate.messaging.operation.Send
Sets acknowledgement mode to AckMode.NOT_NEEDED.
withNodeName(String) - Method in class io.hekate.core.HekateBootstrap
Fluent-style version of HekateBootstrap.setNodeName(String).
withOutHighWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
withOutLowWatermark(int) - Method in class io.hekate.messaging.MessagingBackPressureConfig
withOutOverflowPolicy(MessagingOverflowPolicy) - Method in class io.hekate.messaging.MessagingBackPressureConfig
withPartitions(int) - Method in class io.hekate.messaging.MessagingChannelConfig
withPartitions(int) - Method in class io.hekate.partition.RendezvousHashMapper.Builder
Sets the total amount of partitions that should be managed by the mapper (value must be a power of two).
withPartitions(int) - Method in class io.hekate.rpc.RpcClientConfig
Fluent-style version of RpcClientConfig.setPartitions(int).
withPartitions(int, int) - Method in interface io.hekate.messaging.MessagingChannel
Returns a copy of this channel that will use a RendezvousHashMapper with the specified options.
withPartitions(int, int) - Method in interface io.hekate.rpc.RpcClientBuilder
Returns a new builder that will apply the specified partitions mapping options to all clients that it produces.
withPartitions(PartitionMapper) - Method in interface io.hekate.messaging.MessagingChannel
Returns a copy of this channel that will use the specified PartitionMapper.
withPassword(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withPlugin(Plugin) - Method in class io.hekate.core.HekateBootstrap
Adds the specified plugin to a list of plugins.
withPolicy(SeedNodeProviderGroupPolicy) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
withPort(int) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withPort(int) - Method in class io.hekate.network.NetworkServiceFactory
Fluent-style version of NetworkServiceFactory.setPort(int).
withPortColumn(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withPortRange(int) - Method in class io.hekate.network.NetworkServiceFactory
withProcess(CoordinationProcessConfig) - Method in class io.hekate.coordinate.CoordinationServiceFactory
withProcess(String) - Method in class io.hekate.coordinate.CoordinationServiceFactory
Fluent-style shortcut to register a new CoordinationProcessConfig with the specified name.
withProperty(String, String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withProperty(String, String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
withProperty(String, String) - Method in class io.hekate.core.HekateBootstrap
Puts the specified property value into the node's properties map.
withPropertyProvider(PropertyProvider) - Method in class io.hekate.core.HekateBootstrap
withProtocol(String) - Method in class io.hekate.network.netty.NettyClientFactory
withProtocol(String) - Method in class io.hekate.network.NetworkConnectorConfig
withProtocol(String) - Method in class io.hekate.network.NetworkServerHandlerConfig
withProvider(SeedNodeProvider) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
withProvider(NetworkSslConfig.Provider) - Method in class io.hekate.network.NetworkSslConfig
withProvider(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withProvider(String) - Method in class io.hekate.cluster.seed.jclouds.CloudStoreSeedNodeProviderConfig
withProviders(List<SeedNodeProvider>) - Method in class io.hekate.cluster.seed.SeedNodeProviderGroupConfig
withQueryTimeout(int) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withReadLock(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the read lock.
withReadLock(StateGuard.GuardedSupplier<T, E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the read lock.
withReadLockAndStateCheck(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the read lock.
withReadLockAndStateCheck(StateGuard.GuardedSupplier<T, E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the read lock.
withReadLockIfInitialized(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Conditionally executes the specified task in the read-locked context if this guard is in initialized state.
withReadTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withReceiver(MessageReceiver<T>) - Method in class io.hekate.messaging.MessagingChannelConfig
withReferences(Boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
withRegion(LockRegionConfig) - Method in class io.hekate.lock.LockServiceFactory
Fluent-style version of LockServiceFactory.setRegions(List).
withRegion(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withRegistrationRequired(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
withRepeat(AggregateRepeatCondition<T>) - Method in interface io.hekate.messaging.operation.Aggregate
Condition to repeat for the whole Aggregate operation.
withRepeat(BroadcastRepeatCondition<T>) - Method in interface io.hekate.messaging.operation.Broadcast
Condition to repeat for the whole Broadcast operation.
withRetry(AggregateRetryConfigurer<T>) - Method in interface io.hekate.messaging.operation.Aggregate
Retry policy for each individual message of the aggregation operation.
withRetry(BroadcastRetryConfigurer) - Method in interface io.hekate.messaging.operation.Broadcast
Retry policy.
withRetry(RequestRetryConfigurer<T>) - Method in interface io.hekate.messaging.operation.Request
Retry policy.
withRetry(RequestRetryConfigurer<T>) - Method in interface io.hekate.messaging.operation.Subscribe
Retry policy.
withRetry(SendRetryConfigurer) - Method in interface io.hekate.messaging.operation.Send
Retry policy.
withRetryAddress(InetSocketAddress) - Method in interface io.hekate.network.NetworkServerFailure.Resolution
Sets the new address that server should try during its failover actions.
withRetryDelay(long) - Method in interface io.hekate.network.NetworkServerFailure.Resolution
Sets the amount of time in milliseconds for server to wait before performing another failover attempt.
withRetryInterval(long) - Method in class io.hekate.coordinate.CoordinationServiceFactory
withRetryInterval(long) - Method in class io.hekate.lock.LockServiceFactory
withRetryPolicy(GenericRetryConfigurer) - Method in class io.hekate.messaging.MessagingChannelConfig
withRetryPolicy(GenericRetryConfigurer) - Method in interface io.hekate.rpc.RpcClientBuilder
Returns a new builder that will apply the specifier retry policy to all clients that it produces.
withRetryPolicy(GenericRetryConfigurer) - Method in class io.hekate.rpc.RpcClientConfig
withRole(String) - Method in class io.hekate.core.HekateBootstrap
Adds the specified role to the roles set.
withRpc(Consumer<RpcServiceFactory>) - Method in class io.hekate.core.HekateBootstrap
Configures RpcService.
withRpcInterface(Class<?>) - Method in class io.hekate.rpc.RpcClientConfig
withSeedNodeProvider(SeedNodeProvider) - Method in class io.hekate.cluster.ClusterServiceFactory
withSerializer(Class<?>, Serializer<?>) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Fluent-style version of KryoCodecFactory.setSerializers(Map).
withServer(RpcServerConfig) - Method in class io.hekate.rpc.RpcServiceFactory
Fluent-style version of RpcServiceFactory.setServers(List).
withServer(MBeanServer) - Method in class io.hekate.core.jmx.JmxServiceFactory
withServerHandler(NetworkServerHandler<T>) - Method in class io.hekate.network.NetworkConnectorConfig
withServerProvider(RpcServerConfigProvider) - Method in class io.hekate.rpc.RpcServiceFactory
withService(ServiceFactory<? extends Service>) - Method in class io.hekate.core.HekateBootstrap
Adds the specified factory to the list of service factories.
withService(Class<T>) - Method in class io.hekate.core.HekateBootstrap
Returns an existing service factory of the specified type or creates and registers a new one.
withService(Class<T>, Consumer<T>) - Method in class io.hekate.core.HekateBootstrap
Applies the specified configurer to a service factory of the specified type.
withSessionTimeout(int) - Method in class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
withSharedReferences(Boolean) - Method in class io.hekate.codec.fst.FstCodecFactory
withSoBacklog(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
withSoReceiveBufferSize(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
withSoReceiveBufferSize(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
withSoReuseAddress(Boolean) - Method in class io.hekate.network.netty.NettyClientFactory
withSoReuseAddress(Boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
withSoSendBufferSize(Integer) - Method in class io.hekate.network.netty.NettyClientFactory
withSoSendBufferSize(Integer) - Method in class io.hekate.network.NetworkServerFactoryBase
withSoTimeout(Integer) - Method in class io.hekate.cluster.seed.jclouds.CloudPropertiesBase
withSpeedUpGossipSize(int) - Method in class io.hekate.cluster.ClusterServiceFactory
withSplitBrainCheckInterval(long) - Method in class io.hekate.cluster.ClusterServiceFactory
withSplitBrainDetector(SplitBrainDetector) - Method in class io.hekate.cluster.ClusterServiceFactory
withSsl(NetworkSslConfig) - Method in class io.hekate.network.NetworkServiceFactory
withSsl(SslContext) - Method in class io.hekate.network.netty.NettyClientFactory
Fluent-style version of NettyClientFactory.setSsl(SslContext).
withSsl(SslContext) - Method in class io.hekate.network.netty.NettyServerFactory
Fluent-style version of NettyServerFactory.setSsl(SslContext).
withSslSessionCacheSize(int) - Method in class io.hekate.network.NetworkSslConfig
withSslSessionCacheTimeout(int) - Method in class io.hekate.network.NetworkSslConfig
withTable(String) - Method in class io.hekate.cluster.seed.jdbc.JdbcSeedNodeProviderConfig
withTag(String) - Method in class io.hekate.rpc.RpcClientConfig
Fluent-style version of RpcClientConfig.setTag(String).
withTag(String) - Method in class io.hekate.rpc.RpcServerConfig
Fluent-style version of RpcServerConfig.setTags(Set).
withTag(String, Object) - Method in class io.hekate.util.trace.TraceInfo
Adds a new tag to this trace.
withTag(String, String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
withTcpBacklog(Integer) - Method in class io.hekate.network.NetworkServiceFactory
withTcpNoDelay(boolean) - Method in class io.hekate.network.netty.NettyClientFactory
withTcpNoDelay(boolean) - Method in class io.hekate.network.NetworkServerFactoryBase
withTcpNoDelay(Boolean) - Method in class io.hekate.network.NetworkServiceFactory
withTcpReceiveBufferSize(Integer) - Method in class io.hekate.network.NetworkServiceFactory
withTcpReuseAddress(Boolean) - Method in class io.hekate.network.NetworkServiceFactory
withTcpSendBufferSize(Integer) - Method in class io.hekate.network.NetworkServiceFactory
withTimeout(long) - Method in class io.hekate.rpc.RpcClientConfig
Fluent-style version of RpcClientConfig.setTimeout(long).
withTimeout(long, TimeUnit) - Method in interface io.hekate.messaging.operation.Aggregate
Overrides the channel's default timeout value for this operation.
withTimeout(long, TimeUnit) - Method in interface io.hekate.messaging.operation.Broadcast
Overrides the channel's default timeout value for this operation.
withTimeout(long, TimeUnit) - Method in interface io.hekate.messaging.operation.Request
Overrides the channel's default timeout value for this operation.
withTimeout(long, TimeUnit) - Method in interface io.hekate.messaging.operation.Send
Overrides the channel's default timeout value for this operation.
withTimeout(long, TimeUnit) - Method in interface io.hekate.messaging.operation.Subscribe
Overrides the channel's default timeout value for this operation.
withTimeout(long, TimeUnit) - Method in interface io.hekate.rpc.RpcClientBuilder
Returns a new builder that will apply the specifier timeout to all clients that it produces.
withTransport(NetworkTransportType) - Method in class io.hekate.network.NetworkServiceFactory
withTrustCertificates(Boolean) - Method in class io.hekate.cluster.seed.kubernetes.KubernetesSeedNodeProviderConfig
withTrustStoreAlgorithm(String) - Method in class io.hekate.network.NetworkSslConfig
withTrustStorePassword(String) - Method in class io.hekate.network.NetworkSslConfig
withTrustStorePath(String) - Method in class io.hekate.network.NetworkSslConfig
withTrustStoreType(String) - Method in class io.hekate.network.NetworkSslConfig
withTtl(int) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withUnsafeIo(boolean) - Method in class io.hekate.codec.kryo.KryoCodecFactory
Fluent-style version of KryoCodecFactory.setUnsafeIo(boolean).
withUrl(String) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withUsername(String) - Method in class io.hekate.cluster.seed.etcd.EtcdSeedNodeProviderConfig
withUseUnsafe(boolean) - Method in class io.hekate.codec.fst.FstCodecFactory
Fluent-style version of FstCodecFactory.setUseUnsafe(boolean).
withWaitTime(long) - Method in class io.hekate.cluster.seed.multicast.MulticastSeedNodeProviderConfig
withWarnOnRetry(int) - Method in class io.hekate.messaging.MessagingChannelConfig
withWorkDir(File) - Method in class io.hekate.cluster.seed.fs.FsSeedNodeProviderConfig
withWorkerEventLoop(EventLoopGroup) - Method in class io.hekate.network.netty.NettyServerFactory
withWorkerThreads(int) - Method in class io.hekate.lock.LockServiceFactory
withWorkerThreads(int) - Method in class io.hekate.messaging.MessagingChannelConfig
withWorkerThreads(int) - Method in class io.hekate.rpc.RpcServiceFactory
withWriteLock(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the write lock.
withWriteLock(StateGuard.GuardedSupplier<T, E>) - Method in class io.hekate.util.StateGuard
Executes the specified task while holding the write lock.
withWriteLockIfInitialized(StateGuard.GuardedRunnable<E>) - Method in class io.hekate.util.StateGuard
Conditionally executes the specified task in the write-locked context if this guard is in initialized state.
withWriteTimeout(Long) - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProviderConfig
withZone(String) - Method in class io.hekate.cluster.seed.jclouds.CloudSeedNodeProviderConfig
workerThreads() - Method in interface io.hekate.messaging.MessagingChannel
Returns the worker thread pool size (see MessagingChannelConfig.setWorkerThreads(int)).
workerThreads() - Method in interface io.hekate.rpc.RpcService
Returns the worker thread pool size (see RpcServiceFactory.setWorkerThreads(int)).
writeAddress(InetSocketAddress, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes InetSocketAddress to the specified data output.
writeBigDecimal(BigDecimal) - Method in interface io.hekate.codec.DataWriter
Writes BigDecimal value.
writeBigDecimal(BigDecimal, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes BigDecimal value.
writeBigInteger(BigInteger) - Method in interface io.hekate.codec.DataWriter
Writes BigInteger value.
writeBigInteger(BigInteger, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes BigInteger value.
writeClusterAddress(ClusterAddress, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes ClusterAddress to the specified data output.
writeNodeId(ClusterNodeId, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes ClusterNodeId to the specified data output.
writeTimeout() - Method in class io.hekate.cluster.seed.consul.ConsulSeedNodeProvider
Returns the Consul write timeout in milliseconds.
writeTo(DataWriter) - Method in class io.hekate.messaging.MessageMetaData
Writes the content of this instance into the specified writer.
writeTopologyHash(ClusterHash, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Writes ClusterHash to the specified data output.
writeVarInt(int) - Method in interface io.hekate.codec.DataWriter
Writes a variable-length int value.
writeVarInt(int, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Encodes a value using the variable-length encoding from Google Protocol Buffers.
writeVarIntUnsigned(int) - Method in interface io.hekate.codec.DataWriter
Writes an unsigned variable-length int value.
writeVarIntUnsigned(int, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Encodes a value using the variable-length encoding from Google Protocol Buffers.
writeVarLong(long) - Method in interface io.hekate.codec.DataWriter
Writes a variable-length long value.
writeVarLong(long, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Encodes a value using the variable-length encoding from Google Protocol Buffers.
writeVarLongUnsigned(long) - Method in interface io.hekate.codec.DataWriter
Writes an unsigned variable-length long value.
writeVarLongUnsigned(long, DataOutput) - Static method in class io.hekate.codec.CodecUtils
Encodes a value using the variable-length encoding from Google Protocol Buffers.

Y

yieldLeadership() - Method in interface io.hekate.election.LeaderContext
Asynchronously yields leadership and gives other candidates a chance to become a leader.
youngest() - Method in interface io.hekate.cluster.ClusterTopology
Returns the youngest node of this topology.

Z

zooKeeperSeedNodeProvider(ZooKeeperSeedNodeProviderConfig) - Method in class io.hekate.spring.boot.cluster.HekateZooKeeperSeedNodeProviderConfigurer
ZooKeeperSeedNodeProvider - Class in io.hekate.cluster.seed.zookeeper
ZooKeeper-based implementation of SeedNodeProvider interface.
ZooKeeperSeedNodeProvider(ZooKeeperSeedNodeProviderConfig) - Constructor for class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProvider
Constructs new instance.
zooKeeperSeedNodeProviderConfig() - Method in class io.hekate.spring.boot.cluster.HekateZooKeeperSeedNodeProviderConfigurer
Conditionally constructs a new configuration for ZooKeeperSeedNodeProvider if application doesn't provide its own Bean of ZooKeeperSeedNodeProviderConfig type.
ZooKeeperSeedNodeProviderConfig - Class in io.hekate.cluster.seed.zookeeper
Configuration for ZooKeeperSeedNodeProvider.
ZooKeeperSeedNodeProviderConfig() - Constructor for class io.hekate.cluster.seed.zookeeper.ZooKeeperSeedNodeProviderConfig
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
All Classes All Packages