Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractActor - Class in net.sodacan.core.actor
- AbstractActor(Config, ActorId) - Constructor for class net.sodacan.core.actor.AbstractActor
- AbstractActorGroup - Class in net.sodacan.core.actorgroup
- AbstractActorGroup(Config, int) - Constructor for class net.sodacan.core.actorgroup.AbstractActorGroup
- AbstractActorGroupAssigner - Class in net.sodacan.core.actorgroup
- AbstractActorGroupAssigner(Config) - Constructor for class net.sodacan.core.actorgroup.AbstractActorGroupAssigner
- AbstractCoordinator - Class in net.sodacan.core.coordinator
- AbstractCoordinator(Config) - Constructor for class net.sodacan.core.coordinator.AbstractCoordinator
- AbstractHost - Class in net.sodacan.core.host
-
A host starts out by hosting no actorGroups.
- AbstractHost(Config) - Constructor for class net.sodacan.core.host.AbstractHost
- AbstractPersister - Class in net.sodacan.core.persist
-
This abstract class provides two services to concrete subclasses: First, it stores the configuration and actorId of the Actor instance for which it applies.
- AbstractPersister(Config, ActorId) - Constructor for class net.sodacan.core.persist.AbstractPersister
- acquireItem() - Method in class net.sodacan.core.util.Pool
- activeActorGroups - Variable in class net.sodacan.core.host.AbstractHost
- actor - Variable in class net.sodacan.core.actor.ActorEntry
- Actor - Interface in net.sodacan.core
-
An actor has a unique and permanent Id. An actor is persistent.
- Actor.Builtin - Enum Class in net.sodacan.core
- Actor as a State Machine - Search tag in package net.sodacan.core.actor
- Section
- actorClass - Variable in class net.sodacan.core.config.ActorMetadata
- ActorEntry - Class in net.sodacan.core.actor
-
The scheduler for a actorGroup manages a map of ActorEntries.
- ActorEntry(Config, Scheduler, ActorId) - Constructor for class net.sodacan.core.actor.ActorEntry
-
Construct a new ActorEntry and instantiate and actor contained within it using a configured actor factory.
- actorGroup - Variable in class net.sodacan.core.scheduler.DefaultScheduler
- actorGroup(BiFunction<Config, Integer, ActorGroup>) - Method in class net.sodacan.core.config.BaseBuilder
-
Local factory
- ActorGroup - Interface in net.sodacan.core
-
An actor exists in a single permanent actorGroup.
- actorGroupAssigner(Function<Config, ActorGroupAssigner>) - Method in class net.sodacan.core.config.BaseBuilder
-
Local singleton
- ActorGroupAssigner - Interface in net.sodacan.core
-
When an actorId is created, it depends on an implementation of this class to determine which ActorGroup to assign the new ActorId to.
- actorGroupAssignerFn - Variable in class net.sodacan.core.config.BaseBuilder
- actorGroupFn - Variable in class net.sodacan.core.config.BaseBuilder
- actorGroupReplicas(int) - Method in class net.sodacan.core.config.BaseBuilder
-
The number of replicas of a actorGroup to maintain.
- actorGroupReplicas(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
- actorGroupReplicasFn - Variable in class net.sodacan.core.config.BaseBuilder
- actorGroups(int) - Method in class net.sodacan.core.config.BaseBuilder
-
Specify the number of actorGroups in the system.
- actorGroups(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
- ActorGroupSender - Class in net.sodacan.core.actor
-
This special Actor handles outbound messages from an ActorGroup to another ActorGroup.
- ActorGroupSender(Config, ActorId) - Constructor for class net.sodacan.core.actor.ActorGroupSender
- actorGroupsFn - Variable in class net.sodacan.core.config.BaseBuilder
- ActorGroupStats - Class in net.sodacan.core.actor
-
This host-bound actor displays statistics periodically.
- ActorGroupStats(Config, ActorId) - Constructor for class net.sodacan.core.actor.ActorGroupStats
- ActorGroupStats.Action - Enum Class in net.sodacan.core.actor
- ActorGroupStats.PeriodicStats - Class in net.sodacan.core.actor
- actorGroupThreads(int) - Method in class net.sodacan.core.config.BaseBuilder
-
Local dynamic (maybe) Change effective in new actorGroups only
- actorGroupThreads(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
- actorGroupThreadsFn - Variable in class net.sodacan.core.config.BaseBuilder
- actorId - Variable in class net.sodacan.core.actor.ActorEntry
- actorId - Variable in class net.sodacan.core.serialize.gson.GsonSerializer
- actorId - Variable in class net.sodacan.core.serialize.kryo.KryoSerializer
- ActorId - Class in net.sodacan.core
-
An actorId is made up of a type, an actorGroup, and a unique id for the instance of the actor.
- ActorId() - Constructor for class net.sodacan.core.ActorId
- ActorId(String, int, Long) - Constructor for class net.sodacan.core.ActorId
- ActorId(String, int, String) - Constructor for class net.sodacan.core.ActorId
- ActorId(String, int, UUID) - Constructor for class net.sodacan.core.ActorId
- ActorIdAdapter - Class in net.sodacan.core.serialize.gson
- ActorIdAdapter() - Constructor for class net.sodacan.core.serialize.gson.ActorIdAdapter
- actorIdFactory(Function<Config, ActorIdFactory>) - Method in class net.sodacan.core.config.BaseBuilder
-
Local factory
- ActorIdFactory - Interface in net.sodacan.core
-
An ActorId has no meaning in the business model.
- actorIdFactoryFn - Variable in class net.sodacan.core.config.BaseBuilder
- Actor Lifecycle - Search tag in package net.sodacan.core.actor
- Section
- actorMetadata - Variable in class net.sodacan.core.config.BaseBuilder
- actorMetadata - Variable in class net.sodacan.core.serialize.gson.GsonSerializer
- actorMetadata - Variable in class net.sodacan.core.serialize.kryo.KryoSerializer
- ActorMetadata - Class in net.sodacan.core.config
-
Actor Metadata is gathered during configuration so that it can be static while the system is Active.
- ActorMetadata(Class<? extends Actor>, BiFunction<Config, ActorId, Actor>) - Constructor for class net.sodacan.core.config.ActorMetadata
- ActorSave(ActorId, Map<String, Object>) - Constructor for class net.sodacan.core.serialize.gson.GsonSerializer.ActorSave
- ActorSave(ActorId, Map<String, Object>) - Constructor for class net.sodacan.core.serialize.kryo.KryoSerializer.ActorSave
- Actor State - Search tag in package net.sodacan.core.actor
- Section
- ActorType - Annotation Interface in net.sodacan.core.annotation
-
The ActorType annotation is optional on an ActorClass but strongly advised.
- add(Message) - Method in class net.sodacan.core.actor.EmptyStage
- add(Message) - Method in class net.sodacan.core.Stage
- addChild(BBBTree.Node) - Method in class net.sodacan.core.util.BBBTree.Node
- addMessage(Jug) - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
-
Queue this message for processing by scheduler
- addMessage(Jug) - Method in interface net.sodacan.core.ActorGroup
-
Add a message to be processed depending on Mode
- addMessage(Jug) - Method in interface net.sodacan.core.Scheduler
-
A schedulers job is to accept a message for an actorId.
- addMessage(Jug) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
Add a message to the work queue.
- addNewMessage(Jug) - Method in interface net.sodacan.core.Scheduler
- addNewMessage(Jug) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
Add a new message to the work queue with backpressure.
- advanceClock() - Method in class net.sodacan.core.util.FixedClock
-
Calling advanceClock advances it by one second.
- alloc(int) - Method in class net.sodacan.core.util.BBAlloc
-
Allocate space and return a reference to it.
- applyBackpressure() - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
If there's too many messages in-flight, we're going to wait for a bit
- ask(String) - Method in interface net.sodacan.core.Message
- ask(String) - Method in class net.sodacan.core.message.DefaultMessage
- ask(ActorId) - Method in interface net.sodacan.core.Message
- ask(ActorId) - Method in class net.sodacan.core.message.DefaultMessage
- assign(String, String) - Method in class net.sodacan.core.actorgroup.FixedActorGroupAssigner
-
Assign an actor group randomly.
- assign(String, String) - Method in class net.sodacan.core.actorgroup.RandomActorGroupAssigner
-
Assign an actor group randomly.
- assign(String, String) - Method in interface net.sodacan.core.ActorGroupAssigner
- assignReference() - Method in class net.sodacan.core.util.BBBTree.Node
-
Make sure this node has a ref
- auditMessageLoad(AuditMessageLoad) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
Reactivate any actors with messages waiting.
- AuditMessageLoad - Class in net.sodacan.core.jug
- AuditMessageLoad() - Constructor for class net.sodacan.core.jug.AuditMessageLoad
B
- backpressureLimit(int) - Method in class net.sodacan.core.config.BaseBuilder
- backpressureLimit(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
-
Global dynamic
- backpressureLimitFn - Variable in class net.sodacan.core.config.BaseBuilder
- backpressureWaitMs(int) - Method in class net.sodacan.core.config.BaseBuilder
-
Specify the backpressure limit in an ActorGroup.
- backpressureWaitMs(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
-
Specify the backpressure limit in an ActorGroup.
- backpressureWaitMsFn - Variable in class net.sodacan.core.config.BaseBuilder
- Base62 - Class in net.sodacan.core.util
- Base62() - Constructor for class net.sodacan.core.util.Base62
- BaseBuilder - Class in net.sodacan.core.config
-
Contains all the logic for configuration but no actual configuration.
- BaseBuilder() - Constructor for class net.sodacan.core.config.BaseBuilder
-
Start with an empty builder
- BaseBuilder(BaseBuilder) - Constructor for class net.sodacan.core.config.BaseBuilder
-
Copy constructor builder.
- BBAlloc - Class in net.sodacan.core.util
- BBAlloc(ByteBuffer) - Constructor for class net.sodacan.core.util.BBAlloc
-
Use an existing bytebuffer
- BBAlloc(ByteBuffer, int, int) - Constructor for class net.sodacan.core.util.BBAlloc
- BBAlloc(BBAlloc, ByteBuffer, int, int) - Constructor for class net.sodacan.core.util.BBAlloc
-
Copy constructor, compacting space as we go
- BBBTree - Class in net.sodacan.core.util
-
This BTree can exist on disk.
- BBBTree(BBAlloc) - Constructor for class net.sodacan.core.util.BBBTree
- BBBTree.Node - Class in net.sodacan.core.util
- begin() - Method in class net.sodacan.core.persist.file.FilePersister
-
If we've already loaded the Actor, no need to do it again.
- begin() - Method in class net.sodacan.core.persist.memory.MemoryPersister
- begin() - Method in class net.sodacan.core.persist.rocks.RocksPersister
- begin() - Method in interface net.sodacan.core.Persister
-
The framework calls the begin method when it is about to execute what might turn out to be a series of calls to this persister that should be considered as a single transaction.
- BTree2<T> - Class in net.sodacan.core.util
- BTree2() - Constructor for class net.sodacan.core.util.BTree2
- BTree2Node<T> - Class in net.sodacan.core.util
- BTree2Node() - Constructor for class net.sodacan.core.util.BTree2Node
- build() - Method in class net.sodacan.core.config.BaseBuilder
-
Build the Config object
- builder - Variable in class net.sodacan.core.serialize.gson.GsonSerializerFactory
C
- callProcessMessage(NormalMessage) - Method in class net.sodacan.core.actor.AbstractActor
-
Process one message in the actor which has already been realized, if needed.
- callProcessMessage(NormalMessage) - Method in interface net.sodacan.core.Actor
- ClassUtilities - Class in net.sodacan.core.util
- ClassUtilities() - Constructor for class net.sodacan.core.util.ClassUtilities
- clock(Function<Config, Clock>) - Method in class net.sodacan.core.config.BaseBuilder
- clockFn - Variable in class net.sodacan.core.config.BaseBuilder
- close() - Method in class net.sodacan.core.actor.ActorGroupStats
- close() - Method in class net.sodacan.core.actor.TimeActor
- close() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
-
This works in two ways: For normal ActorGroups, close waits for the actor to finish processing messages.
- close() - Method in class net.sodacan.core.host.AbstractHost
-
Close the host by closing the ActorGroups.
- close() - Method in interface net.sodacan.core.Host
- close() - Method in class net.sodacan.core.persist.file.FilePersisterFactory
-
Nothing to close for this persister type
- close() - Method in class net.sodacan.core.persist.memory.MemoryPersisterFactory
- close() - Method in class net.sodacan.core.persist.rocks.RocksPersisterFactory
- close() - Method in interface net.sodacan.core.Scheduler
- close() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- close() - Method in class net.sodacan.core.util.BBAlloc
- closeHostBoundActor(CloseHostBoundActor) - Method in class net.sodacan.core.actor.ActorEntry
-
Once this actor is closed, we can countdown to allow the ActorGroup to close
- closeHostBoundActor(CloseHostBoundActor) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
HostBound Actors are always alive so just forward to the actor
- CloseHostBoundActor - Class in net.sodacan.core.jug
- CloseHostBoundActor(ActorId, CountDownLatch) - Constructor for class net.sodacan.core.jug.CloseHostBoundActor
- closeLatch - Variable in class net.sodacan.core.actorgroup.AbstractActorGroup
- Cold - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
- Collections - Search tag in package net.sodacan.core.actor
- Section
- commit() - Method in class net.sodacan.core.persist.file.FilePersister
- commit() - Method in class net.sodacan.core.persist.memory.MemoryPersister
- commit() - Method in class net.sodacan.core.persist.rocks.RocksPersister
- commit() - Method in interface net.sodacan.core.Persister
-
This method is called when the framework has concluded a series of writes that could be rolled back in case of an error.
- commit() - Method in class net.sodacan.core.util.BBBTree
-
Save all the updated and new nodes
- compareTo(MessageId) - Method in class net.sodacan.core.message.DefaultMessageId
- Complex routing - Search tag in package net.sodacan.core.message
- Section
- config - Variable in class net.sodacan.core.actor.ActorEntry
- config - Variable in class net.sodacan.core.coordinator.AbstractCoordinator
- Config - Interface in net.sodacan.core
-
The Sodacan configuration contains settings for specifying factories, singleton objects, and static and dynamic settings.
- coordinator(Function<Config, Coordinator>) - Method in class net.sodacan.core.config.BaseBuilder
-
Local singleton
- Coordinator - Interface in net.sodacan.core
- coordinatorFn - Variable in class net.sodacan.core.config.BaseBuilder
- copyRoutesFrom(Message) - Method in interface net.sodacan.core.Message
- copyRoutesFrom(Message) - Method in class net.sodacan.core.message.DefaultMessage
- count() - Method in class net.sodacan.core.util.BBAlloc
-
The number of references allocated
- countDown() - Method in class net.sodacan.core.jug.CloseHostBoundActor
- create(Class<?>, int, String) - Static method in class net.sodacan.core.ActorId
- create(String) - Method in class net.sodacan.core.actor.SequentialActorIdFactory
- create(String) - Method in class net.sodacan.core.actor.UUIDActorIdFactory
- create(String) - Method in interface net.sodacan.core.ActorIdFactory
- create(String, int, String) - Static method in class net.sodacan.core.ActorId
- create(ActorId) - Method in class net.sodacan.core.persist.file.FilePersisterFactory
- create(ActorId) - Method in class net.sodacan.core.persist.memory.MemoryPersisterFactory
- create(ActorId) - Method in interface net.sodacan.core.persist.PersisterFactory
- create(ActorId) - Method in class net.sodacan.core.persist.rocks.RocksPersisterFactory
- create(ActorId) - Method in class net.sodacan.core.serialize.gson.GsonSerializerFactory
-
Create a serializer for the specified actorId.
- create(ActorId) - Method in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
-
Create a serializer for the specified actorId.
- create(ActorId) - Method in interface net.sodacan.core.serialize.SerializerFactory
- createActor(ActorId) - Method in interface net.sodacan.core.Config
- createActor(ActorId) - Method in class net.sodacan.core.config.DefaultConfig
- createActor(Config, ActorId) - Method in class net.sodacan.core.config.ActorMetadata
- createActorGroup(int) - Method in interface net.sodacan.core.Config
-
Create a actorGroup.
- createActorGroup(int) - Method in class net.sodacan.core.config.DefaultConfig
-
Create a actorGroup.
- createActorId(String) - Method in interface net.sodacan.core.Config
- createActorId(String) - Method in class net.sodacan.core.config.DefaultConfig
- createFromString(String) - Static method in class net.sodacan.core.ActorId
- createInstance(Type) - Method in class net.sodacan.core.serialize.gson.MessageIdAdapter
- createItem() - Method in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- createItem() - Method in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
- createItem() - Method in interface net.sodacan.core.util.PoolItemFactory
- createMessage() - Method in interface net.sodacan.core.Config
- createMessage() - Method in class net.sodacan.core.config.DefaultConfig
- createMessageId() - Method in interface net.sodacan.core.Config
- createMessageId() - Method in class net.sodacan.core.config.DefaultConfig
- createScheduler(ActorGroup) - Method in interface net.sodacan.core.Config
-
Create a new scheduler.
- createScheduler(ActorGroup) - Method in class net.sodacan.core.config.DefaultConfig
-
Create a new scheduler.
D
- decreaseMessageLoad() - Method in interface net.sodacan.core.Scheduler
- decreaseMessageLoad() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- DefaultActorGroup - Class in net.sodacan.core.actorgroup
- DefaultActorGroup(Config, int) - Constructor for class net.sodacan.core.actorgroup.DefaultActorGroup
- DefaultConfig - Class in net.sodacan.core.config
-
Default implementation of the Config interface.
- DefaultConfig(BaseBuilder) - Constructor for class net.sodacan.core.config.DefaultConfig
-
Construct a configuration object.
- DefaultHost - Class in net.sodacan.core.host
-
Contains ordinary host behavior.
- DefaultHost(Config) - Constructor for class net.sodacan.core.host.DefaultHost
- DefaultMessage - Class in net.sodacan.core.message
-
All Messages have a messageId and a routing stack.
- DefaultMessage() - Constructor for class net.sodacan.core.message.DefaultMessage
- DefaultMessage(Message) - Constructor for class net.sodacan.core.message.DefaultMessage
- DefaultMessage(MessageId) - Constructor for class net.sodacan.core.message.DefaultMessage
- DefaultMessageId - Class in net.sodacan.core.message
-
MessageId is normally a Java Instant plus a random integer.
- DefaultMessageId() - Constructor for class net.sodacan.core.message.DefaultMessageId
- DefaultMessageId(Instant, int) - Constructor for class net.sodacan.core.message.DefaultMessageId
- DefaultMessageId(Config) - Constructor for class net.sodacan.core.message.DefaultMessageId
- DefaultScheduler - Class in net.sodacan.core.scheduler
- DefaultScheduler(Config, ActorGroup) - Constructor for class net.sodacan.core.scheduler.DefaultScheduler
-
Construct a default scheduler, one per ActorGroup
- deserialize(byte[]) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
- deserialize(byte[]) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- deserialize(byte[]) - Method in interface net.sodacan.core.Serializer
-
Deserialize a byte array into a new Message.
- deserialize(byte[], Actor) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
-
To deserialize an Actor requires two steps.
- deserialize(byte[], Actor) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- deserialize(byte[], Actor) - Method in interface net.sodacan.core.Serializer
-
Deserialize the @Save fields of an Actor into an existing actor.
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class net.sodacan.core.serialize.gson.ActorIdAdapter
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class net.sodacan.core.serialize.gson.InstantTypeAdapter
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class net.sodacan.core.serialize.gson.MapAdapter
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class net.sodacan.core.serialize.gson.MessageIdAdapter
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class net.sodacan.core.serialize.gson.RouteAdapter
- deserializeField(byte[], Class<?>) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
- deserializeField(byte[], Class<?>) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- deserializeField(byte[], Class<?>) - Method in interface net.sodacan.core.Serializer
-
Deserialize the @Save fields of an Actor into an existing actor.
E
- emptyQueue() - Method in class net.sodacan.core.actor.ActorEntry
- emptyStage - Static variable in class net.sodacan.core.actor.AbstractActor
- EmptyStage - Class in net.sodacan.core.actor
- EmptyStage() - Constructor for class net.sodacan.core.actor.EmptyStage
- encode(StringBuffer, long) - Static method in class net.sodacan.core.util.Base62
-
A String buffer containing the provided long value encoded as a base62 string
- encodeNextId(String, long) - Static method in class net.sodacan.core.util.Base62
-
Convert a number to base62 and append it to the supplied string.
- equals(Object) - Method in class net.sodacan.core.ActorId
- equals(Object) - Method in class net.sodacan.core.coordinator.HostEntry
- equals(Object) - Method in class net.sodacan.core.message.DefaultMessageId
- errorMessage(ErrorMessage) - Method in class net.sodacan.core.scheduler.DefaultScheduler
- ErrorMessage - Class in net.sodacan.core.jug
- ErrorMessage(ActorId, byte[], Throwable) - Constructor for class net.sodacan.core.jug.ErrorMessage
- evict(ActorEntry) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
Decide if we're going to evict an ActorEntry and if so, do it.
- evictAll() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- evictAll() - Method in interface net.sodacan.core.Scheduler
- evicting - Variable in class net.sodacan.core.actor.ActorEntry
- eviction(int) - Method in class net.sodacan.core.config.BaseBuilder
-
Global dynamic
- eviction(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
- evictionFn - Variable in class net.sodacan.core.config.BaseBuilder
- evictionProbability() - Method in class net.sodacan.core.actor.AbstractActor
-
An actor is subject to eviction at any time.
- evictionProbability() - Method in class net.sodacan.core.actor.ActorEntry
-
An actor is subject to eviction at any time.
- evictionProbability() - Method in interface net.sodacan.core.Actor
-
The higher an eviction rate, the higher chance of eviction.
- exitingThread() - Method in class net.sodacan.core.actor.AbstractActor
-
The default saves the state of the actor
- exitingThread() - Method in interface net.sodacan.core.Actor
-
The default saves the state of the actor.
F
- factory - Variable in class net.sodacan.core.config.ActorMetadata
- factory - Variable in class net.sodacan.core.serialize.gson.GsonSerializer
- factory - Variable in class net.sodacan.core.serialize.kryo.KryoSerializer
- fetch(int) - Method in class net.sodacan.core.util.BBAlloc
-
Store a string and return a reference to it
- FilePersister - Class in net.sodacan.core.persist.file
-
Persist all @Save fields for one actor into a file.
- FilePersister(Config, ActorId) - Constructor for class net.sodacan.core.persist.file.FilePersister
- FilePersisterFactory - Class in net.sodacan.core.persist.file
- FilePersisterFactory(Config) - Constructor for class net.sodacan.core.persist.file.FilePersisterFactory
- FixedActorGroupAssigner - Class in net.sodacan.core.actorgroup
-
Only for testing, always assigns a single group number
- FixedActorGroupAssigner(Config, int) - Constructor for class net.sodacan.core.actorgroup.FixedActorGroupAssigner
- FixedClock - Class in net.sodacan.core.util
- FixedClock() - Constructor for class net.sodacan.core.util.FixedClock
-
If you just need a clock that doesn't move, without calling advanceClock, use this constructor
- FixedClock(Instant) - Constructor for class net.sodacan.core.util.FixedClock
-
If you need a clock that is fixed based on an instant that you provide, use this one
- FixedRandom - Class in net.sodacan.core.util
-
Random that is fixed, for testing
- FixedRandom(int) - Constructor for class net.sodacan.core.util.FixedRandom
- format(long) - Static method in class net.sodacan.core.util.TextUtil
- formatLong(long) - Static method in class net.sodacan.core.util.TextUtil
- formatNumber(double, String) - Static method in class net.sodacan.core.util.TextUtil
- formatSeconds(double, String) - Static method in class net.sodacan.core.util.TextUtil
- formatSize(double, String) - Static method in class net.sodacan.core.util.TextUtil
- forward(Config, Message) - Method in class net.sodacan.core.Stage
-
Send the message on to its next route.
- forwardToHost(int, NormalMessage) - Method in class net.sodacan.core.host.AbstractHost
-
Figure our where the host is and send this message there
- from(Message) - Method in class net.sodacan.core.message.DefaultMessage
-
Copy guts of provided message into this message but don't copy routes.
- from(Message) - Method in interface net.sodacan.core.Message
- fromByteBuffer(ByteBuffer) - Static method in class net.sodacan.core.journal.JournalEntry
- fullKey(String) - Method in class net.sodacan.core.persist.rocks.RocksPersister
G
- generics - Variable in class net.sodacan.core.config.ActorMetadata
- get(String) - Method in class net.sodacan.core.message.DefaultMessage
- get(String) - Method in interface net.sodacan.core.Message
-
Find the info with the matching name (case insensitive).
- get(String, Class<T>) - Method in class net.sodacan.core.message.DefaultMessage
- get(String, Class<T>) - Method in interface net.sodacan.core.Message
- getActiveThreadCount() - Method in class net.sodacan.core.scheduler.Statistics
- getActorClass() - Method in class net.sodacan.core.config.ActorMetadata
- getActorClass(String) - Method in class net.sodacan.core.config.DefaultConfig
-
Get the class associated with an ActorType which is either a string assigned to the actor by the ActorType annotation or the full class name.
- getActorClass(String) - Method in interface net.sodacan.core.Config
-
Static.
- getActorClassesFromPackage(String, BaseBuilder) - Static method in class net.sodacan.core.util.ClassUtilities
-
Find all classes in the named package that implement the Actor interface and add them to our collection of known Actor classes.
- getActorGroup() - Method in class net.sodacan.core.actor.AbstractActor
- getActorGroup() - Method in interface net.sodacan.core.Actor
- getActorGroup() - Method in class net.sodacan.core.ActorId
- getActorGroup() - Method in class net.sodacan.core.coordinator.HostEntry
- getActorGroup() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- getActorGroup() - Method in interface net.sodacan.core.Scheduler
- getActorGroup(HostEntry) - Method in class net.sodacan.core.host.AbstractHost
- getActorGroup(HostEntry) - Method in interface net.sodacan.core.Host
- getActorGroupAssigner() - Method in class net.sodacan.core.config.DefaultConfig
- getActorGroupAssigner() - Method in interface net.sodacan.core.Config
- getActorGroupName() - Method in class net.sodacan.core.scheduler.Statistics
- getActorGroupNumber() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- getActorGroupNumber() - Method in interface net.sodacan.core.ActorGroup
-
A actorGroup has a unique id.
- getActorGroupReplicas() - Method in class net.sodacan.core.config.DefaultConfig
- getActorGroupReplicas() - Method in interface net.sodacan.core.Config
- getActorGroups() - Method in class net.sodacan.core.config.DefaultConfig
-
The number of actorGroups in a network is more or less fixed.
- getActorGroups() - Method in interface net.sodacan.core.Config
-
The number of actorGroups in a network is more or less fixed.
- getActorGroups() - Method in class net.sodacan.core.host.AbstractHost
- getActorGroups() - Method in interface net.sodacan.core.Host
- getActorGroupsForHost() - Method in interface net.sodacan.core.Coordinator
- getActorGroupsForHost() - Method in class net.sodacan.core.coordinator.SingleHostCoordinator
-
A simple one host coordinator.
- getActorGroupStatistics() - Method in class net.sodacan.core.host.AbstractHost
- getActorGroupStatistics() - Method in interface net.sodacan.core.Host
-
Get stats for all active actorGroups
- getActorGroupThreads() - Method in class net.sodacan.core.config.DefaultConfig
-
Local static Return the current number of threads
- getActorGroupThreads() - Method in interface net.sodacan.core.Config
-
Local static Return the current number of threads
- getActorId() - Method in class net.sodacan.core.actor.AbstractActor
- getActorId() - Method in class net.sodacan.core.actor.ActorEntry
- getActorId() - Method in interface net.sodacan.core.Actor
- getActorId() - Method in class net.sodacan.core.jug.CloseHostBoundActor
- getActorId() - Method in class net.sodacan.core.jug.ErrorMessage
- getActorId() - Method in class net.sodacan.core.jug.NormalMessage
- getActorId() - Method in class net.sodacan.core.jug.StoppedActor
- getActorId() - Method in class net.sodacan.core.persist.AbstractPersister
- getActorId() - Method in class net.sodacan.core.serialize.gson.GsonSerializer.ActorSave
- getActorId() - Method in class net.sodacan.core.serialize.kryo.KryoSerializer.ActorSave
- getActorId(String) - Method in class net.sodacan.core.message.DefaultMessage
-
Find the Info record the matching name (case insensitive) and return its String Contents
- getActorId(String) - Method in interface net.sodacan.core.Message
-
Find the Info record the matching name (case insensitive) and return its String Contents
- getActorMetadata(String) - Method in class net.sodacan.core.config.DefaultConfig
- getActorMetadata(String) - Method in interface net.sodacan.core.Config
-
Static.
- getActorsEvicted() - Method in class net.sodacan.core.scheduler.Statistics
- getActorsRealized() - Method in class net.sodacan.core.scheduler.Statistics
-
A single actor can be realized more than once at the whim of Sodacan.
- getActorTypes() - Method in class net.sodacan.core.config.DefaultConfig
-
Return all of the actorClasses that we know of
- getActorTypes() - Method in interface net.sodacan.core.Config
-
Return all of the actorClasses that we know of
- getAddress(int) - Method in class net.sodacan.core.util.BBAlloc
-
Return an address in space, the address is the actual data, not including the length
- getAlloc() - Method in class net.sodacan.core.util.BBBTree
- getBackpressureLimit() - Method in class net.sodacan.core.config.DefaultConfig
-
The number of messages inFlight before backpressure is applied.
- getBackpressureLimit() - Method in interface net.sodacan.core.Config
-
The number of messages inFlight before backpressure is applied.
- getBackpressureWaitMs() - Method in class net.sodacan.core.config.DefaultConfig
- getBackpressureWaitMs() - Method in interface net.sodacan.core.Config
- getBuilderFor(ActorId) - Method in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- getChangedNodes() - Method in class net.sodacan.core.util.BBBTree
- getChildren() - Method in class net.sodacan.core.util.BBBTree.Node
- getClock() - Method in class net.sodacan.core.config.DefaultConfig
- getClock() - Method in interface net.sodacan.core.Config
-
Return the clock used throuhout the system.
- getClosing() - Method in class net.sodacan.core.scheduler.Statistics
- getConfig() - Method in class net.sodacan.core.actor.AbstractActor
- getConfig() - Method in interface net.sodacan.core.Actor
- getConfig() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- getConfig() - Method in class net.sodacan.core.actorgroup.AbstractActorGroupAssigner
- getConfig() - Method in class net.sodacan.core.coordinator.AbstractCoordinator
- getConfig() - Method in class net.sodacan.core.host.AbstractHost
- getConfig() - Method in interface net.sodacan.core.Host
- getConfig() - Method in class net.sodacan.core.persist.AbstractPersister
- getConfig() - Method in class net.sodacan.core.persist.file.FilePersisterFactory
- getConfig() - Method in class net.sodacan.core.persist.rocks.RocksPersisterFactory
- getConfig() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- getConfig() - Method in interface net.sodacan.core.Scheduler
- getConfig() - Method in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- getConfig() - Method in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
- getCoordinator() - Method in class net.sodacan.core.config.DefaultConfig
- getCoordinator() - Method in interface net.sodacan.core.Config
- getCoordinator() - Method in class net.sodacan.core.host.AbstractHost
- getCoordinator() - Method in interface net.sodacan.core.Host
- getCpuCores() - Method in class net.sodacan.core.scheduler.Statistics
- getCurrentHeapUsed() - Method in class net.sodacan.core.scheduler.Statistics
- getCurrentJobQueue() - Method in class net.sodacan.core.scheduler.Statistics
- getElapsed() - Method in class net.sodacan.core.scheduler.Statistics
- getEmptyStage() - Method in class net.sodacan.core.actor.AbstractActor
- getEmptyStage() - Method in interface net.sodacan.core.Actor
- getErrorCount() - Method in class net.sodacan.core.scheduler.Statistics
- getEviction() - Method in class net.sodacan.core.config.DefaultConfig
- getEviction() - Method in interface net.sodacan.core.Config
- getException() - Method in class net.sodacan.core.jug.ErrorMessage
- getFieldValues() - Method in class net.sodacan.core.serialize.gson.GsonSerializer.ActorSave
- getFieldValues() - Method in class net.sodacan.core.serialize.kryo.KryoSerializer.ActorSave
- getHistory() - Method in class net.sodacan.core.message.DefaultMessage
- getHistory() - Method in interface net.sodacan.core.Message
-
Return a copy of the message routing history
- getHost() - Method in class net.sodacan.core.config.DefaultConfig
-
Return the singleton host for this application instance
- getHost() - Method in interface net.sodacan.core.Config
-
Return the singleton host for this application instance
- getHost() - Method in class net.sodacan.core.coordinator.HostEntry
- getHostBoundActorTypes() - Method in class net.sodacan.core.config.DefaultConfig
- getHostBoundActorTypes() - Method in interface net.sodacan.core.Config
-
Return a list of host-bound actor types
- getHostEntries() - Method in class net.sodacan.core.host.AbstractHost
- getHostEntries() - Method in interface net.sodacan.core.Host
- getHostNumber() - Method in class net.sodacan.core.config.DefaultConfig
-
Each host in the network has a unique number.
- getHostNumber() - Method in interface net.sodacan.core.Config
-
Each host in the network has a unique number.
- getHostNumber() - Method in class net.sodacan.core.host.AbstractHost
- getHostNumber() - Method in interface net.sodacan.core.Host
- getHostsForActorGroup(int) - Method in interface net.sodacan.core.Coordinator
- getHostsForActorGroup(int) - Method in class net.sodacan.core.coordinator.SingleHostCoordinator
-
This returns the hosts, including the current host, as to where messages should be sent.
- getId() - Method in class net.sodacan.core.ActorId
- getInteger(String) - Method in class net.sodacan.core.message.DefaultMessage
- getInteger(String) - Method in interface net.sodacan.core.Message
-
Find the integer Info matching the name (case insensitive) and return its Integer Contents
- getLiveActorGroupStatistics() - Method in class net.sodacan.core.actor.AbstractActor
-
Make a map of actorGroup statistics.
- getLiveHostForActorGroup(int) - Method in interface net.sodacan.core.Coordinator
- getLiveHostForActorGroup(int) - Method in class net.sodacan.core.coordinator.SingleHostCoordinator
- getMaxMessageLoad() - Method in class net.sodacan.core.scheduler.Statistics
- getMaxThreadQueueDepth() - Method in class net.sodacan.core.scheduler.Statistics
- getMessage() - Method in class net.sodacan.core.jug.ErrorMessage
- getMessage() - Method in class net.sodacan.core.jug.NormalMessage
- getMessageClass() - Method in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- getMessageClass() - Method in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
- getMessageCount() - Method in class net.sodacan.core.scheduler.Statistics
- getMessageId() - Method in class net.sodacan.core.message.DefaultMessage
- getMessageId() - Method in interface net.sodacan.core.Message
- getMessageLoad() - Method in class net.sodacan.core.scheduler.Statistics
- getMessages() - Method in class net.sodacan.core.Stage
- getMessagesPerSecond() - Method in class net.sodacan.core.scheduler.Statistics
- getMode() - Method in class net.sodacan.core.coordinator.HostEntry
- getName() - Method in class net.sodacan.core.util.BBBTree.Node
- getNextActorId() - Method in class net.sodacan.core.message.DefaultMessage
- getNextActorId() - Method in interface net.sodacan.core.Message
- getNextVerb() - Method in class net.sodacan.core.message.DefaultMessage
-
Peek at the next verb or null if there's no more routes.
- getNextVerb() - Method in interface net.sodacan.core.Message
- getNodeString(Integer) - Method in class net.sodacan.core.util.BBBTree
- getParent() - Method in class net.sodacan.core.util.BBBTree.Node
- getPayload() - Method in class net.sodacan.core.message.DefaultMessage
-
Get a fresh copy of the payload of this message
- getPayload() - Method in interface net.sodacan.core.Message
-
Return a copy of the payload
- getPersisterFactory() - Method in class net.sodacan.core.config.DefaultConfig
- getPersisterFactory() - Method in interface net.sodacan.core.Config
-
The PersisterFactory provides access to persistent services for an Actor.
- getProperty(String) - Method in class net.sodacan.core.config.DefaultConfig
- getProperty(String) - Method in interface net.sodacan.core.Config
- getQueueSize() - Method in class net.sodacan.core.actor.ActorEntry
- getRandom() - Method in class net.sodacan.core.config.DefaultConfig
- getRandom() - Method in interface net.sodacan.core.Config
-
Get a Random Number Generator.
- getRef() - Method in class net.sodacan.core.util.BBBTree.Node
- getRestoreCount() - Method in class net.sodacan.core.scheduler.Statistics
- getRoot() - Method in class net.sodacan.core.util.BBBTree
- getRootDirectory() - Method in class net.sodacan.core.config.DefaultConfig
- getRootDirectory() - Method in interface net.sodacan.core.Config
-
Get the root directory for this host.
- getRoute() - Method in class net.sodacan.core.message.DefaultMessage
-
Get the current route
- getRoute() - Method in interface net.sodacan.core.Message
-
Get the current route.
- getRoutes() - Method in class net.sodacan.core.message.DefaultMessage
- getRoutes() - Method in interface net.sodacan.core.Message
- getRunning() - Method in class net.sodacan.core.scheduler.Statistics
- getSaveCount() - Method in class net.sodacan.core.scheduler.Statistics
- getSaveFields() - Method in class net.sodacan.core.config.ActorMetadata
- getScheduler() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- getScheduler() - Method in interface net.sodacan.core.ActorGroup
- getSecondsPerMessage() - Method in class net.sodacan.core.scheduler.Statistics
- getSerializerFactory() - Method in class net.sodacan.core.config.DefaultConfig
- getSerializerFactory() - Method in interface net.sodacan.core.Config
-
The SerializerFactory is instantiated during configuration
- getShutdownWaitMs() - Method in class net.sodacan.core.config.DefaultConfig
- getShutdownWaitMs() - Method in interface net.sodacan.core.Config
- getSize(int) - Method in class net.sodacan.core.util.BBAlloc
-
Return the size of a particular allocation which could be zero if there is none yet.
- getSpaceUsed() - Method in class net.sodacan.core.util.BBAlloc
- getStatistics() - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
These are live statistics.
- getStatistics() - Method in interface net.sodacan.core.Scheduler
- getStatisticsFor(ActorId) - Method in class net.sodacan.core.host.AbstractHost
- getStatisticsFor(ActorId) - Method in interface net.sodacan.core.Host
- getString(String) - Method in class net.sodacan.core.message.DefaultMessage
-
Find the Info record the matching name (case insensitive) and return its String Contents
- getString(String) - Method in interface net.sodacan.core.Message
-
Find the Info record the matching name (case insensitive) and return its String Contents
- getTarget() - Method in class net.sodacan.core.message.DefaultMessage
- getTarget() - Method in interface net.sodacan.core.Message
-
Get the target actorId of the current route.
- getTarget() - Method in class net.sodacan.core.Route
- getTimestamp() - Method in class net.sodacan.core.message.DefaultMessage
- getTimestamp() - Method in class net.sodacan.core.message.DefaultMessageId
- getTimestamp() - Method in interface net.sodacan.core.Message
- getTimestamp() - Method in interface net.sodacan.core.MessageId
- getTotalSleepTime() - Method in class net.sodacan.core.scheduler.Statistics
- getType() - Method in class net.sodacan.core.ActorId
- getUnique() - Method in class net.sodacan.core.message.DefaultMessageId
- getUnique() - Method in interface net.sodacan.core.MessageId
- getUsage() - Method in class net.sodacan.core.actor.ActorEntry
- getVerb() - Method in class net.sodacan.core.message.DefaultMessage
- getVerb() - Method in interface net.sodacan.core.Message
-
Get the verb of the current route.
- getVerb() - Method in class net.sodacan.core.Route
- getWastedSpace() - Method in class net.sodacan.core.util.BBAlloc
-
The amount of space that can no longer be allocated (without some effort)
- getZone() - Method in class net.sodacan.core.util.FixedClock
- GsonSerializer - Class in net.sodacan.core.serialize.gson
-
Serialize and deserialize Actors and Messages to Json using Google's Gson.
- GsonSerializer(GsonSerializerFactory, ActorId, ActorMetadata) - Constructor for class net.sodacan.core.serialize.gson.GsonSerializer
- GsonSerializer.ActorSave - Class in net.sodacan.core.serialize.gson
- GsonSerializerFactory - Class in net.sodacan.core.serialize.gson
-
Factory that creates individual Serializers.
- GsonSerializerFactory(Config) - Constructor for class net.sodacan.core.serialize.gson.GsonSerializerFactory
H
- handleStage(Stage) - Method in class net.sodacan.core.actor.AbstractActor
-
Send each message in the stage - we're still in the Actor's run thread.
- hashCode() - Method in class net.sodacan.core.ActorId
- hashCode() - Method in class net.sodacan.core.coordinator.HostEntry
- hashCode() - Method in class net.sodacan.core.message.DefaultMessageId
- hasSaveFields() - Method in class net.sodacan.core.config.ActorMetadata
-
Determine if this ActorType has any fields with @Save annotation.
- HEADER_SIZE - Static variable in class net.sodacan.core.util.BBAlloc
- host - Variable in class net.sodacan.core.actorgroup.AbstractActorGroup
- host(Function<Config, Host>) - Method in class net.sodacan.core.config.BaseBuilder
-
local singleton
- Host - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
- Host - Interface in net.sodacan.core
-
A Host sits at the top of the hierarchy of actorGroups and actors in a single Java application
- hostBound - Variable in class net.sodacan.core.config.ActorMetadata
- HostBound - Interface in net.sodacan.core.actor
-
A host bound Actor is locked to a specific host rather than moving with its actor group.
- HostBound ActorGroup - Search tag in package net.sodacan.core.actorgroup
- Section
- Host Bound Actors - Search tag in package net.sodacan.core.actor
- Section
- HostEntry - Class in net.sodacan.core.coordinator
-
Contains a combination of host number, actorgroup number, and actorGroup state.
- HostEntry(int, int, HostEntry.Mode) - Constructor for class net.sodacan.core.coordinator.HostEntry
- HostEntry.Mode - Enum Class in net.sodacan.core.coordinator
-
Active state means that this actorGroup is able to process messages. Replica state means that this actorGroup is only receiving actor state messages and storing them locally in anticipation of possibly becoming active. The Host mode allows the specified ActorGroup to remain bound to the host; It can't move like an ordinary ActorrGroup.
- hostFn - Variable in class net.sodacan.core.config.BaseBuilder
- hostNumber(int) - Method in class net.sodacan.core.config.BaseBuilder
-
Local Static
- hostNumber(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
- hostNumberFn - Variable in class net.sodacan.core.config.BaseBuilder
- Hot - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
I
- inbound - Variable in class net.sodacan.core.actor.AbstractActor
- increaseErrorCount() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- increaseErrorCount() - Method in interface net.sodacan.core.Scheduler
- increaseMessageCount() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- increaseMessageCount() - Method in interface net.sodacan.core.Scheduler
- increaseMessageLoad() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- increaseMessageLoad() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- increaseMessageLoad() - Method in interface net.sodacan.core.Scheduler
- increaseRestoreCount() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- increaseRestoreCount() - Method in interface net.sodacan.core.Scheduler
- increaseSaveCount() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- increaseSaveCount() - Method in interface net.sodacan.core.Scheduler
- incrementActorsEvicted() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- incrementActorsEvicted() - Method in interface net.sodacan.core.Scheduler
- incrementActorsRealized() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- incrementActorsRealized() - Method in interface net.sodacan.core.Scheduler
- incrementSleepTime() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- incrementSleepTime() - Method in interface net.sodacan.core.Scheduler
- INITIAL_NODE_ALLOCATION - Static variable in class net.sodacan.core.util.BBBTree
- initialize() - Method in class net.sodacan.core.actor.ActorEntry
- initialize() - Method in class net.sodacan.core.host.DefaultHost
-
Get things started in a host.
- instant() - Method in class net.sodacan.core.util.FixedClock
- InstantTypeAdapter - Class in net.sodacan.core.serialize.gson
- InstantTypeAdapter() - Constructor for class net.sodacan.core.serialize.gson.InstantTypeAdapter
- INT_SIZE - Static variable in class net.sodacan.core.util.BBAlloc
- InterHost communication - Search tag in package net.sodacan.core
- Section
- isClosing() - Method in class net.sodacan.core.scheduler.Statistics
- isHostBound() - Method in class net.sodacan.core.config.ActorMetadata
- isInitialized() - Method in class net.sodacan.core.host.AbstractHost
- isKeepHistory() - Method in class net.sodacan.core.message.DefaultMessage
- isKeepHistory() - Method in interface net.sodacan.core.Message
J
- JournalEntry - Class in net.sodacan.core.journal
-
A journal entry suitable for writing/reading with nio.
- JournalEntry() - Constructor for class net.sodacan.core.journal.JournalEntry
- JournalHeader - Class in net.sodacan.core.journal
-
The first 2^16 bytes of a journal file are reserved for header information pertaining to the format of the rest of the file.
- JournalHeader() - Constructor for class net.sodacan.core.journal.JournalHeader
- JournalWriter - Class in net.sodacan.core.actor
-
A JournalWriter Actor is responsible for writing state to a journal.
- JournalWriter(Config, ActorId) - Constructor for class net.sodacan.core.actor.JournalWriter
- Jug - Interface in net.sodacan.core
-
Why the name Jug?
K
- keepHistory(boolean) - Method in class net.sodacan.core.message.DefaultMessage
- keepHistory(boolean) - Method in interface net.sodacan.core.Message
- killStatus() - Method in class net.sodacan.core.actor.ActorGroupStats
-
If the periodic status in running, kill it.
- KryoSerializer - Class in net.sodacan.core.serialize.kryo
- KryoSerializer(KryoSerializerFactory, ActorId, ActorMetadata) - Constructor for class net.sodacan.core.serialize.kryo.KryoSerializer
- KryoSerializer.ActorSave - Class in net.sodacan.core.serialize.kryo
- KryoSerializerFactory - Class in net.sodacan.core.serialize.kryo
-
Factory that creates individual Serializers.
- KryoSerializerFactory(Config) - Constructor for class net.sodacan.core.serialize.kryo.KryoSerializerFactory
L
- linger() - Method in class net.sodacan.core.actor.ActorEntry
-
If return true, then try to grab a new message, otherwise, get out
- listActors(PrintStream) - Method in class net.sodacan.core.config.DefaultConfig
-
Send a list of actorType names and actor class name pairs
- listActors(PrintStream) - Method in interface net.sodacan.core.Config
-
Send a list of actorType names and actor class name pairs
- Live - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
- livelinessCheck() - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
Subjective check to see if messages are being processed.
- loadFieldMetadata() - Method in class net.sodacan.core.config.ActorMetadata
-
Called from constructor
- loadVerbs() - Method in class net.sodacan.core.config.ActorMetadata
-
Most Actors will declare one or more verbs that it can handle in the form of an enum.
M
- MAGIC_NUMBER - Static variable in class net.sodacan.core.util.BBAlloc
- main(String[]) - Static method in class net.sodacan.core.Main
- Main - Class in net.sodacan.core
- Main() - Constructor for class net.sodacan.core.Main
- makeFactory() - Method in class net.sodacan.core.config.ActorMetadata
- makeFile(String) - Method in class net.sodacan.core.persist.AbstractPersister
-
Files are organized by ActorGroup, type of actor, and actor id.
- makeFolder() - Method in class net.sodacan.core.persist.AbstractPersister
-
This method return a file handle to folder assigned to the specific actorId.
- makeHostFolder() - Method in class net.sodacan.core.persist.rocks.RocksPersisterFactory
- makeTypeFolder() - Method in class net.sodacan.core.persist.AbstractPersister
-
This method return a file handle to the ActorType directory within the specified ActorGroup directory within the specified Host directory within the specified root folder creating directories that do not exist.
- MapAdapter - Class in net.sodacan.core.serialize.gson
- MapAdapter() - Constructor for class net.sodacan.core.serialize.gson.MapAdapter
- maxActorGroups - Variable in class net.sodacan.core.actorgroup.AbstractActorGroupAssigner
- MemoryPersister - Class in net.sodacan.core.persist.memory
- MemoryPersister(Config, ActorId, Map<String, byte[]>) - Constructor for class net.sodacan.core.persist.memory.MemoryPersister
- MemoryPersisterFactory - Class in net.sodacan.core.persist.memory
-
As with all persisters, the factory hangs around until host closes it.
- MemoryPersisterFactory(Config) - Constructor for class net.sodacan.core.persist.memory.MemoryPersisterFactory
- message(Function<Config, Message>) - Method in class net.sodacan.core.config.BaseBuilder
- Message - Interface in net.sodacan.core
-
Overview
- messageClass - Variable in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- messageClass - Variable in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
- messageFn - Variable in class net.sodacan.core.config.BaseBuilder
- messageId(Function<Config, MessageId>) - Method in class net.sodacan.core.config.BaseBuilder
- MessageId - Search tag in package net.sodacan.core.message
- Section
- MessageId - Interface in net.sodacan.core
-
A messageId is statistically unique and sortable by its timestamp.
- MessageIdAdapter - Class in net.sodacan.core.serialize.gson
- MessageIdAdapter() - Constructor for class net.sodacan.core.serialize.gson.MessageIdAdapter
- messageIdFn - Variable in class net.sodacan.core.config.BaseBuilder
- Message Lifecycle - Search tag in interface net.sodacan.core.Message
- Section
- Message Processing - Search tag in package net.sodacan.core.actor
- Section
- MessageUtils - Class in net.sodacan.core.util
- MessageUtils() - Constructor for class net.sodacan.core.util.MessageUtils
N
- name() - Element in annotation interface net.sodacan.core.annotation.ActorType
- name() - Element in annotation interface net.sodacan.core.annotation.Save
- net.sodacan.core - package net.sodacan.core
-
This package contains most of the Interfaces of Sodacan.
- net.sodacan.core.actor - package net.sodacan.core.actor
-
A small island of compute sending and receiving messages to/from other Actors.
- net.sodacan.core.actorgroup - package net.sodacan.core.actorgroup
-
An ActorGroup contains a dynamic number of actors.
- net.sodacan.core.annotation - package net.sodacan.core.annotation
- net.sodacan.core.config - package net.sodacan.core.config
- net.sodacan.core.coordinator - package net.sodacan.core.coordinator
-
The Sodacan coordinator keeps a network-wide "ideal" distribution of ActorGroups along with a snapshot of the current Host/ActorGroup arrangement.
- net.sodacan.core.host - package net.sodacan.core.host
-
A Host manages ActorGroups.
- net.sodacan.core.journal - package net.sodacan.core.journal
-
A Sodacan journal primarily stores Actor state messages which can also be interleaved with other messages.
- net.sodacan.core.jug - package net.sodacan.core.jug
-
These subclasses of Jug are used within an ActorGroup for special purposes
- net.sodacan.core.message - package net.sodacan.core.message
-
A message flows from a source Actor to a destination Actor.
- net.sodacan.core.persist - package net.sodacan.core.persist
- net.sodacan.core.persist.file - package net.sodacan.core.persist.file
- net.sodacan.core.persist.memory - package net.sodacan.core.persist.memory
-
Memory-based persister, recorded values in memory only.
- net.sodacan.core.persist.rocks - package net.sodacan.core.persist.rocks
- net.sodacan.core.scheduler - package net.sodacan.core.scheduler
-
The Scheduler for an ActorGroup is concerned with thread coordination.
- net.sodacan.core.serialize - package net.sodacan.core.serialize
-
Serializer implementations are in this package.
- net.sodacan.core.serialize.gson - package net.sodacan.core.serialize.gson
- net.sodacan.core.serialize.kryo - package net.sodacan.core.serialize.kryo
- net.sodacan.core.util - package net.sodacan.core.util
- nextInt() - Method in class net.sodacan.core.util.FixedRandom
- nextRoute() - Method in class net.sodacan.core.actor.AbstractActor
-
Convenience method to continue processing the next route in the inbound message with no other messages in the stage.
- Node(BBBTree) - Constructor for class net.sodacan.core.util.BBBTree.Node
- Node(BBBTree, Integer) - Constructor for class net.sodacan.core.util.BBBTree.Node
-
Create a skeleton node which won't be realized until it's first needed
- Node(BBBTree, BBBTree.Node) - Constructor for class net.sodacan.core.util.BBBTree.Node
- normalMessage(NormalMessage) - Method in class net.sodacan.core.actor.ActorEntry
- normalMessage(NormalMessage) - Method in class net.sodacan.core.scheduler.DefaultScheduler
- NormalMessage - Class in net.sodacan.core.jug
-
The carrier for messages sent between Actors.
- NormalMessage(ActorId, byte[]) - Constructor for class net.sodacan.core.jug.NormalMessage
- notImplemented(Config, Actor) - Method in class net.sodacan.core.message.DefaultMessage
- notImplemented(Config, Actor) - Method in interface net.sodacan.core.Message
-
This method is called when a message is sent to an Actor but the Actor has not overriden the processMessage method.
- now() - Method in class net.sodacan.core.config.DefaultConfig
- now() - Method in interface net.sodacan.core.Config
-
Return the current instant of the configured clock.
O
- Observability - Search tag in interface net.sodacan.core.Message
- Section
- OffLine - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
- open() - Method in class net.sodacan.core.persist.file.FilePersisterFactory
- open() - Method in class net.sodacan.core.persist.memory.MemoryPersisterFactory
- open() - Method in interface net.sodacan.core.persist.PersisterFactory
- open() - Method in class net.sodacan.core.persist.rocks.RocksPersisterFactory
-
Persister must call this to open the db.
- Overview - Search tag in interface net.sodacan.core.Message
- Section
- Overview - Search tag in package net.sodacan.core.message
- Section
P
- Package Contents - Search tag in package net.sodacan.core
- Section
- Payload - Search tag in package net.sodacan.core.message
- Section
- peekRoute() - Method in class net.sodacan.core.message.DefaultMessage
-
Peek at the next route or null if there's no more routes in the message.
- peekRoute() - Method in interface net.sodacan.core.Message
- peekTailRoute() - Method in class net.sodacan.core.message.DefaultMessage
- PeriodicStats(Map<Integer, Statistics>, int) - Constructor for class net.sodacan.core.actor.ActorGroupStats.PeriodicStats
- Persister - Interface in net.sodacan.core
-
Implementations of this interface save and restore a serialized form of an Actor.
- persisterFactory(Function<Config, PersisterFactory>) - Method in class net.sodacan.core.config.BaseBuilder
- PersisterFactory - Interface in net.sodacan.core.persist
-
A persister Factory is created during configuration.
- persisterFactoryFn - Variable in class net.sodacan.core.config.BaseBuilder
- pool - Variable in class net.sodacan.core.serialize.gson.GsonSerializerFactory
- pool - Variable in class net.sodacan.core.serialize.kryo.KryoSerializerFactory
- Pool<T> - Class in net.sodacan.core.util
- Pool(int, PoolItemFactory<T>) - Constructor for class net.sodacan.core.util.Pool
- PoolItemFactory<T> - Interface in net.sodacan.core.util
- popRoute() - Method in class net.sodacan.core.message.DefaultMessage
-
Popping a route sets the current route in the message and it also renders the message immutable.
- popRoute() - Method in interface net.sodacan.core.Message
- postprocess(Config, Actor) - Method in class net.sodacan.core.message.DefaultMessage
- postprocess(Config, Actor) - Method in interface net.sodacan.core.Message
-
This method is called when a message is sent by an Actor.
- prepareBuildRoute() - Method in class net.sodacan.core.message.DefaultMessage
- preprocess(Config, Actor) - Method in class net.sodacan.core.message.DefaultMessage
- preprocess(Config, Actor) - Method in interface net.sodacan.core.Message
-
This method is called after a message is deserialized and ready to be processed by the target actor.
- print(PrintStream) - Method in class net.sodacan.core.message.DefaultMessage
- print(PrintStream) - Method in interface net.sodacan.core.Message
- printConfig(PrintStream) - Method in class net.sodacan.core.config.DefaultConfig
-
Send a list of actorType names and actor class name pairs
- printConfig(PrintStream) - Method in interface net.sodacan.core.Config
-
Send a list of actorType names and actor class name pairs
- processMessage() - Method in class net.sodacan.core.actor.AbstractActor
-
Default behavior for an actor is to throw an exception
- processMessage() - Method in class net.sodacan.core.actor.ActorGroupSender
- processMessage() - Method in class net.sodacan.core.actor.ActorGroupStats
- processMessage() - Method in class net.sodacan.core.actor.JournalWriter
- processMessage() - Method in interface net.sodacan.core.Actor
-
Process one message.
- processMessage() - Method in class net.sodacan.core.actor.Sleeper
- property(String, String) - Method in class net.sodacan.core.config.BaseBuilder
-
Set a system property
- pushRoute(Route) - Method in class net.sodacan.core.message.DefaultMessage
- put(String, Integer) - Method in class net.sodacan.core.message.DefaultMessage
-
Put new Integer entry in payload.
- put(String, Integer) - Method in interface net.sodacan.core.Message
- put(String, Object) - Method in class net.sodacan.core.message.DefaultMessage
-
Add an Info entry to payload, see convenience methods as well.
- put(String, Object) - Method in interface net.sodacan.core.Message
-
Put new entry in payload
- put(String, String) - Method in class net.sodacan.core.message.DefaultMessage
-
Put new String entry in payload.
- put(String, String) - Method in interface net.sodacan.core.Message
-
Put new entry in payload convenience for a String
- put(String, ActorId) - Method in class net.sodacan.core.message.DefaultMessage
-
Put new entry in payload convenience for an ActorId
- put(String, ActorId) - Method in interface net.sodacan.core.Message
-
Put new entry in payload convenience for an ActorId
Q
- queueMessage(Jug) - Method in class net.sodacan.core.actor.ActorEntry
-
Callable from any thread to add a message to this queue.
R
- random(Function<Config, Random>) - Method in class net.sodacan.core.config.BaseBuilder
- RandomActorGroupAssigner - Class in net.sodacan.core.actorgroup
- RandomActorGroupAssigner(Config) - Constructor for class net.sodacan.core.actorgroup.RandomActorGroupAssigner
- randomFn - Variable in class net.sodacan.core.config.BaseBuilder
- read(String) - Method in class net.sodacan.core.persist.file.FilePersister
- read(String) - Method in class net.sodacan.core.persist.memory.MemoryPersister
- read(String) - Method in class net.sodacan.core.persist.rocks.RocksPersister
- read(String) - Method in interface net.sodacan.core.Persister
-
This method is called by the framework when an actor's processMessage method is about to be called for the first time after the Actor has been instantiated.
- realize() - Method in class net.sodacan.core.util.BBBTree.Node
-
Populate a node from a serialized form from disk Can be called repeatedly, does nothing if already done.
- Receiver - Interface in net.sodacan.core
-
A Receiver implementation receives an inbound serialized message and adds the message to an appropriate ActorGroup queue.
- reduceMessageLoad() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- registerActorsInPackage(String) - Method in class net.sodacan.core.config.BaseBuilder
-
global static
- registerActorType(String, Class<? extends Actor>) - Method in class net.sodacan.core.config.BaseBuilder
-
Register a new ActorType with a default constructor
- registerActorType(String, Class<? extends Actor>, BiFunction<Config, ActorId, Actor>) - Method in class net.sodacan.core.config.BaseBuilder
-
global static Explicitly register an actor type name to actor class.
- remove(String) - Method in class net.sodacan.core.message.DefaultMessage
- remove(String) - Method in interface net.sodacan.core.Message
-
Remove entry from payload
- replace(int, String) - Method in class net.sodacan.core.util.BBAlloc
-
We already have an item stored, we need to replace the value stored there.
- replicate(int, NormalMessage) - Method in class net.sodacan.core.host.AbstractHost
- restore() - Method in class net.sodacan.core.actor.AbstractActor
-
Restore each of the @Save fields of an actor
- restore() - Method in interface net.sodacan.core.Actor
- returnItem(T) - Method in class net.sodacan.core.util.Pool
- RocksPersister - Class in net.sodacan.core.persist.rocks
- RocksPersister(Config, RocksDB, ActorId) - Constructor for class net.sodacan.core.persist.rocks.RocksPersister
- RocksPersisterFactory - Class in net.sodacan.core.persist.rocks
-
Only one persister factory in a host so this is where we open RocksDb.
- RocksPersisterFactory(Config, String) - Constructor for class net.sodacan.core.persist.rocks.RocksPersisterFactory
- rollback() - Method in class net.sodacan.core.actor.AbstractActor
-
Empty the list of staged messages and restore the state of the actor.
- rollback() - Method in class net.sodacan.core.persist.file.FilePersister
- rollback() - Method in class net.sodacan.core.persist.memory.MemoryPersister
- rollback() - Method in class net.sodacan.core.persist.rocks.RocksPersister
- rollback() - Method in interface net.sodacan.core.Persister
-
When a series of writes should be rolled back: not written in the first place, replaced with a previous version, etc.
- rootDirectory(String) - Method in class net.sodacan.core.config.BaseBuilder
- rootDirectory(Function<Config, String>) - Method in class net.sodacan.core.config.BaseBuilder
- rootDirectoryFn - Variable in class net.sodacan.core.config.BaseBuilder
- Route - Class in net.sodacan.core
-
A message route carries the information needed to get a message to where it is going and what it's purpose is when it gets there.
- Route() - Constructor for class net.sodacan.core.Route
- RouteAdapter - Class in net.sodacan.core.serialize.gson
-
A Route needs special handling, specifically because of the verb contained within.
- RouteAdapter() - Constructor for class net.sodacan.core.serialize.gson.RouteAdapter
- Route Types - Verb - Search tag in package net.sodacan.core.message
- Section
- Routing - Search tag in package net.sodacan.core.message
- Section
- run() - Method in class net.sodacan.core.actor.ActorEntry
- run() - Method in class net.sodacan.core.actor.ActorGroupStats.PeriodicStats
- run() - Method in class net.sodacan.core.scheduler.DefaultScheduler
S
- save() - Method in class net.sodacan.core.actor.AbstractActor
-
Save state of the save fields of an actor in two steps: Serialize a field content and then persist the resulting serialized byte array
- save() - Method in interface net.sodacan.core.Actor
- Save - Annotation Interface in net.sodacan.core.annotation
-
Any field annotated with @Save will be saved and restored as needed.
- saveFields - Variable in class net.sodacan.core.config.ActorMetadata
- saveHeader() - Method in class net.sodacan.core.util.BBAlloc
-
Must remain in sync with restoreHeader.
- saveNode() - Method in class net.sodacan.core.util.BBBTree.Node
-
By the time we're called, every node should have a ref assigned
- scheduler - Variable in class net.sodacan.core.actor.ActorEntry
- scheduler(BiFunction<Config, ActorGroup, Scheduler>) - Method in class net.sodacan.core.config.BaseBuilder
-
Local factory
- Scheduler - Interface in net.sodacan.core
- schedulerFn - Variable in class net.sodacan.core.config.BaseBuilder
- send(Jug) - Method in class net.sodacan.core.host.AbstractHost
-
Send this message to live actor and also copy it to other specified host(s)
- send(Jug) - Method in interface net.sodacan.core.Host
- send(Message) - Method in class net.sodacan.core.actor.AbstractActor
-
If there are any more routes left in the message, the message will be sent to the Host (not directly to target) in case the target ActorGroup has changed to a different Host.
- send(Message) - Method in interface net.sodacan.core.Actor
-
Send a message immediately rather than in the Stage.
- Sender - Interface in net.sodacan.core
-
A Sender is a delegate of a Host tasked with sending messages to other hosts.
- sendNormalMessage(NormalMessage) - Method in class net.sodacan.core.host.AbstractHost
- sendStartMessage(ActorId) - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- SequentialActorIdFactory - Class in net.sodacan.core.actor
-
Create a sequential ActorId for testing.
- SequentialActorIdFactory(Config) - Constructor for class net.sodacan.core.actor.SequentialActorIdFactory
- serialize(Instant, Type, JsonSerializationContext) - Method in class net.sodacan.core.serialize.gson.InstantTypeAdapter
- serialize(Map<String, Object>, Type, JsonSerializationContext) - Method in class net.sodacan.core.serialize.gson.MapAdapter
- serialize(Actor) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
-
We are asked to serialize the fields of an actor, rather than the Actor as a whole.
- serialize(Actor) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- serialize(Actor) - Method in interface net.sodacan.core.Serializer
-
Serialize the @Save fields of an Actor
- serialize(ActorId, Type, JsonSerializationContext) - Method in class net.sodacan.core.serialize.gson.ActorIdAdapter
- serialize(Message) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
- serialize(Message) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- serialize(Message) - Method in interface net.sodacan.core.Serializer
-
Serialize a Message to a byte array
- serialize(Route, Type, JsonSerializationContext) - Method in class net.sodacan.core.serialize.gson.RouteAdapter
- serializeField(Object) - Method in class net.sodacan.core.serialize.gson.GsonSerializer
-
Serialize a field rather than a whole actor
- serializeField(Object) - Method in class net.sodacan.core.serialize.kryo.KryoSerializer
- serializeField(Object) - Method in interface net.sodacan.core.Serializer
-
Serialize a @Save field of an Actor
- serializer - Variable in class net.sodacan.core.actor.ActorEntry
- Serializer - Interface in net.sodacan.core
-
A Serializer is concerned with serializing and deserializing Actors and Messages.
- serializerFactory(Function<Config, SerializerFactory>) - Method in class net.sodacan.core.config.BaseBuilder
- SerializerFactory - Interface in net.sodacan.core.serialize
-
A serializer Factory is created during configuration.
- serializerFactoryFn - Variable in class net.sodacan.core.config.BaseBuilder
- setActiveThreadCount(int) - Method in class net.sodacan.core.scheduler.DefaultScheduler
- setActiveThreadCount(int) - Method in interface net.sodacan.core.Scheduler
- setActorGroup(ActorGroup) - Method in class net.sodacan.core.actor.AbstractActor
- setActorGroup(ActorGroup) - Method in interface net.sodacan.core.Actor
- setClosing() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- setClosing() - Method in interface net.sodacan.core.Scheduler
- setCurrentJobQueue(int) - Method in class net.sodacan.core.scheduler.DefaultScheduler
- setCurrentJobQueue(int) - Method in interface net.sodacan.core.Scheduler
- setHost(Host) - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- setHost(Host) - Method in interface net.sodacan.core.ActorGroup
- setInitialized(boolean) - Method in class net.sodacan.core.host.AbstractHost
- setName(String) - Method in class net.sodacan.core.util.BBBTree.Node
- setPointerAddress(int, int) - Method in class net.sodacan.core.util.BBAlloc
- setRoot(BBBTree.Node) - Method in class net.sodacan.core.util.BBBTree
- setTarget(ActorId) - Method in class net.sodacan.core.Route
- setVerb(Verb) - Method in class net.sodacan.core.Route
- showStatus(int) - Method in class net.sodacan.core.actor.ActorGroupStats
- showSummary() - Method in class net.sodacan.core.actor.ActorGroupStats
- shutdownWaitMs(int) - Method in class net.sodacan.core.config.BaseBuilder
- shutdownWaitMs(Function<Config, Integer>) - Method in class net.sodacan.core.config.BaseBuilder
-
global dynamic
- shutdownWaitMsFn - Variable in class net.sodacan.core.config.BaseBuilder
- SimpleBuilder - Class in net.sodacan.core.config
- SimpleBuilder() - Constructor for class net.sodacan.core.config.SimpleBuilder
- SingleHostCoordinator - Class in net.sodacan.core.coordinator
-
For this Single host coordinator, the static configuration is provided and used.
- SingleHostCoordinator(Config) - Constructor for class net.sodacan.core.coordinator.SingleHostCoordinator
- Sleeper - Class in net.sodacan.core.actor
-
A kind of WorkerActor that Sleeps for a while, sends a message, and then goes away.
- Sleeper(Config, ActorId) - Constructor for class net.sodacan.core.actor.Sleeper
- SodacanException - Exception Class in net.sodacan.core
- SodacanException(String) - Constructor for exception class net.sodacan.core.SodacanException
- Stage - Class in net.sodacan.core
-
While an Actor processes a message, it populates this object with messages to be sent to other actors upon completion of processing the message.
- Stage() - Constructor for class net.sodacan.core.Stage
- start() - Method in class net.sodacan.core.host.DefaultHost
- start() - Method in interface net.sodacan.core.Host
-
Start this Host.
- Start - Enum constant in enum class net.sodacan.core.Actor.Builtin
- startThread(ThreadPoolExecutor) - Method in class net.sodacan.core.actor.ActorEntry
-
Kick off the thread if its not running
- startup() - Method in class net.sodacan.core.actor.ActorGroupStats
- Statistics - Class in net.sodacan.core.scheduler
-
Hold live statistics for an actor group
- Statistics(ActorGroup) - Constructor for class net.sodacan.core.scheduler.Statistics
- stats - Enum constant in enum class net.sodacan.core.actor.ActorGroupStats.Action
- stats - Variable in class net.sodacan.core.actor.ActorGroupStats
- stoppedActor(StoppedActor) - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
When an actorEntry says there are no more messages and thus has stopped, see if there's actually more work to do.
- StoppedActor - Class in net.sodacan.core.jug
- StoppedActor(ActorId) - Constructor for class net.sodacan.core.jug.StoppedActor
- stopThread() - Method in class net.sodacan.core.actor.ActorEntry
- store(Integer, String) - Method in class net.sodacan.core.util.BBAlloc
-
Store a string at the supplied reference
- store(Integer, String) - Method in class net.sodacan.core.util.BBBTree
- store(String) - Method in class net.sodacan.core.util.BBAlloc
-
Store a string and return a reference to it
- store(String) - Method in class net.sodacan.core.util.BBBTree
- submit(Config, Message) - Static method in class net.sodacan.core.util.MessageUtils
-
For testing only.
- submitToNewActor(Config, String, Verb) - Static method in class net.sodacan.core.util.MessageUtils
-
Submit a new message to a new Actor
T
- terminal(Config, Actor) - Method in class net.sodacan.core.message.DefaultMessage
- terminal(Config, Actor) - Method in interface net.sodacan.core.Message
-
This method is called when a message is sent by an Actor and the message as no further routes this it will be destroyed just after this method is called.
- TextUtil - Class in net.sodacan.core.util
- TextUtil() - Constructor for class net.sodacan.core.util.TextUtil
- TimeActor - Class in net.sodacan.core.actor
-
This timer actor provides a simple but important service for other Actors: It will accept a message, hold on to the message for a specified amount of time and then forward that message to its next step which could be the Actor that sent the message or any other actor.
- TimeActor(Config, ActorId) - Constructor for class net.sodacan.core.actor.TimeActor
- timestamp - Variable in class net.sodacan.core.message.DefaultMessageId
- to(Verb) - Method in class net.sodacan.core.message.DefaultMessage
- to(Verb) - Method in interface net.sodacan.core.Message
- toJson(PrintStream) - Method in class net.sodacan.core.message.DefaultMessage
- toString() - Method in class net.sodacan.core.actor.ActorEntry
- toString() - Method in class net.sodacan.core.actorgroup.AbstractActorGroup
- toString() - Method in class net.sodacan.core.actorgroup.FixedActorGroupAssigner
- toString() - Method in class net.sodacan.core.actorgroup.RandomActorGroupAssigner
- toString() - Method in class net.sodacan.core.ActorId
- toString() - Method in class net.sodacan.core.config.ActorMetadata
- toString() - Method in class net.sodacan.core.coordinator.HostEntry
- toString() - Method in class net.sodacan.core.coordinator.SingleHostCoordinator
- toString() - Method in class net.sodacan.core.host.DefaultHost
- toString() - Method in class net.sodacan.core.journal.JournalEntry
- toString() - Method in class net.sodacan.core.jug.NormalMessage
- toString() - Method in class net.sodacan.core.message.DefaultMessage
- toString() - Method in class net.sodacan.core.message.DefaultMessageId
- toString() - Method in class net.sodacan.core.Route
- toString() - Method in class net.sodacan.core.scheduler.DefaultScheduler
- toString() - Method in class net.sodacan.core.util.BBBTree.Node
- trace(boolean) - Method in class net.sodacan.core.message.DefaultMessage
U
- unique - Variable in class net.sodacan.core.message.DefaultMessageId
- update() - Method in class net.sodacan.core.host.AbstractHost
-
Get the updated configuration from coordinator and add/remove actor groups as needed.
- update() - Method in interface net.sodacan.core.Host
-
Update the host configuration by consulting with coordinator
- usage - Variable in class net.sodacan.core.actor.ActorEntry
- UUIDActorIdFactory - Class in net.sodacan.core.actor
- UUIDActorIdFactory(Config) - Constructor for class net.sodacan.core.actor.UUIDActorIdFactory
V
- validate(BaseBuilder) - Method in class net.sodacan.core.config.DefaultConfig
- validateMessage(Config) - Method in class net.sodacan.core.message.DefaultMessage
-
If nothing to do in the message, return false.
- validateRoute(Message, Stage) - Method in class net.sodacan.core.actor.AbstractActor
- valueOf(String) - Static method in enum class net.sodacan.core.actor.ActorGroupStats.Action
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class net.sodacan.core.Actor.Builtin
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class net.sodacan.core.coordinator.HostEntry.Mode
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class net.sodacan.core.actor.ActorGroupStats.Action
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class net.sodacan.core.Actor.Builtin
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class net.sodacan.core.coordinator.HostEntry.Mode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- Verb - Interface in net.sodacan.core
W
- waitForMessagesToFinish() - Method in class net.sodacan.core.host.AbstractHost
-
This method is only useful for testing when it is expected that the message load will drop to zero.
- waitForMessagesToFinish() - Method in interface net.sodacan.core.Host
-
This method is only useful for testing when it is expected that the message load will drop to zero.
- waitForMessagesToFinish() - Method in class net.sodacan.core.scheduler.DefaultScheduler
-
In production, this is where we wait for an ActorGroup to settle down so we can move the ActorGroup to another host or otherwise change it's state.
- waitForMessagesToFinish() - Method in interface net.sodacan.core.Scheduler
-
Wait for the number of in-flight messages to go to zero.
- Warm - Enum constant in enum class net.sodacan.core.coordinator.HostEntry.Mode
- withZone(ZoneId) - Method in class net.sodacan.core.util.FixedClock
- WorkerActor - Class in net.sodacan.core.actor
-
A WorkerActor has no state, it's ephemeral.
- WorkerActor(Config, ActorId) - Constructor for class net.sodacan.core.actor.WorkerActor
- write(String, byte[]) - Method in class net.sodacan.core.persist.file.FilePersister
- write(String, byte[]) - Method in class net.sodacan.core.persist.memory.MemoryPersister
- write(String, byte[]) - Method in class net.sodacan.core.persist.rocks.RocksPersister
- write(String, byte[]) - Method in interface net.sodacan.core.Persister
-
The save method is called by the framework when an actor's state has been updated.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form