Index

A B C D E F G H I J K L M N O P R S T U V W Y 
All Classes and Interfaces|All Packages|Serialized Form

A

Accumulator - Interface in com.scivicslab.pojoactor.core.accumulator
Interface for accumulating results from multiple sources.
AccumulatorFactory - Class in com.scivicslab.pojoactor.workflow.accumulator
Factory for creating Accumulator instances and actors.
AccumulatorFactory() - Constructor for class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorFactory
 
AccumulatorIIAR - Class in com.scivicslab.pojoactor.workflow.accumulator
Interpreter-interfaced actor reference for Accumulator implementations.
AccumulatorIIAR(String, Accumulator, IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorIIAR
Constructs a new AccumulatorIIAR.
AccumulatorResult<T> - Record Class in com.scivicslab.pojoactor.core.accumulator
A result entry in an accumulator.
AccumulatorResult(String, T, Instant) - Constructor for record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Creates an instance of a AccumulatorResult record class.
action() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Executes the actions in the current row of the workflow matrix.
Action - Class in com.scivicslab.pojoactor.workflow
Represents a single action in a workflow transition.
Action() - Constructor for class com.scivicslab.pojoactor.workflow.Action
Constructs an empty Action.
Action(String, String, Object) - Constructor for class com.scivicslab.pojoactor.workflow.Action
Constructs an Action with specified parameters.
Action Methods: - Search tag in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Section
ActionResult - Class in com.scivicslab.pojoactor.core
Represents the result of executing an action on an actor.
ActionResult(boolean, String) - Constructor for class com.scivicslab.pojoactor.core.ActionResult
Constructs a new ActionResult.
ActorMessage - Class in com.scivicslab.pojoactor.core.distributed
Message protocol for distributed actor invocation.
ActorMessage(String, String, String) - Constructor for class com.scivicslab.pojoactor.core.distributed.ActorMessage
Constructs a new ActorMessage without reply address.
ActorMessage(String, String, String, String, String) - Constructor for class com.scivicslab.pojoactor.core.distributed.ActorMessage
Constructs a new ActorMessage with specified parameters.
actorName - Variable in class com.scivicslab.pojoactor.core.ActorRef
 
actorOf(String, T) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Creates a new actor with the specified name and object.
ActorProvider - Interface in com.scivicslab.pojoactor.core
Service provider interface for plugin-based actor registration.
ActorRef<T> - Class in com.scivicslab.pojoactor.core
A reference to an actor that provides messaging capabilities and lifecycle management.
ActorRef(String, T) - Constructor for class com.scivicslab.pojoactor.core.ActorRef
Constructs an ActorRef with the specified name and object.
ActorRef(String, T, ActorSystem) - Constructor for class com.scivicslab.pojoactor.core.ActorRef
Constructs an ActorRef with the specified name, object, and actor system.
actors - Variable in class com.scivicslab.pojoactor.core.ActorSystem
A name to an ActorRef correspondance.
actorSystem - Variable in class com.scivicslab.pojoactor.core.ActorRef
 
ActorSystem - Class in com.scivicslab.pojoactor.core
A lightweight actor system implementation that manages actor lifecycles and thread pools.
ActorSystem(String) - Constructor for class com.scivicslab.pojoactor.core.ActorSystem
Constructs an ActorSystem with the specified name and default thread pool.
ActorSystem(String, int) - Constructor for class com.scivicslab.pojoactor.core.ActorSystem
Constructs an ActorSystem with the specified name and thread count.
ActorSystem.Builder - Class in com.scivicslab.pojoactor.core
Builder class for creating ActorSystem instances with custom configurations.
add(String, String, String) - Method in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Adds a result to this accumulator.
add(String, String, String) - Method in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
 
add(String, String, String) - Method in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
 
add(String, String, String) - Method in class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
 
add(String, String, String) - Method in class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
 
addActor(ActorRef<T>) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Add the directly generated Actor to the ActorSystem.
addActor(ActorRef<T>, String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Add the directly generated Actor to the ActorSystem while changing the name used within the ActorSystem.
addActor(String, ActorRef<T>) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Deprecated.
addIIActor(IIActorRef<T>) - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Adds an interpreter-interfaced actor to this system.
addToAccumulator(String, String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Adds a result to the accumulator actor in the system.
addToAccumulator(String, String, String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Adds a result to a named accumulator actor in the system.
addWorkStealingPool(int) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Adds a new work stealing pool to the actor system.
apply(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Applies an action to existing child actors (with wildcard support).
Architecture - Search tag in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Section
ask(Function<T, R>) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to actor and returns a CompletableFuture to be completed with the response value.
ask(Function<T, R>, ExecutorService) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to this actor and returns a response using a specific executor service.
askNow(Function<T, R>) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to the actor and returns a response, bypassing the mailbox and executing immediately.
autoDetect() - Static method in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Automatically detects the execution environment and returns an appropriate NodeDiscovery implementation.
autoDetect(int) - Static method in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Automatically detects the execution environment and returns an appropriate NodeDiscovery implementation with specified port.
awaitTermination(long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 

B

Basic Usage - Search tag in class com.scivicslab.pojoactor.core.DynamicActorLoader
Section
BufferedAccumulator - Class in com.scivicslab.pojoactor.core.accumulator
An accumulator that buffers results and outputs them on getSummary().
BufferedAccumulator() - Constructor for class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
 
BufferedAccumulator.ResultEntry - Record Class in com.scivicslab.pojoactor.core.accumulator
A single result entry.
build() - Method in class com.scivicslab.pojoactor.core.ActorSystem.Builder
Builds and returns a new ActorSystem instance.
build() - Method in class com.scivicslab.pojoactor.workflow.Interpreter.Builder
Builds and returns a new Interpreter instance.
build(Path) - Method in class com.scivicslab.pojoactor.workflow.kustomize.WorkflowKustomizer
Builds the customized workflows from the specified directory.
buildAsYaml(Path) - Method in class com.scivicslab.pojoactor.workflow.kustomize.WorkflowKustomizer
Builds the customized workflows and returns them as a YAML string.
Builder() - Constructor for class com.scivicslab.pojoactor.workflow.Interpreter.Builder
Constructs a new Builder.
Builder(String) - Constructor for class com.scivicslab.pojoactor.core.ActorSystem.Builder
Constructs a new Builder with the specified system name.

C

call(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Calls a subworkflow by creating a child interpreter, executing it, and removing it.
CallableByActionName - Interface in com.scivicslab.pojoactor.core
Interface for actors that can be invoked dynamically by action name strings.
callByActionName(String, String) - Method in interface com.scivicslab.pojoactor.core.CallableByActionName
Executes an action identified by its name with the given arguments.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Invokes an action on the remote actor.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Invokes an action on the scheduler by name with the given arguments.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorIIAR
 
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.DynamicActorLoaderActor
 
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.IIActorRef
Executes an action identified by its name with the given arguments.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.InterpreterIIAR
Invokes an action on the interpreter by name with the given arguments.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Executes actions by name.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.scheduler.SchedulerIIAR
Invokes an action on the scheduler by name with the given arguments.
callByActionName(String, String) - Method in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Executes actions by name.
cancelJobsForActor(String) - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Cancels all pending jobs for a specific actor.
cancelJobsForActor(String) - Method in interface com.scivicslab.pojoactor.core.WorkerPool
Cancels all pending jobs for a specific actor.
cancelTask(String) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Cancels a scheduled task.
clear() - Method in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Clears all accumulated results.
clear() - Method in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
 
clear() - Method in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
 
clear() - Method in class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
 
clear() - Method in class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
 
clearPendingMessages() - Method in class com.scivicslab.pojoactor.core.ActorRef
Clears all pending messages from this actor's message queue and WorkStealingPool.
close() - Method in class com.scivicslab.pojoactor.core.ActorRef
Destroys the actor and cleans up its resources.
close() - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Shuts down the scheduler and cancels all scheduled tasks.
code - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
 
com.scivicslab.pojoactor.core - package com.scivicslab.pojoactor.core
 
com.scivicslab.pojoactor.core.accumulator - package com.scivicslab.pojoactor.core.accumulator
 
com.scivicslab.pojoactor.core.distributed - package com.scivicslab.pojoactor.core.distributed
 
com.scivicslab.pojoactor.core.distributed.discovery - package com.scivicslab.pojoactor.core.distributed.discovery
 
com.scivicslab.pojoactor.core.scheduler - package com.scivicslab.pojoactor.core.scheduler
 
com.scivicslab.pojoactor.pojo - package com.scivicslab.pojoactor.pojo
 
com.scivicslab.pojoactor.workflow - package com.scivicslab.pojoactor.workflow
 
com.scivicslab.pojoactor.workflow.accumulator - package com.scivicslab.pojoactor.workflow.accumulator
 
com.scivicslab.pojoactor.workflow.distributed - package com.scivicslab.pojoactor.workflow.distributed
 
com.scivicslab.pojoactor.workflow.kustomize - package com.scivicslab.pojoactor.workflow.kustomize
 
com.scivicslab.pojoactor.workflow.scheduler - package com.scivicslab.pojoactor.workflow.scheduler
 
Comparison with Reflection Approach - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
Comparison with SubWorkflowCaller: - Search tag in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Section
ControllableWorkStealingPool - Class in com.scivicslab.pojoactor.core
A controllable thread pool executor that supports actor-level job management.
ControllableWorkStealingPool(int) - Constructor for class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Creates a ControllableWorkStealingPool with the specified parallelism level.
create(String) - Static method in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorFactory
Creates an Accumulator instance of the specified type.
createActor(String, IIActorSystem) - Static method in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorFactory
Creates an AccumulatorIIAR with the default name "accumulator" and registers it.
createActor(String, String, IIActorSystem) - Static method in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorFactory
Creates an AccumulatorIIAR and registers it with the actor system.
createChild(String, K) - Method in class com.scivicslab.pojoactor.core.ActorRef
Creates a child actor under this actor's supervision.
createDistributedSystem() - Static method in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Creates a DistributedActorSystem with default port 8080.
createDistributedSystem(int) - Static method in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Creates a DistributedActorSystem with automatic node discovery and registration.
currentState - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
 
currentVertexIndex - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
 

D

data() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns the value of the data record component.
Design Philosophy - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
DIRECT - Enum constant in enum class com.scivicslab.pojoactor.workflow.ExecutionMode
Execute action as direct synchronous call.
DistributedActorSystem - Class in com.scivicslab.pojoactor.workflow.distributed
Distributed actor system with HTTP-based inter-node communication.
DistributedActorSystem(String, int) - Constructor for class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Constructs a new DistributedActorSystem listening on all interfaces.
DistributedActorSystem(String, String, int) - Constructor for class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Constructs a new DistributedActorSystem.
Distributed System Support - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
DynamicActorLoader - Class in com.scivicslab.pojoactor.core
Dynamic actor loader for runtime-extensible actor system.
DynamicActorLoader() - Constructor for class com.scivicslab.pojoactor.core.DynamicActorLoader
 
DynamicActorLoaderActor - Class in com.scivicslab.pojoactor.workflow
Generic actor that dynamically loads and creates other actors from plugins.
DynamicActorLoaderActor(IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.DynamicActorLoaderActor
Constructs a new DynamicActorLoaderActor.

E

equals(Object) - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
 
Example Output - Search tag in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
Section
Example Output - Search tag in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
Section
Example Output - Search tag in class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
Section
Example Output - Search tag in class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
Section
Example Workflow Usage - Search tag in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorIIAR
Section
execCode() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Executes the loaded workflow code.
execute(Runnable) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
ExecutionMode - Enum Class in com.scivicslab.pojoactor.workflow
Execution mode for workflow actions.

F

Features - Search tag in class com.scivicslab.pojoactor.core.DynamicActorLoader
Section
findMatchingActors(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Finds all actors in the system matching a wildcard pattern.
findMatchingChildActors(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Finds child actors matching a wildcard pattern.
findNextMatchingVertex() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Finds the first step whose from-state pattern matches the current state.
ForkJoinPoolWrapper - Class in com.scivicslab.pojoactor.core
A WorkerPool implementation that wraps ForkJoinPool (work-stealing executor).
ForkJoinPoolWrapper() - Constructor for class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
Creates a ForkJoinPoolWrapper with default parallelism.
ForkJoinPoolWrapper(int) - Constructor for class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
Creates a ForkJoinPoolWrapper with specified parallelism.
fromJson(String) - Static method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Deserializes an ActorMessage from JSON string.
fromString(String) - Static method in enum class com.scivicslab.pojoactor.workflow.ExecutionMode
Parses execution mode from string (case-insensitive).

G

generateChildName(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Generates a unique child actor name for subworkflow execution.
getActionName() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Returns the action name to invoke.
getActions() - Method in class com.scivicslab.pojoactor.workflow.Vertex
Returns the list of Action objects for this vertex.
getActor() - Method in class com.scivicslab.pojoactor.workflow.Action
Gets the actor name.
getActor(String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Retrieves an actor by name.
getActorName() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Returns the target actor name.
getActorName() - Method in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Returns the name of the remote actor.
getAddress() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Returns the network address in "host:port" format.
getAllNodes() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
 
getAllNodes() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
 
getAllNodes() - Method in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Returns information about all nodes in the cluster.
getAllNodes() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
 
getApiVersion() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the API version.
getArgs() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Returns the action arguments.
getArguments() - Method in class com.scivicslab.pojoactor.workflow.Action
Gets the arguments (String, List, or Map).
getBases() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the list of base directories.
getCallCount() - Method in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Returns the number of successful sub-workflow calls.
getCallCount() - Method in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Returns the number of successful sub-workflow calls.
getCode() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Returns the currently loaded workflow code.
getCommonLabels() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the common labels map.
getCount() - Method in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Returns the number of results that have been added.
getCount() - Method in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
 
getCount() - Method in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
 
getCount() - Method in class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
 
getCount() - Method in class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
 
getCurrentState() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Gets the current state of the interpreter.
getCurrentVertexIndex() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Gets the current step index.
getExecution() - Method in class com.scivicslab.pojoactor.workflow.Action
Gets the execution mode.
getHost() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Returns the hostname or IP address.
getHost() - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Returns the hostname for this system.
getIIActor(String) - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Retrieves an interpreter-interfaced actor by name.
getIIActorCount() - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Returns the number of interpreter-interfaced actors in this system.
getKind() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the kind.
getLogger() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Gets the current logger instance.
getMessageId() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Returns the unique message identifier.
getMethod() - Method in class com.scivicslab.pojoactor.workflow.Action
Gets the method name.
getMyHost() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
 
getMyHost() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
 
getMyHost() - Method in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Returns the hostname or IP address for the current node.
getMyHost() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
 
getMyNodeId() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
 
getMyNodeId() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
 
getMyNodeId() - Method in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Returns the unique identifier for the current node.
getMyNodeId() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
 
getMyPort() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
 
getMyPort() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
 
getMyPort() - Method in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Returns the default port number for actor communication.
getMyPort() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
 
getName() - Method in class com.scivicslab.pojoactor.core.ActorRef
Returns the name of this actor.
getName() - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Returns the name of this workflow.
getNamePrefix() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the name prefix.
getNamesOfChildren() - Method in class com.scivicslab.pojoactor.core.ActorRef
Returns the names of all child actors supervised by this actor.
getNameSuffix() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the name suffix.
getNodeId() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Returns the node identifier.
getNodeId() - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Returns the node identifier for this system.
getNodeInfo() - Method in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Returns information about the node hosting this actor.
getParentName() - Method in class com.scivicslab.pojoactor.core.ActorRef
Returns the name of this actor's parent, if any.
getPatch() - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Gets the patch file name.
getPatches() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the list of patch entries.
getPatchFile() - Method in exception class com.scivicslab.pojoactor.workflow.kustomize.OrphanVertexException
Gets the patch file name.
getPendingJobCountForActor(String) - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Gets the number of pending jobs for a specific actor.
getPendingJobCountForActor(String) - Method in interface com.scivicslab.pojoactor.core.WorkerPool
Gets the number of pending jobs for a specific actor.
getPluginName() - Method in interface com.scivicslab.pojoactor.core.ActorProvider
Returns the name of this plugin.
getPluginVersion() - Method in interface com.scivicslab.pojoactor.core.ActorProvider
Returns the version of this plugin.
getPoolIndex() - Method in class com.scivicslab.pojoactor.workflow.Action
Gets the pool index.
getPort() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Returns the HTTP port number.
getPort() - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Returns the HTTP port for this system.
getRemoteActor(String, String) - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Gets a remote actor reference.
getReplyTo() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Returns the reply address.
getResult() - Method in class com.scivicslab.pojoactor.core.ActionResult
Returns the result message or data.
getResults() - Method in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
Returns an unmodifiable list of all result entries.
getResultsAsJson() - Method in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
Returns the results as a JSONObject.
getScheduledTaskCount() - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Returns the number of currently scheduled tasks.
getStates() - Method in class com.scivicslab.pojoactor.workflow.Vertex
Returns the list of states for this vertex.
getSteps() - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Deprecated.
getSummary() - Method in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Returns a formatted summary of all accumulated results.
getSummary() - Method in class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator
 
getSummary() - Method in class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
 
getSummary() - Method in class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
 
getSummary() - Method in class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
 
getTarget() - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Gets the target workflow file name.
getToState(Vertex) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Gets the to-state from a vertex.
getTrackedActorCount() - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Gets the total number of actors currently tracked.
getUrl() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Returns the base URL for this node.
getVars() - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Gets the variable substitution map.
getVertexName() - Method in exception class com.scivicslab.pojoactor.workflow.kustomize.OrphanVertexException
Gets the name of the orphan vertex.
getVertexName() - Method in class com.scivicslab.pojoactor.workflow.Vertex
Returns the vertex name.
getVertices() - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Returns the workflow vertices.
getWorkflowBaseDir() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Gets the base directory for resolving relative workflow file paths.
getWorkStealingPool() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Returns the default work stealing pool of the actor system.
getWorkStealingPool(int) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Returns a work stealing pool at the specified index.
GridEngineNodeDiscovery - Class in com.scivicslab.pojoactor.core.distributed.discovery
Node discovery implementation for Grid Engine (SGE/UGE/OGE).
GridEngineNodeDiscovery() - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
Constructs a GridEngineNodeDiscovery with default port 8080.
GridEngineNodeDiscovery(int) - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
Constructs a GridEngineNodeDiscovery with specified port.
Grid Engine Script Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
Section

H

hasActor(String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Checks if an actor with the specified name exists in the system.
hasCodeLoaded() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Checks if workflow code is loaded.
hashCode() - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Returns a hash code value for this object.
hashCode() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns a hash code value for this object.
hashCode() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
 
hasIIActor(String) - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Checks if an interpreter-interfaced actor with the given name exists.
hasTarget() - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Checks if this patch entry has a specific target.
hello() - Method in class com.scivicslab.pojoactor.pojo.Root
Returns a greeting message from the root actor.
Helper Method - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Section

I

IIActorRef<T> - Class in com.scivicslab.pojoactor.workflow
An interpreter-interfaced actor reference that can be invoked by action name strings.
IIActorRef(String, T) - Constructor for class com.scivicslab.pojoactor.workflow.IIActorRef
Constructs a new IIActorRef with the specified actor name and object.
IIActorRef(String, T, IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.IIActorRef
Constructs a new IIActorRef with the specified actor name, object, and actor system.
IIActorSystem - Class in com.scivicslab.pojoactor.workflow
Interpreter-interfaced actor system for managing workflow actors.
IIActorSystem(String) - Constructor for class com.scivicslab.pojoactor.workflow.IIActorSystem
Constructs a new IIActorSystem with the specified system name.
IIActorSystem(String, int) - Constructor for class com.scivicslab.pojoactor.workflow.IIActorSystem
Constructs a new IIActorSystem with the specified system name and thread count.
Implementation Notes: - Search tag in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Section
initLogger(String) - Method in class com.scivicslab.pojoactor.core.ActorRef
Initializes the logger with the specified name.
initLogger(String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Initializes the system logger with the specified name.
Interpreter - Class in com.scivicslab.pojoactor.workflow
Workflow interpreter that executes matrix-based workflow definitions.
Interpreter() - Constructor for class com.scivicslab.pojoactor.workflow.Interpreter
 
Interpreter.Builder - Class in com.scivicslab.pojoactor.workflow
Builder for constructing Interpreter instances.
InterpreterIIAR - Class in com.scivicslab.pojoactor.workflow
Interpreter-interfaced actor reference for Interpreter instances.
InterpreterIIAR(String, Interpreter) - Constructor for class com.scivicslab.pojoactor.workflow.InterpreterIIAR
Constructs a new InterpreterIIAR with the specified actor name and interpreter object.
InterpreterIIAR(String, Interpreter, IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.InterpreterIIAR
Constructs a new InterpreterIIAR with the specified actor name, interpreter object, and actor system.
invokeAll(Collection<? extends Callable<T>>) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
isAlive() - Method in class com.scivicslab.pojoactor.core.ActorRef
Checks if this actor is still alive and able to process messages.
isAlive() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Checks if the actor system is alive (no thread pools are shut down).
isAlive(String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Checks if a specific actor is alive.
isApplicable() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
 
isApplicable() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
 
isApplicable() - Method in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Checks if this discovery implementation is applicable to the current environment.
isApplicable() - Method in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
 
isScheduled(String) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Checks if a task with the given ID is currently scheduled.
isShutdown() - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
isSuccess() - Method in class com.scivicslab.pojoactor.core.ActionResult
Returns whether the action completed successfully.
isTerminated() - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 

J

JsonAccumulator - Class in com.scivicslab.pojoactor.core.accumulator
An accumulator that outputs results in JSON format.
JsonAccumulator() - Constructor for class com.scivicslab.pojoactor.core.accumulator.JsonAccumulator
 

K

K8sNodeDiscovery - Class in com.scivicslab.pojoactor.core.distributed.discovery
Node discovery implementation for Kubernetes StatefulSets.
K8sNodeDiscovery() - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
Constructs a K8sNodeDiscovery with default port 8080 and default namespace.
K8sNodeDiscovery(int, String) - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
Constructs a K8sNodeDiscovery with specified port and namespace.
Key Features: - Search tag in class com.scivicslab.pojoactor.workflow.kustomize.WorkflowKustomizer
Section
Kubernetes Configuration Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
Section

L

Lifecycle: - Search tag in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Section
listActorNames() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Returns a list of all actor names in the system.
listActorNames() - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Returns the names of all interpreter-interfaced actors in this system.
loadActor(Path, String, String) - Static method in class com.scivicslab.pojoactor.core.DynamicActorLoader
Loads a class from an external JAR file and wraps it as an ActorRef.
loadActorIntoSystem(ActorSystem, Path, String, String) - Static method in class com.scivicslab.pojoactor.core.DynamicActorLoader
Loads a class from an external JAR file and wraps it as an ActorRef, registering it with the given ActorSystem.
loadWorkflowFromClasspath(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Loads a workflow from the classpath.
logger - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
 
loggerName(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter.Builder
Sets the logger name for this interpreter.

M

matchesCurrentState(Vertex) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Checks if a vertex's from-state matches the current state.
matchesStatePattern(String, String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Checks if a state pattern matches a given state value.
MatrixCode - Class in com.scivicslab.pojoactor.workflow
Represents a matrix-based workflow definition.
MatrixCode() - Constructor for class com.scivicslab.pojoactor.workflow.MatrixCode
Constructs an empty MatrixCode.
Message Format - Search tag in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Section

N

Network Protocol - Search tag in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Section
NodeDiscovery - Interface in com.scivicslab.pojoactor.core.distributed.discovery
Interface for node discovery in distributed actor systems.
NodeDiscoveryFactory - Class in com.scivicslab.pojoactor.core.distributed.discovery
Factory for automatic node discovery based on runtime environment.
NodeInfo - Class in com.scivicslab.pojoactor.core.distributed
Information about a node in the distributed actor system.
NodeInfo(String, String, int) - Constructor for class com.scivicslab.pojoactor.core.distributed.NodeInfo
Constructs a new NodeInfo with specified parameters.

O

object - Variable in class com.scivicslab.pojoactor.core.ActorRef
 
onEnterVertex(Vertex) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Hook method called when entering a vertex during workflow execution.
OrphanVertexException - Exception Class in com.scivicslab.pojoactor.workflow.kustomize
Exception thrown when a patch contains a new vertex without an anchor.
OrphanVertexException(String, String) - Constructor for exception class com.scivicslab.pojoactor.workflow.kustomize.OrphanVertexException
Constructs a new OrphanVertexException.
OverlayConf - Class in com.scivicslab.pojoactor.workflow.kustomize
Represents an overlay-conf.yaml configuration file.
OverlayConf() - Constructor for class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
 

P

PatchEntry - Class in com.scivicslab.pojoactor.workflow.kustomize
Represents a patch entry in overlay-conf.yaml.
PatchEntry() - Constructor for class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Default constructor for YAML deserialization.
PatchEntry(String) - Constructor for class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Constructs a PatchEntry with just a patch file (no specific target).
PatchEntry(String, String) - Constructor for class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Constructs a PatchEntry with both target and patch.
Performance Considerations: - Search tag in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Section
POOL - Enum constant in enum class com.scivicslab.pojoactor.workflow.ExecutionMode
Execute action on work-stealing pool thread.

R

readJson(InputStream) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Reads and parses a workflow definition from a JSON input stream.
readXml(InputStream) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Reads and parses a workflow definition from an XML input stream.
readYaml(InputStream) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Reads and parses a workflow definition from a YAML input stream.
readYaml(Path) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Reads and parses a workflow definition from a YAML file.
readYaml(Path, Path) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Reads and parses a workflow definition from a YAML file with overlay applied.
registerActors(ActorSystem) - Method in interface com.scivicslab.pojoactor.core.ActorProvider
Registers actors provided by this plugin into the given ActorSystem.
registerRemoteNode(String, String, int) - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Registers a remote node in the node registry.
RemoteActorRef - Class in com.scivicslab.pojoactor.core.distributed
Reference to an actor hosted on a remote node.
RemoteActorRef(String, NodeInfo) - Constructor for class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Constructs a new RemoteActorRef.
removeActor(String) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Removes an actor from the system.
removeChildActor(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Removes a child actor from the system and parent-child relationship.
removeIIActor(String) - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Removes an interpreter-interfaced actor from this system.
Requirements - Search tag in class com.scivicslab.pojoactor.core.DynamicActorLoader
Section
reset() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Resets the interpreter to its initial state.
resolveActorPath(String, String) - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Resolves an actor path relative to a given actor using Unix-style path notation.
result() - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Returns the value of the result record component.
ResultEntry(String, String, String, Instant) - Constructor for record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Creates an instance of a ResultEntry record class.
ReusableSubWorkflowCaller - Class in com.scivicslab.pojoactor.workflow
Reusable sub-workflow caller that reuses a single Interpreter instance.
ReusableSubWorkflowCaller(IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Constructs a new ReusableSubWorkflowCaller.
root() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Deprecated.
Use ActorSystem.getActor(String) with "ROOT" instead
Root - Class in com.scivicslab.pojoactor.pojo
The root actor class that serves as the top-level actor in the system hierarchy.
Root() - Constructor for class com.scivicslab.pojoactor.pojo.Root
 
runUntilEnd() - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Executes the workflow until reaching the "end" state.
runUntilEnd(int) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Executes the workflow until reaching the "end" state with a custom iteration limit.
runWorkflow(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Loads and runs a workflow file to completion.
runWorkflow(String, int) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Loads and runs a workflow file to completion with custom iteration limit.

S

scheduleAtFixedRate(String, String, String, String, long, long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Schedules a task to execute periodically at a fixed rate.
scheduleOnce(String, String, String, String, long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Schedules a task to execute once after a specified delay.
Scheduler - Class in com.scivicslab.pojoactor.core.scheduler
A scheduler for periodic task execution in an actor system.
Scheduler(ActorSystem) - Constructor for class com.scivicslab.pojoactor.core.scheduler.Scheduler
Constructs a new Scheduler with the specified actor system.
Scheduler(ActorSystem, int) - Constructor for class com.scivicslab.pojoactor.core.scheduler.Scheduler
Constructs a new Scheduler with the specified actor system and thread pool size.
SchedulerIIAR - Class in com.scivicslab.pojoactor.workflow.scheduler
Interpreter-interfaced actor reference for Scheduler instances.
SchedulerIIAR(String, Scheduler) - Constructor for class com.scivicslab.pojoactor.workflow.scheduler.SchedulerIIAR
Constructs a new SchedulerIIAR with the specified actor name and scheduler object.
SchedulerIIAR(String, Scheduler, IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.scheduler.SchedulerIIAR
Constructs a new SchedulerIIAR with the specified actor name, scheduler object, and actor system.
scheduleWithFixedDelay(String, String, String, String, long, long, TimeUnit) - Method in class com.scivicslab.pojoactor.core.scheduler.Scheduler
Schedules a task to execute periodically with a fixed delay between executions.
selfActorRef - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
Reference to the actor executing this interpreter (for Unix-style path resolution).
setActions(List<Action>) - Method in class com.scivicslab.pojoactor.workflow.Vertex
Sets the list of actions for this vertex.
setActor(String) - Method in class com.scivicslab.pojoactor.workflow.Action
Sets the actor name.
setApiVersion(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the API version.
setArguments(Object) - Method in class com.scivicslab.pojoactor.workflow.Action
Sets the arguments (String, List, or Map).
setBases(List<String>) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the list of base directories.
setCode(MatrixCode) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Sets the workflow code directly (for testing purposes).
setCommonLabels(Map<String, String>) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the common labels map.
setExecution(ExecutionMode) - Method in class com.scivicslab.pojoactor.workflow.Action
Sets the execution mode.
setKind(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the kind.
setLogger(Logger) - Method in class com.scivicslab.pojoactor.core.ActorSystem
Sets the logger for the actor system.
setMethod(String) - Method in class com.scivicslab.pojoactor.workflow.Action
Sets the method name.
setName(String) - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Sets the name of this workflow.
setNamePrefix(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the name prefix.
setNameSuffix(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the name suffix.
setParentName(String) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sets the parent name for this actor.
setPatch(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Sets the patch file name.
setPatches(List<PatchEntry>) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the list of patch entries.
setPoolIndex(int) - Method in class com.scivicslab.pojoactor.workflow.Action
Sets the pool index.
setSelfActorRef(IIActorRef<?>) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Sets the reference to the actor executing this interpreter.
setStates(List<String>) - Method in class com.scivicslab.pojoactor.workflow.Vertex
Sets the list of states for this vertex.
setSteps(List<Vertex>) - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Deprecated.
setTarget(String) - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
Sets the target workflow file name.
setVars(Map<String, String>) - Method in class com.scivicslab.pojoactor.workflow.kustomize.OverlayConf
Sets the variable substitution map.
setVertexName(String) - Method in class com.scivicslab.pojoactor.workflow.Vertex
Sets the vertex name.
setVertices(List<Vertex>) - Method in class com.scivicslab.pojoactor.workflow.MatrixCode
Sets the workflow vertices.
setWorkflowBaseDir(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Sets the base directory for resolving relative workflow file paths.
shutdown() - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
shutdownNow() - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
Simple Plugin - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
SlurmNodeDiscovery - Class in com.scivicslab.pojoactor.core.distributed.discovery
Node discovery implementation for Slurm workload manager.
SlurmNodeDiscovery() - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
Constructs a SlurmNodeDiscovery with default port 8080.
SlurmNodeDiscovery(int) - Constructor for class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
Constructs a SlurmNodeDiscovery with specified port.
source() - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Returns the value of the source record component.
source() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns the value of the source record component.
Standard Implementations - Search tag in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Section
StreamingAccumulator - Class in com.scivicslab.pojoactor.core.accumulator
An accumulator that outputs results immediately as they are added.
StreamingAccumulator() - Constructor for class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
Constructs a StreamingAccumulator with default settings.
StreamingAccumulator(PrintStream, String) - Constructor for class com.scivicslab.pojoactor.core.accumulator.StreamingAccumulator
Constructs a StreamingAccumulator with custom output and format.
submit(Runnable) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
submit(Runnable, T) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
submit(Callable<T>) - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
submitForActor(String, Runnable) - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Submits a task associated with a specific actor.
submitUrgentForActor(String, Runnable) - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
Submits an urgent task to the front of the queue.
SubWorkflowCaller - Class in com.scivicslab.pojoactor.workflow
General-purpose sub-workflow caller actor.
SubWorkflowCaller(IIActorSystem) - Constructor for class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Constructs a new SubWorkflowCaller.
Supported Actions - Search tag in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorIIAR
Section
Supported Environments - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Section
supportsCancellation() - Method in class com.scivicslab.pojoactor.core.ControllableWorkStealingPool
 
supportsCancellation() - Method in class com.scivicslab.pojoactor.core.ForkJoinPoolWrapper
 
supportsCancellation() - Method in interface com.scivicslab.pojoactor.core.WorkerPool
Checks if this worker pool supports job cancellation per actor.
system - Variable in class com.scivicslab.pojoactor.workflow.DynamicActorLoaderActor
 
system - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
 
system() - Method in class com.scivicslab.pojoactor.core.ActorRef
Returns the actor system this actor belongs to.
systemName - Variable in class com.scivicslab.pojoactor.core.ActorSystem
 

T

TableAccumulator - Class in com.scivicslab.pojoactor.core.accumulator
An accumulator that formats results as a table.
TableAccumulator() - Constructor for class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
Constructs a TableAccumulator with default column width of 30 characters.
TableAccumulator(int) - Constructor for class com.scivicslab.pojoactor.core.accumulator.TableAccumulator
Constructs a TableAccumulator with custom column width.
team(IIActorSystem) - Method in class com.scivicslab.pojoactor.workflow.Interpreter.Builder
Sets the actor system for this interpreter.
tell(Consumer<T>) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to the actor defined by this reference.
tell(Consumer<T>, ExecutorService) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to this actor using a specific executor service.
tellNow(Consumer<T>) - Method in class com.scivicslab.pojoactor.core.ActorRef
Sends a message to the actor for immediate execution, bypassing the normal message queue.
terminate() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Terminates the actor system by closing all actors and shutting down thread pools.
terminate() - Method in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Terminates this actor system and stops the HTTP server.
terminateIIActors() - Method in class com.scivicslab.pojoactor.workflow.IIActorSystem
Terminates all interpreter-interfaced actors managed by this system.
threadNum(int) - Method in class com.scivicslab.pojoactor.core.ActorSystem.Builder
Sets the number of threads for the actor system.
Thread Safety: - Search tag in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Section
timestamp() - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Returns the value of the timestamp record component.
timestamp() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns the value of the timestamp record component.
toJson() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Serializes this message to JSON string.
toString() - Method in record class com.scivicslab.pojoactor.core.accumulator.AccumulatorResult
Returns a string representation of this record class.
toString() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns a string representation of this record class.
toString() - Method in class com.scivicslab.pojoactor.core.ActionResult
 
toString() - Method in class com.scivicslab.pojoactor.core.ActorSystem
Returns a string representation of the actor system.
toString() - Method in class com.scivicslab.pojoactor.core.distributed.ActorMessage
 
toString() - Method in class com.scivicslab.pojoactor.core.distributed.NodeInfo
 
toString() - Method in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
 
toString() - Method in class com.scivicslab.pojoactor.workflow.kustomize.PatchEntry
 
toYamlString(int) - Method in class com.scivicslab.pojoactor.workflow.Vertex
Returns a YAML-formatted string representation of this vertex.
transformToGraph(File, File) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow file to HTML graph view.
transformToGraph(InputStream, OutputStream) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow input stream to HTML graph view.
transformToGraphString(File) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow file to HTML graph view and returns as String.
transformToGraphString(InputStream) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow input stream to HTML graph view and returns as String.
transformToTable(File, File) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow file to HTML table view.
transformToTable(InputStream, OutputStream) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow input stream to HTML table view.
transformToTableString(File) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow file to HTML table view and returns as String.
transformToTableString(InputStream) - Static method in class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
Transforms an XML workflow input stream to HTML table view and returns as String.
transitionTo(String) - Method in class com.scivicslab.pojoactor.workflow.Interpreter
Transitions to a new state and finds the next matching row.
type() - Method in record class com.scivicslab.pojoactor.core.accumulator.BufferedAccumulator.ResultEntry
Returns the value of the type record component.

U

Usage: - Search tag in class com.scivicslab.pojoactor.workflow.kustomize.WorkflowKustomizer
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.ActionResult
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.ActorMessage
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.NodeInfo
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.RemoteActorRef
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.GridEngineNodeDiscovery
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.K8sNodeDiscovery
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscoveryFactory
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.core.distributed.discovery.SlurmNodeDiscovery
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.workflow.accumulator.AccumulatorFactory
Section
Usage Example - Search tag in class com.scivicslab.pojoactor.workflow.distributed.DistributedActorSystem
Section
Usage Example - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
Usage Example - Search tag in interface com.scivicslab.pojoactor.core.distributed.discovery.NodeDiscovery
Section
Usage Example: - Search tag in class com.scivicslab.pojoactor.workflow.ReusableSubWorkflowCaller
Section
Usage Example: - Search tag in class com.scivicslab.pojoactor.workflow.SubWorkflowCaller
Section
Usage in Application - Search tag in interface com.scivicslab.pojoactor.core.ActorProvider
Section
Usage in Plugin - Search tag in interface com.scivicslab.pojoactor.core.ActorProvider
Section
Usage Pattern - Search tag in interface com.scivicslab.pojoactor.core.accumulator.Accumulator
Section

V

valueOf(String) - Static method in enum class com.scivicslab.pojoactor.workflow.ExecutionMode
Returns the enum constant of this class with the specified name.
values() - Static method in enum class com.scivicslab.pojoactor.workflow.ExecutionMode
Returns an array containing the constants of this enum class, in the order they are declared.
Vertex - Class in com.scivicslab.pojoactor.workflow
Represents a single vertex in the workflow graph.
Vertex() - Constructor for class com.scivicslab.pojoactor.workflow.Vertex
 

W

With Actor System - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
WorkerPool - Interface in com.scivicslab.pojoactor.core
Interface for worker pools that execute CPU-bound jobs for actors.
workerPools - Variable in class com.scivicslab.pojoactor.core.ActorSystem
 
workflowBaseDir - Variable in class com.scivicslab.pojoactor.workflow.Interpreter
Base directory for resolving relative workflow file paths.
WorkflowKustomizer - Class in com.scivicslab.pojoactor.workflow.kustomize
Processes YAML overlays to generate customized workflows.
WorkflowKustomizer() - Constructor for class com.scivicslab.pojoactor.workflow.kustomize.WorkflowKustomizer
Constructs a new WorkflowKustomizer.
WorkflowXsltTransformer - Class in com.scivicslab.pojoactor.workflow
Utility class for transforming XML workflow definitions into HTML using XSLT.
WorkflowXsltTransformer() - Constructor for class com.scivicslab.pojoactor.workflow.WorkflowXsltTransformer
 

Y

YAML Workflow Example - Search tag in interface com.scivicslab.pojoactor.core.CallableByActionName
Section
A B C D E F G H I J K L M N O P R S T U V W Y 
All Classes and Interfaces|All Packages|Serialized Form