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

A

AbstractActor<T> - Class in cloud.orbit.actors.runtime
Base class to all actor implementations.
AbstractActor() - Constructor for class cloud.orbit.actors.runtime.AbstractActor
 
AbstractStorageExtension - Class in cloud.orbit.actors.extensions
 
AbstractStorageExtension() - Constructor for class cloud.orbit.actors.extensions.AbstractStorageExtension
 
activateAsync() - Method in class cloud.orbit.actors.runtime.AbstractActor
Called by the framework when activating the actor.
activation - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
Actor - Interface in cloud.orbit.actors
Interface marker for orbit actors.
ActorClassFinder - Interface in cloud.orbit.actors.extensions
 
ActorConstructionExtension - Interface in cloud.orbit.actors.extensions
Created by joeh on 2017-05-29.
ActorExtension - Interface in cloud.orbit.actors.extensions
Base interface for actor extensions.
ActorFactoryGenerator - Class in cloud.orbit.actors.runtime
Class to create actor factories, actor references and actor invokers.
ActorFactoryGenerator() - Constructor for class cloud.orbit.actors.runtime.ActorFactoryGenerator
 
actorIdentity() - Method in class cloud.orbit.actors.runtime.AbstractActor
Gets a string that represents uniquely this actor
ActorObserver - Interface in cloud.orbit.actors
Used to create interfaces to client objects that can be passed as remote references to actors.
ActorRuntime - Interface in cloud.orbit.actors.runtime
Interface used by the generated code to interact with the orbit actors runtime.
ActorState - Interface in cloud.orbit.actors.runtime
 
actorSupported_no - Static variable in interface cloud.orbit.actors.runtime.NodeCapabilities
 
actorSupported_noneSupported - Static variable in interface cloud.orbit.actors.runtime.NodeCapabilities
 
actorSupported_yes - Static variable in interface cloud.orbit.actors.runtime.NodeCapabilities
 
ActorTaskContext - Class in cloud.orbit.actors.runtime
 
ActorTaskContext() - Constructor for class cloud.orbit.actors.runtime.ActorTaskContext
 
addFirst(String, Handler) - Method in interface cloud.orbit.actors.net.Pipeline
 
addHandlerAfter(String, String, Handler) - Method in interface cloud.orbit.actors.net.Pipeline
 
addHandlerBefore(String, String, Handler) - Method in interface cloud.orbit.actors.net.Pipeline
 
addLast(String, Handler) - Method in interface cloud.orbit.actors.net.Pipeline
 
addObserver(T) - Method in class cloud.orbit.actors.ObserverManager
Ensures that this collection contains the specified observer.
Addressable - Interface in cloud.orbit.actors
Common interface for actor and observer references used internally by the framework.
afterInvoke(long, Object, Method, Object[], Map<?, ?>) - Method in interface cloud.orbit.actors.extensions.InvocationHandlerExtension
Called after an invocation is performed.
afterInvokeChain(long, Object, Method, Object[], Map<?, ?>) - Method in interface cloud.orbit.actors.extensions.InvocationHandlerExtension
Called after an invocation chain has completed.
asMap() - Method in interface cloud.orbit.actors.runtime.ActorState
 
asUUID() - Method in interface cloud.orbit.actors.cluster.NodeAddress
 
asUUID() - Method in class cloud.orbit.actors.cluster.NodeAddressImpl
 
AsyncObserver<T> - Interface in cloud.orbit.actors.streams
 
AsyncStream<T> - Interface in cloud.orbit.actors.streams
 
AsyncStreamReference<T> - Class in cloud.orbit.actors.runtime
Indirection to allow streams to be send from one node to another.
AsyncStreamReference() - Constructor for class cloud.orbit.actors.runtime.AsyncStreamReference
 
AsyncStreamReference(String, Class<T>, String) - Constructor for class cloud.orbit.actors.runtime.AsyncStreamReference
 
AsyncStreamReference(String, Class<T>, String, AsyncStream<T>) - Constructor for class cloud.orbit.actors.runtime.AsyncStreamReference
 

B

BasicRuntime - Interface in cloud.orbit.actors.runtime
Interface used by the generated code to interact with the orbit actors runtime.
beforeInvoke(long, Object, Method, Object[], Map<?, ?>) - Method in interface cloud.orbit.actors.extensions.InvocationHandlerExtension
Called before an invocation is performed.
bind() - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
bind() - Method in interface cloud.orbit.actors.runtime.BasicRuntime
 

C

CacheResponse - Annotation Type in cloud.orbit.actors.annotation
Caches responses from annotated Actor methods.
canActivate(String) - Method in interface cloud.orbit.actors.runtime.NodeCapabilities
Asked a single time or infrequently to find out if this node knows and is able to serve this kind of actor.
cast(Class<T>, Actor) - Static method in interface cloud.orbit.actors.Actor
 
cast(Class<T>, Actor) - Static method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
ClassId - Annotation Type in cloud.orbit.actors.annotation
Defines a fixed value for the classId
ClassIdGenerationStrategy - Interface in cloud.orbit.actors.reflection
 
ClassIdStrategy - Annotation Type in cloud.orbit.actors.annotation
 
ClassPathSearch - Class in cloud.orbit.actors.runtime
Internal class to locate interface implementations.
ClassPathSearch(Class<?>...) - Constructor for class cloud.orbit.actors.runtime.ClassPathSearch
 
cleanup() - Method in class cloud.orbit.actors.ObserverManager
Pings all observers and removes the ones that no longer exist or that return an exception.
cleanup() - Method in class cloud.orbit.actors.ObserverMapManager
 
cleanup() - Method in interface cloud.orbit.actors.runtime.RemoteClient
 
clear() - Method in class cloud.orbit.actors.ObserverManager
Remove all observers
clearState(RemoteReference<?>, Object) - Method in interface cloud.orbit.actors.extensions.StorageExtension
Asynchronously clears an actors state.
clearState() - Method in class cloud.orbit.actors.runtime.AbstractActor
Asynchronously clears the actor's state.
ClientObject - Interface in cloud.orbit.actors
 
clock() - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Gets the local clock.
clone(T) - Method in interface cloud.orbit.actors.cloner.ExecutionObjectCloner
 
cloneContext() - Method in class cloud.orbit.actors.runtime.ActorTaskContext
 
close(HandlerContext) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
close(HandlerContext) - Method in interface cloud.orbit.actors.net.Handler
 
close(HandlerContext) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
close() - Method in interface cloud.orbit.actors.net.HandlerContext
 
close() - Method in interface cloud.orbit.actors.net.Pipeline
 
cloud.orbit.actors - package cloud.orbit.actors
 
cloud.orbit.actors.annotation - package cloud.orbit.actors.annotation
 
cloud.orbit.actors.annotation.processor - package cloud.orbit.actors.annotation.processor
 
cloud.orbit.actors.cache - package cloud.orbit.actors.cache
 
cloud.orbit.actors.cloner - package cloud.orbit.actors.cloner
 
cloud.orbit.actors.cluster - package cloud.orbit.actors.cluster
 
cloud.orbit.actors.concurrent - package cloud.orbit.actors.concurrent
 
cloud.orbit.actors.extensions - package cloud.orbit.actors.extensions
 
cloud.orbit.actors.net - package cloud.orbit.actors.net
 
cloud.orbit.actors.peer - package cloud.orbit.actors.peer
 
cloud.orbit.actors.reflection - package cloud.orbit.actors.reflection
 
cloud.orbit.actors.runtime - package cloud.orbit.actors.runtime
 
cloud.orbit.actors.streams - package cloud.orbit.actors.streams
 
cloud.orbit.actors.util - package cloud.orbit.actors.util
 
ClusterPeer - Interface in cloud.orbit.actors.cluster
Represents a node connection to a cluster of orbit actor nodes.
connect(HandlerContext, Object) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
connect(HandlerContext, Object) - Method in interface cloud.orbit.actors.net.Handler
 
connect(HandlerContext, Object) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
connect(Object) - Method in interface cloud.orbit.actors.net.HandlerContext
 
connect(Object) - Method in interface cloud.orbit.actors.net.Pipeline
 
containsKey(K) - Method in class cloud.orbit.actors.ObserverMapManager
 
createDefaultState() - Method in class cloud.orbit.actors.runtime.AbstractActor
Creates a default state representation for this actor
createReference(String) - Method in class cloud.orbit.actors.runtime.ReferenceFactory
 
current() - Static method in class cloud.orbit.actors.runtime.ActorTaskContext
 
currentActor() - Static method in class cloud.orbit.actors.runtime.ActorTaskContext
 
currentFor(Thread) - Static method in class cloud.orbit.actors.runtime.ActorTaskContext
Finds out what task context is active in a certain thread.

D

deactivate(Actor) - Static method in interface cloud.orbit.actors.Actor
Requests the deactivation of an actor
deactivateActor(Actor) - Method in interface cloud.orbit.actors.runtime.RuntimeActions
 
deactivateAsync() - Method in class cloud.orbit.actors.runtime.AbstractActor
Called by the framework when deactivating the actor.
DEFAULT_PROVIDER - Static variable in interface cloud.orbit.actors.streams.AsyncStream
 
DefaultClassDictionary - Class in cloud.orbit.actors.runtime
 
DefaultDescriptorFactory - Class in cloud.orbit.actors.runtime
 
DescriptorFactory - Interface in cloud.orbit.actors.runtime
 
deserializeMessage(BasicRuntime, byte[]) - Method in interface cloud.orbit.actors.extensions.MessageSerializer
 
disconnect(HandlerContext) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
disconnect(HandlerContext) - Method in interface cloud.orbit.actors.net.Handler
 
disconnect(HandlerContext) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
disconnect() - Method in interface cloud.orbit.actors.net.HandlerContext
 
disconnect() - Method in interface cloud.orbit.actors.net.Pipeline
 
dispose() - Method in interface cloud.orbit.actors.runtime.Registration
 
DistributedMap<K,V> - Interface in cloud.orbit.actors.cluster
 

E

equals(Object) - Method in class cloud.orbit.actors.cluster.NodeAddressImpl
 
equals(Object) - Method in class cloud.orbit.actors.runtime.RemoteReference
 
executeSerialized(Supplier<Task<R>>, int) - Method in interface cloud.orbit.actors.concurrent.ExecutionSerializer
 
ExecutionCacheFlushManager - Class in cloud.orbit.actors.cache
 
ExecutionCacheFlushManager() - Constructor for class cloud.orbit.actors.cache.ExecutionCacheFlushManager
 
ExecutionCacheFlushObserver - Interface in cloud.orbit.actors.cache
 
ExecutionObjectCloner - Interface in cloud.orbit.actors.cloner
Used by Execution to clone objects
ExecutionSerializer - Interface in cloud.orbit.actors.concurrent
 
ExplicitClassIdStrategy - Class in cloud.orbit.actors.reflection
 
ExplicitClassIdStrategy() - Constructor for class cloud.orbit.actors.reflection.ExplicitClassIdStrategy
 

F

findActorImplementation(Class<T>) - Method in interface cloud.orbit.actors.extensions.ActorClassFinder
 
findActorInterfaces(Predicate<Class<T>>) - Method in interface cloud.orbit.actors.extensions.ActorClassFinder
 
findImplementation(Class<T>) - Method in class cloud.orbit.actors.runtime.ClassPathSearch
 
findImplementation(Class<T>, int) - Method in class cloud.orbit.actors.runtime.ClassPathSearch
 
fireActive() - Method in interface cloud.orbit.actors.net.HandlerContext
 
fireEventTriggered(Object) - Method in interface cloud.orbit.actors.net.HandlerContext
 
fireExceptionCaught(Throwable) - Method in interface cloud.orbit.actors.net.HandlerContext
 
fireInactive() - Method in interface cloud.orbit.actors.net.HandlerContext
 
fireRead(Object) - Method in interface cloud.orbit.actors.net.HandlerContext
 
flush(Actor) - Method in interface cloud.orbit.actors.cache.ExecutionCacheFlushObserver
 
flushAll(Actor) - Static method in class cloud.orbit.actors.cache.ExecutionCacheFlushManager
 
flushWithoutWaiting(Actor) - Method in interface cloud.orbit.actors.cache.ExecutionCacheFlushObserver
 
forEach(BiConsumer<K, V>) - Method in class cloud.orbit.actors.ObserverMapManager
 
from(AbstractActor) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 
from(Actor) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 

G

generateIdForClass(Annotation, String) - Method in interface cloud.orbit.actors.reflection.ClassIdGenerationStrategy
 
generateIdForClass(Annotation, String) - Method in class cloud.orbit.actors.reflection.ExplicitClassIdStrategy
 
generateIdForField(Annotation, String) - Method in interface cloud.orbit.actors.reflection.ClassIdGenerationStrategy
 
generateIdForField(Annotation, String) - Method in class cloud.orbit.actors.reflection.ExplicitClassIdStrategy
 
generateIdForMethod(Annotation, String) - Method in interface cloud.orbit.actors.reflection.ClassIdGenerationStrategy
 
generateIdForMethod(Annotation, String) - Method in class cloud.orbit.actors.reflection.ExplicitClassIdStrategy
 
get(K) - Method in interface cloud.orbit.actors.cluster.DistributedMap
 
get(Method, Pair<Addressable, String>) - Method in interface cloud.orbit.actors.extensions.ResponseCachingExtension
 
get(K) - Method in class cloud.orbit.actors.ObserverMapManager
 
get() - Static method in class cloud.orbit.actors.runtime.DefaultClassDictionary
 
get() - Static method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
getActive() - Method in class cloud.orbit.actors.runtime.NodeInfo
 
getActor() - Method in class cloud.orbit.actors.runtime.ActorTaskContext
 
getActorCount() - Method in interface cloud.orbit.actors.runtime.RuntimeActions
 
getActorRuntime() - Static method in class cloud.orbit.actors.runtime.RuntimeBinder
Gets the current runtime, first looking at a thread local, then at a global variable that contains the lasted runtime created
getAddress() - Method in class cloud.orbit.actors.runtime.NodeInfo
 
getAddress(RemoteReference<?>) - Static method in class cloud.orbit.actors.runtime.RemoteReference
Utility method used by the framework and framework extensions to retrieve the target node address for this reference.
getAfterHandlerName() - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
getAfterHandlerName() - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
getAllExtensions(Class<T>) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getAllNodes() - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getBasicRuntime() - Static method in class cloud.orbit.actors.runtime.RuntimeBinder
Gets the current runtime, first looking at a thread local, then at a global variable that contains the lasted runtime created
getBeforeHandlerName() - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
getBeforeHandlerName() - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
getCache(String) - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Gets a reference to a distributed cache
getClassById(int) - Method in class cloud.orbit.actors.runtime.DefaultClassDictionary
 
getClassById(int, boolean) - Method in class cloud.orbit.actors.runtime.DefaultClassDictionary
 
getClassId(Class<?>) - Method in class cloud.orbit.actors.runtime.DefaultClassDictionary
 
getClusterActorCount() - Static method in interface cloud.orbit.actors.Actor
Requests the global actor count across the cluster.
getCurrentTickTime() - Method in class cloud.orbit.actors.runtime.TickStatus
 
getExtendedProperty(String) - Method in interface cloud.orbit.actors.runtime.ActorState
Sets an extended property not initially defined in the actor state.
getExtensions() - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getFactory(Class<T>) - Method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
getFactoryFor(Class<T>) - Method in class cloud.orbit.actors.runtime.ActorFactoryGenerator
 
getFirstExtension(Class<T>) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getFirstTickTime() - Method in class cloud.orbit.actors.runtime.TickStatus
 
getFromNode() - Method in class cloud.orbit.actors.runtime.Message
 
getHeader(String) - Method in class cloud.orbit.actors.runtime.Message
 
getHeaders() - Method in class cloud.orbit.actors.runtime.Message
 
getId(RemoteReference<?>) - Static method in class cloud.orbit.actors.runtime.RemoteReference
Utility method used by the framework and framework extensions to retrieve the object from the references.
getId(AbstractActor) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 
getIdentity(Actor) - Static method in interface cloud.orbit.actors.Actor
Gets a the id of an actor reference or instance.
getIdentity() - Method in interface cloud.orbit.actors.Actor
Gets a the id of the current actor reference or instance.
getIdentity(RemoteReference<?>) - Method in class cloud.orbit.actors.extensions.AbstractStorageExtension
 
getInterface() - Method in class cloud.orbit.actors.runtime.ObjectInvoker
 
getInterface() - Method in class cloud.orbit.actors.runtime.ReferenceFactory
 
getInterfaceClass(RemoteReference<R>) - Static method in class cloud.orbit.actors.runtime.RemoteReference
Utility method used by the framework and framework extensions to retrieve the Actor or ActorObserver interface implemented by this reference.
getInterfaceClass(AbstractActor) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 
getInterfaceId() - Method in class cloud.orbit.actors.runtime.Message
 
getInterfaceId() - Method in class cloud.orbit.actors.runtime.ReferenceFactory
 
getInterfaceId(RemoteReference<?>) - Static method in class cloud.orbit.actors.runtime.RemoteReference
Utility method used by the framework and framework extensions to retrieve the integer identifier of the Actor or ActorObserver interface implemented by this reference.
getInvoker(Class) - Method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
getInvoker(int) - Method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
getInvoker(Class) - Method in interface cloud.orbit.actors.runtime.DescriptorFactory
 
getInvoker(int) - Method in interface cloud.orbit.actors.runtime.DescriptorFactory
 
getInvoker() - Method in class cloud.orbit.actors.runtime.ReferenceFactory
 
getInvokerFor(Class<?>) - Method in class cloud.orbit.actors.runtime.ActorFactoryGenerator
 
getLocalAddress() - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Gets the current node address in the cluster.
getLogger(Object) - Method in interface cloud.orbit.actors.extensions.LoggerExtension
 
getLogger() - Method in class cloud.orbit.actors.runtime.AbstractActor
The recommended way to log from an actor.
getLogger(String) - Method in class cloud.orbit.actors.runtime.AbstractActor
Deprecated.
get the runtime and ask for a logger instead.
getLogger(Object) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
 
getMessageId() - Method in class cloud.orbit.actors.runtime.Message
 
getMessageType() - Method in class cloud.orbit.actors.runtime.Message
 
getMethod(int) - Method in class cloud.orbit.actors.runtime.ObjectInvoker
 
getMethodId(Method) - Method in class cloud.orbit.actors.runtime.ActorFactoryGenerator
 
getMethodId() - Method in class cloud.orbit.actors.runtime.Message
 
getName() - Method in class cloud.orbit.actors.extensions.AbstractStorageExtension
 
getName() - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
getName() - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
getName() - Method in interface cloud.orbit.actors.extensions.StorageExtension
Returns this storage provider name.
getName() - Method in interface cloud.orbit.actors.extensions.StreamProvider
 
getObjectId() - Method in class cloud.orbit.actors.runtime.Message
 
getObserverReference(NodeAddress, Class<T>, String) - Static method in interface cloud.orbit.actors.ActorObserver
Gets a reference to a remote observer.
getPayload() - Method in class cloud.orbit.actors.runtime.Message
 
getPeriod() - Method in class cloud.orbit.actors.runtime.TickStatus
 
getPlacementGroup() - Method in interface cloud.orbit.actors.runtime.NodeCapabilities
 
getReference(Class<T>, String) - Static method in interface cloud.orbit.actors.Actor
Gets a reference to an actor.
getReference(Class<T>) - Static method in interface cloud.orbit.actors.Actor
Gets a reference to an actor that has the NoIdentity annotation.
getReference(Class<T>, Object) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Returns an actor reference
getReference(BasicRuntime, NodeAddress, Class<T>, Object) - Method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
getReference(BasicRuntime, NodeAddress, Class<T>, Object) - Method in interface cloud.orbit.actors.runtime.DescriptorFactory
 
getReference(NodeAddress, Class<T>, Object) - Method in interface cloud.orbit.actors.runtime.DescriptorFactory
 
getReference(Class<T>, Object) - Method in interface cloud.orbit.actors.runtime.DescriptorFactory
 
getReferenceAddress() - Method in class cloud.orbit.actors.runtime.Message
 
getRemoteObserverReference(NodeAddress, Class<T>, Object) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Returns an observer reference to an observer in another node.
getRuntime() - Method in interface cloud.orbit.actors.net.HandlerContext
 
getRuntime() - Static method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getRuntime() - Method in class cloud.orbit.actors.runtime.ActorTaskContext
 
getRuntime() - Static method in interface cloud.orbit.actors.runtime.BasicRuntime
 
getRuntime(RemoteReference<?>) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 
getStateClass() - Method in class cloud.orbit.actors.runtime.AbstractActor
 
getStream(Class<T>, String) - Method in interface cloud.orbit.actors.extensions.StreamProvider
 
getStream(String, Class<T>, String) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
 
getStream(Class<T>, String) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
 
getStream(Class<DATA>, String) - Static method in interface cloud.orbit.actors.streams.AsyncStream
 
getStream(Class<DATA>, String, String) - Static method in interface cloud.orbit.actors.streams.AsyncStream
 
getStreamProvider(String) - Method in class cloud.orbit.actors.runtime.AbstractActor
 
getStreamProvider(String) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
 
getSupportedSourceVersion() - Method in class cloud.orbit.actors.annotation.processor.Processor
 
getToNode() - Method in class cloud.orbit.actors.runtime.Message
 

H

Handler - Interface in cloud.orbit.actors.net
 
HandlerAdapter - Class in cloud.orbit.actors.net
 
HandlerAdapter() - Constructor for class cloud.orbit.actors.net.HandlerAdapter
 
HandlerContext - Interface in cloud.orbit.actors.net
 
hashCode() - Method in class cloud.orbit.actors.cluster.NodeAddressImpl
 
hashCode() - Method in class cloud.orbit.actors.runtime.RemoteReference
 

I

IdUtils - Class in cloud.orbit.actors.util
 
IdUtils() - Constructor for class cloud.orbit.actors.util.IdUtils
 
Immutable - Annotation Type in cloud.orbit.actors.annotation
Defines whether an object is considered immutable and can be excluded from being cloned.
init(ProcessingEnvironment) - Method in class cloud.orbit.actors.annotation.processor.Processor
 
InvocationHandlerExtension - Interface in cloud.orbit.actors.extensions
 
invoke(RemoteReference, Method, boolean, int, Object[]) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Handles calls to actor reference methods.
invoke(T, int, Object[]) - Method in class cloud.orbit.actors.runtime.ObjectInvoker
 
invoke(Method, boolean, int, Object[]) - Method in class cloud.orbit.actors.runtime.RemoteReference
Invokes a remote method.
invokeEvent(String, Object[]) - Method in interface cloud.orbit.actors.runtime.ActorState
Invoke state event used for event sourced states
isActive() - Method in interface cloud.orbit.actors.net.Pipeline
 
isBusy() - Method in interface cloud.orbit.actors.concurrent.ExecutionSerializer
Checks if the executor is currently running any tasks.
isBusy() - Method in interface cloud.orbit.actors.concurrent.MultiExecutionSerializer
 
isEmpty() - Method in class cloud.orbit.actors.ObserverManager
Returns whether any observers are registered with this manager.

J

join(String, String) - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Joins a cluster

L

leave() - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Leaves the cluster.
LifetimeExtension - Interface in cloud.orbit.actors.extensions
Listener the actor activation/deactivation process.
localAddress() - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Gets the cluster address of the local node represented by this peer.
locateActor(Addressable, boolean) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Locates the node address of an actor.
logger - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
LoggerExtension - Interface in cloud.orbit.actors.extensions
 

M

makeStateClass(Class<? extends AbstractActor>) - Static method in class cloud.orbit.actors.runtime.ActorFactoryGenerator
 
Message - Class in cloud.orbit.actors.runtime
Represents a message being sent between orbit servers.
Message() - Constructor for class cloud.orbit.actors.runtime.Message
 
MessageDefinitions - Class in cloud.orbit.actors.runtime
 
MessageDefinitions() - Constructor for class cloud.orbit.actors.runtime.MessageDefinitions
 
MessageListener - Interface in cloud.orbit.actors.cluster
Callback for receiving cluster messages.
MessageListener - Interface in cloud.orbit.actors.net
 
MessageSerializer - Interface in cloud.orbit.actors.extensions
Extension interface to define how actor messages are serialized.
moved(RemoteReference<?>, NodeAddress, NodeAddress) - Method in interface cloud.orbit.actors.runtime.NodeCapabilities
 
MultiExecutionSerializer<T> - Interface in cloud.orbit.actors.concurrent
Ensures that only a single task is executed at each time per key.

N

name - Variable in class cloud.orbit.actors.extensions.AbstractStorageExtension
 
NamedPipelineExtension - Class in cloud.orbit.actors.extensions
 
NamedPipelineExtension() - Constructor for class cloud.orbit.actors.extensions.NamedPipelineExtension
 
NamedPipelineExtension(String) - Constructor for class cloud.orbit.actors.extensions.NamedPipelineExtension
 
NamedPipelineExtension(String, String, String) - Constructor for class cloud.orbit.actors.extensions.NamedPipelineExtension
 
NeverDeactivate - Annotation Type in cloud.orbit.actors.annotation
 
newInstance(Class<T>) - Method in interface cloud.orbit.actors.extensions.ActorConstructionExtension
Called to construct actor.
NO_IDENTITY - Static variable in annotation type cloud.orbit.actors.annotation.NoIdentity
 
NodeAddress - Interface in cloud.orbit.actors.cluster
Generic representation of a node address.
NodeAddressImpl - Class in cloud.orbit.actors.cluster
The actual implementation of INodeAddress.
NodeAddressImpl(UUID) - Constructor for class cloud.orbit.actors.cluster.NodeAddressImpl
 
NodeCapabilities - Interface in cloud.orbit.actors.runtime
 
NodeCapabilities.NodeState - Enum in cloud.orbit.actors.runtime
 
NodeCapabilities.NodeTypeEnum - Enum in cloud.orbit.actors.runtime
 
NodeInfo - Class in cloud.orbit.actors.runtime
 
NodeInfo(NodeAddress) - Constructor for class cloud.orbit.actors.runtime.NodeInfo
 
nodeModeChanged(NodeAddress, NodeCapabilities.NodeState) - Method in interface cloud.orbit.actors.runtime.NodeCapabilities
 
NodeSelectorExtension - Interface in cloud.orbit.actors.extensions
 
NoIdentity - Annotation Type in cloud.orbit.actors.annotation
Actor interfaces marked with NoIdentity do not have an identity.
notifyObservers(Consumer<T>) - Method in class cloud.orbit.actors.ObserverManager
Used to notify the observers (call some method of their remote interface)
notifyObservers(Consumer<V>) - Method in class cloud.orbit.actors.ObserverMapManager
Used to notify the observers (call some method of their remote interface)
notifyObservers(BiConsumer<K, V>) - Method in class cloud.orbit.actors.ObserverMapManager
Used to notify the observers (call some method of their remote interface)

O

ObjectInvoker<T> - Class in cloud.orbit.actors.runtime
 
ObjectInvoker() - Constructor for class cloud.orbit.actors.runtime.ObjectInvoker
 
ObserverManager<T extends ActorObserver> - Class in cloud.orbit.actors
ObserverManager is an optional thread safe collection that can be used by actors which need to call observers.
ObserverManager() - Constructor for class cloud.orbit.actors.ObserverManager
 
ObserverMapManager<K,V extends ActorObserver> - Class in cloud.orbit.actors
ObserverMapManager is an optional thread safe "map" that can be used by actors which need to verify if an ActorObserver associated to another object eg.
ObserverMapManager() - Constructor for class cloud.orbit.actors.ObserverMapManager
 
observerRef(NodeAddress, Class<T>, String) - Static method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
offerJob(T, Supplier<Task<R>>, int) - Method in interface cloud.orbit.actors.concurrent.MultiExecutionSerializer
Only accepts if the queue size is not exceeded.
onActive(HandlerContext) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onActive(HandlerContext) - Method in interface cloud.orbit.actors.net.Handler
 
onActive(HandlerContext) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
ONE_WAY_MESSAGE - Static variable in class cloud.orbit.actors.runtime.MessageDefinitions
 
onError(Exception) - Method in interface cloud.orbit.actors.streams.AsyncObserver
 
onEventTriggered(HandlerContext, Object) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onEventTriggered(HandlerContext, Object) - Method in interface cloud.orbit.actors.net.Handler
 
onEventTriggered(HandlerContext, Object) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
OneWay - Annotation Type in cloud.orbit.actors.annotation
Actor methods annotated with OneWay will not message back the invocation result.
onExceptionCaught(HandlerContext, Throwable) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onExceptionCaught(HandlerContext, Throwable) - Method in interface cloud.orbit.actors.net.Handler
 
onExceptionCaught(HandlerContext, Throwable) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
onInactive(HandlerContext) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onInactive(HandlerContext) - Method in interface cloud.orbit.actors.net.Handler
 
onInactive(HandlerContext) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
OnlyIfActivated - Annotation Type in cloud.orbit.actors.annotation
 
onNext(T, StreamSequenceToken) - Method in interface cloud.orbit.actors.streams.AsyncObserver
 
onRead(HandlerContext, Object) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onRead(HandlerContext, Object) - Method in interface cloud.orbit.actors.net.Handler
 
onRead(HandlerContext, Object) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
onRegistered(HandlerContext) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
onRegistered(HandlerContext) - Method in interface cloud.orbit.actors.net.Handler
 
onRegistered(HandlerContext) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
onViewChange(Collection<NodeAddress>) - Method in interface cloud.orbit.actors.cluster.ViewListener
 

P

PeerExtension - Interface in cloud.orbit.actors.peer
 
ping() - Method in interface cloud.orbit.actors.ActorObserver
Allows the application to verify if the observer is still alive.
Pipeline - Interface in cloud.orbit.actors.net
This is an implementation of the chain of responsibility pattern for the orbit message pipeline.
PipelineExtension - Interface in cloud.orbit.actors.extensions
Listener to extend the message pipeline.
postActivation(AbstractActor<?>) - Method in interface cloud.orbit.actors.extensions.LifetimeExtension
Called immediately after invoking the actors activation.
postDeactivation(AbstractActor<?>) - Method in interface cloud.orbit.actors.extensions.LifetimeExtension
Called immediately after invoking the actors deactivation code.
preActivation(AbstractActor<?>) - Method in interface cloud.orbit.actors.extensions.LifetimeExtension
Called immediately before invoking the actors activation.
preDeactivation(AbstractActor<?>) - Method in interface cloud.orbit.actors.extensions.LifetimeExtension
Called immediately before invoking the actors deactivation code.
PreferLocalPlacement - Annotation Type in cloud.orbit.actors.annotation
 
process(Set<? extends TypeElement>, RoundEnvironment) - Method in class cloud.orbit.actors.annotation.processor.Processor
 
Processor - Class in cloud.orbit.actors.annotation.processor
Annotation processor to write class info for ActorObservers and Actors This info speeds up classId lookup.
Processor() - Constructor for class cloud.orbit.actors.annotation.processor.Processor
 
publish(T) - Method in class cloud.orbit.actors.runtime.AsyncStreamReference
 
publish(T) - Method in interface cloud.orbit.actors.streams.AsyncStream
 
pulse() - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Pulses with the stage pulse
pushNew() - Static method in class cloud.orbit.actors.runtime.ActorTaskContext
Creates a new actor task context and pushes it to the current thread context stack.
put(K, V) - Method in interface cloud.orbit.actors.cluster.DistributedMap
 
put(Method, Pair<Addressable, String>, Task<?>) - Method in interface cloud.orbit.actors.extensions.ResponseCachingExtension
 
put(K, V) - Method in class cloud.orbit.actors.ObserverMapManager
 
putAll(Map<String, Object>) - Method in interface cloud.orbit.actors.runtime.ActorState
Updates the actor state
putIfAbsent(K, V) - Method in interface cloud.orbit.actors.cluster.DistributedMap
 

R

readState(RemoteReference<?>, Object) - Method in interface cloud.orbit.actors.extensions.StorageExtension
Asynchronously reads an actors state.
readState() - Method in class cloud.orbit.actors.runtime.AbstractActor
Asynchronously reads the actor's state.
receive(NodeAddress, byte[]) - Method in interface cloud.orbit.actors.cluster.MessageListener
Called when a cluster message is received.
receiveReminder(String, TickStatus) - Method in interface cloud.orbit.actors.Remindable
Receive reminder will be called by the reminder subsystem.
recvMessage(Message) - Method in interface cloud.orbit.actors.net.MessageListener
 
Reentrant - Annotation Type in cloud.orbit.actors.annotation
By default, the Orbit execution serializer requires an activation to completely finish processing one request before invoking the next request.
ref(int, String) - Static method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
ref(Class<T>, String) - Static method in class cloud.orbit.actors.runtime.DefaultDescriptorFactory
 
reference - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
ReferenceFactory<T> - Class in cloud.orbit.actors.runtime
 
ReferenceFactory() - Constructor for class cloud.orbit.actors.runtime.ReferenceFactory
 
registerMessageReceiver(MessageListener) - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Registers a listener that will be called every time a cluster message is received.
registerObserver(Class<T>, T) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Installs this observer into this node.
registerObserver(Class<T>, String, T) - Method in interface cloud.orbit.actors.runtime.BasicRuntime
Installs this observer into this node.
registerReminder(String, long, long, TimeUnit) - Method in class cloud.orbit.actors.runtime.AbstractActor
Registers or updated a persisted reminder.
registerReminder(Remindable, String, long, long, TimeUnit) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Registers or updated a persisted reminder.
registerTimer(Callable<Task<?>>, long, long, TimeUnit) - Method in class cloud.orbit.actors.runtime.AbstractActor
Registers a timer for the current actor.
registerTimer(Callable<Task<?>>, long, TimeUnit) - Method in class cloud.orbit.actors.runtime.AbstractActor
Registers a single shot timer for the current actor.
registerTimer(AbstractActor<?>, Callable<Task<?>>, long, long, TimeUnit) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Registers a timer for the orbit actor
registerViewListener(ViewListener) - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Registers a callback that will be invoked every time the set of cluster nodes changed.
Registration - Interface in cloud.orbit.actors.runtime
 
Remindable - Interface in cloud.orbit.actors
Actors that register reminders must implement the interface Remindable.
RemoteClient - Interface in cloud.orbit.actors.runtime
 
RemoteReference<T> - Class in cloud.orbit.actors.runtime
Base class for Actor or ActorObserver references.
RemoteReference(Object) - Constructor for class cloud.orbit.actors.runtime.RemoteReference
Actor reference constructor called by subclasses.
remove(K, V) - Method in interface cloud.orbit.actors.cluster.DistributedMap
 
remove(K) - Method in class cloud.orbit.actors.ObserverMapManager
 
remove(RemoteReference<?>) - Method in interface cloud.orbit.actors.runtime.NodeCapabilities
 
removeObserver(T) - Method in class cloud.orbit.actors.ObserverManager
Remove one observer
REQUEST_MESSAGE - Static variable in class cloud.orbit.actors.runtime.MessageDefinitions
 
RESPONSE_ERROR - Static variable in class cloud.orbit.actors.runtime.MessageDefinitions
 
RESPONSE_OK - Static variable in class cloud.orbit.actors.runtime.MessageDefinitions
 
RESPONSE_PROTOCOL_ERROR - Static variable in class cloud.orbit.actors.runtime.MessageDefinitions
 
ResponseCachingExtension - Interface in cloud.orbit.actors.extensions
 
runtime - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
RuntimeActions - Interface in cloud.orbit.actors.runtime
 
RuntimeBinder - Class in cloud.orbit.actors.runtime
Utility class to get the current ActorRuntime.
runtimeIdentity() - Method in class cloud.orbit.actors.runtime.AbstractActor
Gets a string that represents uniquely the node that currently holds this actor.
runtimeIdentity() - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Gets a string that represents uniquely the node that currently holds this actor.

S

safeInvoke(T, int, Object[]) - Method in class cloud.orbit.actors.runtime.ObjectInvoker
Safely invokes a method, no exceptions ever thrown, and the returned Task is always non null.
select(String, NodeAddress, List<NodeInfo>) - Method in interface cloud.orbit.actors.extensions.NodeSelectorExtension
 
sendMessage(NodeAddress, byte[]) - Method in interface cloud.orbit.actors.cluster.ClusterPeer
Sends a message to other cluster node.
sequentialLongId() - Static method in class cloud.orbit.actors.util.IdUtils
Returns long id unique for this jvm instance.
serializeMessage(BasicRuntime, Message) - Method in interface cloud.orbit.actors.extensions.MessageSerializer
 
setAddress(RemoteReference<?>, NodeAddress) - Static method in class cloud.orbit.actors.runtime.RemoteReference
Utility method used by the framework and framework extensions to set the target node address for this reference.
setAfterHandlerName(String) - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
setBeforeHandlerName(String) - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
setExtendedProperty(String, Object) - Method in interface cloud.orbit.actors.runtime.ActorState
Sets an extended property not initially defined in the actor state.
setFromNode(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
setHeader(String, Object) - Method in class cloud.orbit.actors.runtime.Message
 
setHeaders(Map<String, Object>) - Method in class cloud.orbit.actors.runtime.Message
 
setInterfaceId(int) - Method in class cloud.orbit.actors.runtime.Message
 
setMessageId(int) - Method in class cloud.orbit.actors.runtime.Message
 
setMessageType(int) - Method in class cloud.orbit.actors.runtime.Message
 
setMethodId(int) - Method in class cloud.orbit.actors.runtime.Message
 
setName(String) - Method in class cloud.orbit.actors.extensions.AbstractStorageExtension
 
setName(String) - Method in class cloud.orbit.actors.extensions.NamedPipelineExtension
 
setObjectId(Object) - Method in class cloud.orbit.actors.runtime.Message
 
setPayload(Object) - Method in class cloud.orbit.actors.runtime.Message
 
setReferenceAddress(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
setRuntime(WeakReference<ActorRuntime>) - Static method in interface cloud.orbit.actors.runtime.ActorRuntime
Sets a static reference to the last created runtime.
setRuntime(WeakReference<? extends BasicRuntime>) - Static method in interface cloud.orbit.actors.runtime.BasicRuntime
Sets a static reference to the last created runtime.
setRuntime(RemoteReference<?>, BasicRuntime) - Static method in class cloud.orbit.actors.runtime.RemoteReference
 
setRuntime(WeakReference<? extends BasicRuntime>) - Static method in class cloud.orbit.actors.runtime.RuntimeBinder
Sets the runtime associated with the current thread.
setToNode(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
shutdown() - Method in interface cloud.orbit.actors.concurrent.MultiExecutionSerializer
 
size() - Method in class cloud.orbit.actors.ObserverMapManager
 
SkipUpdateLastAccess - Annotation Type in cloud.orbit.actors.annotation
Actor implementation methods may be marked with the SkipUpdateLastAccess annotation to indicate that the last access timestamp will not be updated thus potentially allowing the actor to deactivate sooner.
state - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
state() - Method in class cloud.orbit.actors.runtime.AbstractActor
The current actor's persistable state.
stateExtension - Variable in class cloud.orbit.actors.runtime.AbstractActor
 
StatelessWorker - Annotation Type in cloud.orbit.actors.annotation
Actor interfaces marked with @StatelessWorker will handle concurrent execution by creating multiple instances (activations) of that actor.
StorageExtension - Annotation Type in cloud.orbit.actors.annotation
 
StorageExtension - Interface in cloud.orbit.actors.extensions
Storage extensions are used by the orbit actors framework to load and store actor states.
stream() - Method in class cloud.orbit.actors.ObserverManager
Returns a sequential Stream with this collection as its source.
stream() - Method in class cloud.orbit.actors.ObserverMapManager
 
StreamProvider - Interface in cloud.orbit.actors.extensions
 
StreamSequenceToken - Interface in cloud.orbit.actors.streams
Represents a position in the stream sequence.
StreamSubscriptionHandle<T> - Interface in cloud.orbit.actors.streams
 
subscribe(AsyncObserver<T>, StreamSequenceToken) - Method in class cloud.orbit.actors.runtime.AsyncStreamReference
 
subscribe(AsyncObserver<T>) - Method in interface cloud.orbit.actors.streams.AsyncStream
 
subscribe(AsyncObserver<T>, StreamSequenceToken) - Method in interface cloud.orbit.actors.streams.AsyncStream
 

T

TickStatus - Class in cloud.orbit.actors.runtime
The current status of the reminder when it's called.
TickStatus(long, long, long) - Constructor for class cloud.orbit.actors.runtime.TickStatus
 
Timeout - Annotation Type in cloud.orbit.actors.annotation
Defines a custom timeout for the given actor method that will be used instead of the configured responseTimeoutMillis.
TimeToLive - Annotation Type in cloud.orbit.actors.annotation
Defines a custom time to live for the given actor that will be used instead of the configured defaultActorTTL.
toString() - Method in class cloud.orbit.actors.cluster.NodeAddressImpl
 
toString() - Method in class cloud.orbit.actors.runtime.Message
 
toString() - Method in class cloud.orbit.actors.runtime.RemoteReference
 

U

unregisterReminder(String) - Method in class cloud.orbit.actors.runtime.AbstractActor
Removes a previously registered reminder.
unregisterReminder(Remindable, String) - Method in interface cloud.orbit.actors.runtime.ActorRuntime
Removes a previously registered reminder.
unsubscribe(StreamSubscriptionHandle<T>) - Method in class cloud.orbit.actors.runtime.AsyncStreamReference
 
unsubscribe(StreamSubscriptionHandle<T>) - Method in interface cloud.orbit.actors.streams.AsyncStream
 
urlSafeString(int) - Static method in class cloud.orbit.actors.util.IdUtils
Generate a string using base64 url safe characters with numBits bits.

V

valueOf(String) - Static method in enum cloud.orbit.actors.runtime.NodeCapabilities.NodeState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum cloud.orbit.actors.runtime.NodeCapabilities.NodeTypeEnum
Returns the enum constant of this type with the specified name.
values() - Static method in enum cloud.orbit.actors.runtime.NodeCapabilities.NodeState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum cloud.orbit.actors.runtime.NodeCapabilities.NodeTypeEnum
Returns an array containing the constants of this enum type, in the order they are declared.
ViewListener - Interface in cloud.orbit.actors.cluster
 

W

withFromNode(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
withHeader(String, Object) - Method in class cloud.orbit.actors.runtime.Message
 
withHeaders(Map<String, Object>) - Method in class cloud.orbit.actors.runtime.Message
 
withInterfaceId(int) - Method in class cloud.orbit.actors.runtime.Message
 
withMessageId(int) - Method in class cloud.orbit.actors.runtime.Message
 
withMessageType(int) - Method in class cloud.orbit.actors.runtime.Message
 
withMethodId(int) - Method in class cloud.orbit.actors.runtime.Message
 
withObjectId(Object) - Method in class cloud.orbit.actors.runtime.Message
 
withPayload(Object) - Method in class cloud.orbit.actors.runtime.Message
 
withReferenceAddress(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
withToNode(NodeAddress) - Method in class cloud.orbit.actors.runtime.Message
 
write(HandlerContext, Object) - Method in interface cloud.orbit.actors.extensions.PipelineExtension
 
write(HandlerContext, Object) - Method in interface cloud.orbit.actors.net.Handler
 
write(HandlerContext, Object) - Method in class cloud.orbit.actors.net.HandlerAdapter
 
write(Object) - Method in interface cloud.orbit.actors.net.HandlerContext
 
write(Object) - Method in interface cloud.orbit.actors.net.Pipeline
 
writeState(RemoteReference<?>, Object) - Method in interface cloud.orbit.actors.extensions.StorageExtension
Asynchronously writes an actors state.
writeState() - Method in class cloud.orbit.actors.runtime.AbstractActor
Asynchronously writes the actor's state.

_

_interfaceClass() - Method in class cloud.orbit.actors.runtime.RemoteReference
Implemented by subclasses to return the actor or actor observer interface implemented by this reference.
_interfaceId() - Method in class cloud.orbit.actors.runtime.RemoteReference
Implemented by subclasses to return the interface id.
A B C D E F G H I J L M N O P R S T U V W _ 
Skip navigation links

Copyright © 2019 Electronic Arts Inc. All rights reserved.