Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X 

A

AbstractRedisClient - Class in services.moleculer.util.redis
Promise-based abstract Redis client.
AbstractRedisClient(String[], String, boolean, ExecutorService, EventBus) - Constructor for class services.moleculer.util.redis.AbstractRedisClient
 
acknowledgeMode - Variable in class services.moleculer.transporter.JmsTransporter
 
ackTimeout - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
action - Variable in exception services.moleculer.error.QueueIsFullError
 
action - Variable in exception services.moleculer.error.RequestRejectedError
 
action - Variable in exception services.moleculer.error.RequestSkippedError
 
action - Variable in exception services.moleculer.error.RequestTimeoutError
 
action - Variable in exception services.moleculer.error.ServiceNotAvailableError
 
action - Variable in exception services.moleculer.error.ServiceNotFoundError
 
Action - Interface in services.moleculer.service
Interface all Actions.
action - Variable in class services.moleculer.service.PendingPromise
 
ActionEndpoint - Class in services.moleculer.service
 
ActionEndpoint(String, String, Tree) - Constructor for class services.moleculer.service.ActionEndpoint
 
actions - Variable in class services.moleculer.internal.NodeService
Implementation of the "$node.actions" action
actual - Variable in exception services.moleculer.error.ProtocolVersionMismatchError
 
addActions(String, Service) - Method in class services.moleculer.service.DefaultServiceRegistry
 
addActions(String, Tree) - Method in class services.moleculer.service.DefaultServiceRegistry
 
addActions(String, Service) - Method in class services.moleculer.service.ServiceRegistry
 
addActions(String, Tree) - Method in class services.moleculer.service.ServiceRegistry
 
addCacheConfiguration(String, Configuration<String, byte[]>) - Method in class services.moleculer.cacher.JCacheCacher
 
addClassLoaderMetrics() - Method in class services.moleculer.metrics.DefaultMetrics
 
addEndpoint(T) - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
addEndpoint(T) - Method in class services.moleculer.strategy.ShardStrategy
 
addEndpoint(T) - Method in class services.moleculer.strategy.Strategy
 
addExecutorServiceMetrics(ExecutorService, String, String...) - Method in class services.moleculer.metrics.DefaultMetrics
 
addIgnoredType(Class<? extends Throwable>) - Method in class services.moleculer.breaker.CircuitBreaker
 
addJvmGcMetrics() - Method in class services.moleculer.metrics.DefaultMetrics
 
addJvmMemoryMetrics() - Method in class services.moleculer.metrics.DefaultMetrics
 
addJvmThreadMetrics() - Method in class services.moleculer.metrics.DefaultMetrics
 
addKeysTo(Tree, String) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
addListeners(String, Service) - Method in class services.moleculer.eventbus.DefaultEventbus
 
addListeners(String, Tree) - Method in class services.moleculer.eventbus.DefaultEventbus
 
addListeners(String, Service) - Method in class services.moleculer.eventbus.Eventbus
 
addListeners(String, Tree) - Method in class services.moleculer.eventbus.Eventbus
 
addMetrics(MeterBinder) - Method in class services.moleculer.metrics.DefaultMetrics
 
addOnlineActions(String, Service) - Method in class services.moleculer.service.DefaultServiceRegistry
 
addProcessorMetrics() - Method in class services.moleculer.metrics.DefaultMetrics
 
addValue(long) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 
advancedStats - Variable in class services.moleculer.transporter.NatsTransporter
Turn on advanced stats, primarily for test/benchmarks.
algorithm - Variable in class services.moleculer.serializer.BlockCipherSerializer
Type of the block Cipher.
AmqpTransporter - Class in services.moleculer.transporter
AMQP Transporter based on RabbitMQ's AMQP client API.
AmqpTransporter() - Constructor for class services.moleculer.transporter.AmqpTransporter
 
AmqpTransporter(String) - Constructor for class services.moleculer.transporter.AmqpTransporter
 
AmqpTransporter(String, String, SslContextFactory, String) - Constructor for class services.moleculer.transporter.AmqpTransporter
 
append(byte[]) - Method in class services.moleculer.transporter.tcp.SendBuffer
Adds a packet to the buffer's queue.
append(String, SendBuffer, byte[]) - Method in class services.moleculer.transporter.tcp.TcpWriter
 
appendMessages(StringBuilder, Throwable) - Method in class services.moleculer.logger.FastLogFormatter
 
appendMessages(LinkedList<String>, Throwable, int) - Method in class services.moleculer.logger.FastLogFormatter
 
appendToFile(String, byte[]) - Method in class services.moleculer.logger.AsyncFileLogger
 
appendToKey(StringBuilder, Tree) - Method in class services.moleculer.cacher.Cacher
 
appendTree(StringBuilder, Object) - Method in class services.moleculer.cacher.Cacher
 
ArrayBasedStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Abstract class for Round-Robin and Random invocation strategies.
ArrayBasedStrategy(ServiceBroker, boolean) - Constructor for class services.moleculer.strategy.ArrayBasedStrategy
 
ArrayBasedStrategyFactory - Class in services.moleculer.strategy
Abstract class for Round-Robin and Random invocation strategy factories.
ArrayBasedStrategyFactory() - Constructor for class services.moleculer.strategy.ArrayBasedStrategyFactory
Constructor that uses local services when available.
ArrayBasedStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.ArrayBasedStrategyFactory
Constructor that can be configured to use local services if possible.
ArraySerializer() - Constructor for class services.moleculer.cacher.OHCacher.ArraySerializer
 
asOutputStream() - Method in class services.moleculer.stream.PacketStream
 
asWritableByteChannel() - Method in class services.moleculer.stream.PacketStream
 
AsyncFileLogger - Class in services.moleculer.logger
To set up, add the following line to the JVM properties:

-Djava.util.logging.config.file=.
AsyncFileLogger() - Constructor for class services.moleculer.logger.AsyncFileLogger
 
asyncLocalInvocation - Variable in class services.moleculer.service.DefaultServiceRegistry
Invoke all local services via Thread pool (true) or directly (false)
AT - Static variable in class services.moleculer.logger.FastLogFormatter
 
authHandler - Variable in class services.moleculer.transporter.NatsTransporter
Optional AuthHandler.
average - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 

B

binders - Variable in class services.moleculer.metrics.DefaultMetrics
 
BlockCipherSerializer - Class in services.moleculer.serializer
Serializer with Symmetric Key Encryption.
BlockCipherSerializer() - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a JSON Serializer that uses AES encryption algorithm with the default password (using the hard-coded, default password is not very secure).
BlockCipherSerializer(String) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a JSON Serializer that uses AES encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(Serializer) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(Serializer, String) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(Serializer, String, String) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(String, String, byte[]) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(String, String, String) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(Serializer, String, String, String) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
BlockCipherSerializer(Serializer, String, String, byte[]) - Constructor for class services.moleculer.serializer.BlockCipherSerializer
Creates a Serializer that uses a symmetric encryption algorithm to encrypt/decrypt messages.
blockerBuffer - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
BREAK - Static variable in class services.moleculer.logger.FastLogFormatter
 
BREAK_STRING - Static variable in class services.moleculer.logger.FastLogFormatter
 
broadcast(String, Tree, Groups, PacketStream, CallOptions.Options, boolean) - Method in class services.moleculer.context.Context
 
broadcast(String, Object...) - Method in class services.moleculer.context.ContextSource
Sends an event to ALL listeners from ALL (or the specified) event group(s), who are listening this event.
broadcast(String, Tree, Groups) - Method in class services.moleculer.context.ContextSource
Sends an event to ALL listeners from the specified event group(s), who are listening this event.
broadcast(String, Tree) - Method in class services.moleculer.context.ContextSource
Sends an event to ALL listeners from ALL event groups, who are listening this event.
broadcast(String, PacketStream) - Method in class services.moleculer.context.ContextSource
Sends an event to ALL listeners from ALL event groups, who are listening this event.
broadcast(String, PacketStream, Groups) - Method in class services.moleculer.context.ContextSource
Sends an event to ALL listeners from ALL event groups, who are listening this event.
broadcast(String, Tree, Groups, PacketStream, CallOptions.Options, boolean) - Method in class services.moleculer.context.ContextSource
 
broadcast(Context, Groups, boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
broadcast(Context, Groups, boolean) - Method in class services.moleculer.eventbus.Eventbus
 
broadcasterCache - Variable in class services.moleculer.eventbus.DefaultEventbus
 
broadcastInfoPacket() - Method in class services.moleculer.transporter.TcpTransporter
 
broadcastInfoPacket() - Method in class services.moleculer.transporter.Transporter
 
broadcastInternal(Context, Groups, boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
broadcastLocal(String, Object...) - Method in class services.moleculer.context.ContextSource
Emits a LOCAL event to ALL listeners from ALL (or the specified) event group(s), who are listening this event.
broadcastLocal(String, Tree, Groups) - Method in class services.moleculer.context.ContextSource
Emits a LOCAL event to ALL listeners from the specified event group(s), who are listening this event.
broadcastLocal(String, Tree) - Method in class services.moleculer.context.ContextSource
Emits a LOCAL event to ALL listeners from ALL event groups, who are listening this event.
broadcastNodeConnected(Tree, boolean) - Method in class services.moleculer.transporter.Transporter
 
broadcastNodeDisconnected(Tree, boolean) - Method in class services.moleculer.transporter.Transporter
 
broadcastNodeUpdated(Tree) - Method in class services.moleculer.transporter.Transporter
 
broadcastReceiver - Variable in class services.moleculer.transporter.tcp.UDPBroadcastReceiver
Broadcast receiver
broadcastServicesChanged(boolean) - Method in class services.moleculer.service.DefaultServiceRegistry
 
broadcastServicesChanged() - Method in class services.moleculer.ServiceBroker
 
broadcastTransporterConnected() - Method in class services.moleculer.transporter.Transporter
 
broadcastTransporterDisconnected() - Method in class services.moleculer.transporter.Transporter
 
broker - Variable in class services.moleculer.service.MoleculerComponent
 
BROKER_OPTIONS_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
BrokerOptionsError - Exception in services.moleculer.error
Custom Moleculer exception class for broker option errors.
BrokerOptionsError(String, String, Object...) - Constructor for exception services.moleculer.error.BrokerOptionsError
 
BrokerOptionsError(Tree) - Constructor for exception services.moleculer.error.BrokerOptionsError
 
BsonSerializer - Class in services.moleculer.serializer
BSON Serializer

Binary BSON reader and writer.
BsonSerializer() - Constructor for class services.moleculer.serializer.BsonSerializer
 
buffer - Variable in class services.moleculer.stream.PacketStream
Memory-buffer of an unconnected stream.
BUFFER_IS_CLOSED - Static variable in class services.moleculer.transporter.tcp.SendBuffer
 
buffers - Variable in class services.moleculer.transporter.tcp.TcpWriter
 
bufferSize - Variable in class services.moleculer.transporter.NatsTransporter
Sets the initial size for buffers in the connection.
build() - Method in class services.moleculer.config.ServiceBrokerBuilder
 
builder() - Static method in class services.moleculer.ServiceBroker
Creates a new ServiceBrokerBuilder instance.
bytesToKey(byte[]) - Method in class services.moleculer.cacher.OHCacher
 
bytesToValue(byte[]) - Method in class services.moleculer.cacher.OHCacher
 

C

Cache - Annotation Type in services.moleculer.cacher
Cache annotation to set the caching policy of Actions.
cache - Variable in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
cache - Variable in class services.moleculer.cacher.OHCacher
 
cache - Variable in class services.moleculer.strategy.ShardStrategy.Ring
Accelerator cache
cacheConfigurations - Variable in class services.moleculer.cacher.JCacheCacher
Optional cache configurations by cache regions
cachedCPU - Static variable in class services.moleculer.monitor.Monitor
Cached CPU usage
cachedDescriptor - Variable in class services.moleculer.service.DefaultServiceRegistry
 
cachedDescriptor - Variable in class services.moleculer.transporter.TcpTransporter
Current node descriptor
cachedHelloMessage - Variable in class services.moleculer.transporter.TcpTransporter
 
cachedPID - Static variable in class services.moleculer.monitor.Monitor
Cached process ID
cacheManager - Variable in class services.moleculer.cacher.JCacheCacher
 
Cacher - Class in services.moleculer.cacher
Base superclass of all Cacher implementations.
Cacher() - Constructor for class services.moleculer.cacher.Cacher
 
cacher(Cacher) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
cacher - Variable in class services.moleculer.config.ServiceBrokerConfig
 
cacheSize - Variable in class services.moleculer.strategy.ShardStrategy
Size of the memory cache (0 = disabled)
cacheSize - Variable in class services.moleculer.strategy.ShardStrategyFactory
Size of the memory cache (0 = disabled)
cacheTimeout - Variable in class services.moleculer.monitor.Monitor
CPU cache timeout in MILLISECONDS
call(Context, String, int) - Method in class services.moleculer.breaker.CircuitBreaker
 
call(String, Tree, CallOptions.Options, PacketStream) - Method in class services.moleculer.context.Context
Calls an action (local or remote).
call(String, Object...) - Method in class services.moleculer.context.ContextSource
Calls an action (local or remote).
call(String, Tree) - Method in class services.moleculer.context.ContextSource
Calls an action (local or remote).
call(String, Tree, CallOptions.Options) - Method in class services.moleculer.context.ContextSource
Calls an action (local or remote).
call(String, PacketStream) - Method in class services.moleculer.context.ContextSource
Calls an action (local or remote).
call(String, PacketStream, CallOptions.Options) - Method in class services.moleculer.context.ContextSource
Calls an action (local or remote).
call(String, Tree, CallOptions.Options, PacketStream) - Method in class services.moleculer.context.ContextSource
 
call(Context) - Method in class services.moleculer.service.DefaultServiceInvoker
 
call(Context, String, int) - Method in class services.moleculer.service.DefaultServiceInvoker
 
call(Context) - Method in class services.moleculer.service.ServiceInvoker
 
CallOptions - Class in services.moleculer.context
Calling options (timeout, target nodeID, number of retries).
CallOptions() - Constructor for class services.moleculer.context.CallOptions
 
CallOptions.Options - Class in services.moleculer.context
 
callTimeoutTimer - Variable in class services.moleculer.service.DefaultServiceRegistry
Cancelable timer for handling timeouts of action calls
canRemove(long) - Method in class services.moleculer.breaker.ErrorCounter
 
capacity - Variable in class services.moleculer.cacher.MemoryCacher
Maximum number of entries per partition
capacity - Variable in class services.moleculer.cacher.OHCacher
Maximum capacity of whole cache in MEGABYTES
cause - Variable in class services.moleculer.stream.PacketStream
Cause (blocking error).
CborSerializer - Class in services.moleculer.serializer
CBOR Serializer

CBOR is based on the wildly successful JSON data model: numbers, strings, arrays, maps (called objects in JSON), and a few values such as false, true, and null.
CborSerializer() - Constructor for class services.moleculer.serializer.CborSerializer
 
ChainedSerializer - Class in services.moleculer.serializer
Superclass of chainable Serializers.
ChainedSerializer(Serializer) - Constructor for class services.moleculer.serializer.ChainedSerializer
 
channel - Variable in class services.moleculer.transporter.AmqpTransporter
 
channel - Variable in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
channel - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
channel(String, String) - Method in class services.moleculer.transporter.Transporter
 
channels - Variable in class services.moleculer.transporter.InternalTransporter
 
checkedMiddlewares - Variable in class services.moleculer.service.ActionEndpoint
 
CheckedTree - Class in services.moleculer.util
For internal use only!
CheckedTree(Object) - Constructor for class services.moleculer.util.CheckedTree
 
CheckedTree(Object, Object) - Constructor for class services.moleculer.util.CheckedTree
 
checkServicesOnline() - Method in class services.moleculer.service.DefaultServiceRegistry
 
checkTimeouts() - Method in class services.moleculer.eventbus.DefaultEventbus
 
checkTimeouts() - Method in class services.moleculer.service.DefaultServiceRegistry
 
checkTimeouts() - Method in class services.moleculer.transporter.Transporter
 
checkTimeoutTimer - Variable in class services.moleculer.transporter.Transporter
Cancelable "Check Activities / Infos" timer
checkVersion - Variable in class services.moleculer.eventbus.DefaultEventbus
Check protocol version
checkVersion - Variable in class services.moleculer.service.DefaultServiceRegistry
Check protocol version
CircuitBreaker - Class in services.moleculer.breaker
Special service invoker with retry logic + circuit breaker.
CircuitBreaker() - Constructor for class services.moleculer.breaker.CircuitBreaker
 
clean(String) - Method in class services.moleculer.cacher.Cacher
Cleans this cache.
clean(String) - Method in class services.moleculer.cacher.JCacheCacher
 
clean(Cache<String, byte[]>, String) - Static method in class services.moleculer.cacher.JCacheCacher
 
clean(String) - Method in class services.moleculer.cacher.MemoryCacher
 
clean(String) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
clean(String) - Method in class services.moleculer.cacher.OHCacher
 
clean(String) - Method in class services.moleculer.cacher.RedisCacher
 
clean(String, AtomicLong) - Method in class services.moleculer.util.redis.RedisGetSetClient
Deletes a group of items.
cleanSession - Variable in class services.moleculer.transporter.MqttTransporter
 
cleanup - Variable in class services.moleculer.breaker.CircuitBreaker
Cleanup period time, in SECONDS (0 = disable cleanup process)
cleanup - Variable in class services.moleculer.cacher.MemoryCacher
Cleanup period time, in SECONDS (0 = disable cleanup process)
cleanup() - Method in class services.moleculer.transporter.tcp.TcpWriter
 
clear() - Method in class services.moleculer.util.FastBuildMap
 
clearDescriptorCache() - Method in class services.moleculer.service.DefaultServiceRegistry
 
client - Variable in class services.moleculer.cacher.RedisCacher
 
client - Variable in class services.moleculer.transporter.AmqpTransporter
 
client - Variable in class services.moleculer.transporter.JmsTransporter
 
client - Variable in class services.moleculer.transporter.MqttTransporter
 
client - Variable in class services.moleculer.transporter.NatsStreamingTransporter
Nats connection.
client - Variable in class services.moleculer.transporter.NatsTransporter
 
clientId - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
clientPub - Variable in class services.moleculer.transporter.RedisTransporter
 
clientSub - Variable in class services.moleculer.transporter.RedisTransporter
 
close() - Method in class services.moleculer.logger.AsyncFileLogger
 
close() - Method in class services.moleculer.transporter.tcp.SendBuffer
 
close(SelectionKey, Exception) - Method in class services.moleculer.transporter.tcp.TcpReader
 
close(String) - Method in class services.moleculer.transporter.tcp.TcpWriter
 
close(SelectionKey, Exception) - Method in class services.moleculer.transporter.tcp.TcpWriter
 
CLOSE_MARKER - Static variable in class services.moleculer.stream.PacketStream
 
closed - Variable in class services.moleculer.stream.PacketStream
Is stream closed?
closeEmptyPartitions - Variable in class services.moleculer.cacher.JCacheCacher
Close empty caches
closeReporter(Closeable) - Method in class services.moleculer.metrics.DropwizardReportersImpl
 
closeResources() - Method in class services.moleculer.transporter.tcp.SendBuffer
 
closeStream() - Method in class services.moleculer.logger.AsyncFileLogger
 
clusterId - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
code - Variable in exception services.moleculer.error.MoleculerError
 
collectCount - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
Number of samples used for average calculation.
collectExpiredEntries(long, LinkedList<String>) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
ColoredConsoleLogger - Class in services.moleculer.logger
"Colorized" ANSI logger.
ColoredConsoleLogger() - Constructor for class services.moleculer.logger.ColoredConsoleLogger
 
coloredPrinter - Variable in class services.moleculer.logger.ColoredConsoleLogger
 
command - Variable in class services.moleculer.monitor.CommandMonitor
 
CommandMonitor - Class in services.moleculer.monitor
CPU monitor, which detects the current CPU usage via command line.
CommandMonitor() - Constructor for class services.moleculer.monitor.CommandMonitor
 
CommandMonitor(String) - Constructor for class services.moleculer.monitor.CommandMonitor
 
CommonUtils - Class in services.moleculer.util
Common utilities.
CommonUtils() - Constructor for class services.moleculer.util.CommonUtils
 
compress(byte[], int) - Static method in class services.moleculer.util.CommonUtils
 
compressAbove - Variable in class services.moleculer.cacher.OHCacher
Compress key and/or value above this size (BYTES), 0 = disable compression
compressAfterDays - Variable in class services.moleculer.logger.AsyncFileLogger
 
compressionLevel - Variable in class services.moleculer.cacher.OHCacher
Compression level (best speed = 1, best compression = 9)
compressionLevel - Variable in class services.moleculer.serializer.DeflaterSerializer
Compression level (best speed = 1, best compression = 9)
compressOrDeleteOldFiles() - Method in class services.moleculer.logger.AsyncFileLogger
 
config - Variable in class services.moleculer.config.ServiceBrokerBuilder
 
CONFIG - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
CONFIG - Static variable in class services.moleculer.logger.FastLogFormatter
 
CONFIG - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
config - Variable in class services.moleculer.service.ActionEndpoint
 
config - Variable in class services.moleculer.ServiceBroker
Configuration settings and internal components (event bus, cacher, service registry, etc.) of this node / broker.
configure() - Method in class services.moleculer.logger.AsyncFileLogger
 
connect() - Method in class services.moleculer.cacher.RedisCacher
 
connect() - Method in class services.moleculer.transporter.AmqpTransporter
 
connect() - Method in class services.moleculer.transporter.FileSystemTransporter
 
connect() - Method in class services.moleculer.transporter.InternalTransporter
 
connect() - Method in class services.moleculer.transporter.JmsTransporter
 
connect() - Method in class services.moleculer.transporter.KafkaTransporter
 
connect() - Method in class services.moleculer.transporter.MqttTransporter
 
connect() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
connect() - Method in class services.moleculer.transporter.NatsTransporter
 
connect() - Method in class services.moleculer.transporter.NullTransporter
 
connect() - Method in class services.moleculer.transporter.RedisTransporter
 
connect() - Method in class services.moleculer.transporter.tcp.TcpReader
 
connect() - Method in class services.moleculer.transporter.tcp.TcpWriter
 
connect() - Method in class services.moleculer.transporter.tcp.UDPBroadcastReceiver
 
connect() - Method in class services.moleculer.transporter.tcp.UDPLocator
 
connect() - Method in class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
connect() - Method in class services.moleculer.transporter.tcp.UDPReceiver
 
connect() - Method in class services.moleculer.transporter.TcpTransporter
 
connect() - Method in class services.moleculer.transporter.Transporter
 
connect() - Method in class services.moleculer.util.redis.AbstractRedisClient
 
connect() - Method in class services.moleculer.util.redis.RedisGetSetClient
 
connect() - Method in class services.moleculer.util.redis.RedisPubSubClient
 
connected(SelectionKey, SocketChannel) - Method in class services.moleculer.transporter.tcp.SendBuffer
 
connected() - Method in class services.moleculer.transporter.Transporter
 
connected(boolean) - Method in class services.moleculer.transporter.Transporter
 
connectionEvent(Connection, ConnectionListener.Events) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
connectionEvent(Connection, ConnectionListener.Events) - Method in class services.moleculer.transporter.NatsTransporter
 
connectionFactoryJndiName - Variable in class services.moleculer.transporter.JmsTransporter
 
connectionLost(Throwable) - Method in class services.moleculer.transporter.MqttTransporter
 
connectionLost(StreamingConnection, Exception) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
connectionTimeout - Variable in class services.moleculer.transporter.MqttTransporter
 
connectionTimeout - Variable in class services.moleculer.transporter.NatsTransporter
Set the timeout for connection attempts in MILLISECONDS.
connectTimeout - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
console - Variable in class services.moleculer.logger.AsyncFileLogger
 
ConsoleLogger - Interface in services.moleculer.logger
 
ConstantMonitor - Class in services.moleculer.monitor
"Fake" system monitor, which returns a constant value.
ConstantMonitor() - Constructor for class services.moleculer.monitor.ConstantMonitor
 
ConstantMonitor(int) - Constructor for class services.moleculer.monitor.ConstantMonitor
 
consumer - Variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
consumerProperties - Variable in class services.moleculer.transporter.KafkaTransporter
 
containsKey(Object) - Method in class services.moleculer.util.FastBuildMap
 
containsValue(Object) - Method in class services.moleculer.util.FastBuildMap
 
CONTENT - Static variable in class services.moleculer.cacher.DistributedCacher
 
CONTENT - Static variable in class services.moleculer.cacher.OHCacher
 
context - Static variable in class services.moleculer.config.MoleculerRunner
 
Context - Class in services.moleculer.context
 
Context(ServiceInvoker, Eventbus, UidGenerator, String, String, Tree, int, String, String, PacketStream, CallOptions.Options, String) - Constructor for class services.moleculer.context.Context
 
ContextSource - Class in services.moleculer.context
Base superclass of all objects that can send events (eg.
ContextSource(ServiceInvoker, Eventbus, UidGenerator, String) - Constructor for class services.moleculer.context.ContextSource
 
convertAnnotations(Tree, Annotation[]) - Static method in class services.moleculer.util.CommonUtils
 
counter - Variable in class services.moleculer.strategy.RoundRobinStrategy
 
counter - Variable in class services.moleculer.uid.IncrementalUidGenerator
 
counter - Variable in class services.moleculer.uid.XorShiftRandomUidGenerator
 
counterClean - Variable in class services.moleculer.cacher.JCacheCacher
 
counterClean - Variable in class services.moleculer.cacher.MemoryCacher
 
counterClean - Variable in class services.moleculer.cacher.OHCacher
 
counterClean - Variable in class services.moleculer.cacher.RedisCacher
 
counterDel - Variable in class services.moleculer.cacher.JCacheCacher
 
counterDel - Variable in class services.moleculer.cacher.MemoryCacher
 
counterDel - Variable in class services.moleculer.cacher.OHCacher
 
counterDel - Variable in class services.moleculer.cacher.RedisCacher
 
counterExpired - Variable in class services.moleculer.cacher.MemoryCacher
 
counterFound - Variable in class services.moleculer.cacher.JCacheCacher
 
counterFound - Variable in class services.moleculer.cacher.MemoryCacher
 
counterFound - Variable in class services.moleculer.cacher.OHCacher
 
counterFound - Variable in class services.moleculer.cacher.RedisCacher
 
counterGet - Variable in class services.moleculer.cacher.JCacheCacher
 
counterGet - Variable in class services.moleculer.cacher.MemoryCacher
 
counterGet - Variable in class services.moleculer.cacher.OHCacher
 
counterGet - Variable in class services.moleculer.cacher.RedisCacher
 
counterOrphanResponseTotal - Variable in class services.moleculer.service.DefaultServiceRegistry
 
counterSet - Variable in class services.moleculer.cacher.JCacheCacher
 
counterSet - Variable in class services.moleculer.cacher.MemoryCacher
 
counterSet - Variable in class services.moleculer.cacher.OHCacher
 
counterSet - Variable in class services.moleculer.cacher.RedisCacher
 
counterTransporterPacketsReceivedBytes - Variable in class services.moleculer.transporter.Transporter
 
counterTransporterPacketsReceivedTotal - Variable in class services.moleculer.transporter.Transporter
 
counterTransporterPacketsSentBytes - Variable in class services.moleculer.transporter.Transporter
 
counterTransporterPacketsSentTotal - Variable in class services.moleculer.transporter.Transporter
 
countOnlineServices(Collection<String>) - Method in class services.moleculer.service.DefaultServiceRegistry
 
cpu - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
cpuDetectedAt - Static variable in class services.moleculer.monitor.Monitor
Timestamp of CPU detection
cpuSeq - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
CpuUsageStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Lowest CPU usage invocation strategy.
CpuUsageStrategy(ServiceBroker, boolean, int, int, Transporter) - Constructor for class services.moleculer.strategy.CpuUsageStrategy
 
CpuUsageStrategyFactory - Class in services.moleculer.strategy
Factory of lowest CPU usage strategy.
CpuUsageStrategyFactory() - Constructor for class services.moleculer.strategy.CpuUsageStrategyFactory
Constructor that calls for service based primarily on its own (CPU-based) logic.
CpuUsageStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.CpuUsageStrategyFactory
Constructor that can be configured to use local services if possible.
CpuUsageStrategyFactory(boolean, int, int) - Constructor for class services.moleculer.strategy.CpuUsageStrategyFactory
 
cpuWhen - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
create(Tree) - Static method in class services.moleculer.error.MoleculerErrorUtils
 
create() - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
 
create() - Method in class services.moleculer.strategy.NanoSecRandomStrategyFactory
 
create() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
create() - Method in class services.moleculer.strategy.RoundRobinStrategyFactory
 
create() - Method in class services.moleculer.strategy.SecureRandomStrategyFactory
 
create() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
create() - Method in class services.moleculer.strategy.StrategyFactory
 
create() - Method in class services.moleculer.strategy.XorShiftRandomStrategyFactory
 
createdAt - Variable in class services.moleculer.context.Context
Timestamp
createOrGetPublisher(String) - Method in class services.moleculer.transporter.JmsTransporter
 
createPingPacket(String) - Method in class services.moleculer.transporter.Transporter
 
createService(Service) - Method in class services.moleculer.ServiceBroker
Installs a new service instance and notifies other nodes about the actions/listeners of the new service.
createService(String, Service) - Method in class services.moleculer.ServiceBroker
Installs a new service with the specified name (eg.
createStream() - Method in class services.moleculer.context.ContextSource
Creates a stream what is suitable for transferring large files (or other "unlimited" media content) between Moleculer Nodes.
current - Variable in class services.moleculer.service.ActionEndpoint
 
currentDescriptor() - Method in class services.moleculer.service.DefaultServiceRegistry
 
currentPort - Variable in class services.moleculer.transporter.tcp.TcpReader
Current TPC port
currentPort - Variable in class services.moleculer.transporter.TcpTransporter
Current TCP port
customWebSocketHeaders - Variable in class services.moleculer.transporter.MqttTransporter
 

D

data - Variable in exception services.moleculer.error.MoleculerError
 
data - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 
data - Variable in class services.moleculer.util.ParseResult
 
DAY - Static variable in class services.moleculer.logger.AsyncFileLogger
 
debug - Variable in class services.moleculer.cacher.Cacher
 
debug - Variable in class services.moleculer.serializer.Serializer
Enable debug mode.
debug - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
debug - Variable in class services.moleculer.transporter.tcp.SendBuffer
Debug mode
debug - Variable in class services.moleculer.transporter.tcp.TcpReader
Debug mode
debug - Variable in class services.moleculer.transporter.tcp.TcpWriter
Debug mode
debug - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Debug mode
debug - Variable in class services.moleculer.transporter.Transporter
Writes the communication of method calls and events into the log.
debugHeartbeats - Variable in class services.moleculer.transporter.Transporter
Writes the communication of heartbeats/gossiping into the log.
decompress(byte[]) - Static method in class services.moleculer.util.CommonUtils
 
decrement() - Method in interface services.moleculer.metrics.MetricCounter
 
decrement(long) - Method in interface services.moleculer.metrics.MetricCounter
 
decriptors - Variable in class services.moleculer.serializer.BlockCipherSerializer
 
decrypt(Cipher, byte[]) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
DEFAULT_ALGORITHM - Static variable in class services.moleculer.serializer.BlockCipherSerializer
Same as "aes-256-cbc" in Node.js.
DEFAULT_MIN_PACKET_SIZE - Static variable in class services.moleculer.stream.PacketStream
 
defaultConfiguration - Variable in class services.moleculer.cacher.JCacheCacher
Default cache cconfiguration
DefaultEventbus - Class in services.moleculer.eventbus
Default EventBus implementation.
DefaultEventbus() - Constructor for class services.moleculer.eventbus.DefaultEventbus
 
DefaultMetrics - Class in services.moleculer.metrics
 
DefaultMetrics() - Constructor for class services.moleculer.metrics.DefaultMetrics
 
DefaultMetrics(MeterRegistry...) - Constructor for class services.moleculer.metrics.DefaultMetrics
 
DefaultServiceInvoker - Class in services.moleculer.service
Default service invoker with retry logic.
DefaultServiceInvoker() - Constructor for class services.moleculer.service.DefaultServiceInvoker
 
DefaultServiceRegistry - Class in services.moleculer.service
Default implementation of the Service Registry.
DefaultServiceRegistry() - Constructor for class services.moleculer.service.DefaultServiceRegistry
 
DefaultServiceRegistry(boolean) - Constructor for class services.moleculer.service.DefaultServiceRegistry
 
DeflaterSerializer - Class in services.moleculer.serializer
Message compressor / decompressor.
DeflaterSerializer() - Constructor for class services.moleculer.serializer.DeflaterSerializer
Creates a JSON-based Serializer that compresses content above 1024 bytes with compression level "1".
DeflaterSerializer(int) - Constructor for class services.moleculer.serializer.DeflaterSerializer
Creates a JSON-based Serializer that compresses content above a specified size (see the "compressAbove" parameter).
DeflaterSerializer(int, int) - Constructor for class services.moleculer.serializer.DeflaterSerializer
Creates a JSON-based Serializer that compresses content above a specified size with the specified compression level (1-9).
DeflaterSerializer(Serializer) - Constructor for class services.moleculer.serializer.DeflaterSerializer
Creates a custom Serializer that compresses content above 1024 bytes size with the compression level "1".
DeflaterSerializer(Serializer, int, int) - Constructor for class services.moleculer.serializer.DeflaterSerializer
Creates a custom Serializer that compresses content above a specified size with the specified compression level (1-9).
del(String) - Method in class services.moleculer.cacher.Cacher
Deletes a content from this cache.
del(String) - Method in class services.moleculer.cacher.JCacheCacher
 
del(String) - Method in class services.moleculer.cacher.MemoryCacher
 
del(String) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
del(String) - Method in class services.moleculer.cacher.OHCacher
 
del(String) - Method in class services.moleculer.cacher.RedisCacher
 
del(String) - Method in class services.moleculer.util.redis.RedisGetSetClient
Deletes a content with the specified key.
deleteAfterDays - Variable in class services.moleculer.logger.AsyncFileLogger
 
deliveryComplete(IMqttDeliveryToken) - Method in class services.moleculer.transporter.MqttTransporter
 
deliveryMode - Variable in class services.moleculer.transporter.JmsTransporter
 
Dependencies - Annotation Type in services.moleculer.service
 
deregister(String) - Method in class services.moleculer.service.DefaultServiceRegistry
 
deregister() - Method in class services.moleculer.transporter.InternalTransporter
 
deregister(String, InternalTransporter, boolean) - Method in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
deregister(InternalTransporter) - Method in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
deregisterCustomError(String) - Static method in class services.moleculer.error.MoleculerErrorUtils
 
deserialize(ByteBuffer) - Method in class services.moleculer.cacher.OHCacher.ArraySerializer
 
detectPID() - Method in class services.moleculer.monitor.CommandMonitor
Returns the PID of Java VM.
detectPID() - Method in class services.moleculer.monitor.ConstantMonitor
Returns the system CPU usage, in percents, between 0 and 100.
detectPID() - Method in class services.moleculer.monitor.JmxMonitor
Returns the system CPU usage, in percents, between 0 and 100.
detectPID() - Method in class services.moleculer.monitor.Monitor
Returns the system CPU usage, in percents, between 0 and 100.
detectPID() - Method in class services.moleculer.monitor.SigarMonitor
Returns the PID of Java VM.
detectTotalCpuPercent() - Method in class services.moleculer.monitor.CommandMonitor
Returns the system CPU usage, in percents, between 0 and 100.
detectTotalCpuPercent() - Method in class services.moleculer.monitor.ConstantMonitor
Returns the system CPU usage, in percents, between 0 and 100.
detectTotalCpuPercent() - Method in class services.moleculer.monitor.JmxMonitor
Returns the system CPU usage, in percents, between 0 and 100.
detectTotalCpuPercent() - Method in class services.moleculer.monitor.Monitor
Returns the system CPU usage, in percents, between 0 and 100.
detectTotalCpuPercent() - Method in class services.moleculer.monitor.SigarMonitor
Returns the system CPU usage, in percents, between 0 and 100.
directory - Variable in class services.moleculer.logger.AsyncFileLogger
 
directory - Variable in class services.moleculer.transporter.FileSystemTransporter
Root directory of message files (eg.
directory - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
DirectoryHandler(File, long, boolean, boolean, boolean, int) - Constructor for class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
disconnect() - Method in class services.moleculer.cacher.RedisCacher
 
disconnect() - Method in class services.moleculer.transporter.AmqpTransporter
 
disconnect() - Method in class services.moleculer.transporter.JmsTransporter
 
disconnect() - Method in class services.moleculer.transporter.KafkaTransporter
 
disconnect() - Method in class services.moleculer.transporter.MqttTransporter
 
disconnect() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
disconnect() - Method in class services.moleculer.transporter.NatsTransporter
 
disconnect() - Method in class services.moleculer.transporter.RedisTransporter
 
disconnect() - Method in class services.moleculer.transporter.tcp.TcpReader
 
disconnect() - Method in class services.moleculer.transporter.tcp.TcpWriter
 
disconnect() - Method in class services.moleculer.transporter.tcp.UDPBroadcastReceiver
 
disconnect() - Method in class services.moleculer.transporter.tcp.UDPLocator
 
disconnect() - Method in class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
disconnect() - Method in class services.moleculer.transporter.tcp.UDPReceiver
 
disconnect() - Method in class services.moleculer.transporter.TcpTransporter
 
disconnect() - Method in class services.moleculer.util.redis.AbstractRedisClient
 
disconnect() - Method in class services.moleculer.util.redis.RedisGetSetClient
 
disconnect() - Method in class services.moleculer.util.redis.RedisPubSubClient
 
disconnectChannel - Variable in class services.moleculer.transporter.Transporter
 
discoverBroadcastChannel - Variable in class services.moleculer.transporter.Transporter
 
discoverChannel - Variable in class services.moleculer.transporter.Transporter
 
discoverPrefix - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
dispatcher - Variable in class services.moleculer.transporter.NatsTransporter
 
DistributedCacher - Class in services.moleculer.cacher
Abstract class of distributed cachers.
DistributedCacher() - Constructor for class services.moleculer.cacher.DistributedCacher
 
DistributedCacher(int) - Constructor for class services.moleculer.cacher.DistributedCacher
 
distributionStatisticBufferLength - Variable in class services.moleculer.metrics.DefaultMetrics
 
dropwizardInstalled - Variable in class services.moleculer.metrics.DropwizardReportersImpl
 
dropwizardRegistry - Variable in class services.moleculer.metrics.DropwizardReportersImpl
 
DropwizardReporters - Interface in services.moleculer.metrics
 
DropwizardReportersImpl - Class in services.moleculer.metrics
 
DropwizardReportersImpl() - Constructor for class services.moleculer.metrics.DropwizardReportersImpl
 
dump(Throwable, int, int) - Method in class services.moleculer.logger.FastLogFormatter
 

E

emit(String, Tree, Groups, PacketStream, CallOptions.Options) - Method in class services.moleculer.context.Context
 
emit(String, Object...) - Method in class services.moleculer.context.ContextSource
Emits an event to ONE listener from ALL (or the specified) event group(s), who are listening this event.
emit(String, Tree, Groups) - Method in class services.moleculer.context.ContextSource
Emits an event to ONE listener from the specified event group(s), who are listening this event.
emit(String, Tree) - Method in class services.moleculer.context.ContextSource
Emits an event to ONE listener from ALL event groups, who are listening this event.
emit(String, PacketStream) - Method in class services.moleculer.context.ContextSource
Emits an event to ONE listener from ALL event groups, who are listening this event.
emit(String, PacketStream, Groups) - Method in class services.moleculer.context.ContextSource
Emits an event to ONE listener from ALL event groups, who are listening this event.
emit(String, Tree, Groups, PacketStream, CallOptions.Options) - Method in class services.moleculer.context.ContextSource
 
emit(Context, Groups, boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
emit(Context, Groups, boolean) - Method in class services.moleculer.eventbus.Eventbus
 
emitInternal(Context, Groups, boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
emitterCache - Variable in class services.moleculer.eventbus.DefaultEventbus
 
EMPTY_IV - Static variable in class services.moleculer.serializer.BlockCipherSerializer
Empty IV block.
enableColors - Variable in class services.moleculer.logger.AsyncFileLogger
 
encriptors - Variable in class services.moleculer.serializer.BlockCipherSerializer
 
encrypt(Cipher, byte[]) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
Endpoint - Class in services.moleculer.service
 
Endpoint(String) - Constructor for class services.moleculer.service.Endpoint
 
endpointCache - Variable in class services.moleculer.strategy.ArrayBasedStrategy
 
EndpointKey - Class in services.moleculer.breaker
 
EndpointKey(String, String) - Constructor for class services.moleculer.breaker.EndpointKey
 
endpoints - Variable in class services.moleculer.strategy.ArrayBasedStrategy
 
entrySet() - Method in class services.moleculer.util.FastBuildMap
 
equals(Object) - Method in class services.moleculer.breaker.EndpointKey
 
equals(Object) - Method in class services.moleculer.eventbus.ListenerEndpoint
 
equals(Object) - Method in class services.moleculer.service.ActionEndpoint
 
equals(Object) - Method in class services.moleculer.transporter.FileSystemTransporter.RemovableFile
 
error(Throwable) - Method in class services.moleculer.stream.IncomingStream
 
error(Throwable) - Method in class services.moleculer.transporter.AmqpTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.JmsTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.KafkaTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.MqttTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.NatsTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.RedisTransporter
 
error(Throwable) - Method in class services.moleculer.transporter.Transporter
Any I/O error occurred.
ErrorCounter - Class in services.moleculer.breaker
 
ErrorCounter(long, long, int) - Constructor for class services.moleculer.breaker.ErrorCounter
 
ErrorCounter.Status - Enum in services.moleculer.breaker
 
errorCounters - Variable in class services.moleculer.breaker.CircuitBreaker
 
errorOccurred(Connection, String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
errors - Variable in class services.moleculer.breaker.ErrorCounter
 
errorWriter - Variable in class services.moleculer.logger.ColoredConsoleLogger
 
event - Variable in exception services.moleculer.error.ListenerNotAvailableError
 
eventbus(Eventbus) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
eventbus - Variable in class services.moleculer.config.ServiceBrokerConfig
 
eventbus - Variable in class services.moleculer.context.ContextSource
Eventbus of the ServiceBroker or Context.
Eventbus - Class in services.moleculer.eventbus
Base superclass of all Event Bus implementations.
Eventbus() - Constructor for class services.moleculer.eventbus.Eventbus
 
eventbus - Variable in class services.moleculer.service.DefaultServiceInvoker
 
eventbus - Variable in class services.moleculer.service.DefaultServiceRegistry
 
eventbus - Variable in class services.moleculer.transporter.Transporter
 
eventChannel - Variable in class services.moleculer.transporter.Transporter
 
events - Variable in class services.moleculer.internal.NodeService
Implementation of the "$node.events" action
exceptionOccurred(Connection, Exception) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
exchangeProperties - Variable in class services.moleculer.transporter.AmqpTransporter
 
exchangeType - Variable in class services.moleculer.transporter.AmqpTransporter
 
exclusive - Variable in class services.moleculer.transporter.AmqpTransporter
 
executor - Variable in class services.moleculer.cacher.RedisCacher
 
executor(ExecutorService) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
executor - Variable in class services.moleculer.config.ServiceBrokerConfig
 
executor - Variable in class services.moleculer.logger.AsyncFileLogger
 
executor - Variable in class services.moleculer.service.DefaultServiceRegistry
 
executor - Variable in class services.moleculer.transporter.KafkaTransporter
Executor of reader loop for incoming messages
executor - Variable in class services.moleculer.transporter.tcp.TcpReader
Server's executor
executor - Variable in class services.moleculer.transporter.tcp.TcpWriter
Writer thread
executor - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Receiver's executor
executor - Variable in class services.moleculer.transporter.Transporter
 
executorServiceTimeout - Variable in class services.moleculer.transporter.MqttTransporter
 
expiration - Variable in class services.moleculer.cacher.RedisCacher
 
expireAt - Variable in class services.moleculer.cacher.MemoryCacher.PartitionEntry
 
extractStream(Tree) - Static method in class services.moleculer.util.CommonUtils
 

F

factory - Variable in class services.moleculer.strategy.NetworkLatencyStrategy
 
factory - Variable in class services.moleculer.transporter.AmqpTransporter
 
factory - Variable in class services.moleculer.transporter.JmsTransporter
 
FastBuildEntrySet(int, String[], Object[]) - Constructor for class services.moleculer.util.FastBuildMap.FastBuildEntrySet
 
FastBuildMap - Class in services.moleculer.util
This Map is optimized for fast building and serialization.
FastBuildMap(int) - Constructor for class services.moleculer.util.FastBuildMap
 
FastBuildMap.FastBuildEntrySet - Class in services.moleculer.util
 
FastBuildTree - Class in services.moleculer.util
This Tree is optimized for fast building and serialization.
FastBuildTree() - Constructor for class services.moleculer.util.FastBuildTree
 
FastBuildTree(int) - Constructor for class services.moleculer.util.FastBuildTree
 
FastLogFormatter - Class in services.moleculer.logger
Fast log formatter for AsyncFileLogger.
FastLogFormatter() - Constructor for class services.moleculer.logger.FastLogFormatter
 
file - Variable in class services.moleculer.transporter.FileSystemTransporter.RemovableFile
 
FILE_FORMAT - Variable in class services.moleculer.logger.AsyncFileLogger
 
fileEncoding - Variable in class services.moleculer.logger.AsyncFileLogger
 
FileSystemTransporter - Class in services.moleculer.transporter
Filesystem-based transporter.
FileSystemTransporter() - Constructor for class services.moleculer.transporter.FileSystemTransporter
 
FileSystemTransporter(String) - Constructor for class services.moleculer.transporter.FileSystemTransporter
 
FileSystemTransporter(String, long) - Constructor for class services.moleculer.transporter.FileSystemTransporter
 
FileSystemTransporter.DirectoryHandler - Class in services.moleculer.transporter
 
FileSystemTransporter.RemovableFile - Class in services.moleculer.transporter
 
fileTimeout - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
fileTimeout - Variable in class services.moleculer.transporter.FileSystemTransporter
Read timeout of request in MILLISECONDS (deleted request files after this limit).
finalize() - Method in class services.moleculer.transporter.InternalTransporter
 
finalize() - Method in class services.moleculer.transporter.tcp.TcpReader
 
finalize() - Method in class services.moleculer.transporter.tcp.TcpWriter
 
finalize() - Method in class services.moleculer.transporter.tcp.UDPLocator
 
findLogDirectory(File) - Method in class services.moleculer.logger.AsyncFileLogger
 
FINE - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
FINE - Static variable in class services.moleculer.logger.FastLogFormatter
 
FINE - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
FINER - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
FINER - Static variable in class services.moleculer.logger.FastLogFormatter
 
FINER - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
FINEST - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
FINEST - Static variable in class services.moleculer.logger.FastLogFormatter
 
FINEST - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
firstError - Static variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
flush() - Method in class services.moleculer.logger.AsyncFileLogger
 
format(LogRecord) - Method in class services.moleculer.logger.FastLogFormatter
 
format - Variable in class services.moleculer.serializer.Serializer
Name of the format (eg.
formatNamoSec(long) - Static method in class services.moleculer.util.CommonUtils
 
formatNumber(Number) - Static method in class services.moleculer.util.CommonUtils
 
formatPath(String) - Static method in class services.moleculer.util.CommonUtils
 

G

gaugeExpired - Variable in class services.moleculer.cacher.OHCacher
 
gaugeRequestsActive - Variable in class services.moleculer.service.DefaultServiceRegistry
 
gaugeStreamsReceiveActive - Variable in class services.moleculer.service.DefaultServiceRegistry
 
gaugeTransitConnected - Variable in class services.moleculer.transporter.Transporter
 
generateGossipHello() - Method in class services.moleculer.transporter.TcpTransporter
Create Gossip HELLO packet.
generateListenerDescriptor(String) - Method in class services.moleculer.eventbus.DefaultEventbus
 
generateListenerDescriptor(String) - Method in class services.moleculer.eventbus.Eventbus
 
get(String) - Method in class services.moleculer.cacher.Cacher
Gets a cached content by a key.
get(String) - Method in class services.moleculer.cacher.JCacheCacher
 
get(String) - Method in class services.moleculer.cacher.MemoryCacher
 
get(String) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
get(String) - Method in class services.moleculer.cacher.OHCacher
 
get(String) - Method in class services.moleculer.cacher.RedisCacher
 
get() - Method in class services.moleculer.cacher.RedisCacher
 
get() - Method in class services.moleculer.transporter.RedisTransporter
 
get(Object) - Method in class services.moleculer.util.FastBuildMap
 
get(String) - Method in class services.moleculer.util.redis.RedisGetSetClient
Gets a content by a key.
getAcknowledgeMode() - Method in class services.moleculer.transporter.JmsTransporter
 
getAckTimeout() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getAction() - Method in exception services.moleculer.error.QueueIsFullError
 
getAction() - Method in exception services.moleculer.error.RequestRejectedError
 
getAction() - Method in exception services.moleculer.error.RequestSkippedError
 
getAction() - Method in exception services.moleculer.error.RequestTimeoutError
 
getAction() - Method in exception services.moleculer.error.ServiceNotAvailableError
 
getAction() - Method in exception services.moleculer.error.ServiceNotFoundError
 
getAction() - Method in class services.moleculer.service.ActionEndpoint
 
getAction(String, String) - Method in class services.moleculer.service.DefaultServiceRegistry
 
getAction(String, String) - Method in class services.moleculer.service.ServiceRegistry
 
getAction(String) - Method in class services.moleculer.ServiceBroker
Returns an action by name.
getAction(String, String) - Method in class services.moleculer.ServiceBroker
Returns an action by name and nodeID.
getActual() - Method in exception services.moleculer.error.ProtocolVersionMismatchError
 
getAddress(String) - Method in class services.moleculer.transporter.Transporter
 
getAlgorithm() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getAlgorithmName() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getAllEndpoints() - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
getAllEndpoints() - Method in class services.moleculer.strategy.Strategy
 
getAllNodeIDs() - Method in class services.moleculer.transporter.Transporter
 
getAuthHandler() - Method in class services.moleculer.transporter.NatsTransporter
 
getAverage() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 
getAverageResponseTime(String) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
getBroker() - Method in class services.moleculer.service.MoleculerComponent
 
getBufferSize() - Method in class services.moleculer.transporter.NatsTransporter
 
getCacheConfigurations() - Method in class services.moleculer.cacher.JCacheCacher
 
getCacheKey(String, Tree, String...) - Method in class services.moleculer.cacher.Cacher
Creates a cacher-specific key by name and params.
getCacheKey(String, Tree, String...) - Method in class services.moleculer.cacher.DistributedCacher
Creates a cacher-specific key by name and params.
getCacheKey(String, Groups) - Method in class services.moleculer.eventbus.DefaultEventbus
 
getCacheKeys() - Method in class services.moleculer.cacher.Cacher
Lists all keys of cached entries.
getCacheKeys() - Method in class services.moleculer.cacher.JCacheCacher
Lists all keys of cached entries.
getCacheKeys() - Method in class services.moleculer.cacher.MemoryCacher
Lists all keys of cached entries.
getCacheKeys() - Method in class services.moleculer.cacher.OHCacher
Lists all keys of cached entries.
getCacheKeys() - Method in class services.moleculer.cacher.RedisCacher
Lists all keys of cached entries.
getCacheKeys(Tree) - Method in class services.moleculer.util.redis.RedisGetSetClient
 
getCacheManager() - Method in class services.moleculer.cacher.JCacheCacher
 
getCacher() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getCacheSize() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
getCapacity() - Method in class services.moleculer.cacher.MemoryCacher
 
getCapacity() - Method in class services.moleculer.cacher.OHCacher
 
getCause() - Method in class services.moleculer.stream.PacketStream
 
getChannelDirectory(String) - Method in class services.moleculer.transporter.FileSystemTransporter
 
getCleanup() - Method in class services.moleculer.breaker.CircuitBreaker
 
getCleanup() - Method in class services.moleculer.cacher.MemoryCacher
 
getClientId() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getClusterId() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getCode() - Method in exception services.moleculer.error.MoleculerError
 
getCollectCount() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
getCommand() - Method in class services.moleculer.monitor.CommandMonitor
 
getCompressAbove() - Method in class services.moleculer.cacher.OHCacher
 
getCompressionLevel() - Method in class services.moleculer.cacher.OHCacher
 
getCompressionLevel() - Method in class services.moleculer.serializer.DeflaterSerializer
 
getConfig() - Method in class services.moleculer.service.ActionEndpoint
 
getConfig() - Method in class services.moleculer.ServiceBroker
Returns the configuration settings and internal components (event bus, cacher, service registry, etc.) of this node / broker.
getConnectionFactoryJndiName() - Method in class services.moleculer.transporter.JmsTransporter
 
getConnectionTimeout() - Method in class services.moleculer.transporter.MqttTransporter
 
getConnectionTimeout() - Method in class services.moleculer.transporter.NatsTransporter
 
getConnectTimeout() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getConsumerProperties() - Method in class services.moleculer.transporter.KafkaTransporter
 
getCpuUsage(String) - Method in class services.moleculer.transporter.Transporter
 
getCurrentPort() - Method in class services.moleculer.transporter.tcp.TcpReader
 
getCurrentPort() - Method in class services.moleculer.transporter.TcpTransporter
 
getCustomWebSocketHeaders() - Method in class services.moleculer.transporter.MqttTransporter
 
getData() - Method in exception services.moleculer.error.MoleculerError
 
getDecryptor() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getDefaultConfiguration() - Method in class services.moleculer.cacher.JCacheCacher
 
getDeliveryMode() - Method in class services.moleculer.transporter.JmsTransporter
 
getDescriptor() - Method in class services.moleculer.service.DefaultServiceRegistry
 
getDescriptor() - Method in class services.moleculer.service.ServiceRegistry
 
getDescriptor() - Method in class services.moleculer.transporter.TcpTransporter
 
getDescriptor(String) - Method in class services.moleculer.transporter.Transporter
 
getDirectory() - Method in class services.moleculer.transporter.FileSystemTransporter
 
getDiscoverPrefix() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getDistributionStatisticBufferLength() - Method in class services.moleculer.metrics.DefaultMetrics
 
getEncriptor() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getEndpoint(Context, String) - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
getEndpoint(Context, String) - Method in class services.moleculer.strategy.Strategy
 
getEndpointsByNodeID(String) - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
getErrorCounter(EndpointKey) - Method in class services.moleculer.breaker.CircuitBreaker
 
getErrorCounter(long) - Method in class services.moleculer.breaker.ErrorCounter
 
getEvent() - Method in exception services.moleculer.error.ListenerNotAvailableError
 
getEventbus() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getExchangeProperties() - Method in class services.moleculer.transporter.AmqpTransporter
 
getExchangeType() - Method in class services.moleculer.transporter.AmqpTransporter
 
getExecutor() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getExecutor() - Method in class services.moleculer.transporter.KafkaTransporter
 
getExecutorServiceTimeout() - Method in class services.moleculer.transporter.MqttTransporter
 
getFactory() - Method in class services.moleculer.transporter.AmqpTransporter
 
getFieldFromProxy(Object, Field) - Static method in class services.moleculer.util.CommonUtils
 
getFileTimeout() - Method in class services.moleculer.transporter.FileSystemTransporter
 
getFormat() - Method in class services.moleculer.serializer.ChainedSerializer
 
getFormat() - Method in class services.moleculer.serializer.Serializer
 
getFormat(String) - Static method in class services.moleculer.util.CommonUtils
 
getGossipPeriod() - Method in class services.moleculer.transporter.TcpTransporter
 
getHash() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
getHashTableSize() - Method in class services.moleculer.cacher.OHCacher
 
getHeartbeatInterval() - Method in class services.moleculer.transporter.Transporter
 
getHeartbeatTimeout() - Method in class services.moleculer.transporter.Transporter
 
getHostName() - Static method in class services.moleculer.util.CommonUtils
 
getHostnameVerifier() - Method in class services.moleculer.transporter.MqttTransporter
 
getHostOrIP(boolean, Tree) - Static method in class services.moleculer.util.CommonUtils
 
getIgnoredTypes() - Method in class services.moleculer.breaker.CircuitBreaker
 
getInstanceID() - Method in class services.moleculer.transporter.Transporter
 
getIv() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getJsonReaders() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getJsonWriters() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getKeepAliveInterval() - Method in class services.moleculer.transporter.MqttTransporter
 
getKeyFromContext(Context) - Method in class services.moleculer.strategy.ShardStrategy
 
getLastError() - Method in class services.moleculer.breaker.ErrorCounter
 
getLastHeartbeatTime(String) - Method in class services.moleculer.transporter.Transporter
 
getLevel() - Method in exception services.moleculer.error.MaxCallLevelError
 
getLocalService(String) - Method in class services.moleculer.ServiceBroker
Returns a local service by name (eg.
getLockTimeout() - Method in class services.moleculer.breaker.CircuitBreaker
 
getLogger() - Method in class services.moleculer.service.MoleculerComponent
 
getLogger() - Method in class services.moleculer.ServiceBroker
Returns the SLF4J logger of this broker instance.
getLogger(Class<?>) - Method in class services.moleculer.ServiceBroker
Returns a logger named corresponding to the class passed as parameter.
getLogger(String) - Method in class services.moleculer.ServiceBroker
Return a logger named according to the name parameter.
getLowCpuUsage() - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
 
getMaxCallLevel() - Method in class services.moleculer.eventbus.DefaultEventbus
 
getMaxCallLevel() - Method in class services.moleculer.service.DefaultServiceInvoker
 
getMaxConnections() - Method in class services.moleculer.transporter.TcpTransporter
 
getMaxErrors() - Method in class services.moleculer.breaker.CircuitBreaker
 
getMaxInflight() - Method in class services.moleculer.transporter.MqttTransporter
 
getMaxPacketSize() - Method in class services.moleculer.transporter.TcpTransporter
 
getMaxParamsLength() - Method in class services.moleculer.cacher.DistributedCacher
 
getMaxPingsOut() - Method in class services.moleculer.transporter.NatsTransporter
 
getMaxPubAcksInFlight() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getMaxSameNodes() - Method in class services.moleculer.breaker.CircuitBreaker
 
getMaxTries() - Method in class services.moleculer.breaker.CircuitBreaker
 
getMessageProperties() - Method in class services.moleculer.transporter.AmqpTransporter
 
getMetric(String, String[], Supplier<T>) - Method in class services.moleculer.metrics.DefaultMetrics
 
getMetrics() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getMonitor() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getMqttVersion() - Method in class services.moleculer.transporter.MqttTransporter
 
getName() - Method in exception services.moleculer.error.MoleculerError
 
getName() - Method in class services.moleculer.service.MoleculerComponent
 
getNamespace() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getNamespace() - Method in class services.moleculer.transporter.Transporter
 
getNodeID() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getNodeID() - Method in class services.moleculer.service.Endpoint
 
getNodeID() - Method in class services.moleculer.ServiceBroker
Returns the unique ContextSource.nodeID of this node (~= ServiceBroker instance).
getNodeInfos(ServiceBroker, Transporter) - Static method in class services.moleculer.util.CommonUtils
 
getOfflineTimeout() - Method in class services.moleculer.transporter.Transporter
 
getPackagesToScan() - Method in class services.moleculer.config.SpringRegistrator
 
getPacketDelay() - Method in class services.moleculer.stream.PacketStream
 
getPacketSize() - Method in class services.moleculer.stream.PacketStream
 
getPacketStream() - Method in class services.moleculer.stream.IncomingStream
 
getParameter(Context, String, boolean) - Method in class services.moleculer.internal.NodeService
 
getPartition(String) - Method in class services.moleculer.cacher.JCacheCacher
 
getPartition(String) - Method in class services.moleculer.cacher.MemoryCacher
 
getPassword() - Method in class services.moleculer.cacher.RedisCacher
 
getPassword() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getPassword() - Method in class services.moleculer.transporter.AmqpTransporter
 
getPassword() - Method in class services.moleculer.transporter.JmsTransporter
 
getPassword() - Method in class services.moleculer.transporter.MqttTransporter
 
getPassword() - Method in class services.moleculer.transporter.NatsTransporter
 
getPassword() - Method in class services.moleculer.transporter.RedisTransporter
 
getPercentilePrecision() - Method in class services.moleculer.metrics.DefaultMetrics
 
getPercentiles() - Method in class services.moleculer.metrics.DefaultMetrics
 
getPersistence() - Method in class services.moleculer.transporter.MqttTransporter
 
getPID() - Method in class services.moleculer.monitor.Monitor
Returns the cached PID of Java VM.
getPingInterval() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
getPingInterval() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getPingInterval() - Method in class services.moleculer.transporter.NatsTransporter
 
getPingsMaxOut() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getPingTimeout() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
getPollingDelay() - Method in class services.moleculer.transporter.FileSystemTransporter
 
getPort() - Method in class services.moleculer.transporter.TcpTransporter
 
getPrefix() - Method in class services.moleculer.transporter.Transporter
 
getPrefix() - Method in class services.moleculer.uid.IncrementalUidGenerator
 
getPrefix() - Method in class services.moleculer.uid.XorShiftRandomUidGenerator
 
getPriority() - Method in class services.moleculer.transporter.JmsTransporter
 
getProducerProperties() - Method in class services.moleculer.transporter.KafkaTransporter
 
getProperty(String, String) - Method in class services.moleculer.logger.AsyncFileLogger
 
getProtocolVersion() - Method in class services.moleculer.ServiceBroker
Returns the version of the implemented Moleculer Protocol.
getQos() - Method in class services.moleculer.transporter.MqttTransporter
 
getQueueProperties() - Method in class services.moleculer.transporter.AmqpTransporter
 
getReceived() - Method in exception services.moleculer.error.ProtocolVersionMismatchError
 
getRetryLogic() - Method in class services.moleculer.service.DefaultServiceInvoker
 
getRingSize() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
getSampleCount() - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
 
getSampleCount() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
getScheduler() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getSecretKey() - Method in class services.moleculer.serializer.BlockCipherSerializer
 
getSegmentCount() - Method in class services.moleculer.cacher.OHCacher
 
getSerializer() - Method in class services.moleculer.cacher.OHCacher
 
getSerializer() - Method in class services.moleculer.cacher.RedisCacher
 
getSerializer() - Method in class services.moleculer.transporter.Transporter
 
getService(String) - Method in class services.moleculer.service.DefaultServiceRegistry
 
getService(String) - Method in class services.moleculer.service.ServiceRegistry
 
getServiceInvoker() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getServiceRegistry() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getShardKey() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
getSocketFactory() - Method in class services.moleculer.transporter.MqttTransporter
 
getSslClientProps() - Method in class services.moleculer.transporter.MqttTransporter
 
getSslContext() - Method in class services.moleculer.transporter.NatsTransporter
 
getSslContextFactory() - Method in class services.moleculer.transporter.AmqpTransporter
 
getStack() - Method in exception services.moleculer.error.MoleculerError
 
getStatistics() - Method in class services.moleculer.transporter.NatsTransporter
 
getStatus(long) - Method in class services.moleculer.breaker.ErrorCounter
 
getStoredFileNames() - Method in class services.moleculer.transporter.FileSystemTransporter
 
getStrategyFactory() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getStreamTimeout() - Method in class services.moleculer.eventbus.DefaultEventbus
 
getStreamTimeout() - Method in class services.moleculer.service.DefaultServiceRegistry
 
getSubscriptionOptions() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getSubscriptionSet(String) - Method in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
getSubscriptionTimeout() - Method in class services.moleculer.transporter.Transporter
 
getThreshold() - Method in class services.moleculer.serializer.DeflaterSerializer
 
getTimeoutAt() - Method in class services.moleculer.stream.IncomingStream
 
getTimestamp() - Method in class services.moleculer.service.DefaultServiceRegistry
 
getTimestamp() - Method in class services.moleculer.service.ServiceRegistry
 
getTopicConnectionFactory() - Method in class services.moleculer.transporter.JmsTransporter
 
getTotalCpuPercent() - Method in class services.moleculer.monitor.ConstantMonitor
Returns the system CPU usage, in percents, between 0 and 100.
getTotalCpuPercent() - Method in class services.moleculer.monitor.Monitor
Returns the cached system CPU usage, in percents, between 0 and 100.
getTraceConnection() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getTransferedBytes() - Method in class services.moleculer.stream.PacketStream
 
getTransporter() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getTtl() - Method in class services.moleculer.cacher.MemoryCacher
 
getTtl() - Method in class services.moleculer.cacher.OHCacher
 
getTtl() - Method in class services.moleculer.cacher.RedisCacher
 
getTtl() - Method in class services.moleculer.transporter.JmsTransporter
 
getType() - Method in exception services.moleculer.error.MoleculerError
 
getUdpBindAddress() - Method in class services.moleculer.transporter.TcpTransporter
 
getUdpMaxDiscovery() - Method in class services.moleculer.transporter.TcpTransporter
 
getUdpMulticast() - Method in class services.moleculer.transporter.TcpTransporter
 
getUdpMulticastTTL() - Method in class services.moleculer.transporter.TcpTransporter
 
getUdpPeriod() - Method in class services.moleculer.transporter.TcpTransporter
 
getUdpPort() - Method in class services.moleculer.transporter.TcpTransporter
 
getUidGenerator() - Method in class services.moleculer.config.ServiceBrokerConfig
 
getUnsentPackets() - Method in class services.moleculer.transporter.tcp.SendBuffer
 
getUrl() - Method in class services.moleculer.transporter.AmqpTransporter
 
getUrl() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
getUrls() - Method in class services.moleculer.cacher.RedisCacher
 
getUrls() - Method in class services.moleculer.transporter.KafkaTransporter
 
getUrls() - Method in class services.moleculer.transporter.MqttTransporter
 
getUrls() - Method in class services.moleculer.transporter.NatsTransporter
 
getUrls() - Method in class services.moleculer.transporter.RedisTransporter
 
getUrls() - Method in class services.moleculer.transporter.TcpTransporter
 
getUsername() - Method in class services.moleculer.transporter.AmqpTransporter
 
getUsername() - Method in class services.moleculer.transporter.JmsTransporter
 
getUsername() - Method in class services.moleculer.transporter.MqttTransporter
 
getUsername() - Method in class services.moleculer.transporter.NatsTransporter
 
getVnodes() - Method in class services.moleculer.strategy.ShardStrategyFactory
 
getWindowLength() - Method in class services.moleculer.breaker.CircuitBreaker
 
gossiperTimer - Variable in class services.moleculer.transporter.TcpTransporter
Cancelable timer of gossiper
gossipPeriod - Variable in class services.moleculer.transporter.TcpTransporter
Gossiping period time, in SECONDS.
GRACEFUL_STOP_TIMEOUT_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
GracefulStopTimeoutError - Exception in services.moleculer.error
Custom Moleculer error class for graceful stopping.
GracefulStopTimeoutError(String, Object...) - Constructor for exception services.moleculer.error.GracefulStopTimeoutError
 
GracefulStopTimeoutError(Tree) - Constructor for exception services.moleculer.error.GracefulStopTimeoutError
 
Group - Annotation Type in services.moleculer.eventbus
Event group.
group - Variable in class services.moleculer.eventbus.ListenerEndpoint
 
Groups - Class in services.moleculer.eventbus
 
groups() - Method in class services.moleculer.eventbus.Groups
 
groups - Variable in class services.moleculer.util.ParseResult
 

H

handler(Context) - Method in interface services.moleculer.service.Action
Action's main method.
handler(Context) - Method in class services.moleculer.service.ActionEndpoint
 
hash - Variable in class services.moleculer.strategy.ShardStrategy
Hasher function (generated hash is 32 bits long, default method is MD5)
hash - Variable in class services.moleculer.strategy.ShardStrategyFactory
Default hash function (MD5).
hashCode - Variable in class services.moleculer.breaker.EndpointKey
 
hashCode() - Method in class services.moleculer.breaker.EndpointKey
 
hashCode - Variable in class services.moleculer.eventbus.ListenerEndpoint
 
hashCode() - Method in class services.moleculer.eventbus.ListenerEndpoint
 
hashCode - Variable in class services.moleculer.service.ActionEndpoint
 
hashCode() - Method in class services.moleculer.service.ActionEndpoint
 
hashCode() - Method in class services.moleculer.transporter.FileSystemTransporter.RemovableFile
 
hashers - Variable in class services.moleculer.cacher.DistributedCacher
 
hashTableSize - Variable in class services.moleculer.cacher.OHCacher
Hash table size (must be a power of 2), defaults to 8192
health - Variable in class services.moleculer.internal.NodeService
Implementation of the "$node.health" action
heartbeatChannel - Variable in class services.moleculer.transporter.Transporter
 
heartbeatInterval - Variable in class services.moleculer.transporter.Transporter
Heartbeat sending period in SECONDS.
heartbeatTimeout - Variable in class services.moleculer.transporter.Transporter
Heartbeat timeout in SECONDS.
heartBeatTimer - Variable in class services.moleculer.transporter.Transporter
Cancelable "Heart Beat" timer
host - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
host - Variable in class services.moleculer.transporter.tcp.RemoteAddress
 
host - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
hostnameVerifier - Variable in class services.moleculer.transporter.MqttTransporter
 
httpsHostnameVerificationEnabled - Variable in class services.moleculer.transporter.MqttTransporter
 

I

id - Variable in class services.moleculer.context.Context
Unique context ID
ignoredTypes - Variable in class services.moleculer.breaker.CircuitBreaker
 
immediate - Variable in class services.moleculer.transporter.AmqpTransporter
 
IncomingStream - Class in services.moleculer.stream
 
IncomingStream(String, ScheduledExecutorService, long) - Constructor for class services.moleculer.stream.IncomingStream
 
increment(String, String, double, String...) - Method in class services.moleculer.metrics.DefaultMetrics
 
increment() - Method in interface services.moleculer.metrics.MetricCounter
 
increment(long) - Method in interface services.moleculer.metrics.MetricCounter
 
increment(String, String, String...) - Method in interface services.moleculer.metrics.Metrics
 
increment(String, String, double, String...) - Method in interface services.moleculer.metrics.Metrics
 
IncrementalUidGenerator - Class in services.moleculer.uid
Fast UidGenerator, based on nodeID and an atomic sequence number.
IncrementalUidGenerator() - Constructor for class services.moleculer.uid.IncrementalUidGenerator
 
INFO - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
INFO - Static variable in class services.moleculer.logger.FastLogFormatter
 
INFO - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
info - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
infoBroadcastChannel - Variable in class services.moleculer.transporter.Transporter
 
infoChannel - Variable in class services.moleculer.transporter.Transporter
 
infoScheduled - Variable in class services.moleculer.transporter.Transporter
 
infoScheduledAt - Variable in class services.moleculer.transporter.Transporter
 
inited - Variable in class services.moleculer.stream.IncomingStream
 
inited() - Method in class services.moleculer.stream.IncomingStream
 
initJsonReader() - Method in class services.moleculer.ServiceBroker
Set global JSON reader API (Jackson, Gson, Boon, FastJson, etc.).
initJsonWriter() - Method in class services.moleculer.ServiceBroker
Set global JSON writer API (Jackson, Gson, Boon, FastJson, etc.)
inputDirectories - Variable in class services.moleculer.transporter.FileSystemTransporter
 
install(Action, Tree) - Method in class services.moleculer.cacher.Cacher
 
install(Action, Tree) - Method in class services.moleculer.metrics.MetricMiddleware
 
install(Action, Tree) - Method in class services.moleculer.service.Middleware
 
instanceCounter - Variable in class services.moleculer.config.ServiceBrokerConfig
Service Broker instance counter (0...N)
instanceID - Variable in class services.moleculer.transporter.Transporter
 
internal - Variable in class services.moleculer.transporter.AmqpTransporter
 
internalServices(boolean) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
internalServices - Variable in class services.moleculer.config.ServiceBrokerConfig
Install internal ($node) services?
InternalTransporter - Class in services.moleculer.transporter
This is a Transporter that can connect multiple ServiceBrokers running in the same JVM.
InternalTransporter() - Constructor for class services.moleculer.transporter.InternalTransporter
 
InternalTransporter(InternalTransporter.Subscriptions) - Constructor for class services.moleculer.transporter.InternalTransporter
 
InternalTransporter.Subscriptions - Class in services.moleculer.transporter
 
InternalTransporter.SubscriptionSet - Class in services.moleculer.transporter
 
INVALID_PACKET_DATA_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
invalidMonitor - Static variable in class services.moleculer.monitor.Monitor
 
InvalidPacketDataError - Exception in services.moleculer.error
Invalid packet format error.
InvalidPacketDataError(String, Object...) - Constructor for exception services.moleculer.error.InvalidPacketDataError
 
InvalidPacketDataError(Tree) - Constructor for exception services.moleculer.error.InvalidPacketDataError
 
invoker(ServiceInvoker) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
IonSerializer - Class in services.moleculer.serializer
Amazon ION Serializer

Description: Amazon Ion is a richly-typed, self-describing, hierarchical data serialization format offering interchangeable binary and text representations.
IonSerializer() - Constructor for class services.moleculer.serializer.IonSerializer
 
isAdvancedStats() - Method in class services.moleculer.transporter.NatsTransporter
 
isAsyncLocalInvocation() - Method in class services.moleculer.service.DefaultServiceRegistry
 
isAvailable(long) - Method in class services.moleculer.breaker.ErrorCounter
 
isCachingDisabledByTheContext(Context) - Method in class services.moleculer.cacher.Cacher
Is the request disables caching?
isCheckVersion() - Method in class services.moleculer.eventbus.DefaultEventbus
 
isCheckVersion() - Method in class services.moleculer.service.DefaultServiceRegistry
 
isCleanSession() - Method in class services.moleculer.transporter.MqttTransporter
 
isClosed() - Method in class services.moleculer.stream.PacketStream
 
isCloseEmptyPartitions() - Method in class services.moleculer.cacher.JCacheCacher
 
isDebug() - Method in class services.moleculer.cacher.Cacher
Is debug enabled?
isDebug() - Method in class services.moleculer.serializer.Serializer
 
isDebug() - Method in class services.moleculer.transporter.Transporter
 
isDebugHeartbeats() - Method in class services.moleculer.transporter.Transporter
 
isEmpty() - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
isEmpty() - Method in class services.moleculer.strategy.Strategy
 
isEmpty() - Method in class services.moleculer.util.FastBuildMap
 
isExclusive() - Method in class services.moleculer.transporter.AmqpTransporter
 
isHttpsHostnameVerificationEnabled() - Method in class services.moleculer.transporter.MqttTransporter
 
isImmediate() - Method in class services.moleculer.transporter.AmqpTransporter
 
isInternal() - Method in class services.moleculer.transporter.AmqpTransporter
 
isInternalServices() - Method in class services.moleculer.config.ServiceBrokerConfig
 
isLocal() - Method in class services.moleculer.eventbus.ListenerEndpoint
 
isLocal() - Method in class services.moleculer.eventbus.LocalListenerEndpoint
 
isLocal() - Method in class services.moleculer.eventbus.RemoteListenerEndpoint
 
isLocalOnly() - Method in class services.moleculer.service.ActionEndpoint
 
isMandatory() - Method in class services.moleculer.transporter.AmqpTransporter
 
isMetricsEnabled() - Method in class services.moleculer.config.ServiceBrokerConfig
 
isNoEcho() - Method in class services.moleculer.transporter.NatsTransporter
 
isNoRandomize() - Method in class services.moleculer.transporter.NatsTransporter
 
isOldRequestStyle() - Method in class services.moleculer.transporter.NatsTransporter
 
isOnline(String) - Method in class services.moleculer.transporter.Transporter
 
isOpentls() - Method in class services.moleculer.transporter.NatsTransporter
 
isPedantic() - Method in class services.moleculer.transporter.NatsTransporter
 
isPreferHostname() - Method in class services.moleculer.transporter.Transporter
 
isPreferLocal() - Method in class services.moleculer.strategy.ArrayBasedStrategyFactory
 
isPrivate() - Method in class services.moleculer.eventbus.ListenerEndpoint
 
isPublishPercentileHistogram() - Method in class services.moleculer.metrics.DefaultMetrics
 
isRemote() - Method in exception services.moleculer.error.MoleculerError
 
isRetryable() - Method in exception services.moleculer.error.MoleculerError
 
isSecure() - Method in class services.moleculer.cacher.RedisCacher
 
isSecure() - Method in class services.moleculer.transporter.NatsTransporter
 
isSecure() - Method in class services.moleculer.transporter.RedisTransporter
 
isServicesOnline(Collection<String>) - Method in class services.moleculer.service.DefaultServiceRegistry
 
isShutDownThreadPools() - Method in class services.moleculer.config.ServiceBrokerConfig
 
isShutDownThreadPools() - Method in class services.moleculer.transporter.KafkaTransporter
 
isTransacted() - Method in class services.moleculer.transporter.JmsTransporter
 
isUdpBroadcast() - Method in class services.moleculer.transporter.TcpTransporter
 
isUdpReuseAddr() - Method in class services.moleculer.transporter.TcpTransporter
 
isUseCloning() - Method in class services.moleculer.cacher.MemoryCacher
 
isUseHostname() - Method in class services.moleculer.transporter.TcpTransporter
 
isUtf8Support() - Method in class services.moleculer.transporter.NatsTransporter
 
isVerbose() - Method in class services.moleculer.transporter.NatsTransporter
 
isWriteErrorsToLog() - Method in class services.moleculer.eventbus.DefaultEventbus
 
isWriteErrorsToLog() - Method in class services.moleculer.service.DefaultServiceInvoker
 
isWriteErrorsToLog() - Method in class services.moleculer.service.DefaultServiceRegistry
 
isWriteRegistrations() - Method in class services.moleculer.service.DefaultServiceRegistry
 
iterator() - Method in class services.moleculer.util.FastBuildMap.FastBuildEntrySet
 
iv - Variable in class services.moleculer.serializer.BlockCipherSerializer
Algorithm parameters (IV).

J

JAVA - Static variable in class services.moleculer.logger.FastLogFormatter
 
JavaSerializer - Class in services.moleculer.serializer
Serializer based on Java Object Serialization

Type safe, but Java-dependent and slower than the JsonSerializer.
JavaSerializer() - Constructor for class services.moleculer.serializer.JavaSerializer
 
JCacheCacher - Class in services.moleculer.cacher
JSR-107 JCache is a standardized caching API that is Java 6 compatible and introduced in JEE 8.
JCacheCacher() - Constructor for class services.moleculer.cacher.JCacheCacher
 
JCacheCacher(URI) - Constructor for class services.moleculer.cacher.JCacheCacher
 
JCacheCacher(CacheManager) - Constructor for class services.moleculer.cacher.JCacheCacher
 
JmsTransporter - Class in services.moleculer.transporter
JMS Transporter.
JmsTransporter() - Constructor for class services.moleculer.transporter.JmsTransporter
 
JmsTransporter(String) - Constructor for class services.moleculer.transporter.JmsTransporter
 
JmsTransporter(TopicConnectionFactory) - Constructor for class services.moleculer.transporter.JmsTransporter
 
JmsTransporter(String, String, String) - Constructor for class services.moleculer.transporter.JmsTransporter
 
JmsTransporter(String, String, TopicConnectionFactory) - Constructor for class services.moleculer.transporter.JmsTransporter
 
JmxMonitor - Class in services.moleculer.monitor
JMX-based System Monitor.
JmxMonitor() - Constructor for class services.moleculer.monitor.JmxMonitor
 
jsonReaders - Variable in class services.moleculer.config.ServiceBrokerConfig
Name (or comma-separated list) of the JSON deserializer API ("jackson", "boon", "builtin", "gson", "fastjson", "genson", etc., null = autodetect / fastest)
JsonSerializer - Class in services.moleculer.serializer
Generic JSON serializer

JSON (JavaScript Object Notation) is a lightweight data-interchange format.
JsonSerializer() - Constructor for class services.moleculer.serializer.JsonSerializer
 
jsonWriters - Variable in class services.moleculer.config.ServiceBrokerConfig
Name (or comma-separated list) of the JSON serializer API ("jackson", "boon", "builtin", "gson", "fast", "genson", "flex", "nano", etc., null = autodetect / fastest)

K

KafkaPoller(KafkaTransporter) - Constructor for class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
KafkaTransporter - Class in services.moleculer.transporter
Kafka Transporter.
KafkaTransporter() - Constructor for class services.moleculer.transporter.KafkaTransporter
 
KafkaTransporter(String...) - Constructor for class services.moleculer.transporter.KafkaTransporter
 
KafkaTransporter.KafkaPoller - Class in services.moleculer.transporter
 
keepAliveInterval - Variable in class services.moleculer.transporter.MqttTransporter
 
key - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
keys - Variable in class services.moleculer.util.FastBuildMap
 
keySet() - Method in class services.moleculer.util.FastBuildMap
 
keyToBytes(String) - Method in class services.moleculer.cacher.OHCacher
 

L

lastChecked - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
lastCleanup - Variable in class services.moleculer.breaker.CircuitBreaker
 
lastModified - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
lastPos - Variable in class services.moleculer.breaker.ErrorCounter
 
lastReceivedMessageAt - Variable in class services.moleculer.transporter.Transporter
 
level - Variable in class services.moleculer.context.Context
Request level (in nested-calls) - the first level is 1
level - Variable in exception services.moleculer.error.MaxCallLevelError
 
limitMap - Variable in class services.moleculer.strategy.ShardStrategy.Ring
The "hash ring" (https://www.toptal.com/big-data/consistent-hashing)
line - Variable in class services.moleculer.logger.FastLogFormatter
 
list - Variable in class services.moleculer.internal.NodeService
Implementation of the "$node.list" action
Listener - Interface in services.moleculer.eventbus
Interface of all local event listeners.
listener - Variable in class services.moleculer.eventbus.LocalListenerEndpoint
Listener instance (it's a field / inner class in Service object)
LISTENER_NOT_AVAILABLE_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
ListenerEndpoint - Class in services.moleculer.eventbus
 
ListenerEndpoint(String, String, String, String, boolean) - Constructor for class services.moleculer.eventbus.ListenerEndpoint
 
ListenerNotAvailableError - Exception in services.moleculer.error
 
ListenerNotAvailableError(String, String) - Constructor for exception services.moleculer.error.ListenerNotAvailableError
 
ListenerNotAvailableError(Tree) - Constructor for exception services.moleculer.error.ListenerNotAvailableError
 
listeners - Variable in class services.moleculer.eventbus.DefaultEventbus
 
listeners - Variable in class services.moleculer.stream.PacketStream
Array of PacketListeners (receivers).
listFiles(long) - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
loadedFiles - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
local - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
LocalActionEndpoint - Class in services.moleculer.service
 
LocalActionEndpoint(DefaultServiceRegistry, ExecutorService, String, String, Tree, Action, String) - Constructor for class services.moleculer.service.LocalActionEndpoint
 
localBroadcasterCache - Variable in class services.moleculer.eventbus.DefaultEventbus
 
LocalListenerEndpoint - Class in services.moleculer.eventbus
 
LocalListenerEndpoint(String, String, String, String, Listener, boolean, Metrics) - Constructor for class services.moleculer.eventbus.LocalListenerEndpoint
 
localNodeID - Variable in class services.moleculer.internal.NodeService
 
localOnly - Variable in class services.moleculer.service.ActionEndpoint
Private Action; only the local Broker can access it and cannot be called remotely.
locator - Variable in class services.moleculer.transporter.TcpTransporter
UDP broadcaster
lockTimeout - Variable in class services.moleculer.breaker.CircuitBreaker
Half-open timeout in MILLISECONDS
lockTimeout - Variable in class services.moleculer.breaker.ErrorCounter
 
log(LinkedList<LogRecord>, StringBuilder) - Method in class services.moleculer.logger.ColoredConsoleLogger
 
log(LinkedList<LogRecord>, StringBuilder) - Method in interface services.moleculer.logger.ConsoleLogger
 
log(LinkedList<LogRecord>, StringBuilder) - Method in class services.moleculer.logger.SimpleConsoleLogger
 
logClean(String, String, long) - Method in class services.moleculer.cacher.Cacher
 
logDirectory - Variable in class services.moleculer.logger.AsyncFileLogger
 
logger - Variable in class services.moleculer.config.SpringRegistrator
 
logger - Variable in class services.moleculer.eventbus.ListenerEndpoint
 
logger - Static variable in class services.moleculer.metrics.DefaultMetrics
 
logger - Static variable in class services.moleculer.metrics.DropwizardReportersImpl
 
logger - Variable in class services.moleculer.monitor.Monitor
 
logger - Static variable in class services.moleculer.service.ActionEndpoint
 
logger - Variable in class services.moleculer.service.MoleculerComponent
 
logger - Static variable in class services.moleculer.ServiceBroker
SLF4J logger of this class.
logger - Static variable in class services.moleculer.stream.PacketStream
 
logger - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
logger - Static variable in class services.moleculer.transporter.tcp.SendBuffer
 
logger - Static variable in class services.moleculer.transporter.tcp.TcpReader
 
logger - Static variable in class services.moleculer.transporter.tcp.TcpWriter
 
logger - Static variable in class services.moleculer.transporter.tcp.UDPLocator
 
logger - Static variable in class services.moleculer.transporter.tcp.UDPReceiver
 
logToConsole - Variable in class services.moleculer.logger.AsyncFileLogger
 
logUnableToInvokeAction(String, Throwable) - Method in class services.moleculer.service.DefaultServiceRegistry
 
logUnableToInvokeListener(Throwable) - Method in class services.moleculer.eventbus.DefaultEventbus
 
lowCpuUsage - Variable in class services.moleculer.strategy.CpuUsageStrategy
lowCpuUsage ~= zero CPU usage
lowCpuUsage - Variable in class services.moleculer.strategy.CpuUsageStrategyFactory
lowCpuUsage ~= zero CPU usage

M

main(String[]) - Static method in class services.moleculer.config.MoleculerRunner
Starts/stops Moleculer as a standalone application or as a Windows service.
mandatory - Variable in class services.moleculer.transporter.AmqpTransporter
 
map - Variable in class services.moleculer.util.FastBuildTree
 
markAsOffline() - Method in class services.moleculer.transporter.tcp.NodeDescriptor
 
markAsOffline(long) - Method in class services.moleculer.transporter.tcp.NodeDescriptor
 
markAsOnline(Tree) - Method in class services.moleculer.transporter.tcp.NodeDescriptor
 
Matcher - Class in services.moleculer.eventbus
Event mask matcher (eg.
Matcher() - Constructor for class services.moleculer.eventbus.Matcher
 
matches(String, String) - Static method in class services.moleculer.eventbus.Matcher
 
MAX_CALL_LEVEL_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
maxCallLevel - Variable in class services.moleculer.eventbus.DefaultEventbus
Max call level (for nested events)
maxCallLevel - Variable in class services.moleculer.service.DefaultServiceInvoker
Max call level (for nested calls)
MaxCallLevelError - Exception in services.moleculer.error
'Max request call level' error message.
MaxCallLevelError(String, int) - Constructor for exception services.moleculer.error.MaxCallLevelError
 
MaxCallLevelError(Tree) - Constructor for exception services.moleculer.error.MaxCallLevelError
 
maxConnections - Variable in class services.moleculer.transporter.tcp.TcpWriter
Max number of opened connections
maxConnections - Variable in class services.moleculer.transporter.TcpTransporter
Max number of keep-alive connections (-1 = unlimited, 0 = disable keep-alive connections).
maxErrors - Variable in class services.moleculer.breaker.CircuitBreaker
Maximum number of errors in time-window
maxInflight - Variable in class services.moleculer.transporter.MqttTransporter
 
maxPacketSize - Variable in class services.moleculer.transporter.tcp.TcpReader
Maximum size of an incoming packet
maxPacketSize - Variable in class services.moleculer.transporter.TcpTransporter
Max enable packet size (BYTES).
maxParamsLength - Variable in class services.moleculer.cacher.DistributedCacher
 
maxPingsOut - Variable in class services.moleculer.transporter.NatsTransporter
Set the maximum number of pings the client can have in flight.
maxPubAcksInFlight - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
maxSameNodes - Variable in class services.moleculer.breaker.CircuitBreaker
Exit from "maxTries" loop, when strategy returns number of "maxSameNodes" corresponding node IDs
maxTries - Variable in class services.moleculer.breaker.CircuitBreaker
Number of max tries
MemoryCacher - Class in services.moleculer.cacher
On-heap memory cache.
MemoryCacher() - Constructor for class services.moleculer.cacher.MemoryCacher
 
MemoryCacher(int, int) - Constructor for class services.moleculer.cacher.MemoryCacher
 
MemoryCacher(int, int, int) - Constructor for class services.moleculer.cacher.MemoryCacher
 
MemoryCacher.MemoryPartition - Class in services.moleculer.cacher
 
MemoryCacher.PartitionEntry - Class in services.moleculer.cacher
 
MemoryPartition(MemoryCacher) - Constructor for class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
mergeMeta(Tree) - Method in class services.moleculer.context.Context
 
mergeMeta(Tree, Tree) - Static method in class services.moleculer.util.CommonUtils
 
message(byte[], byte[]) - Method in class services.moleculer.transporter.RedisTransporter
 
message(byte[], byte[], byte[]) - Method in class services.moleculer.transporter.RedisTransporter
 
messageArrived(String, MqttMessage) - Method in class services.moleculer.transporter.MqttTransporter
 
messageProperties - Variable in class services.moleculer.transporter.AmqpTransporter
 
messages - Variable in class services.moleculer.logger.AsyncFileLogger
 
MetricConstants - Interface in services.moleculer.metrics
 
MetricCounter - Interface in services.moleculer.metrics
 
MetricGauge - Interface in services.moleculer.metrics
 
MetricMiddleware - Class in services.moleculer.metrics
 
MetricMiddleware() - Constructor for class services.moleculer.metrics.MetricMiddleware
 
metrics - Variable in class services.moleculer.breaker.CircuitBreaker
 
metrics - Variable in class services.moleculer.cacher.Cacher
 
metrics(Metrics) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
metrics - Variable in class services.moleculer.config.ServiceBrokerConfig
 
metrics - Variable in class services.moleculer.eventbus.DefaultEventbus
 
metrics - Variable in class services.moleculer.eventbus.LocalListenerEndpoint
Metrics registry (or null)
metrics - Variable in class services.moleculer.metrics.MetricMiddleware
 
Metrics - Interface in services.moleculer.metrics
 
metrics - Variable in class services.moleculer.service.DefaultServiceInvoker
 
metrics - Variable in class services.moleculer.service.DefaultServiceRegistry
 
metrics - Variable in class services.moleculer.transporter.Transporter
 
metricsEnabled(boolean) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
metricsEnabled - Variable in class services.moleculer.config.ServiceBrokerConfig
 
micrometerRegistry - Variable in class services.moleculer.metrics.DropwizardReportersImpl
 
Middleware - Class in services.moleculer.service
 
Middleware() - Constructor for class services.moleculer.service.Middleware
 
Middleware(String) - Constructor for class services.moleculer.service.Middleware
 
middlewares - Variable in class services.moleculer.service.DefaultServiceRegistry
 
middlewares - Variable in class services.moleculer.ServiceBroker
Middlewares which defined and added to the Broker before the boot process.
MOLECULER_CACHER_CLEAN_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_CLEAN_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_CLEAN_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_CLEAN_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_DEL_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_DEL_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_DEL_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_DEL_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_EXPIRED_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_EXPIRED_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_FOUND_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_FOUND_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_GET_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_GET_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_GET_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_GET_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_SET_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_SET_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_SET_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CACHER_SET_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_HALF_OPENED_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_HALF_OPENED_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_OPENED_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_OPENED_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_OPENED_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CIRCUIT_BREAKER_OPENED_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_CLIENT_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
MOLECULER_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
MOLECULER_EVENT_BROADCAST_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_BROADCAST_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_BROADCASTLOCAL_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_BROADCASTLOCAL_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_EMIT_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_EMIT_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_ERROR_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_ERROR_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EVENT_RECEIVED_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_EXECUTOR - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_ERROR_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_ERROR_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_LEVELS - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_LEVELS_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_RETRY_ATTEMPTS_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_RETRY_ATTEMPTS_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TIME - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TIME_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TIMEOUT_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TIMEOUT_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_REQUEST_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_RETRYABLE_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
MOLECULER_SCHEDULER - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_SERVER_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
MOLECULER_TRANSIT_CONNECTED - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_CONNECTED_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_ORPHAN_RESPONSE_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_ORPHAN_RESPONSE_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_REQUESTS_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_REQUESTS_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_STREAMS_RECEIVE_ACTIVE - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSIT_STREAMS_RECEIVE_ACTIVE_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_RECEIVED_BYTES - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_RECEIVED_BYTES_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_RECEIVED_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_RECEIVED_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_SENT_BYTES - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_SENT_BYTES_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_SENT_TOTAL - Static variable in interface services.moleculer.metrics.MetricConstants
 
MOLECULER_TRANSPORTER_PACKETS_SENT_TOTAL_DESC - Static variable in interface services.moleculer.metrics.MetricConstants
 
MoleculerClientError - Exception in services.moleculer.error
Moleculer error class for client errors which is not retryable.
MoleculerClientError(String, String) - Constructor for exception services.moleculer.error.MoleculerClientError
 
MoleculerClientError(String, Throwable, String, Tree) - Constructor for exception services.moleculer.error.MoleculerClientError
 
MoleculerClientError(String, Throwable, String, int, String, Tree) - Constructor for exception services.moleculer.error.MoleculerClientError
 
MoleculerClientError(String, Throwable, String, String, int, String, Object...) - Constructor for exception services.moleculer.error.MoleculerClientError
 
MoleculerClientError(Tree) - Constructor for exception services.moleculer.error.MoleculerClientError
 
MoleculerComponent - Class in services.moleculer.service
 
MoleculerComponent() - Constructor for class services.moleculer.service.MoleculerComponent
 
MoleculerComponent(String) - Constructor for class services.moleculer.service.MoleculerComponent
 
MoleculerError - Exception in services.moleculer.error
Custom Moleculer Exception class.
MoleculerError(String, String, boolean) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(String, String, boolean, int) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(String, String, boolean, int, Tree) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(String, String, boolean, int, String, Tree) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(String, Throwable, String, boolean, int, String, Tree) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(String, Throwable, String, String, boolean, int, String, Object...) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerError(Tree) - Constructor for exception services.moleculer.error.MoleculerError
 
MoleculerErrorUtils - Class in services.moleculer.error
 
MoleculerErrorUtils() - Constructor for class services.moleculer.error.MoleculerErrorUtils
 
MoleculerLifecycle - Interface in services.moleculer.service
 
MoleculerRetryableError - Exception in services.moleculer.error
Custom Moleculer error class for retryable errors.
MoleculerRetryableError(String, String) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(String, String, int) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(String, String, int, Tree) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(String, String, int, String, Tree) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(String, Throwable, String, int, String, Tree) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(String, Throwable, String, String, int, String, Object...) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRetryableError(Tree) - Constructor for exception services.moleculer.error.MoleculerRetryableError
 
MoleculerRunner - Class in services.moleculer.config
Runs Service Broker as a standalone Java application (or Windows service).
MoleculerRunner() - Constructor for class services.moleculer.config.MoleculerRunner
 
MoleculerServerError - Exception in services.moleculer.error
Moleculer error class for server error which is retryable.
MoleculerServerError(String, String, String) - Constructor for exception services.moleculer.error.MoleculerServerError
 
MoleculerServerError(String, String, String, Tree) - Constructor for exception services.moleculer.error.MoleculerServerError
 
MoleculerServerError(String, Throwable, String, String, Object...) - Constructor for exception services.moleculer.error.MoleculerServerError
 
MoleculerServerError(Tree) - Constructor for exception services.moleculer.error.MoleculerServerError
 
monitor(Monitor) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
monitor - Variable in class services.moleculer.config.ServiceBrokerConfig
 
monitor - Variable in class services.moleculer.internal.NodeService
 
Monitor - Class in services.moleculer.monitor
Base superclass of all System Monitor implementations.
Monitor() - Constructor for class services.moleculer.monitor.Monitor
 
monitor - Variable in class services.moleculer.transporter.Transporter
 
MqttTransporter - Class in services.moleculer.transporter
MQTT Transporter (eg. for Mosquitto MQTT Server or ActiveMQ Server).
MqttTransporter() - Constructor for class services.moleculer.transporter.MqttTransporter
 
MqttTransporter(String...) - Constructor for class services.moleculer.transporter.MqttTransporter
 
MqttTransporter(String, String, String...) - Constructor for class services.moleculer.transporter.MqttTransporter
 
mqttVersion - Variable in class services.moleculer.transporter.MqttTransporter
 
MsgPackSerializer - Class in services.moleculer.serializer
MessagePack serializer

MessagePack is an efficient binary serialization format.
MsgPackSerializer() - Constructor for class services.moleculer.serializer.MsgPackSerializer
 
multicastReceiver - Variable in class services.moleculer.transporter.tcp.UDPMulticastReceiver
Multicast receiver

N

name - Variable in class services.moleculer.breaker.EndpointKey
 
name - Variable in class services.moleculer.context.Context
Action name
name - Variable in exception services.moleculer.error.MoleculerError
 
name - Variable in class services.moleculer.monitor.JmxMonitor
 
name - Variable in class services.moleculer.service.ActionEndpoint
 
name - Variable in class services.moleculer.service.MoleculerComponent
 
Name - Annotation Type in services.moleculer.service
Human readable name of a Moleculer Component (eg.
nameOf(String, Field) - Static method in class services.moleculer.util.CommonUtils
 
nameOf(Object, boolean) - Static method in class services.moleculer.util.CommonUtils
 
nameOf(Class<?>, boolean) - Static method in class services.moleculer.util.CommonUtils
 
names - Variable in class services.moleculer.service.DefaultServiceRegistry
 
namespace(String) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
namespace - Variable in class services.moleculer.config.ServiceBrokerConfig
Namespace of Broker.
namespace - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Current namespace
namespace - Variable in class services.moleculer.transporter.Transporter
Namespace of channels.
NanoSecRandomStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Nanosec-based pseudorandom invocation strategy.
NanoSecRandomStrategy(ServiceBroker, boolean) - Constructor for class services.moleculer.strategy.NanoSecRandomStrategy
 
NanoSecRandomStrategyFactory - Class in services.moleculer.strategy
Factory of nanosec-based pseudorandom invocation strategy.
NanoSecRandomStrategyFactory() - Constructor for class services.moleculer.strategy.NanoSecRandomStrategyFactory
Constructor that uses local services when available.
NanoSecRandomStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.NanoSecRandomStrategyFactory
Constructor that can be configured to use local services if possible.
NatsStreamingTransporter - Class in services.moleculer.transporter
NATS-streaming Transporter.
NatsStreamingTransporter() - Constructor for class services.moleculer.transporter.NatsStreamingTransporter
 
NatsStreamingTransporter(String) - Constructor for class services.moleculer.transporter.NatsStreamingTransporter
 
NatsTransporter - Class in services.moleculer.transporter
NATS Transporter.
NatsTransporter() - Constructor for class services.moleculer.transporter.NatsTransporter
 
NatsTransporter(String...) - Constructor for class services.moleculer.transporter.NatsTransporter
 
NatsTransporter(String, String, boolean, String...) - Constructor for class services.moleculer.transporter.NatsTransporter
 
netIf - Variable in class services.moleculer.transporter.tcp.UDPMulticastReceiver
Network interface (or null)
NetworkLatencyStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Lowest network latency strategy.
NetworkLatencyStrategy(ServiceBroker, boolean, int, NetworkLatencyStrategyFactory) - Constructor for class services.moleculer.strategy.NetworkLatencyStrategy
 
NetworkLatencyStrategyFactory - Class in services.moleculer.strategy
Factory of lowest network latency strategy.
NetworkLatencyStrategyFactory() - Constructor for class services.moleculer.strategy.NetworkLatencyStrategyFactory
Constructor that calls for service based primarily on its own (latency-based) logic.
NetworkLatencyStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.NetworkLatencyStrategyFactory
Constructor that can be configured to use local services if possible.
NetworkLatencyStrategyFactory.Samples - Class in services.moleculer.strategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.CpuUsageStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.NanoSecRandomStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.NetworkLatencyStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.RoundRobinStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.SecureRandomStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.ShardStrategy
 
next(Context, Endpoint[]) - Method in class services.moleculer.strategy.XorShiftRandomStrategy
 
nextIndex - Variable in class services.moleculer.transporter.tcp.UDPLocator
 
nextLong() - Method in class services.moleculer.uid.XorShiftRandomUidGenerator
 
nextUID() - Method in class services.moleculer.uid.IncrementalUidGenerator
 
nextUID() - Method in class services.moleculer.uid.StandardUidGenerator
 
nextUID() - Method in class services.moleculer.uid.TimeBasedUidGenerator
 
nextUID() - Method in class services.moleculer.uid.UidGenerator
 
nextUID() - Method in class services.moleculer.uid.XorShiftRandomUidGenerator
 
NodeDescriptor - Class in services.moleculer.transporter.tcp
Node descriptor of all (remote and local) nodes.
NodeDescriptor(String, boolean, boolean) - Constructor for class services.moleculer.transporter.tcp.NodeDescriptor
 
NodeDescriptor(String, boolean, String, int) - Constructor for class services.moleculer.transporter.tcp.NodeDescriptor
 
NodeDescriptor(String, boolean, boolean, Tree) - Constructor for class services.moleculer.transporter.tcp.NodeDescriptor
 
nodeID - Variable in class services.moleculer.breaker.EndpointKey
 
nodeID(String) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
nodeID - Variable in class services.moleculer.config.ServiceBrokerConfig
Unique NodeID of Broker.
nodeID(String) - Static method in class services.moleculer.context.CallOptions
 
nodeID - Variable in class services.moleculer.context.CallOptions.Options
Target nodeID (null = select automatically by the Invocation Strategy)
nodeID(String) - Method in class services.moleculer.context.CallOptions.Options
 
nodeID - Variable in class services.moleculer.context.Context
Source nodeID
nodeID - Variable in class services.moleculer.context.ContextSource
Source nodeID
nodeID - Variable in exception services.moleculer.error.MoleculerError
 
nodeID - Variable in class services.moleculer.eventbus.DefaultEventbus
Local Node ID
nodeID - Variable in class services.moleculer.service.DefaultServiceRegistry
 
nodeID - Variable in class services.moleculer.service.Endpoint
 
nodeID - Variable in class services.moleculer.service.PendingPromise
 
nodeID - Variable in class services.moleculer.strategy.ArrayBasedStrategy
 
nodeID - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
nodeID - Variable in class services.moleculer.stream.IncomingStream
Currrent nodeID.
nodeID - Variable in class services.moleculer.stream.PacketStream
Current node ID.
nodeID - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
nodeID - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
nodeID - Variable in class services.moleculer.transporter.tcp.UDPLocator
Current NodeID
nodeID - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Current NodeID
nodeID - Variable in class services.moleculer.transporter.Transporter
Local Node ID.
nodes - Variable in class services.moleculer.transporter.Transporter
 
NodeService - Class in services.moleculer.internal
The broker contains some internal services to check the health of node or get broker statistics.
NodeService() - Constructor for class services.moleculer.internal.NodeService
 
noEcho - Variable in class services.moleculer.transporter.NatsTransporter
Turn off echo.
noRandomize - Variable in class services.moleculer.transporter.NatsTransporter
Turn off server pool randomization.
normalizeLine(String) - Method in class services.moleculer.logger.FastLogFormatter
 
normalizeWord(String) - Method in class services.moleculer.logger.FastLogFormatter
 
NullTransporter - Class in services.moleculer.transporter
"Null" / empty transporter.
NullTransporter() - Constructor for class services.moleculer.transporter.NullTransporter
 
numberOfSubmittedPackets - Variable in class services.moleculer.transporter.tcp.UDPLocator
 

O

of(String...) - Static method in class services.moleculer.eventbus.Groups
 
offlineSince - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
offlineTimeout - Variable in class services.moleculer.transporter.Transporter
How long keep information in registry about the offline nodes (SECONDS).
OHCacher - Class in services.moleculer.cacher
Off-heap cache implementation (it's similar to MemoryCacher, but stores entries in the off-heap RAM).
OHCacher() - Constructor for class services.moleculer.cacher.OHCacher
Creates Off-heap Cacher with the default settings.
OHCacher(long, int) - Constructor for class services.moleculer.cacher.OHCacher
Creates Off-heap Cacher.
OHCacher(long, int, int, int, int) - Constructor for class services.moleculer.cacher.OHCacher
Creates Off-heap Cacher.
OHCacher.ArraySerializer - Class in services.moleculer.cacher
 
oldRequestStyle - Variable in class services.moleculer.transporter.NatsTransporter
Turn on the old request style that uses a new inbox and subscriber for each request.
on(Context) - Method in interface services.moleculer.eventbus.Listener
 
on(Context, Groups, boolean) - Method in class services.moleculer.eventbus.ListenerEndpoint
 
on(Context, Groups, boolean) - Method in class services.moleculer.eventbus.LocalListenerEndpoint
 
on(Context, Groups, boolean) - Method in class services.moleculer.eventbus.RemoteListenerEndpoint
 
ONE_SECOND - Static variable in interface services.moleculer.metrics.Metrics
 
onError(ErrorCounter, EndpointKey, Throwable) - Method in class services.moleculer.breaker.CircuitBreaker
 
onError(long) - Method in class services.moleculer.breaker.ErrorCounter
 
onMessage(Message) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
onMessage(Message) - Method in class services.moleculer.transporter.NatsTransporter
 
onPacket(byte[], Throwable, boolean) - Method in interface services.moleculer.stream.PacketListener
 
onPacket(PacketListener) - Method in class services.moleculer.stream.PacketStream
 
onSuccess() - Method in class services.moleculer.breaker.ErrorCounter
 
opened - Variable in class services.moleculer.transporter.tcp.TcpWriter
 
openedFile - Variable in class services.moleculer.logger.AsyncFileLogger
 
openedStream - Variable in class services.moleculer.logger.AsyncFileLogger
 
opentls - Variable in class services.moleculer.transporter.NatsTransporter
Set the SSL context to one that accepts any server certificate and has no client certificate.
Options(String, long, int) - Constructor for class services.moleculer.context.CallOptions.Options
 
opts - Variable in class services.moleculer.context.Context
Calling options
opts - Variable in class services.moleculer.util.ParseResult
 
outputDirectories - Variable in class services.moleculer.transporter.FileSystemTransporter
 

P

packagesToScan - Variable in class services.moleculer.config.SpringRegistrator
Java package(s) where the custom Spring/Moleculer Services are located.
PACKET_DISCONNECT - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_DISCOVER - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_EVENT - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_EVENT_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_GOSSIP_HELLO_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_GOSSIP_REQ_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_GOSSIP_RSP_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_HEARTBEAT - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_INFO - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_PING - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_PING_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_PONG - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_PONG_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_REQUEST - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_REQUEST_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
PACKET_RESPONSE - Static variable in class services.moleculer.transporter.Transporter
 
PACKET_RESPONSE_ID - Static variable in class services.moleculer.transporter.TcpTransporter
 
packetDelay - Variable in class services.moleculer.stream.PacketStream
Time between each packet sent.
PacketListener - Interface in services.moleculer.stream
Interface of all packet/stream receivers.
packetSize - Variable in class services.moleculer.stream.PacketStream
Minimum size of packets.
PacketStream - Class in services.moleculer.stream
NodeJS compatible streaming API to transfer binary files/content.
PacketStream(String, ScheduledExecutorService) - Constructor for class services.moleculer.stream.PacketStream
 
params - Variable in class services.moleculer.context.Context
Request parameters (including meta)
parent - Variable in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
parent - Variable in class services.moleculer.serializer.ChainedSerializer
 
parentID - Variable in class services.moleculer.context.Context
Parent context ID (in nested-calls)
parseParams(Object[]) - Static method in class services.moleculer.util.CommonUtils
 
ParseResult - Class in services.moleculer.util
 
parseURLs(Tree, String, String[]) - Static method in class services.moleculer.util.CommonUtils
 
parseURLs(String[], String, boolean) - Method in class services.moleculer.util.redis.AbstractRedisClient
 
PartitionEntry(Tree, long) - Constructor for class services.moleculer.cacher.MemoryCacher.PartitionEntry
 
partitionPosition(String, boolean) - Method in class services.moleculer.cacher.JCacheCacher
 
partitionPosition(String, boolean) - Method in class services.moleculer.cacher.MemoryCacher
 
partitions - Variable in class services.moleculer.cacher.JCacheCacher
 
partitions - Variable in class services.moleculer.cacher.MemoryCacher
 
password - Variable in class services.moleculer.cacher.RedisCacher
 
password - Variable in class services.moleculer.serializer.BlockCipherSerializer
Password for Symmetric Key Encryption.
password - Variable in class services.moleculer.transporter.AmqpTransporter
 
password - Variable in class services.moleculer.transporter.JmsTransporter
 
password - Variable in class services.moleculer.transporter.MqttTransporter
 
password - Variable in class services.moleculer.transporter.NatsTransporter
Password for basic authentication.
password - Variable in class services.moleculer.transporter.RedisTransporter
 
password - Variable in class services.moleculer.util.redis.AbstractRedisClient
 
pedantic - Variable in class services.moleculer.transporter.NatsTransporter
Turn on pedantic mode for the server.
PendingPromise - Class in services.moleculer.service
Promise container of a pending action calls.
percentilePrecision - Variable in class services.moleculer.metrics.DefaultMetrics
 
percentiles - Variable in class services.moleculer.metrics.DefaultMetrics
 
persistence - Variable in class services.moleculer.transporter.MqttTransporter
 
ping(long, String) - Method in class services.moleculer.service.DefaultServiceRegistry
 
ping(long, String) - Method in class services.moleculer.service.ServiceRegistry
 
ping(String) - Method in class services.moleculer.ServiceBroker
Sends a PING message to the specified node.
ping(long, String) - Method in class services.moleculer.ServiceBroker
Sends a PING message to the specified node.
pingChannel - Variable in class services.moleculer.transporter.Transporter
 
pingInterval - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
Ping period time, in SECONDS.
pingInterval - Variable in class services.moleculer.transporter.NatsTransporter
Set the interval between attempts to pings the server in MILLISECONDS.
pingTimeout - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
Ping timeout time, in MILLISECONDS.
pingTimer - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
Cancelable timer of ping loop
pointer - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 
polled - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
poller - Variable in class services.moleculer.transporter.KafkaTransporter
 
pollerProcess - Variable in class services.moleculer.transporter.FileSystemTransporter
Cancelable timer of poller/cleanup process
pollerProcess() - Method in class services.moleculer.transporter.FileSystemTransporter
 
pollingDelay - Variable in class services.moleculer.transporter.FileSystemTransporter
Poll period in MILLISECONDS.
pongChannel - Variable in class services.moleculer.transporter.Transporter
 
pool - Variable in class services.moleculer.stream.IncomingStream
 
port - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
port - Variable in class services.moleculer.transporter.tcp.RemoteAddress
 
port - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
port - Variable in class services.moleculer.transporter.tcp.UDPReceiver
TCP port (used by the Transporter and Gossiper services)
port - Variable in class services.moleculer.transporter.TcpTransporter
TCP port (used by the Transporter and Gossiper services).
position - Variable in class services.moleculer.logger.FastLogFormatter
 
preferHostname - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
preferHostname - Variable in class services.moleculer.transporter.Transporter
Use hostnames instead of IP addresses As the DHCP environment is dynamic, any later attempt to use IPs instead hostnames would most likely yield false results.
preferLocal - Variable in class services.moleculer.strategy.ArrayBasedStrategy
 
preferLocal - Variable in class services.moleculer.strategy.ArrayBasedStrategyFactory
Invoke local actions if possible
prefix - Variable in class services.moleculer.logger.AsyncFileLogger
 
prefix - Variable in class services.moleculer.transporter.Transporter
Prefix of channels.
prefix - Variable in class services.moleculer.uid.IncrementalUidGenerator
UID prefix (null = nodeID)
prefix - Variable in class services.moleculer.uid.XorShiftRandomUidGenerator
UID prefix (null = nodeID)
previousNodeID - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
prevSeq - Variable in class services.moleculer.stream.IncomingStream
 
prevStatus - Variable in class services.moleculer.breaker.ErrorCounter
 
prevTimeoutAt - Variable in class services.moleculer.service.DefaultServiceRegistry
Next scheduled time to check timeouts
printStackTrace() - Method in exception services.moleculer.error.MoleculerError
 
printStackTrace(PrintWriter) - Method in exception services.moleculer.error.MoleculerError
 
printStackTrace(PrintStream) - Method in exception services.moleculer.error.MoleculerError
 
priority - Variable in class services.moleculer.transporter.JmsTransporter
 
privateAccess - Variable in class services.moleculer.eventbus.ListenerEndpoint
Private Listener; only the local Broker can access it and cannot be called remotely.
processGossipHello(Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
processGossipRequest(Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
processGossipResponse(Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
processMessage(Tree) - Method in class services.moleculer.stream.IncomingStream
 
processPacket(byte[], int) - Method in class services.moleculer.transporter.tcp.TcpReader
 
processReceivedMessage(DatagramPacket, byte[]) - Method in class services.moleculer.transporter.tcp.UDPReceiver
 
processReceivedMessage(String, byte[]) - Method in class services.moleculer.transporter.Transporter
Process incoming message directly (without new Task).
processReceivedMessage(String, Tree) - Method in class services.moleculer.transporter.Transporter
Process incoming message directly (without new Task).
producer - Variable in class services.moleculer.transporter.KafkaTransporter
 
producerProperties - Variable in class services.moleculer.transporter.KafkaTransporter
 
promise - Variable in class services.moleculer.service.PendingPromise
 
promise - Variable in class services.moleculer.service.ServiceListener
 
promises - Variable in class services.moleculer.service.DefaultServiceRegistry
 
PROTOCOL_VERSION_MISMATCH_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
protocolVersion - Variable in class services.moleculer.eventbus.DefaultEventbus
ServiceBroker's protocol version
protocolVersion - Variable in class services.moleculer.service.DefaultServiceRegistry
ServiceBroker's protocol version
protocolVersion - Variable in class services.moleculer.transporter.Transporter
ServiceBroker's protocol version
ProtocolVersionMismatchError - Exception in services.moleculer.error
Protocol version mismatch exception.
ProtocolVersionMismatchError(String, String, String) - Constructor for exception services.moleculer.error.ProtocolVersionMismatchError
 
ProtocolVersionMismatchError(Tree) - Constructor for exception services.moleculer.error.ProtocolVersionMismatchError
 
psubscribed(byte[], long) - Method in class services.moleculer.transporter.RedisTransporter
 
publish(Event) - Method in class services.moleculer.cacher.RedisCacher
 
publish(LogRecord) - Method in class services.moleculer.logger.AsyncFileLogger
 
publish(String, Tree) - Method in class services.moleculer.transporter.AmqpTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.FileSystemTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.InternalTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.JmsTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.KafkaTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.MqttTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.NatsTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.NullTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.RedisTransporter
 
publish(Event) - Method in class services.moleculer.transporter.RedisTransporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
publish(String, String, Tree) - Method in class services.moleculer.transporter.Transporter
 
publish(String, Tree) - Method in class services.moleculer.transporter.Transporter
 
publish(String, byte[]) - Method in class services.moleculer.util.redis.RedisPubSubClient
 
publishers - Variable in class services.moleculer.transporter.JmsTransporter
 
publishPercentileHistogram - Variable in class services.moleculer.metrics.DefaultMetrics
 
punsubscribed(byte[], long) - Method in class services.moleculer.transporter.RedisTransporter
 
put(String, Object) - Method in class services.moleculer.util.FastBuildMap
WARNING: All key must be unique!
putAll(Map) - Method in class services.moleculer.util.FastBuildMap
 
putListUnsafe(String, int) - Method in class services.moleculer.util.FastBuildTree
 
putMapUnsafe(String, int) - Method in class services.moleculer.util.FastBuildTree
 
putUnsafe(String, Object) - Method in class services.moleculer.util.FastBuildTree
 
putUnsafe(String, Tree) - Method in class services.moleculer.util.FastBuildTree
 
putUnsafe(String, FastBuildTree) - Method in class services.moleculer.util.FastBuildTree
 

Q

qos - Variable in class services.moleculer.transporter.MqttTransporter
 
queue - Variable in class services.moleculer.transporter.tcp.SendBuffer
 
QUEUE_IS_FULL_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
QueueIsFullError - Exception in services.moleculer.error
'Queue is full' error message.
QueueIsFullError(String, String) - Constructor for exception services.moleculer.error.QueueIsFullError
 
QueueIsFullError(Tree) - Constructor for exception services.moleculer.error.QueueIsFullError
 
queueProperties - Variable in class services.moleculer.transporter.AmqpTransporter
 

R

read(byte[]) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
read(byte[]) - Method in class services.moleculer.serializer.DeflaterSerializer
 
read(byte[]) - Method in class services.moleculer.serializer.Serializer
 
readAndRemoveNextFiles() - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
reader - Variable in class services.moleculer.serializer.Serializer
Data deserializer (eg.
reader - Variable in class services.moleculer.transporter.TcpTransporter
Socket reader
readers(String) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
readFully(InputStream) - Static method in class services.moleculer.util.CommonUtils
 
readLock - Variable in class services.moleculer.breaker.CircuitBreaker
 
readLock - Variable in class services.moleculer.cacher.JCacheCacher
 
readLock - Variable in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
readLock - Variable in class services.moleculer.cacher.MemoryCacher
 
readLock - Variable in class services.moleculer.metrics.DefaultMetrics
 
readLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
readLock - Variable in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
readLock - Variable in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
readLock - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
readTree(String) - Static method in class services.moleculer.util.CommonUtils
 
readTree(InputStream, String) - Static method in class services.moleculer.util.CommonUtils
 
rebuild() - Method in class services.moleculer.strategy.ShardStrategy
 
receive(Tree) - Method in class services.moleculer.stream.IncomingStream
 
receive() - Method in class services.moleculer.transporter.tcp.UDPBroadcastReceiver
 
receive() - Method in class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
receive() - Method in class services.moleculer.transporter.tcp.UDPReceiver
 
received - Variable in exception services.moleculer.error.ProtocolVersionMismatchError
 
received(byte, byte[]) - Method in class services.moleculer.transporter.TcpTransporter
 
received(String, byte[]) - Method in class services.moleculer.transporter.Transporter
Process incoming message later (in a new Runnable or JoinForkTask).
receiveEvent(Tree) - Method in class services.moleculer.eventbus.DefaultEventbus
 
receiveEvent(Tree) - Method in class services.moleculer.eventbus.Eventbus
 
receivePong(Tree) - Method in class services.moleculer.service.DefaultServiceRegistry
 
receivePong(Tree) - Method in class services.moleculer.service.ServiceRegistry
 
receiveRequest(Tree) - Method in class services.moleculer.service.DefaultServiceRegistry
 
receiveRequest(Tree) - Method in class services.moleculer.service.ServiceRegistry
 
receiveResponse(Tree) - Method in class services.moleculer.service.DefaultServiceRegistry
 
receiveResponse(Tree) - Method in class services.moleculer.service.ServiceRegistry
 
receivers - Variable in class services.moleculer.transporter.tcp.UDPLocator
 
reconnect() - Method in class services.moleculer.cacher.RedisCacher
 
reconnect() - Method in class services.moleculer.transporter.AmqpTransporter
 
reconnect(Throwable) - Method in class services.moleculer.transporter.JmsTransporter
 
reconnect(Throwable) - Method in class services.moleculer.transporter.KafkaTransporter
 
reconnect(Throwable) - Method in class services.moleculer.transporter.MqttTransporter
 
reconnect() - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
reconnect() - Method in class services.moleculer.transporter.NatsTransporter
 
reconnect() - Method in class services.moleculer.transporter.RedisTransporter
 
reconnect() - Method in class services.moleculer.transporter.TcpTransporter
 
RedisCacher - Class in services.moleculer.cacher
Redis-based distributed cache.
RedisCacher() - Constructor for class services.moleculer.cacher.RedisCacher
 
RedisCacher(String...) - Constructor for class services.moleculer.cacher.RedisCacher
 
RedisCacher(String, int, boolean, String...) - Constructor for class services.moleculer.cacher.RedisCacher
 
RedisGetSetClient - Class in services.moleculer.util.redis
Promise-based get/set Redis client.
RedisGetSetClient(String[], String, boolean, ExecutorService, EventBus) - Constructor for class services.moleculer.util.redis.RedisGetSetClient
 
RedisPubSubClient - Class in services.moleculer.util.redis
Promise-based pub/sub Redis client.
RedisPubSubClient(String[], String, boolean, ExecutorService, EventBus, RedisPubSubListener<byte[], byte[]>) - Constructor for class services.moleculer.util.redis.RedisPubSubClient
 
RedisTransporter - Class in services.moleculer.transporter
Redis Transporter.
RedisTransporter() - Constructor for class services.moleculer.transporter.RedisTransporter
 
RedisTransporter(String...) - Constructor for class services.moleculer.transporter.RedisTransporter
 
RedisTransporter(String, boolean, String...) - Constructor for class services.moleculer.transporter.RedisTransporter
 
register(String, Promise, long, String, String, Tree) - Method in class services.moleculer.service.DefaultServiceRegistry
 
register(String, InternalTransporter) - Method in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
register(InternalTransporter) - Method in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
registerAsNewNode(String, String, int) - Method in class services.moleculer.transporter.TcpTransporter
 
registerCustomError(String, Class<? extends MoleculerError>) - Static method in class services.moleculer.error.MoleculerErrorUtils
 
registry(ServiceRegistry) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
registry - Variable in class services.moleculer.metrics.DefaultMetrics
 
registry - Variable in class services.moleculer.transporter.Transporter
 
registryReadLock - Variable in class services.moleculer.eventbus.DefaultEventbus
Reader lock of the Event Bus
registryWriteLock - Variable in class services.moleculer.eventbus.DefaultEventbus
Writer lock of the Event Bus
RemoteActionEndpoint - Class in services.moleculer.service
 
RemoteActionEndpoint(DefaultServiceRegistry, Transporter, String, String, Tree, String) - Constructor for class services.moleculer.service.RemoteActionEndpoint
 
RemoteAddress - Class in services.moleculer.transporter.tcp
 
RemoteAddress(String, int) - Constructor for class services.moleculer.transporter.tcp.RemoteAddress
 
RemoteListenerEndpoint - Class in services.moleculer.eventbus
 
RemoteListenerEndpoint(String, String, String, String, Transporter) - Constructor for class services.moleculer.eventbus.RemoteListenerEndpoint
 
RemovableFile(File, long) - Constructor for class services.moleculer.transporter.FileSystemTransporter.RemovableFile
 
removableFiles - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
remove(String) - Method in class services.moleculer.strategy.ArrayBasedStrategy
 
remove(String) - Method in class services.moleculer.strategy.ShardStrategy
 
remove(String) - Method in class services.moleculer.strategy.Strategy
 
remove(Object) - Method in class services.moleculer.util.FastBuildMap
 
removeActions(String) - Method in class services.moleculer.service.DefaultServiceRegistry
 
removeActions(String) - Method in class services.moleculer.service.ServiceRegistry
 
removeAllFiles() - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
removeAllSavedFiles() - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
removeAt - Variable in class services.moleculer.transporter.FileSystemTransporter.RemovableFile
 
removeCacheConfiguration(String) - Method in class services.moleculer.cacher.JCacheCacher
 
removeIgnoredType(Class<? extends Throwable>) - Method in class services.moleculer.breaker.CircuitBreaker
 
removeListeners(String) - Method in class services.moleculer.eventbus.DefaultEventbus
 
removeListeners(String) - Method in class services.moleculer.eventbus.Eventbus
 
removeLocalEvents(Tree) - Static method in class services.moleculer.util.CommonUtils
 
removeOldEntries(long) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
removeTimeoutedFiles() - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
repl() - Method in class services.moleculer.ServiceBroker
Starts a local (System in/out) developer console.
repl(boolean) - Method in class services.moleculer.ServiceBroker
Starts a local (System in/out) or a remote (telnet-based) developer console.
reporters - Variable in class services.moleculer.metrics.DefaultMetrics
 
reporters() - Method in class services.moleculer.metrics.DefaultMetrics
 
reporters - Variable in class services.moleculer.metrics.DropwizardReportersImpl
 
req - Variable in class services.moleculer.service.PendingPromise
 
REQUEST_REJECTED_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
REQUEST_SKIPPED_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
REQUEST_TIMEOUT_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
requestChannel - Variable in class services.moleculer.transporter.Transporter
 
requestID - Variable in class services.moleculer.context.Context
Request ID (= first context ID)
RequestRejectedError - Exception in services.moleculer.error
'Request rejected' error message.
RequestRejectedError(String, String) - Constructor for exception services.moleculer.error.RequestRejectedError
 
RequestRejectedError(Tree) - Constructor for exception services.moleculer.error.RequestRejectedError
 
RequestSkippedError - Exception in services.moleculer.error
'Request skipped' error message.
RequestSkippedError(String, String) - Constructor for exception services.moleculer.error.RequestSkippedError
 
RequestSkippedError(Tree) - Constructor for exception services.moleculer.error.RequestSkippedError
 
requestStreamReadLock - Variable in class services.moleculer.eventbus.DefaultEventbus
 
requestStreamReadLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
requestStreams - Variable in class services.moleculer.eventbus.DefaultEventbus
 
requestStreams - Variable in class services.moleculer.service.DefaultServiceRegistry
 
requestStreamWriteLock - Variable in class services.moleculer.eventbus.DefaultEventbus
 
requestStreamWriteLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
RequestTimeoutError - Exception in services.moleculer.error
'Request timed out' error message.
RequestTimeoutError(String, String) - Constructor for exception services.moleculer.error.RequestTimeoutError
 
RequestTimeoutError(Tree) - Constructor for exception services.moleculer.error.RequestTimeoutError
 
reschedule(long) - Method in class services.moleculer.service.DefaultServiceRegistry
Recalculates the next timeout checking time.
reset() - Method in class services.moleculer.stream.IncomingStream
Used for testing.
resolveUnit(String) - Static method in class services.moleculer.util.CommonUtils
 
resources - Variable in class services.moleculer.util.redis.AbstractRedisClient
 
responseChannel - Variable in class services.moleculer.transporter.Transporter
 
responseStreamReadLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
responseStreams - Variable in class services.moleculer.service.DefaultServiceRegistry
 
responseStreamWriteLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
responseTimes - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
retry(Context, String, int, Throwable) - Method in class services.moleculer.service.DefaultServiceInvoker
 
retryable - Variable in exception services.moleculer.error.MoleculerError
 
retryCount - Variable in class services.moleculer.context.CallOptions.Options
Number of retries (0 = disable retries)
retryCount(int) - Method in class services.moleculer.context.CallOptions.Options
 
retryCount(int) - Static method in class services.moleculer.context.CallOptions
 
retryLogic - Variable in class services.moleculer.service.DefaultServiceInvoker
 
Ring(int, int, Integer, int) - Constructor for class services.moleculer.strategy.ShardStrategy.Ring
 
ringRef - Variable in class services.moleculer.strategy.ShardStrategy
The "hash ring" (https://www.toptal.com/big-data/consistent-hashing)
ringSize - Variable in class services.moleculer.strategy.ShardStrategy.Ring
Actual/minimum ring size (or -1, if not set)
ringSize - Variable in class services.moleculer.strategy.ShardStrategy
Ring size (optional)
ringSize - Variable in class services.moleculer.strategy.ShardStrategyFactory
Ring size (optional)
rnd - Variable in class services.moleculer.strategy.SecureRandomStrategy
 
rnd - Variable in class services.moleculer.strategy.XorShiftRandomStrategy
 
rnd - Variable in class services.moleculer.transporter.TcpTransporter
Random generator.
rnd - Variable in class services.moleculer.uid.XorShiftRandomUidGenerator
 
RoundRobinStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Round-Robin invocation strategy.
RoundRobinStrategy(ServiceBroker, boolean) - Constructor for class services.moleculer.strategy.RoundRobinStrategy
 
RoundRobinStrategyFactory - Class in services.moleculer.strategy
Factory of Round-Robin invocation strategy.
RoundRobinStrategyFactory() - Constructor for class services.moleculer.strategy.RoundRobinStrategyFactory
Constructor that uses local services when available.
RoundRobinStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.RoundRobinStrategyFactory
Constructor that can be configured to use local services if possible.
run() - Method in class services.moleculer.breaker.CircuitBreaker
 
run() - Method in class services.moleculer.cacher.MemoryCacher
 
run() - Method in class services.moleculer.logger.AsyncFileLogger
 
run() - Method in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
run() - Method in class services.moleculer.transporter.tcp.TcpReader
 
run() - Method in class services.moleculer.transporter.tcp.TcpWriter
 

S

sampleCount - Variable in class services.moleculer.strategy.CpuUsageStrategy
This strategy compares number of 'sampleCount' random node.
sampleCount - Variable in class services.moleculer.strategy.CpuUsageStrategyFactory
This strategy compares number of 'sampleCount' random node.
sampleCount - Variable in class services.moleculer.strategy.NetworkLatencyStrategy
This strategy compares number of 'sampleCount' random node.
sampleCount - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
This strategy compares number of 'sampleCount' random node.
Samples(int) - Constructor for class services.moleculer.strategy.NetworkLatencyStrategyFactory.Samples
 
saveTempFile(byte[]) - Method in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
scheduleInfoPacket() - Method in class services.moleculer.transporter.Transporter
 
scheduleNextPacket(ReadableByteChannel, OutputStream, Promise, ByteBuffer) - Method in class services.moleculer.stream.PacketStream
 
scheduleNextPacket(InputStream, OutputStream, Promise, byte[]) - Method in class services.moleculer.stream.PacketStream
 
scheduler - Variable in class services.moleculer.cacher.RedisCacher
 
scheduler(ScheduledExecutorService) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
scheduler - Variable in class services.moleculer.config.ServiceBrokerConfig
 
scheduler - Variable in class services.moleculer.eventbus.DefaultEventbus
 
scheduler - Variable in class services.moleculer.service.DefaultServiceRegistry
 
scheduler - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
scheduler - Variable in class services.moleculer.stream.PacketStream
 
scheduler - Variable in class services.moleculer.transporter.tcp.UDPLocator
Sender's executor
scheduler - Variable in class services.moleculer.transporter.Transporter
 
secretKey - Variable in class services.moleculer.serializer.BlockCipherSerializer
SecretKeySpec, can be specified externally.
secure - Variable in class services.moleculer.cacher.RedisCacher
 
secure - Variable in class services.moleculer.transporter.NatsTransporter
Use the default SSL Context, if it exists.
secure - Variable in class services.moleculer.transporter.RedisTransporter
 
secure - Variable in class services.moleculer.util.redis.AbstractRedisClient
 
SecureRandomStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Java Random/SecureRandom-based invocation strategy.
SecureRandomStrategy(ServiceBroker, boolean) - Constructor for class services.moleculer.strategy.SecureRandomStrategy
 
SecureRandomStrategyFactory - Class in services.moleculer.strategy
Factory of Java SecureRandom-based invocation strategy.
SecureRandomStrategyFactory() - Constructor for class services.moleculer.strategy.SecureRandomStrategyFactory
Constructor that uses local services when available.
SecureRandomStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.SecureRandomStrategyFactory
Constructor that can be configured to use local services if possible.
segmentCount - Variable in class services.moleculer.cacher.OHCacher
Number of segments (must be a power of 2), defaults to number-of-cores * 2
selector - Variable in class services.moleculer.transporter.tcp.TcpReader
 
selector - Variable in class services.moleculer.transporter.tcp.TcpWriter
 
send(String, byte[]) - Method in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
send(byte[]) - Method in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
send(String, byte[]) - Method in class services.moleculer.transporter.tcp.TcpWriter
 
send() - Method in class services.moleculer.transporter.tcp.UDPBroadcastReceiver
 
send() - Method in class services.moleculer.transporter.tcp.UDPLocator
 
send() - Method in class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
send() - Method in class services.moleculer.transporter.tcp.UDPReceiver
 
SendBuffer - Class in services.moleculer.transporter.tcp
Attachment of TcpWriter's SelectionKeys.
SendBuffer(String, String, int, boolean) - Constructor for class services.moleculer.transporter.tcp.SendBuffer
 
sendClose() - Method in class services.moleculer.stream.PacketStream
 
sendClosePacket(String, String, Context, long) - Method in class services.moleculer.transporter.Transporter
 
sendData(byte[]) - Method in class services.moleculer.stream.PacketStream
 
sendDataPacket(String, String, Context, byte[], long) - Method in class services.moleculer.transporter.Transporter
 
sendDisconnectPacket() - Method in class services.moleculer.transporter.TcpTransporter
 
sendDisconnectPacket() - Method in class services.moleculer.transporter.Transporter
 
sendDiscoverPacket(String) - Method in class services.moleculer.transporter.Transporter
 
sendError(Throwable) - Method in class services.moleculer.stream.PacketStream
 
sendErrorPacket(String, String, Context, Throwable, long) - Method in class services.moleculer.transporter.Transporter
 
sendEventPacket(String, Context, Groups, boolean) - Method in class services.moleculer.transporter.Transporter
 
sendGossipRequest() - Method in class services.moleculer.transporter.TcpTransporter
Create and send a Gossip request packet.
sendGossipToRandomEndpoint(String[], int, byte[], Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
sendHeartbeatPacket() - Method in class services.moleculer.transporter.Transporter
 
sendInfoPacket(String) - Method in class services.moleculer.transporter.Transporter
 
sendNextPing() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
sendPing(String) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
sendPongPacket(String, Tree) - Method in class services.moleculer.transporter.Transporter
 
sendRequestPacket(String, Context) - Method in class services.moleculer.transporter.Transporter
 
seq - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
serialize(byte[], ByteBuffer) - Method in class services.moleculer.cacher.OHCacher.ArraySerializer
 
serialize(byte, Tree) - Method in class services.moleculer.transporter.TcpTransporter
 
serializedSize(byte[]) - Method in class services.moleculer.cacher.OHCacher.ArraySerializer
 
serializeKey(StringBuilder, Tree, String...) - Method in class services.moleculer.cacher.Cacher
 
serializer - Variable in class services.moleculer.cacher.JCacheCacher
 
serializer - Variable in class services.moleculer.cacher.OHCacher
 
serializer - Variable in class services.moleculer.cacher.RedisCacher
 
Serializer - Class in services.moleculer.serializer
Base superclass of all data serializer implementations.
Serializer(String) - Constructor for class services.moleculer.serializer.Serializer
 
serializer - Variable in class services.moleculer.transporter.Transporter
 
server - Variable in class services.moleculer.monitor.JmxMonitor
 
serverChannel - Variable in class services.moleculer.transporter.tcp.TcpReader
 
service - Variable in class services.moleculer.service.ActionEndpoint
 
Service - Class in services.moleculer.service
Superclass of Moleculer Services.
Service() - Constructor for class services.moleculer.service.Service
 
Service(String) - Constructor for class services.moleculer.service.Service
 
SERVICE_NOT_AVAILABLE_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
SERVICE_NOT_FOUND_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
SERVICE_SCHEMA_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
ServiceBroker - Class in services.moleculer
The ServiceBroker is the main component of Moleculer.
ServiceBroker(ServiceBrokerConfig) - Constructor for class services.moleculer.ServiceBroker
Creates a new ServiceBroker by the specified configuration.
ServiceBroker() - Constructor for class services.moleculer.ServiceBroker
Creates a new ServiceBroker without Transporter.
ServiceBroker(String) - Constructor for class services.moleculer.ServiceBroker
Creates a new ServiceBroker without Transporter and with the specified ContextSource.nodeID.
ServiceBroker(String, Cacher, Transporter) - Constructor for class services.moleculer.ServiceBroker
Creates a new ServiceBroker with the specified ContextSource.nodeID, Cacher, and Transporter.
ServiceBrokerBuilder - Class in services.moleculer.config
Builder-style ServiceBroker factory.
ServiceBrokerBuilder() - Constructor for class services.moleculer.config.ServiceBrokerBuilder
 
ServiceBrokerConfig - Class in services.moleculer.config
 
ServiceBrokerConfig() - Constructor for class services.moleculer.config.ServiceBrokerConfig
 
ServiceBrokerConfig(String, Cacher, Transporter) - Constructor for class services.moleculer.config.ServiceBrokerConfig
 
serviceInvoker - Variable in class services.moleculer.config.ServiceBrokerConfig
 
serviceInvoker - Variable in class services.moleculer.context.ContextSource
Service Invoker of the ServiceBroker or Context.
serviceInvoker - Variable in class services.moleculer.eventbus.DefaultEventbus
 
serviceInvoker - Variable in class services.moleculer.service.DefaultServiceRegistry
 
ServiceInvoker - Class in services.moleculer.service
Base superclass of all Service Invoker implementations.
ServiceInvoker() - Constructor for class services.moleculer.service.ServiceInvoker
 
serviceInvoker - Variable in class services.moleculer.transporter.Transporter
 
ServiceListener - Class in services.moleculer.service
Promise container of a "waitingForServices" calls.
serviceListeners - Variable in class services.moleculer.service.DefaultServiceRegistry
Promises of the "waitingForServices" calls
serviceName - Variable in class services.moleculer.eventbus.ListenerEndpoint
 
serviceNames - Variable in class services.moleculer.ServiceBroker
Service names (keys).
ServiceNotAvailableError - Exception in services.moleculer.error
'Service not available' error message.
ServiceNotAvailableError(String, String) - Constructor for exception services.moleculer.error.ServiceNotAvailableError
 
ServiceNotAvailableError(Tree) - Constructor for exception services.moleculer.error.ServiceNotAvailableError
 
ServiceNotFoundError - Exception in services.moleculer.error
'Service not found' error message.
ServiceNotFoundError(String, String) - Constructor for exception services.moleculer.error.ServiceNotFoundError
 
ServiceNotFoundError(Tree) - Constructor for exception services.moleculer.error.ServiceNotFoundError
 
serviceRegistry - Variable in class services.moleculer.breaker.CircuitBreaker
 
serviceRegistry - Variable in class services.moleculer.config.ServiceBrokerConfig
 
serviceRegistry - Variable in class services.moleculer.service.DefaultServiceInvoker
 
ServiceRegistry - Class in services.moleculer.service
Base superclass of all Service Registry implementations.
ServiceRegistry() - Constructor for class services.moleculer.service.ServiceRegistry
 
serviceRegistry - Variable in class services.moleculer.ServiceBroker
Implementation of the service registry of the current node.
services - Variable in class services.moleculer.internal.NodeService
Implementation of the "$node.services" action
services - Variable in class services.moleculer.service.DefaultServiceRegistry
 
services - Variable in class services.moleculer.service.ServiceListener
 
services - Variable in class services.moleculer.ServiceBroker
Services which defined and added to the Broker before the boot process.
services.moleculer - package services.moleculer
 
services.moleculer.breaker - package services.moleculer.breaker
 
services.moleculer.cacher - package services.moleculer.cacher
 
services.moleculer.config - package services.moleculer.config
 
services.moleculer.context - package services.moleculer.context
 
services.moleculer.error - package services.moleculer.error
 
services.moleculer.eventbus - package services.moleculer.eventbus
 
services.moleculer.internal - package services.moleculer.internal
 
services.moleculer.logger - package services.moleculer.logger
 
services.moleculer.metrics - package services.moleculer.metrics
 
services.moleculer.monitor - package services.moleculer.monitor
 
services.moleculer.serializer - package services.moleculer.serializer
 
services.moleculer.service - package services.moleculer.service
 
services.moleculer.strategy - package services.moleculer.strategy
 
services.moleculer.stream - package services.moleculer.stream
 
services.moleculer.transporter - package services.moleculer.transporter
 
services.moleculer.transporter.tcp - package services.moleculer.transporter.tcp
 
services.moleculer.uid - package services.moleculer.uid
 
services.moleculer.util - package services.moleculer.util
 
services.moleculer.util.redis - package services.moleculer.util.redis
 
ServiceSchemaError - Exception in services.moleculer.error
Custom Moleculer Exception class for Service schema exceptions.
ServiceSchemaError(String, String, Object...) - Constructor for exception services.moleculer.error.ServiceSchemaError
 
ServiceSchemaError(Tree) - Constructor for exception services.moleculer.error.ServiceSchemaError
 
servicesOnlineTimer - Variable in class services.moleculer.service.DefaultServiceRegistry
Cancelable timer for handling "wait for service" calls
session - Variable in class services.moleculer.transporter.JmsTransporter
 
set(String, Tree, int) - Method in class services.moleculer.cacher.Cacher
Sets a content by key into the cache.
set(String, Tree, int) - Method in class services.moleculer.cacher.JCacheCacher
 
set(String, Tree, int) - Method in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
set(String, Tree, int) - Method in class services.moleculer.cacher.MemoryCacher
 
set(String, Tree, int) - Method in class services.moleculer.cacher.OHCacher
 
set(String, Tree, int) - Method in class services.moleculer.cacher.RedisCacher
 
set(String, String, double, String...) - Method in class services.moleculer.metrics.DefaultMetrics
 
set(double) - Method in interface services.moleculer.metrics.MetricGauge
 
set(String, String, double, String...) - Method in interface services.moleculer.metrics.Metrics
 
set - Variable in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
set(String, byte[], SetArgs) - Method in class services.moleculer.util.redis.RedisGetSetClient
Sets a content by key.
setAcknowledgeMode(int) - Method in class services.moleculer.transporter.JmsTransporter
 
setAckTimeout(Duration) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setAdvancedStats(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setAlgorithm(String) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
setApplicationContext(ApplicationContext) - Method in class services.moleculer.config.SpringRegistrator
 
setAsyncLocalInvocation(boolean) - Method in class services.moleculer.service.DefaultServiceRegistry
 
setAuthHandler(AuthHandler) - Method in class services.moleculer.transporter.NatsTransporter
 
setBufferSize(int) - Method in class services.moleculer.transporter.NatsTransporter
 
setCacheConfigurations(Map<String, Configuration<String, byte[]>>) - Method in class services.moleculer.cacher.JCacheCacher
 
setCacheManager(CacheManager) - Method in class services.moleculer.cacher.JCacheCacher
 
setCacher(Cacher) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setCacheSize(int) - Method in class services.moleculer.strategy.ShardStrategyFactory
 
setCapacity(int) - Method in class services.moleculer.cacher.MemoryCacher
 
setCapacity(long) - Method in class services.moleculer.cacher.OHCacher
 
setCheckVersion(boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
setCheckVersion(boolean) - Method in class services.moleculer.service.DefaultServiceRegistry
 
setCleanSession(boolean) - Method in class services.moleculer.transporter.MqttTransporter
 
setCleanup(int) - Method in class services.moleculer.breaker.CircuitBreaker
 
setCleanup(int) - Method in class services.moleculer.cacher.MemoryCacher
 
setClientId(String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setCloseEmptyPartitions(boolean) - Method in class services.moleculer.cacher.JCacheCacher
 
setClusterId(String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setCollectCount(int) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
setCommand(String) - Method in class services.moleculer.monitor.CommandMonitor
 
setCompressAbove(int) - Method in class services.moleculer.cacher.OHCacher
 
setCompressionLevel(int) - Method in class services.moleculer.cacher.OHCacher
 
setCompressionLevel(int) - Method in class services.moleculer.serializer.DeflaterSerializer
 
setConnectionFactoryJndiName(String) - Method in class services.moleculer.transporter.JmsTransporter
 
setConnectionTimeout(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setConnectionTimeout(long) - Method in class services.moleculer.transporter.NatsTransporter
 
setConnectTimeout(Duration) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setConsumerProperties(Properties) - Method in class services.moleculer.transporter.KafkaTransporter
 
setConsumerProperty(String, String) - Method in class services.moleculer.transporter.KafkaTransporter
 
setCustomWebSocketHeaders(Properties) - Method in class services.moleculer.transporter.MqttTransporter
 
setDebug(boolean) - Method in class services.moleculer.cacher.Cacher
Enable debug messages.
setDebug(boolean) - Method in class services.moleculer.serializer.ChainedSerializer
 
setDebug(boolean) - Method in class services.moleculer.serializer.Serializer
 
setDebug(boolean) - Method in class services.moleculer.transporter.Transporter
 
setDebugHeartbeats(boolean) - Method in class services.moleculer.transporter.Transporter
 
setDefaultConfiguration(Configuration<String, byte[]>) - Method in class services.moleculer.cacher.JCacheCacher
 
setDeliveryMode(int) - Method in class services.moleculer.transporter.JmsTransporter
 
setDirectory(String) - Method in class services.moleculer.transporter.FileSystemTransporter
 
setDiscoverPrefix(String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setDistributionStatisticBufferLength(int) - Method in class services.moleculer.metrics.DefaultMetrics
 
setEventbus(Eventbus) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setExchangeProperties(Map<String, Object>) - Method in class services.moleculer.transporter.AmqpTransporter
 
setExchangeType(String) - Method in class services.moleculer.transporter.AmqpTransporter
 
setExclusive(boolean) - Method in class services.moleculer.transporter.AmqpTransporter
 
setExecutor(ExecutorService) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setExecutor(ExecutorService) - Method in class services.moleculer.transporter.KafkaTransporter
 
setExecutorServiceTimeout(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setFactory(ConnectionFactory) - Method in class services.moleculer.transporter.AmqpTransporter
 
setFileTimeout(long) - Method in class services.moleculer.transporter.FileSystemTransporter
 
setGossipPeriod(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setHash(Function<String, Long>) - Method in class services.moleculer.strategy.ShardStrategyFactory
 
setHashTableSize(int) - Method in class services.moleculer.cacher.OHCacher
 
setHeartbeatInterval(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setHeartbeatInterval(int) - Method in class services.moleculer.transporter.Transporter
 
setHeartbeatTimeout(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setHeartbeatTimeout(int) - Method in class services.moleculer.transporter.Transporter
 
setHostnameVerifier(HostnameVerifier) - Method in class services.moleculer.transporter.MqttTransporter
 
setHttpsHostnameVerificationEnabled(boolean) - Method in class services.moleculer.transporter.MqttTransporter
 
setIgnoredTypes(Set<Class<? extends Throwable>>) - Method in class services.moleculer.breaker.CircuitBreaker
 
setImmediate(boolean) - Method in class services.moleculer.transporter.AmqpTransporter
 
setInternal(boolean) - Method in class services.moleculer.transporter.AmqpTransporter
 
setInternalServices(boolean) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setIv(String) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
setIv(byte[]) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
setJsonReaders(String) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setJsonWriters(String) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setKeepAliveInterval(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setLockTimeout(long) - Method in class services.moleculer.breaker.CircuitBreaker
 
setLowCpuUsage(int) - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
 
setMandatory(boolean) - Method in class services.moleculer.transporter.AmqpTransporter
 
setMaxCallLevel(int) - Method in class services.moleculer.eventbus.DefaultEventbus
 
setMaxCallLevel(int) - Method in class services.moleculer.service.DefaultServiceInvoker
 
setMaxConnections(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setMaxErrors(int) - Method in class services.moleculer.breaker.CircuitBreaker
 
setMaxInflight(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setMaxPacketSize(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setMaxParamsLength(int) - Method in class services.moleculer.cacher.DistributedCacher
 
setMaxPingsOut(int) - Method in class services.moleculer.transporter.NatsTransporter
 
setMaxPubAcksInFlight(Integer) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setMaxSameNodes(int) - Method in class services.moleculer.breaker.CircuitBreaker
 
setMaxTries(int) - Method in class services.moleculer.breaker.CircuitBreaker
 
setMessageProperties(AMQP.BasicProperties) - Method in class services.moleculer.transporter.AmqpTransporter
 
setMetrics(Metrics) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setMetricsEnabled(boolean) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setMonitor(Monitor) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setMqttVersion(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setNamespace(String) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setNamespace(String) - Method in class services.moleculer.transporter.Transporter
 
setNodeID(String) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setNoEcho(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setNoRandomize(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setOfflineTimeout(int) - Method in class services.moleculer.transporter.Transporter
 
setOldRequestStyle(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setOpentls(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setPackagesToScan(String...) - Method in class services.moleculer.config.SpringRegistrator
 
setPacketDelay(long) - Method in class services.moleculer.stream.PacketStream
 
setPacketSize(int) - Method in class services.moleculer.stream.PacketStream
 
setPassword(String) - Method in class services.moleculer.cacher.RedisCacher
 
setPassword(String) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
setPassword(String) - Method in class services.moleculer.transporter.AmqpTransporter
 
setPassword(String) - Method in class services.moleculer.transporter.JmsTransporter
 
setPassword(String) - Method in class services.moleculer.transporter.MqttTransporter
 
setPassword(String) - Method in class services.moleculer.transporter.NatsTransporter
 
setPassword(String) - Method in class services.moleculer.transporter.RedisTransporter
 
setPedantic(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setPercentilePrecision(int) - Method in class services.moleculer.metrics.DefaultMetrics
 
setPercentiles(double[]) - Method in class services.moleculer.metrics.DefaultMetrics
 
setPersistence(MemoryPersistence) - Method in class services.moleculer.transporter.MqttTransporter
 
setPingInterval(int) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
setPingInterval(Duration) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setPingInterval(long) - Method in class services.moleculer.transporter.NatsTransporter
 
setPingsMaxOut(Integer) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setPingTimeout(long) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
setPollingDelay(long) - Method in class services.moleculer.transporter.FileSystemTransporter
 
setPort(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setPreferHostname(boolean) - Method in class services.moleculer.transporter.Transporter
 
setPreferLocal(boolean) - Method in class services.moleculer.strategy.ArrayBasedStrategyFactory
 
setPrefix(String) - Method in class services.moleculer.transporter.Transporter
 
setPrefix(String) - Method in class services.moleculer.uid.IncrementalUidGenerator
 
setPrefix(String) - Method in class services.moleculer.uid.XorShiftRandomUidGenerator
 
setPriority(int) - Method in class services.moleculer.transporter.JmsTransporter
 
setProducerProperties(Properties) - Method in class services.moleculer.transporter.KafkaTransporter
 
setProducerProperty(String, String) - Method in class services.moleculer.transporter.KafkaTransporter
 
setPublishPercentileHistogram(boolean) - Method in class services.moleculer.metrics.DefaultMetrics
 
setQos(int) - Method in class services.moleculer.transporter.MqttTransporter
 
setQueueProperties(Map<String, Object>) - Method in class services.moleculer.transporter.AmqpTransporter
 
setRetryLogic(Predicate<Throwable>) - Method in class services.moleculer.service.DefaultServiceInvoker
 
setRingSize(Integer) - Method in class services.moleculer.strategy.ShardStrategyFactory
 
sets - Variable in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
setSampleCount(int) - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
 
setSampleCount(int) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
setScheduler(ScheduledExecutorService) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setSecretKey(SecretKeySpec) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
setSecure(boolean) - Method in class services.moleculer.cacher.RedisCacher
 
setSecure(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setSecure(boolean) - Method in class services.moleculer.transporter.RedisTransporter
 
setSegmentCount(int) - Method in class services.moleculer.cacher.OHCacher
 
setSerializer(Serializer) - Method in class services.moleculer.cacher.OHCacher
 
setSerializer(Serializer) - Method in class services.moleculer.cacher.RedisCacher
 
setSerializer(Serializer) - Method in class services.moleculer.transporter.Transporter
 
setServiceInvoker(ServiceInvoker) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setServiceRegistry(ServiceRegistry) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setShardKey(String) - Method in class services.moleculer.strategy.ShardStrategyFactory
 
setShutDownThreadPools(boolean) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setShutDownThreadPools(boolean) - Method in class services.moleculer.transporter.KafkaTransporter
 
setSocketFactory(SocketFactory) - Method in class services.moleculer.transporter.MqttTransporter
 
setSslClientProps(Properties) - Method in class services.moleculer.transporter.MqttTransporter
 
setSslContext(SSLContext) - Method in class services.moleculer.transporter.NatsTransporter
 
setSslContextFactory(SslContextFactory) - Method in class services.moleculer.transporter.AmqpTransporter
 
setStoredFileNames(int) - Method in class services.moleculer.transporter.FileSystemTransporter
 
setStrategyFactory(StrategyFactory) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setStreamTimeout(long) - Method in class services.moleculer.eventbus.DefaultEventbus
 
setStreamTimeout(long) - Method in class services.moleculer.service.DefaultServiceRegistry
 
setSubscriptionOptions(SubscriptionOptions) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setSubscriptionTimeout(int) - Method in class services.moleculer.transporter.Transporter
 
setThreshold(int) - Method in class services.moleculer.serializer.DeflaterSerializer
 
setTopicConnectionFactory(TopicConnectionFactory) - Method in class services.moleculer.transporter.JmsTransporter
 
setTotalCpuPercent(int) - Method in class services.moleculer.monitor.ConstantMonitor
 
setTraceConnection(Boolean) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setTransacted(boolean) - Method in class services.moleculer.transporter.JmsTransporter
 
setTransporter(Transporter) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setTtl(int) - Method in class services.moleculer.cacher.MemoryCacher
 
setTtl(int) - Method in class services.moleculer.cacher.OHCacher
 
setTtl(int) - Method in class services.moleculer.cacher.RedisCacher
 
setTtl(int) - Method in class services.moleculer.transporter.JmsTransporter
 
setUdpBindAddress(String) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpBroadcast(boolean) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpMaxDiscovery(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpMulticast(String) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpMulticastTTL(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpPeriod(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpPort(int) - Method in class services.moleculer.transporter.TcpTransporter
 
setUdpReuseAddr(boolean) - Method in class services.moleculer.transporter.TcpTransporter
 
setUidGenerator(UidGenerator) - Method in class services.moleculer.config.ServiceBrokerConfig
 
setUrl(String) - Method in class services.moleculer.transporter.AmqpTransporter
 
setUrl(String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
setUrls(String...) - Method in class services.moleculer.cacher.RedisCacher
 
setUrls(String[]) - Method in class services.moleculer.transporter.KafkaTransporter
 
setUrls(String...) - Method in class services.moleculer.transporter.MqttTransporter
 
setUrls(String...) - Method in class services.moleculer.transporter.NatsTransporter
 
setUrls(String[]) - Method in class services.moleculer.transporter.RedisTransporter
 
setUrls(String...) - Method in class services.moleculer.transporter.TcpTransporter
 
setUseCloning(boolean) - Method in class services.moleculer.cacher.MemoryCacher
 
setUseHostname(boolean) - Method in class services.moleculer.transporter.TcpTransporter
 
setUsername(String) - Method in class services.moleculer.transporter.AmqpTransporter
 
setUsername(String) - Method in class services.moleculer.transporter.JmsTransporter
 
setUsername(String) - Method in class services.moleculer.transporter.MqttTransporter
 
setUsername(String) - Method in class services.moleculer.transporter.NatsTransporter
 
setUtf8Support(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setVerbose(boolean) - Method in class services.moleculer.transporter.NatsTransporter
 
setVnodes(int) - Method in class services.moleculer.strategy.ShardStrategyFactory
 
setWindowLength(long) - Method in class services.moleculer.breaker.CircuitBreaker
 
setWriteErrorsToLog(boolean) - Method in class services.moleculer.eventbus.DefaultEventbus
 
setWriteErrorsToLog(boolean) - Method in class services.moleculer.service.DefaultServiceInvoker
 
setWriteErrorsToLog(boolean) - Method in class services.moleculer.service.DefaultServiceRegistry
 
setWriteRegistrations(boolean) - Method in class services.moleculer.service.DefaultServiceRegistry
 
SEVERE - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
SEVERE - Static variable in class services.moleculer.logger.FastLogFormatter
 
SEVERE - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
shardKey - Variable in class services.moleculer.strategy.ShardStrategy
Shard key's path (eg.
shardKey - Variable in class services.moleculer.strategy.ShardStrategyFactory
Shard key's path (eg.
ShardStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Sharding invocation strategy.
ShardStrategy(ServiceBroker, boolean, String, int, Integer, int, Function<String, Long>) - Constructor for class services.moleculer.strategy.ShardStrategy
 
ShardStrategy.Ring - Class in services.moleculer.strategy
 
ShardStrategyFactory - Class in services.moleculer.strategy
Sharding invocation strategy factory.
ShardStrategyFactory() - Constructor for class services.moleculer.strategy.ShardStrategyFactory
Constructor that calls for service based primarily on its own (hash-based) logic.
ShardStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.ShardStrategyFactory
Constructor that can be configured to use local services if possible.
ShardStrategyFactory(String) - Constructor for class services.moleculer.strategy.ShardStrategyFactory
Constructor that can be configured to use local services if possible.
ShardStrategyFactory(boolean, String) - Constructor for class services.moleculer.strategy.ShardStrategyFactory
Constructor that can be configured to use local services if possible.
shared - Variable in class services.moleculer.transporter.FileSystemTransporter.DirectoryHandler
 
sharedInstance - Static variable in class services.moleculer.transporter.InternalTransporter
 
shutDownThreadPools - Variable in class services.moleculer.config.ServiceBrokerConfig
 
shutDownThreadPools - Variable in class services.moleculer.transporter.KafkaTransporter
 
sigar - Static variable in class services.moleculer.monitor.SigarMonitor
 
SigarMonitor - Class in services.moleculer.monitor
Sigar API-based System Monitor.
SigarMonitor() - Constructor for class services.moleculer.monitor.SigarMonitor
 
SimpleConsoleLogger - Class in services.moleculer.logger
Simple, System.out-based logger.
SimpleConsoleLogger() - Constructor for class services.moleculer.logger.SimpleConsoleLogger
 
size() - Method in class services.moleculer.util.FastBuildMap.FastBuildEntrySet
 
size - Variable in class services.moleculer.util.FastBuildMap
 
size() - Method in class services.moleculer.util.FastBuildMap
 
slowConsumerDetected(Connection, Consumer) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
SmileSerializer - Class in services.moleculer.serializer
Smile Serializer

Smile is a computer data interchange format based on JSON.
SmileSerializer() - Constructor for class services.moleculer.serializer.SmileSerializer
 
socketFactory - Variable in class services.moleculer.transporter.MqttTransporter
 
SOFTWARE_VERSION - Static variable in class services.moleculer.ServiceBroker
Version of the Java ServiceBroker API.
SpringRegistrator - Class in services.moleculer.config
Register Spring Components as Moleculer Services in ServiceBroker.
SpringRegistrator() - Constructor for class services.moleculer.config.SpringRegistrator
 
sslClientProps - Variable in class services.moleculer.transporter.MqttTransporter
 
sslContext - Variable in class services.moleculer.transporter.NatsTransporter
Optional SSL Context.
sslContextFactory - Variable in class services.moleculer.transporter.AmqpTransporter
 
stack - Variable in exception services.moleculer.error.MoleculerError
 
stackTrace - Variable in exception services.moleculer.error.MoleculerError
 
StandardUidGenerator - Class in services.moleculer.uid
Slower UidGenerator (but it produces standard UUID's).
StandardUidGenerator() - Constructor for class services.moleculer.uid.StandardUidGenerator
 
start() - Method in class services.moleculer.ServiceBroker
Start broker.
start(TYPE) - Method in class services.moleculer.ServiceBroker
Starts the specified MoleculerComponent.
startConsoleReporter() - Method in class services.moleculer.metrics.DefaultMetrics
Starts ConsoleReporter.
startConsoleReporter(long, TimeUnit) - Method in class services.moleculer.metrics.DefaultMetrics
Starts ConsoleReporter.
startCsvReporter(String) - Method in class services.moleculer.metrics.DefaultMetrics
Starts CsvReporter.
startCsvReporter(long, TimeUnit, String) - Method in class services.moleculer.metrics.DefaultMetrics
Starts CsvReporter.
started(ServiceBroker) - Method in class services.moleculer.breaker.CircuitBreaker
 
started(ServiceBroker) - Method in class services.moleculer.cacher.Cacher
 
started(ServiceBroker) - Method in class services.moleculer.cacher.JCacheCacher
Initializes cacher instance.
started(ServiceBroker) - Method in class services.moleculer.cacher.MemoryCacher
Initializes cacher instance.
started(ServiceBroker) - Method in class services.moleculer.cacher.OHCacher
Initializes cacher instance.
started(ServiceBroker) - Method in class services.moleculer.cacher.RedisCacher
Initializes cacher instance.
started(ServiceBroker) - Method in class services.moleculer.eventbus.DefaultEventbus
Initializes default EventBus instance.
started(ServiceBroker) - Method in class services.moleculer.internal.NodeService
 
started(ServiceBroker) - Method in class services.moleculer.metrics.DefaultMetrics
 
started(DefaultMetrics, int, long, TimeUnit, String) - Method in interface services.moleculer.metrics.DropwizardReporters
 
started(DefaultMetrics, int, long, TimeUnit, String) - Method in class services.moleculer.metrics.DropwizardReportersImpl
 
started(ServiceBroker) - Method in class services.moleculer.metrics.MetricMiddleware
 
started(ServiceBroker) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
started(ServiceBroker) - Method in class services.moleculer.serializer.ChainedSerializer
 
started(ServiceBroker) - Method in class services.moleculer.serializer.Serializer
 
started(ServiceBroker) - Method in class services.moleculer.service.DefaultServiceInvoker
 
started(ServiceBroker) - Method in class services.moleculer.service.DefaultServiceRegistry
Initializes ServiceRegistry instance.
started(ServiceBroker) - Method in class services.moleculer.service.MoleculerComponent
 
started(ServiceBroker) - Method in interface services.moleculer.service.MoleculerLifecycle
 
started(ServiceBroker) - Method in class services.moleculer.strategy.CpuUsageStrategyFactory
Initializes strategy instance.
started(ServiceBroker) - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
Initializes strategy instance.
started - Variable in class services.moleculer.transporter.AmqpTransporter
 
started(ServiceBroker) - Method in class services.moleculer.transporter.FileSystemTransporter
 
started - Variable in class services.moleculer.transporter.NatsStreamingTransporter
 
started - Variable in class services.moleculer.transporter.NatsTransporter
 
started(ServiceBroker) - Method in class services.moleculer.transporter.Transporter
Initializes transporter instance.
started(ServiceBroker) - Method in class services.moleculer.uid.IncrementalUidGenerator
Initializes UID generator instance.
started(ServiceBroker) - Method in class services.moleculer.uid.XorShiftRandomUidGenerator
Initializes UID generator instance.
startedAt - Static variable in class services.moleculer.internal.NodeService
 
startReceivers(NetworkInterface, String, boolean) - Method in class services.moleculer.transporter.tcp.UDPLocator
 
startReporter(Closeable, long, TimeUnit) - Method in class services.moleculer.metrics.DropwizardReportersImpl
 
startSlf4jReporter() - Method in class services.moleculer.metrics.DefaultMetrics
Starts Slf4jReporter.
startSlf4jReporter(long, TimeUnit) - Method in class services.moleculer.metrics.DefaultMetrics
Starts Slf4jReporter.
startSlf4jReporter(long, TimeUnit, String) - Method in class services.moleculer.metrics.DefaultMetrics
Starts Slf4jReporter.
startTimer(int) - Method in class services.moleculer.cacher.MemoryCacher
 
startupHost - Variable in class services.moleculer.transporter.TcpTransporter
The local hostname specified in the "urls" parameter.
status - Variable in class services.moleculer.cacher.RedisCacher
 
status - Variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
status - Variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_CONNECTED - Static variable in class services.moleculer.cacher.RedisCacher
 
STATUS_CONNECTED - Static variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_CONNECTING - Static variable in class services.moleculer.cacher.RedisCacher
 
STATUS_CONNECTING_1 - Static variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_CONNECTING_2 - Static variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_DISCONNECTED - Static variable in class services.moleculer.cacher.RedisCacher
 
STATUS_DISCONNECTED - Static variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_DISCONNECTING - Static variable in class services.moleculer.cacher.RedisCacher
 
STATUS_DISCONNECTING - Static variable in class services.moleculer.transporter.RedisTransporter
 
STATUS_STOPPED - Static variable in class services.moleculer.cacher.RedisCacher
 
stop() - Method in interface services.moleculer.metrics.StoppableTimer
 
stop() - Method in class services.moleculer.ServiceBroker
Stop broker and all internal components (event bus, context factory, etc.).
stop(MoleculerComponent) - Method in class services.moleculer.ServiceBroker
Stops the specified MoleculerComponent.
stop() - Method in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
stopAllLocalServices() - Method in class services.moleculer.service.DefaultServiceRegistry
 
StoppableTimer - Interface in services.moleculer.metrics
 
stopped() - Method in class services.moleculer.breaker.CircuitBreaker
 
stopped() - Method in class services.moleculer.cacher.JCacheCacher
 
stopped() - Method in class services.moleculer.cacher.MemoryCacher
 
stopped() - Method in class services.moleculer.cacher.OHCacher
 
stopped() - Method in class services.moleculer.cacher.RedisCacher
 
stopped() - Method in class services.moleculer.eventbus.DefaultEventbus
 
stopped() - Method in class services.moleculer.metrics.DefaultMetrics
 
stopped() - Method in interface services.moleculer.metrics.DropwizardReporters
 
stopped() - Method in class services.moleculer.metrics.DropwizardReportersImpl
 
stopped() - Method in class services.moleculer.serializer.ChainedSerializer
 
stopped() - Method in class services.moleculer.service.DefaultServiceRegistry
 
stopped() - Method in class services.moleculer.service.MoleculerComponent
 
stopped() - Method in interface services.moleculer.service.MoleculerLifecycle
 
stopped() - Method in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
stopped() - Method in class services.moleculer.transporter.AmqpTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.FileSystemTransporter
 
stopped() - Method in class services.moleculer.transporter.InternalTransporter
 
stopped() - Method in class services.moleculer.transporter.JmsTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.KafkaTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.MqttTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.NatsStreamingTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.NatsTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.RedisTransporter
Closes transporter.
stopped() - Method in class services.moleculer.transporter.TcpTransporter
Closes TCP Transporter.
stopped() - Method in class services.moleculer.transporter.Transporter
Closes transporter.
STOPPING - Static variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
stopStreaming(Context) - Method in class services.moleculer.eventbus.DefaultEventbus
 
storedFileNames - Variable in class services.moleculer.transporter.FileSystemTransporter
Max stored file names (per channel).
strategies - Variable in class services.moleculer.service.DefaultServiceRegistry
 
strategy(StrategyFactory) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
strategy - Variable in class services.moleculer.eventbus.DefaultEventbus
 
Strategy<T extends Endpoint> - Class in services.moleculer.strategy
Base superclass of all Strategy implementations.
Strategy() - Constructor for class services.moleculer.strategy.Strategy
 
strategyFactory - Variable in class services.moleculer.config.ServiceBrokerConfig
 
strategyFactory - Variable in class services.moleculer.service.DefaultServiceRegistry
 
strategyFactory - Variable in class services.moleculer.ServiceBroker
Default (round-robin) service invocation factory.
StrategyFactory - Class in services.moleculer.strategy
Base class of Invocation Strategies.
StrategyFactory() - Constructor for class services.moleculer.strategy.StrategyFactory
 
stream - Variable in class services.moleculer.context.Context
Streamed content
stream - Variable in class services.moleculer.stream.IncomingStream
Internal stream with listeners.
stream - Variable in class services.moleculer.util.ParseResult
 
streamTimeout - Variable in class services.moleculer.eventbus.DefaultEventbus
Stream inactivity/read timeout in MILLISECONDS (0 = no timeout).
streamTimeout - Variable in class services.moleculer.service.DefaultServiceRegistry
Stream inactivity/read timeout in MILLISECONDS (0 = no timeout).
streamTimeoutTimer - Variable in class services.moleculer.eventbus.DefaultEventbus
Cancelable timer for request streams
subscribe - Variable in class services.moleculer.eventbus.ListenerEndpoint
 
Subscribe - Annotation Type in services.moleculer.eventbus
Mask of the subscribed event (eg.
subscribe(String) - Method in class services.moleculer.transporter.AmqpTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.FileSystemTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.InternalTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.JmsTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
subscribe(String) - Method in class services.moleculer.transporter.KafkaTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.MqttTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.NatsStreamingTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.NatsTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.NullTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.RedisTransporter
 
subscribe(String) - Method in class services.moleculer.transporter.TcpTransporter
 
subscribe(String, String) - Method in class services.moleculer.transporter.Transporter
 
subscribe(String) - Method in class services.moleculer.transporter.Transporter
 
subscribe(String) - Method in class services.moleculer.util.redis.RedisPubSubClient
 
SUBSCRIBED - Static variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
subscribed(byte[], long) - Method in class services.moleculer.transporter.RedisTransporter
 
subscribers - Variable in class services.moleculer.transporter.JmsTransporter
 
subscriptions - Variable in class services.moleculer.transporter.InternalTransporter
 
Subscriptions() - Constructor for class services.moleculer.transporter.InternalTransporter.Subscriptions
 
subscriptions - Variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
SubscriptionSet(String) - Constructor for class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
subscriptionTimeout - Variable in class services.moleculer.transporter.Transporter
Timeout of channel subscriptions (SECONDS).
suggestDependency(String, String, String) - Static method in class services.moleculer.util.CommonUtils
 

T

TcpReader - Class in services.moleculer.transporter.tcp
Packet receiver Thread of the TCP Transporter.
TcpReader(TcpTransporter) - Constructor for class services.moleculer.transporter.tcp.TcpReader
 
TcpTransporter - Class in services.moleculer.transporter
TCP Transporter with optional UDP discovery ("zero configuration") module.
TcpTransporter() - Constructor for class services.moleculer.transporter.TcpTransporter
Start TCP Transporter in "zero config" mode, with automatic UDP service discovery.
TcpTransporter(String...) - Constructor for class services.moleculer.transporter.TcpTransporter
Start TCP Transporter in full TCP mode, without UDP discovery.
TcpTransporter(URL) - Constructor for class services.moleculer.transporter.TcpTransporter
Start TCP Transporter in full TCP mode, without UDP discovery.
TcpWriter - Class in services.moleculer.transporter.tcp
Packet sender Thread of the TCP Transporter.
TcpWriter(TcpTransporter) - Constructor for class services.moleculer.transporter.tcp.TcpWriter
 
threshold - Variable in class services.moleculer.serializer.DeflaterSerializer
Compress key and/or value above this size (BYTES), 0 = disable compression
throwableToTree(String, String, String, Throwable) - Static method in class services.moleculer.util.CommonUtils
 
TimeBasedUidGenerator - Class in services.moleculer.uid
Time-based standard UUID generator.
TimeBasedUidGenerator() - Constructor for class services.moleculer.uid.TimeBasedUidGenerator
 
timeout - Variable in class services.moleculer.context.CallOptions.Options
Timeout of the method invocation (in milliseconds, 0 = no timeout)
timeout(long) - Method in class services.moleculer.context.CallOptions.Options
 
timeout(long) - Static method in class services.moleculer.context.CallOptions
 
timeoutAt - Variable in class services.moleculer.service.PendingPromise
 
timeoutAt - Variable in class services.moleculer.service.ServiceListener
 
timeoutAt - Variable in class services.moleculer.stream.IncomingStream
Timestamp of the next timeout (0 = no timeout).
timeoutMillis - Variable in class services.moleculer.stream.IncomingStream
Stream inactivity/read timeout in MILLISECONDS (0 = no timeout).
timeoutProcess - Variable in class services.moleculer.transporter.FileSystemTransporter
Cancelable timer of poller/cleanup process
timeoutProcess() - Method in class services.moleculer.transporter.FileSystemTransporter
 
timer - Variable in class services.moleculer.breaker.CircuitBreaker
Cancelable timer
timer - Variable in class services.moleculer.cacher.MemoryCacher
Cancelable timer
timer - Variable in class services.moleculer.cacher.OHCacher
Cancelable timer
timer(String, String, Duration, String...) - Method in class services.moleculer.metrics.DefaultMetrics
 
timer(String, String, String...) - Method in interface services.moleculer.metrics.Metrics
 
timer(String, String, Duration, String...) - Method in interface services.moleculer.metrics.Metrics
 
timer - Variable in class services.moleculer.transporter.tcp.UDPLocator
Cancelable timer of sender
timerStarted - Variable in class services.moleculer.cacher.MemoryCacher
 
timerStopped - Variable in class services.moleculer.cacher.MemoryCacher
 
timestamp - Variable in class services.moleculer.service.DefaultServiceRegistry
Timestamp of the service descriptor of this Moleculer Node (~= "generated at" timestamp)
timestamp - Variable in class services.moleculer.transporter.TcpTransporter
Current node descriptor's timestamp
toString() - Method in class services.moleculer.context.Context
 
totalCpuPercent - Variable in class services.moleculer.monitor.ConstantMonitor
 
toTree() - Method in exception services.moleculer.error.MoleculerError
 
toTree(Tree) - Method in exception services.moleculer.error.MoleculerError
 
transacted - Variable in class services.moleculer.transporter.JmsTransporter
 
transferedBytes - Variable in class services.moleculer.stream.PacketStream
Counter of transfered bytes.
transferFrom(URL) - Method in class services.moleculer.stream.PacketStream
 
transferFrom(File) - Method in class services.moleculer.stream.PacketStream
 
transferFrom(InputStream) - Method in class services.moleculer.stream.PacketStream
 
transferFrom(ReadableByteChannel) - Method in class services.moleculer.stream.PacketStream
 
transferTo(File) - Method in class services.moleculer.stream.PacketStream
 
transferTo(File, boolean) - Method in class services.moleculer.stream.PacketStream
 
transferTo(OutputStream) - Method in class services.moleculer.stream.PacketStream
 
transferTo(OutputStream, boolean) - Method in class services.moleculer.stream.PacketStream
 
transferTo(WritableByteChannel) - Method in class services.moleculer.stream.PacketStream
 
transferTo(WritableByteChannel, boolean) - Method in class services.moleculer.stream.PacketStream
 
transporter(Transporter) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
transporter - Variable in class services.moleculer.config.ServiceBrokerConfig
 
transporter - Variable in class services.moleculer.eventbus.DefaultEventbus
 
transporter - Variable in class services.moleculer.eventbus.RemoteListenerEndpoint
 
transporter - Variable in class services.moleculer.internal.NodeService
 
transporter - Variable in class services.moleculer.service.DefaultServiceRegistry
 
transporter - Variable in class services.moleculer.ServiceBroker
Implementation of the Transporter.
transporter - Variable in class services.moleculer.strategy.CpuUsageStrategy
 
transporter - Variable in class services.moleculer.strategy.CpuUsageStrategyFactory
 
transporter - Variable in class services.moleculer.strategy.NetworkLatencyStrategyFactory
 
transporter - Variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
transporter - Variable in class services.moleculer.transporter.tcp.TcpReader
Parent transporter
transporter - Variable in class services.moleculer.transporter.tcp.TcpWriter
 
transporter - Variable in class services.moleculer.transporter.tcp.UDPLocator
Parent transporter
transporter - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Parent transporter
Transporter - Class in services.moleculer.transporter
Base superclass of all Transporter implementations.
Transporter() - Constructor for class services.moleculer.transporter.Transporter
 
Transporter(Serializer) - Constructor for class services.moleculer.transporter.Transporter
 
tryToClose() - Method in class services.moleculer.transporter.tcp.SendBuffer
Tries to close this buffer.
ttl - Variable in class services.moleculer.cacher.MemoryCacher
Expire time, in SECONDS (0 = never expires)
ttl - Variable in class services.moleculer.cacher.OHCacher
Expire time, in seconds (0 = never expires)
ttl - Variable in class services.moleculer.cacher.RedisCacher
 
ttl - Variable in class services.moleculer.transporter.JmsTransporter
 
type - Variable in exception services.moleculer.error.MoleculerError
 
TYPE_CONSOLE - Static variable in interface services.moleculer.metrics.DropwizardReporters
 
TYPE_CSV - Static variable in interface services.moleculer.metrics.DropwizardReporters
 
TYPE_JMX - Static variable in interface services.moleculer.metrics.DropwizardReporters
 
TYPE_SLF4J - Static variable in interface services.moleculer.metrics.DropwizardReporters
 

U

udpAddress - Variable in class services.moleculer.transporter.tcp.UDPReceiver
IP address
udpBindAddress - Variable in class services.moleculer.transporter.TcpTransporter
UDP bind address (null = autodetect)
udpBroadcast - Variable in class services.moleculer.transporter.TcpTransporter
Use UDP broadcast WITH UDP multicast (false = use UDP multicast only)
UDPBroadcastReceiver - Class in services.moleculer.transporter.tcp
 
UDPBroadcastReceiver(String, String, TcpTransporter) - Constructor for class services.moleculer.transporter.tcp.UDPBroadcastReceiver
 
UDPLocator - Class in services.moleculer.transporter.tcp
UDP multicast / broadcast discovery service of the TCP Transporter.
UDPLocator(String, TcpTransporter, ScheduledExecutorService) - Constructor for class services.moleculer.transporter.tcp.UDPLocator
 
udpMaxDiscovery - Variable in class services.moleculer.transporter.TcpTransporter
Maximum number of outgoing multicast packets (0 = runs forever)
udpMulticast - Variable in class services.moleculer.transporter.TcpTransporter
UDP multicast address of automatic discovery service.
UDPMulticastReceiver - Class in services.moleculer.transporter.tcp
 
UDPMulticastReceiver(String, String, TcpTransporter) - Constructor for class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
UDPMulticastReceiver(String, String, TcpTransporter, NetworkInterface) - Constructor for class services.moleculer.transporter.tcp.UDPMulticastReceiver
 
udpMulticastTTL - Variable in class services.moleculer.transporter.tcp.UDPReceiver
UDP multicast TTL
udpMulticastTTL - Variable in class services.moleculer.transporter.TcpTransporter
TTL of UDP multicast packets
udpPacketReceived(String, String, int) - Method in class services.moleculer.transporter.TcpTransporter
 
udpPeriod - Variable in class services.moleculer.transporter.TcpTransporter
UDP broadcast/multicast period in SECONDS
udpPort - Variable in class services.moleculer.transporter.tcp.UDPReceiver
UDP broadcast/multicast port
udpPort - Variable in class services.moleculer.transporter.TcpTransporter
UDP broadcast/multicast port
UDPReceiver - Class in services.moleculer.transporter.tcp
 
UDPReceiver(String, String, TcpTransporter) - Constructor for class services.moleculer.transporter.tcp.UDPReceiver
 
udpReuseAddr - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Resuse addresses
udpReuseAddr - Variable in class services.moleculer.transporter.TcpTransporter
Resuse addresses
uid(UidGenerator) - Method in class services.moleculer.config.ServiceBrokerBuilder
 
uidGenerator - Variable in class services.moleculer.config.ServiceBrokerConfig
 
uidGenerator - Variable in class services.moleculer.context.ContextSource
UID Generator of the ServiceBroker or Context.
uidGenerator - Variable in class services.moleculer.eventbus.DefaultEventbus
 
uidGenerator - Variable in class services.moleculer.service.DefaultServiceInvoker
 
uidGenerator - Variable in class services.moleculer.service.DefaultServiceRegistry
 
uidGenerator - Variable in class services.moleculer.transporter.Transporter
 
UidGenerator - Class in services.moleculer.uid
Base superclass of all UID Generator implementations.
UidGenerator() - Constructor for class services.moleculer.uid.UidGenerator
 
unableToConnect(Exception) - Method in class services.moleculer.transporter.RedisTransporter
 
unableToSend(String, LinkedList<byte[]>, Throwable) - Method in class services.moleculer.transporter.TcpTransporter
 
UNSUBSCRIBED - Static variable in class services.moleculer.transporter.KafkaTransporter.KafkaPoller
 
unsubscribed(byte[], long) - Method in class services.moleculer.transporter.RedisTransporter
 
updateCpu(int) - Method in class services.moleculer.transporter.tcp.NodeDescriptor
 
updateCpu(long, int) - Method in class services.moleculer.transporter.tcp.NodeDescriptor
 
updateNodeInfo(String, Tree) - Method in class services.moleculer.transporter.Transporter
 
url - Variable in class services.moleculer.transporter.AmqpTransporter
 
url - Variable in class services.moleculer.transporter.NatsStreamingTransporter
Nats server url.
urls - Variable in class services.moleculer.cacher.RedisCacher
 
urls - Variable in class services.moleculer.transporter.KafkaTransporter
 
urls - Variable in class services.moleculer.transporter.MqttTransporter
 
urls - Variable in class services.moleculer.transporter.NatsTransporter
Nats server url(s).
urls - Variable in class services.moleculer.transporter.RedisTransporter
 
urls - Variable in class services.moleculer.transporter.TcpTransporter
List of URLs ("tcp://host:port/nodeID" or "host:port/nodeID" or "host/nodeID"), when UDP discovery is disabled.
urls - Variable in class services.moleculer.util.redis.AbstractRedisClient
 
use(Middleware) - Method in class services.moleculer.service.ActionEndpoint
 
use(Collection<Middleware>) - Method in class services.moleculer.service.DefaultServiceRegistry
 
use(Collection<Middleware>) - Method in class services.moleculer.service.ServiceRegistry
 
use(Collection<Middleware>) - Method in class services.moleculer.ServiceBroker
Installs a collection of middlewares.
use(Middleware...) - Method in class services.moleculer.ServiceBroker
Installs one or an array of middleware(s).
useCloning - Variable in class services.moleculer.cacher.MemoryCacher
Do you need to make a copy of the returned values?
useHostname - Variable in class services.moleculer.transporter.tcp.UDPReceiver
Use hostnames instead of IP addresses As the DHCP environment is dynamic, any later attempt to use IPs instead hostnames would most likely yield false results.
useHostname - Variable in class services.moleculer.transporter.TcpTransporter
Use hostnames instead of IP addresses As the DHCP environment is dynamic, any later attempt to use IPs instead hostnames would most likely yield false results.
useMeta - Variable in class services.moleculer.strategy.ShardStrategy
Size of the memory cache (0 = disabled)
username - Variable in class services.moleculer.transporter.AmqpTransporter
 
username - Variable in class services.moleculer.transporter.JmsTransporter
 
username - Variable in class services.moleculer.transporter.MqttTransporter
 
username - Variable in class services.moleculer.transporter.NatsTransporter
Username for basic authentication.
usingJsonSerializer - Variable in class services.moleculer.transporter.Transporter
 
utf8Support - Variable in class services.moleculer.transporter.NatsTransporter
Enable UTF8 channels.

V

VALIDATION_ERROR - Static variable in class services.moleculer.error.MoleculerErrorUtils
 
ValidationError - Exception in services.moleculer.error
Action call validation error.
ValidationError(String, String, String, Object...) - Constructor for exception services.moleculer.error.ValidationError
 
ValidationError(Tree) - Constructor for exception services.moleculer.error.ValidationError
 
value - Variable in class services.moleculer.cacher.MemoryCacher.PartitionEntry
 
valueOf(String) - Static method in enum services.moleculer.breaker.ErrorCounter.Status
Returns the enum constant of this type with the specified name.
values() - Static method in enum services.moleculer.breaker.ErrorCounter.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class services.moleculer.util.FastBuildMap
 
values() - Method in class services.moleculer.util.FastBuildMap
 
valueToBytes(Tree) - Method in class services.moleculer.cacher.OHCacher
 
verbose - Variable in class services.moleculer.transporter.NatsTransporter
Turn on verbose mode with the server.
Version - Annotation Type in services.moleculer.service
Optional version of a Moleculer Service.
Visibility - Annotation Type in services.moleculer.service
The "Visibility" annotation controls the visibility of an Action.
vnodes - Variable in class services.moleculer.strategy.ShardStrategy
Number of virtual nodes
vnodes - Variable in class services.moleculer.strategy.ShardStrategyFactory
Number of virtual nodes

W

waitForServices(long, Collection<String>) - Method in class services.moleculer.service.DefaultServiceRegistry
 
waitForServices(long, Collection<String>) - Method in class services.moleculer.service.ServiceRegistry
 
waitForServices(String...) - Method in class services.moleculer.ServiceBroker
Waits for one or more services.
waitForServices(long, String...) - Method in class services.moleculer.ServiceBroker
Waits for one (or an array of) service(s).
waitForServices(long, Collection<String>) - Method in class services.moleculer.ServiceBroker
Waits for a collection of services.
WARNING - Static variable in class services.moleculer.logger.ColoredConsoleLogger
 
WARNING - Static variable in class services.moleculer.logger.FastLogFormatter
 
WARNING - Static variable in class services.moleculer.logger.SimpleConsoleLogger
 
windowLength - Variable in class services.moleculer.breaker.CircuitBreaker
Length of time-window in MILLISECONDS
windowLength - Variable in class services.moleculer.breaker.ErrorCounter
 
write(Tree) - Method in class services.moleculer.serializer.BlockCipherSerializer
 
write(Tree) - Method in class services.moleculer.serializer.DeflaterSerializer
 
write(Tree) - Method in class services.moleculer.serializer.Serializer
 
write() - Method in class services.moleculer.transporter.tcp.SendBuffer
Writes N bytes to the target channel.
writeErrorsToLog - Variable in class services.moleculer.eventbus.DefaultEventbus
Write exceptions into the log file
writeErrorsToLog - Variable in class services.moleculer.service.DefaultServiceInvoker
Write exceptions into the log file
writeErrorsToLog - Variable in class services.moleculer.service.DefaultServiceRegistry
Write exceptions into the log file
writeLines(LinkedList<LogRecord>, StringBuilder, Formatter) - Method in class services.moleculer.logger.AsyncFileLogger
 
writeLock - Variable in class services.moleculer.breaker.CircuitBreaker
 
writeLock - Variable in class services.moleculer.cacher.JCacheCacher
 
writeLock - Variable in class services.moleculer.cacher.MemoryCacher.MemoryPartition
 
writeLock - Variable in class services.moleculer.cacher.MemoryCacher
 
writeLock - Variable in class services.moleculer.metrics.DefaultMetrics
 
writeLock - Variable in class services.moleculer.service.DefaultServiceRegistry
 
writeLock - Variable in class services.moleculer.transporter.InternalTransporter.Subscriptions
 
writeLock - Variable in class services.moleculer.transporter.InternalTransporter.SubscriptionSet
 
writeLock - Variable in class services.moleculer.transporter.tcp.NodeDescriptor
 
writer - Variable in class services.moleculer.serializer.Serializer
Data serializer (eg.
writer - Variable in class services.moleculer.transporter.TcpTransporter
Socket writer
writeRegistrations - Variable in class services.moleculer.service.DefaultServiceRegistry
Write Service and Action registrations into the log file
writers(String) - Method in class services.moleculer.config.ServiceBrokerBuilder
 

X

XorShiftRandomStrategy<T extends Endpoint> - Class in services.moleculer.strategy
Fast XORSHIFT-based pseudorandom invocation strategy.
XorShiftRandomStrategy(ServiceBroker, boolean) - Constructor for class services.moleculer.strategy.XorShiftRandomStrategy
 
XorShiftRandomStrategyFactory - Class in services.moleculer.strategy
Factory of XORSHIFT-based pseudorandom invocation strategy.
XorShiftRandomStrategyFactory() - Constructor for class services.moleculer.strategy.XorShiftRandomStrategyFactory
Constructor that uses local services when available.
XorShiftRandomStrategyFactory(boolean) - Constructor for class services.moleculer.strategy.XorShiftRandomStrategyFactory
Constructor that can be configured to use local services if possible.
XorShiftRandomUidGenerator - Class in services.moleculer.uid
XORSHIFT-based pseudorandom UID generator.
XorShiftRandomUidGenerator() - Constructor for class services.moleculer.uid.XorShiftRandomUidGenerator
 
A B C D E F G H I J K L M N O P Q R S T U V W X 
Skip navigation links