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

A

acceptEvent(APCRequestSource, Request) - Method in interface org.agilewiki.jactor.Actor
Wraps and enqueues an unwrapped request in the requester's inbox.
acceptEvent(APCRequestSource, Request) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Wraps and enqueues an unwrapped request in the requester's inbox.
acceptRequest(APCRequestSource, Request, RP) - Method in interface org.agilewiki.jactor.Actor
Wraps and enqueues an unwrapped request in the requester's inbox.
acceptRequest(APCRequestSource, Request, RP) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Wraps and enqueues an unwrapped request in the requester's inbox.
acquireControl(EventQueue<E>) - Method in interface org.agilewiki.jactor.events.EventQueue
Gain control of the queue.
acquireControl(EventQueue<E>) - Method in class org.agilewiki.jactor.events.JAEventQueue
Gain control of the queue.
Actor - Interface in org.agilewiki.jactor
Actors are objects which send messages to each other and which process only one message at a time.
ActorFactory - Class in org.agilewiki.jactor.factory
Creates a JLPCActor.
ActorFactory(String) - Constructor for class org.agilewiki.jactor.factory.ActorFactory
Create an ActorFactory.
actorFactory - Variable in class org.agilewiki.jactor.factory.Requirement
The factory of an actor which supports the request.
ActorFunc - Interface in org.agilewiki.jactor.simpleMachine
Returns an actor.
ActorName - Interface in org.agilewiki.jactor.pubsub.actorName
Immutable actor names.
actorType - Variable in class org.agilewiki.jactor.factory.ActorFactory
The actor type.
add(_Operation) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Add an _Operation to the operations.
APCMailbox - Interface in org.agilewiki.jactor.apc
Serves as the asynchronous transport for APCMessages.
APCRequestSource - Interface in org.agilewiki.jactor.apc
The originator of a request.
async - Variable in class org.agilewiki.jactor.simpleMachine.ExtendedResponseProcessor
Set true when a response is received asynchronously.

B

BooleanFunc - Interface in org.agilewiki.jactor.simpleMachine
Returns a boolean.
BufferedEventsDestination<E> - Interface in org.agilewiki.jactor.bufferedEvents
A BufferedEventsDestination receives lists of events from objects operating on a different thread.
BufferedEventsQueue<E> - Interface in org.agilewiki.jactor.bufferedEvents
A BufferedEventsQueue receives buffered events, queues them, and then processes them on another thread.

C

call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._Call
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._Goto
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._IfF
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._IfV
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._Iterator
Perform the operation.
call(SimpleMachine, RP) - Method in interface org.agilewiki.jactor.simpleMachine._Operation
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._ReturnF
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._ReturnV
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._Send
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._SetF
Perform the operation.
call(SimpleMachine, RP) - Method in class org.agilewiki.jactor.simpleMachine._SetV
Perform the operation.
call(RP) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Instantiate and execute a state machine.
call(Object, RP) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Instantiate and execute a state machine.
close() - Method in class org.agilewiki.jactor.concurrent.JAThreadManager
The close method is used to stop all the threads as they become idle.
close() - Method in interface org.agilewiki.jactor.concurrent.ThreadManager
Stop all the threads as they complete their tasks.
close() - Method in class org.agilewiki.jactor.JAMailboxFactory
Stop all the threads as they complete their tasks.
close() - Method in interface org.agilewiki.jactor.MailboxFactory
Stop all the threads as they complete their tasks.
Continuation - Class in org.agilewiki.jactor.continuation
 
Continuation(TargetActor, RP) - Constructor for class org.agilewiki.jactor.continuation.Continuation
 
createAsyncMailbox() - Method in class org.agilewiki.jactor.JAMailboxFactory
Create an asynchronous mailbox.
createAsyncMailbox() - Method in interface org.agilewiki.jactor.MailboxFactory
Create an asynchronous mailbox.
createMailbox() - Method in class org.agilewiki.jactor.JAMailboxFactory
Create a mailbox.
createMailbox() - Method in interface org.agilewiki.jactor.MailboxFactory
Create a mailbox.

D

defineActorType(String, Class) - Method in interface org.agilewiki.jactor.factory.Factory
Bind an actor type to a Class.
defineActorType(String, Class) - Method in class org.agilewiki.jactor.factory.JAFactory
Bind an actor type to a Class.
dispatchEvents() - Method in interface org.agilewiki.jactor.apc.APCMailbox
The dispatchMessages method processes any messages in the queue.
dispatchEvents() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
The dispatchMessages method processes any messages in the queue.
dispatchEvents() - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
The dispatchEvents method processes any events in the queue.
dispatchEvents() - Method in interface org.agilewiki.jactor.events.EventDispatcher
The dispatchEvents method processes any events in the queue.
dispatchEvents() - Method in class org.agilewiki.jactor.events.JAEventQueue
The dispatchEvents method processes any events in the queue.

E

EventDestination<E> - Interface in org.agilewiki.jactor.events
An EventDestination receives an event from objects operating on a different thread.
EventDispatcher<E> - Interface in org.agilewiki.jactor.events
An EventDispatcher processes events on another thread.
eventException(Request, Exception) - Method in class org.agilewiki.jactor.JAMailboxFactory
 
eventException(Request, Exception) - Method in interface org.agilewiki.jactor.MailboxFactory
 
EventProcessor<E> - Interface in org.agilewiki.jactor.events
An ActiveEventProcessor processes events and receives notifications that there are events to be processed.
EventQueue<E> - Interface in org.agilewiki.jactor.events
An EventQueue receives events, queues them, and then processes them on another thread.
ExceptionHandler - Interface in org.agilewiki.jactor
As responses can be received either synchronously or asynchronously, control flow can be somewhat obscure and the code to catch exceptions can be error prone.
execute(Object, RP) - Method in class org.agilewiki.jactor.simpleMachine.SimpleMachine
Executes the state machine.
ExtendedResponseProcessor<RESPONSE_TYPE> - Class in org.agilewiki.jactor.simpleMachine
Supports processing sensitive to how a response is returned.
ExtendedResponseProcessor() - Constructor for class org.agilewiki.jactor.simpleMachine.ExtendedResponseProcessor
 

F

Factory - Interface in org.agilewiki.jactor.factory
Defines actor types and instantiating
fillInStackTrace() - Method in exception org.agilewiki.jactor.lpc.TransparentException
Speeds things up by not filling in the stack trace.
finished() - Method in class org.agilewiki.jactor.parallel.JAResponseCounter2
Signals that all requests have been sent.
finished() - Method in class org.agilewiki.jactor.parallel.JAResponseCounter3
Signals that all requests have been sent.

G

get(SimpleMachine) - Method in interface org.agilewiki.jactor.simpleMachine.ActorFunc
Returns an actor.
get(SimpleMachine) - Method in interface org.agilewiki.jactor.simpleMachine.BooleanFunc
Returns a boolean.
get(SimpleMachine) - Method in interface org.agilewiki.jactor.simpleMachine.ObjectFunc
Returns an object.
get(Object) - Method in class org.agilewiki.jactor.simpleMachine.SimpleMachine
Returns a partial result.
getActorFactory(String) - Method in interface org.agilewiki.jactor.factory.Factory
Returns the requested actor factory.
getActorFactory(Actor, String) - Static method in class org.agilewiki.jactor.factory.JAFactory
Returns the requested actor factory.
getActorFactory(String) - Method in class org.agilewiki.jactor.factory.JAFactory
Returns the requested actor factory.
getActorName() - Method in interface org.agilewiki.jactor.pubsub.actorName.ActorName
Returns the actor name, or null.
getActorName() - Method in class org.agilewiki.jactor.pubsub.actorName.JActorName
Returns the actor name, or null.
getActorType() - Method in interface org.agilewiki.jactor.Actor
Returns the actor type.
getActorType() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the actor type.
getAncestor(Class) - Method in interface org.agilewiki.jactor.Actor
Returns A matching ancestor from the parent chain.
getAncestor(Class) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns A matching ancestor from the parent chain.
getController() - Method in interface org.agilewiki.jactor.events.EventQueue
Returns the controlling queue.
getController() - Method in class org.agilewiki.jactor.events.JAEventQueue
Returns the controlling queue.
getCurrentRequest() - Method in interface org.agilewiki.jactor.apc.APCMailbox
Returns the request message being processed.
getCurrentRequest() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Returns the request message being processed.
getDestinationActor() - Method in class org.agilewiki.jactor.apc.JARequest
Returns the requestProcessor.
getEventQueue() - Method in interface org.agilewiki.jactor.apc.APCMailbox
Returns the event queue.
getEventQueue() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Returns the event queue.
getEventQueue() - Method in interface org.agilewiki.jactor.bufferedEvents.BufferedEventsQueue
Returns the event queue.
getEventQueue() - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Returns the event queue.
getExceptionHandler() - Method in interface org.agilewiki.jactor.apc.APCMailbox
Returns the exception handler.
getExceptionHandler() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Returns the exception handler.
getExceptionHandler() - Method in interface org.agilewiki.jactor.apc.RequestProcessor
Returns the exception handler.
getExceptionHandler() - Method in interface org.agilewiki.jactor.lpc.Internals
Returns the exception handler.
getExceptionHandler() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the exception handler.
getExceptionHandler() - Method in interface org.agilewiki.jactor.lpc.RequestSource
Returns the exception handler.
getFactory() - Method in interface org.agilewiki.jactor.Actor
Returns the factory.
getFactory() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the factory.
getMailbox() - Method in interface org.agilewiki.jactor.Actor
Returns the actor's mailbox.
getMailbox() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the actor's mailbox.
getMailbox() - Method in interface org.agilewiki.jactor.lpc.RequestSource
Returns the actor's mailbox, or null if the request source is not an actor.
getMailboxFactory() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the mailbox factory.
getMailboxFactory() - Method in class org.agilewiki.jactor.lpc.JLPCMailbox
Returns the mailbox factory.
getMailboxFactory() - Method in interface org.agilewiki.jactor.Mailbox
Returns the mailbox factory.
getMatch(Class) - Method in interface org.agilewiki.jactor.Actor
 
getMatch(Class) - Method in class org.agilewiki.jactor.lpc.JLPCActor
 
getOperation(int) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Returns an operation.
getParent() - Method in interface org.agilewiki.jactor.Actor
Returns the actor's parent.
getParent() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the actor's parent.
getProperty(Actor, String) - Static method in class org.agilewiki.jactor.properties.JAProperties
 
getProperty(String) - Method in class org.agilewiki.jactor.properties.JAProperties
 
getProperty(String) - Method in interface org.agilewiki.jactor.properties.Properties
 
getRequest() - Method in class org.agilewiki.jactor.apc.JAResponse
 
getRequest(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._Send
Returns the request.
getRequest(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendFF
Returns the request.
getRequest(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendFV
Returns the request.
getRequest(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendVF
Returns the request.
getRequest(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendVV
Returns the request.
getResultName() - Method in class org.agilewiki.jactor.simpleMachine._Send
Returns the name of the result, or null.
getResultName() - Method in class org.agilewiki.jactor.simpleMachine._SendFF
Returns the name of the result, or null.
getResultName() - Method in class org.agilewiki.jactor.simpleMachine._SendFV
Returns the name of the result, or null.
getResultName() - Method in class org.agilewiki.jactor.simpleMachine._SendVF
Returns the name of the result, or null.
getResultName() - Method in class org.agilewiki.jactor.simpleMachine._SendVV
Returns the name of the result, or null.
GetSubscriber - Class in org.agilewiki.jactor.pubsub.publisher
Get a subscriber with the given name.
GetSubscriber(String) - Constructor for class org.agilewiki.jactor.pubsub.publisher.GetSubscriber
Create a Subscribe request.
getSubscriber(String) - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
Get a subscriber.
getSubscriber(String) - Method in interface org.agilewiki.jactor.pubsub.publisher.Publisher
Get a subscriber.
getTargetActor(Actor) - Method in class org.agilewiki.jactor.lpc.Request
Searches the parent stack for the matching TARGET_TYPE.
getTargetActor(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._Send
Returns the actor which is to receive the message.
getTargetActor(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendFF
Returns the actor which is to receive the message.
getTargetActor(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendFV
Returns the actor which is to receive the message.
getTargetActor(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendVF
Returns the actor which is to receive the message.
getTargetActor(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._SendVV
Returns the actor which is to receive the message.
getThreadManager() - Method in class org.agilewiki.jactor.JAMailboxFactory
Returns the thread manager.
getThreadManager() - Method in interface org.agilewiki.jactor.MailboxFactory
Returns the thread manager.
getUnwrappedRequest() - Method in class org.agilewiki.jactor.apc.JARequest
Returns the unwrapped request.
getUnwrappedResponse() - Method in class org.agilewiki.jactor.apc.JAResponse
Returns the unwrapped response.
go(String) - Method in class org.agilewiki.jactor.simpleMachine.SimpleMachine
Update the program counter with the index assigned to a label.

H

hasDataItem(String) - Method in interface org.agilewiki.jactor.Actor
Returns true when the concurrent data of the actor, or its parent, contains the named data item.
hasDataItem(String) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns true when the concurrent data of the actor, or its parent, contains the named data item.
haveEvents() - Method in interface org.agilewiki.jactor.apc.RequestProcessor
A notification that there are incoming requests and responses that are ready for processing.
haveEvents() - Method in interface org.agilewiki.jactor.events.EventProcessor
The haveEvents method is called when there may be one or more pending events.
haveEvents() - Method in class org.agilewiki.jactor.lpc.JLPCActor
A notification that there are incoming requests and responses that are ready for processing.

I

inactive() - Method in class org.agilewiki.jactor.apc.JARequest
Sets active to false--a response has been returned.
init(SimpleMachine) - Method in class org.agilewiki.jactor.simpleMachine._Iterator
Optional initialization, as required.
initialize() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Initialize a degraded LiteActor
initialize(Actor) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Initialize a degraded LiteActor
initialize(Mailbox) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Initialize a LiteActor
initialize(Mailbox, Actor) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Initialize a LiteActor
initialize(Mailbox, Actor, ActorFactory) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Initialize a LiteActor
instantiateActor() - Method in class org.agilewiki.jactor.factory._ActorFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.factory.ActorFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.factory.JAFactoryFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.nbLock.JNBLockFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.properties.JAPropertiesFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.pubsub.actorName.JActorNameFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisherFactory
Create a JLPCActor.
instantiateActor() - Method in class org.agilewiki.jactor.pubsub.subscriber.JASubscriberFactory
Create a JLPCActor.
Internals - Interface in org.agilewiki.jactor.lpc
The API used when processing a request.
isActive() - Method in class org.agilewiki.jactor.apc.JARequest
Returns true if no response has been returned.
isEmpty() - Method in interface org.agilewiki.jactor.apc.APCMailbox
The isEmpty method returns true when there are no pending messages, though the results may not always be correct due to concurrency issues.
isEmpty() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
The isEmpty method returns true when there are no pending messages, though the results may not always be correct due to concurrency issues.
isEmpty() - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
The isEmpty method returns true when there are no pending events, though the results may not always be correct due to concurrency issues.
isEmpty() - Method in interface org.agilewiki.jactor.events.EventDispatcher
The isEmpty method returns true when there are no pending events, though the results may not always be correct due to concurrency issues.
isEmpty() - Method in class org.agilewiki.jactor.events.JAEventQueue
The isEmpty method returns true when there are no pending events, though the results may not always be correct due to concurrency issues.
isEvent() - Method in class org.agilewiki.jactor.JANoResponse
Returns true when no response is expected.
isEvent() - Method in class org.agilewiki.jactor.RP
Returns true when no response is expected.
isTargetType(Actor) - Method in class org.agilewiki.jactor.lpc.Request
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.nbLock.Lock
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.nbLock.Unlock
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.publisher.GetSubscriber
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.publisher.Publish
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.publisher.Subscribe
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.publisher.Unsubscribe
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.subscriber.Subscribed
Returns true when targetActor is an instanceof TARGET_TYPE
isTargetType(Actor) - Method in class org.agilewiki.jactor.pubsub.subscriber.Unsubscribed
Returns true when targetActor is an instanceof TARGET_TYPE
iterate(RP) - Method in class org.agilewiki.jactor.JAIterator
Iterates over the process method.
iterate(RP) - Method in class org.agilewiki.jactor.simpleMachine._Iterator
 

J

JABufferedEventsQueue<E> - Class in org.agilewiki.jactor.bufferedEvents
A BufferedEventsQueue receives buffered events, queues them, and then processes them on another thread.
JABufferedEventsQueue(EventQueue<ArrayList<E>>) - Constructor for class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Create a BufferedEventsQueue.
JABufferedEventsQueue(ThreadManager, boolean) - Constructor for class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Create a BufferedEventsQueue.
JActorName - Class in org.agilewiki.jactor.pubsub.actorName
Implements immutable actor object names.
JActorName() - Constructor for class org.agilewiki.jactor.pubsub.actorName.JActorName
 
JActorNameFactory - Class in org.agilewiki.jactor.pubsub.actorName
Creates a Properties actor.
JActorNameFactory(String) - Constructor for class org.agilewiki.jactor.pubsub.actorName.JActorNameFactory
Create an ActorFactory.
JAEvent - Class in org.agilewiki.jactor
Used to send a request to an actor without having to wait for a response.
JAEvent() - Constructor for class org.agilewiki.jactor.JAEvent
 
JAEventQueue<E> - Class in org.agilewiki.jactor.events
An JAEventQueue receives messages, queues them, and then processes them on another thread.
JAEventQueue(ThreadManager, boolean) - Constructor for class org.agilewiki.jactor.events.JAEventQueue
Creates a JAEventQueue.
JAFactory - Class in org.agilewiki.jactor.factory
An actor for defining actor types and creating instances.
JAFactory() - Constructor for class org.agilewiki.jactor.factory.JAFactory
 
JAFactoryFactory - Class in org.agilewiki.jactor.factory
Creates a JAFactory.
JAFactoryFactory(String) - Constructor for class org.agilewiki.jactor.factory.JAFactoryFactory
Create an ActorFactory.
JAFuture - Class in org.agilewiki.jactor
Used both in the program's main method and in testing to send a request to an actor and wait for a response.
JAFuture() - Constructor for class org.agilewiki.jactor.JAFuture
 
JAIterator - Class in org.agilewiki.jactor
Iterates over its process method and works within any actor which supports 2-way messages.
JAIterator() - Constructor for class org.agilewiki.jactor.JAIterator
 
JAMailboxFactory - Class in org.agilewiki.jactor
Implements MailboxFactory.
JAMailboxFactory(ThreadManager) - Constructor for class org.agilewiki.jactor.JAMailboxFactory
 
JAMessage - Interface in org.agilewiki.jactor.apc
All requests sent to a mailbox, and all returned responses, are subclasses of JAMessage.
jan - Static variable in class org.agilewiki.jactor.JANull
The JANull singleton.
JANBLock - Class in org.agilewiki.jactor.nbLock
Non-blocking Lock.
JANBLock() - Constructor for class org.agilewiki.jactor.nbLock.JANBLock
 
JANoResponse - Class in org.agilewiki.jactor
Used with on-way messages (Events) to signal that no response is required.
JANull - Class in org.agilewiki.jactor
Represents a null when exiting JAIterator.iterate.
JAPCMailbox - Class in org.agilewiki.jactor.apc
An implementation of APCMailbox.
JAPCMailbox(BufferedEventsQueue<JAMessage>, MailboxFactory) - Constructor for class org.agilewiki.jactor.apc.JAPCMailbox
Create a JAPCMailbox.
JAPCMailbox(ThreadManager, boolean, MailboxFactory) - Constructor for class org.agilewiki.jactor.apc.JAPCMailbox
Create a JAPCMailbox.
JAProperties - Class in org.agilewiki.jactor.properties
GetProperties first checks the component's own table of name/value pairs.
JAProperties() - Constructor for class org.agilewiki.jactor.properties.JAProperties
 
JAPropertiesFactory - Class in org.agilewiki.jactor.properties
Creates a Properties actor.
JAPropertiesFactory(String) - Constructor for class org.agilewiki.jactor.properties.JAPropertiesFactory
Create an ActorFactory.
JAPublisher - Class in org.agilewiki.jactor.pubsub.publisher
Implements Publisher.
JAPublisher() - Constructor for class org.agilewiki.jactor.pubsub.publisher.JAPublisher
 
JAPublisherFactory - Class in org.agilewiki.jactor.pubsub.publisher
Creates a JAPublisher actor.
JAPublisherFactory(String) - Constructor for class org.agilewiki.jactor.pubsub.publisher.JAPublisherFactory
Create an ActorFactory.
JARequest - Class in org.agilewiki.jactor.apc
Requests sent to a JAPCMailbox are wrapped by an JARequest.
JARequest(RequestSource, JLPCActor, Request, RP, Mailbox) - Constructor for class org.agilewiki.jactor.apc.JARequest
 
JAResponse - Class in org.agilewiki.jactor.apc
Responses sent to a JAPCActor are wrapped by an JAResponse, which is then passed to the JAPCMailbox.
JAResponse(Object) - Constructor for class org.agilewiki.jactor.apc.JAResponse
Create a JAResponse.
JAResponseCounter - Class in org.agilewiki.jactor.parallel
Returns a response only when the expected number of responses are received.
JAResponseCounter(int, RP) - Constructor for class org.agilewiki.jactor.parallel.JAResponseCounter
Create a JAResponseCounter.
JAResponseCounter2 - Class in org.agilewiki.jactor.parallel
Counts the number of responses received and responds with the count of requests sent when the iteration is finished.
JAResponseCounter2(RP) - Constructor for class org.agilewiki.jactor.parallel.JAResponseCounter2
Create a PubSubResponseProcessor.
JAResponseCounter3 - Class in org.agilewiki.jactor.parallel
Counts the number of responses received and responds with the count of requests sent when the iteration is finished.
JAResponseCounter3(ArrayList<JAResponseCounter3>) - Constructor for class org.agilewiki.jactor.parallel.JAResponseCounter3
 
JASubscriber - Class in org.agilewiki.jactor.pubsub.subscriber
Implements Subscriber.
JASubscriber() - Constructor for class org.agilewiki.jactor.pubsub.subscriber.JASubscriber
 
JASubscriberFactory - Class in org.agilewiki.jactor.pubsub.subscriber
Creates a JASubscriber actor.
JASubscriberFactory(String) - Constructor for class org.agilewiki.jactor.pubsub.subscriber.JASubscriberFactory
Create an ActorFactory.
JAThreadFactory - Class in org.agilewiki.jactor.concurrent
JAThreadFactory is used to create threads.
JAThreadFactory() - Constructor for class org.agilewiki.jactor.concurrent.JAThreadFactory
 
JAThreadManager - Class in org.agilewiki.jactor.concurrent
A high performance implementation of ThreadManager.
JAThreadManager() - Constructor for class org.agilewiki.jactor.concurrent.JAThreadManager
 
JLPCActor - Class in org.agilewiki.jactor.lpc
An actor which implements Local Procedure Calls (LPC) and mostly works synchronously.
JLPCActor() - Constructor for class org.agilewiki.jactor.lpc.JLPCActor
 
JLPCActor.SMBuilder - Class in org.agilewiki.jactor.lpc
Creates a _SMBuilder.
JLPCActor.SMBuilder() - Constructor for class org.agilewiki.jactor.lpc.JLPCActor.SMBuilder
 
JLPCMailbox - Class in org.agilewiki.jactor.lpc
Implements Mailbox.
JLPCMailbox(BufferedEventsQueue<JAMessage>, MailboxFactory) - Constructor for class org.agilewiki.jactor.lpc.JLPCMailbox
Create a JLPCMailbox.
JLPCMailbox(MailboxFactory, boolean) - Constructor for class org.agilewiki.jactor.lpc.JLPCMailbox
Create a JLPCMailbox.
JLPCMailbox(MailboxFactory) - Constructor for class org.agilewiki.jactor.lpc.JLPCMailbox
Create a JLPCMailbox.
JNBLockFactory - Class in org.agilewiki.jactor.nbLock
Creates a NBLock actor.
JNBLockFactory(String) - Constructor for class org.agilewiki.jactor.nbLock.JNBLockFactory
Create an ActorFactory.

L

lock(RP) - Method in class org.agilewiki.jactor.nbLock.JANBLock
 
Lock - Class in org.agilewiki.jactor.nbLock
Gain exclusive use of a resource.
Lock() - Constructor for class org.agilewiki.jactor.nbLock.Lock
 
logException(boolean, String, Exception) - Method in class org.agilewiki.jactor.concurrent.JAThreadManager
 
logException(boolean, String, Exception) - Method in interface org.agilewiki.jactor.concurrent.ThreadManager
 
logException(boolean, String, Exception) - Method in class org.agilewiki.jactor.JAMailboxFactory
 
logException(boolean, String, Exception) - Method in interface org.agilewiki.jactor.MailboxFactory
 

M

mailbox - Variable in class org.agilewiki.jactor.apc.JARequest
 
Mailbox - Interface in org.agilewiki.jactor
A mailbox is a lightweight thread with an inbox for incoming messages and an outbox for outgoing messages.
MailboxFactory - Interface in org.agilewiki.jactor
Creates Mailboxes and provides access to the thread manager.

N

newActor(Mailbox, Actor) - Method in class org.agilewiki.jactor.factory.ActorFactory
Create and configure an actor.
newActor(String) - Method in interface org.agilewiki.jactor.factory.Factory
Creates a new actor.
newActor(String, Mailbox) - Method in interface org.agilewiki.jactor.factory.Factory
Creates a new actor.
newActor(String, Mailbox, Actor) - Method in interface org.agilewiki.jactor.factory.Factory
Creates a new actor.
newActor(Actor, String) - Static method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newActor(Actor, String, Mailbox) - Static method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newActor(Actor, String, Mailbox, Actor) - Static method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newActor(String) - Method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newActor(String, Mailbox) - Method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newActor(String, Mailbox, Actor) - Method in class org.agilewiki.jactor.factory.JAFactory
Creates a new actor.
newMailboxFactory(int) - Static method in class org.agilewiki.jactor.JAMailboxFactory
Create a JAMailboxFactory
newThread(Runnable) - Method in class org.agilewiki.jactor.concurrent.JAThreadFactory
The newThread method returns a newly created Thread.
newThreadManager(int) - Static method in class org.agilewiki.jactor.concurrent.JAThreadManager
Create a JAThreadManager
newThreadManager(int, ThreadFactory) - Static method in class org.agilewiki.jactor.concurrent.JAThreadManager
Create a JAThreadManager
nrp - Static variable in class org.agilewiki.jactor.JANoResponse
An immutable instance of JANoResponse.

O

ObjectFunc - Interface in org.agilewiki.jactor.simpleMachine
Returns an object.
operationsSize() - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Returns the number of operations.
org.agilewiki.jactor - package org.agilewiki.jactor
Introduction to JActor
org.agilewiki.jactor.apc - package org.agilewiki.jactor.apc
The apc package implements Asynchronous Procedure Calls (APC), or two-way messaging.
org.agilewiki.jactor.bufferedEvents - package org.agilewiki.jactor.bufferedEvents
The bufferedEvents package supports the dispatching of one-way messages (events), but it buffers outgoing events and sends them only when there are no other incoming events to process, which results in a significant improvement in throughput when under load.
org.agilewiki.jactor.concurrent - package org.agilewiki.jactor.concurrent
The concurrent package contains a number of classes that are helpful in delivering high-performance.
org.agilewiki.jactor.continuation - package org.agilewiki.jactor.continuation
 
org.agilewiki.jactor.events - package org.agilewiki.jactor.events
The events package supports the dispatching of one-way messages (events).
org.agilewiki.jactor.factory - package org.agilewiki.jactor.factory
 
org.agilewiki.jactor.lpc - package org.agilewiki.jactor.lpc
Introducing JLPCActor--the Basic Actor
org.agilewiki.jactor.nbLock - package org.agilewiki.jactor.nbLock
NBLock provides exclusive access to a resource without blocking a thread.
org.agilewiki.jactor.parallel - package org.agilewiki.jactor.parallel
Sending multiple requests to different actors and waiting for the responses only after all the requests have been sent is the simplest form of parallel processing and is the focus of this package.
org.agilewiki.jactor.properties - package org.agilewiki.jactor.properties
A table of name/value pairs.
org.agilewiki.jactor.pubsub.actorName - package org.agilewiki.jactor.pubsub.actorName
Actors which include the ActorName component can be named and added to an ActorRegistry.
org.agilewiki.jactor.pubsub.publisher - package org.agilewiki.jactor.pubsub.publisher
 
org.agilewiki.jactor.pubsub.subscriber - package org.agilewiki.jactor.pubsub.subscriber
 
org.agilewiki.jactor.simpleMachine - package org.agilewiki.jactor.simpleMachine
You can think of a State Machine as a kind of computer.

P

process(Runnable) - Method in class org.agilewiki.jactor.concurrent.JAThreadManager
Begin running a task.
process(Runnable) - Method in interface org.agilewiki.jactor.concurrent.ThreadManager
Begin running a task.
process(Exception) - Method in interface org.agilewiki.jactor.ExceptionHandler
Process an exception.
process(RP) - Method in class org.agilewiki.jactor.JAIterator
Perform an iteration.
processEvent(E) - Method in interface org.agilewiki.jactor.events.EventProcessor
The processMessage method is called when there is an incoming event to process.
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.lpc.Request
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.nbLock.Lock
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.nbLock.Unlock
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.GetSubscriber
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.Publish
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.Subscribe
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.Unsubscribe
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.subscriber.Subscribed
 
processRequest(JLPCActor, RP) - Method in class org.agilewiki.jactor.pubsub.subscriber.Unsubscribed
 
processResponse(Object) - Method in class org.agilewiki.jactor.JANoResponse
Receives and ignores a response.
processResponse(Object) - Method in class org.agilewiki.jactor.parallel.JAResponseCounter
Receives and processes a response.
processResponse(Object) - Method in class org.agilewiki.jactor.parallel.JAResponseCounter2
Receives and processes a response.
processResponse(Object) - Method in class org.agilewiki.jactor.parallel.JAResponseCounter3
Receives and processes a response.
processResponse(RESPONSE_TYPE) - Method in class org.agilewiki.jactor.RP
Receives and processes a response.
Properties - Interface in org.agilewiki.jactor.properties
Manages a property set.
publish(Request, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
Publish a request to all the appropriate subscribers.
Publish - Class in org.agilewiki.jactor.pubsub.publisher
Broadcast a request to all applicable subscribers.
Publish(Request) - Constructor for class org.agilewiki.jactor.pubsub.publisher.Publish
Create a Publish request.
publish(Request, RP) - Method in interface org.agilewiki.jactor.pubsub.publisher.Publisher
Publish a request to all the appropriate subscribers.
Publisher - Interface in org.agilewiki.jactor.pubsub.publisher
A publisher actor.
publisher - Variable in class org.agilewiki.jactor.pubsub.subscriber.Subscribed
The publisher to which the target actor has subscribed.
publisher - Variable in class org.agilewiki.jactor.pubsub.subscriber.Unsubscribed
The publisher to which the target actor was subscribed.
publishRequest - Variable in class org.agilewiki.jactor.pubsub.publisher.Publish
The request to be published.
put(String, Object) - Method in class org.agilewiki.jactor.simpleMachine.SimpleMachine
Save a parial result.
putBufferedEvents(ArrayList<JAMessage>) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
The putBufferedEvents method adds events to be processed.
putBufferedEvents(ArrayList<E>) - Method in interface org.agilewiki.jactor.bufferedEvents.BufferedEventsDestination
The putBufferedEvents method adds events to be processed.
putBufferedEvents(ArrayList<E>) - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
The putBufferedEvents method adds events to be processed.
putEvent(E) - Method in interface org.agilewiki.jactor.events.EventDestination
The putEvent method adds an events to the queue of events to be processed.
putEvent(E) - Method in class org.agilewiki.jactor.events.JAEventQueue
The putEvent method adds an events to the queue of events to be processed and if idle, start the task.

R

registerActorFactory(ActorFactory) - Method in interface org.agilewiki.jactor.factory.Factory
Register an actor factory.
registerActorFactory(ActorFactory) - Method in class org.agilewiki.jactor.factory.JAFactory
Register an actor factory.
relinquishControl() - Method in interface org.agilewiki.jactor.events.EventQueue
Relinquish foreign control over the queue.
relinquishControl() - Method in class org.agilewiki.jactor.events.JAEventQueue
Relinquish foreign control over the queue.
req - Static variable in class org.agilewiki.jactor.nbLock.Lock
 
req - Static variable in class org.agilewiki.jactor.nbLock.Unlock
 
request - Variable in class org.agilewiki.jactor.factory.Requirement
A request the must be supported.
Request<RESPONSE_TYPE,TARGET_TYPE extends TargetActor> - Class in org.agilewiki.jactor.lpc
A request.
Request() - Constructor for class org.agilewiki.jactor.lpc.Request
 
request - Variable in class org.agilewiki.jactor.simpleMachine._Call
The (indirect, optional) argument passed when the state machine was invoked.
request - Variable in class org.agilewiki.jactor.simpleMachine.SimpleMachine
The (optional) argument passed when the state machine was invoked.
RequestProcessor - Interface in org.agilewiki.jactor.apc
Processes events and manages events and an exception handler.
requestSource - Variable in class org.agilewiki.jactor.apc.JARequest
The target of the response.
requestSource - Static variable in class org.agilewiki.jactor.JAEvent
Serves as the originator of a request.
RequestSource - Interface in org.agilewiki.jactor.lpc
The originator of a request.
Requirement - Class in org.agilewiki.jactor.factory
Provides a request which must be supported and the factory of an actor which.does.
Requirement(Request, ActorFactory) - Constructor for class org.agilewiki.jactor.factory.Requirement
Create a Requirement.
requirements() - Method in class org.agilewiki.jactor.lpc.JLPCActor
Returns the actor's requirements.
reset() - Method in class org.agilewiki.jactor.apc.JARequest
 
resolve(String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Returns the location assigned to a label.
response(JARequest, Object) - Method in interface org.agilewiki.jactor.apc.APCMailbox
 
response(JARequest, Object) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
_ReturnF the response for processing.
response(BufferedEventsQueue<JAMessage>, Object) - Method in class org.agilewiki.jactor.apc.JARequest
Enqueue a response to be sent when there are no more incoming messages to be processed.
response(Object) - Method in class org.agilewiki.jactor.continuation.Continuation
 
response(JLPCActor, Object) - Method in class org.agilewiki.jactor.continuation.Continuation
 
responseFrom(BufferedEventsQueue<JAMessage>, JAResponse) - Method in interface org.agilewiki.jactor.apc.APCRequestSource
Enqueues the response in the responder's outbox.
responseFrom(BufferedEventsQueue<JAMessage>, JAResponse) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Enqueues the response in the responder's outbox.
restoreSourceMailbox() - Method in class org.agilewiki.jactor.apc.JARequest
 
rp - Variable in class org.agilewiki.jactor.apc.JARequest
 
RP<RESPONSE_TYPE> - Class in org.agilewiki.jactor
Types the response.
RP() - Constructor for class org.agilewiki.jactor.RP
 

S

send(BufferedEventsDestination<JAMessage>, JARequest) - Method in interface org.agilewiki.jactor.apc.APCMailbox
Buffer the request for subsequent sending.
send(BufferedEventsDestination<JAMessage>, JARequest) - Method in interface org.agilewiki.jactor.apc.APCRequestSource
Sends a request to a mailbox.
send(BufferedEventsDestination<JAMessage>, JARequest) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Buffer the request for subsequent sending.
send(BufferedEventsDestination<E>, E) - Method in interface org.agilewiki.jactor.bufferedEvents.BufferedEventsQueue
Buffer the event for subsequent sending.
send(BufferedEventsDestination<E>, E) - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Buffer the event for subsequent sending.
send(Actor, Request) - Method in class org.agilewiki.jactor.JAFuture
Sends a request and waits for a response.
send(Actor, Object, RP) - Method in interface org.agilewiki.jactor.lpc.Internals
Send a request to another actor.
send(BufferedEventsDestination<JAMessage>, JARequest) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Sends a request to a mailbox.
send(Actor, Request, RP) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Send a request to another actor.
send(Actor, Request, RP) - Method in class org.agilewiki.jactor.lpc.JLPCActor.SMBuilder
 
send(JAFuture, Actor) - Method in class org.agilewiki.jactor.lpc.Request
Send a request and waits for a response.
send(JAFuture, TARGET_TYPE) - Method in class org.agilewiki.jactor.lpc.Request
Send a request and waits for a response.
send(APCRequestSource, Actor, RP<RESPONSE_TYPE>) - Method in class org.agilewiki.jactor.lpc.Request
Send a request.
send(APCRequestSource, TARGET_TYPE, RP<RESPONSE_TYPE>) - Method in class org.agilewiki.jactor.lpc.Request
Send a request.
send(Actor, Request, RP) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Send a request to an actor.
send(Actor, Request, RP) - Method in class org.agilewiki.jactor.simpleMachine.SimpleMachine
Send a request to an actor.
sendEvent(Actor, Request) - Method in class org.agilewiki.jactor.JAEvent
Sends a request without having to wait for a response.
sendEvent(Actor, Object) - Method in interface org.agilewiki.jactor.lpc.Internals
Send a request to another actor and discard any response.
sendEvent(Actor, Request) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Send a request to another actor and discard any response.
sendEvent(Actor) - Method in class org.agilewiki.jactor.lpc.Request
Send a request event.
sendEvent(TARGET_TYPE) - Method in class org.agilewiki.jactor.lpc.Request
Send a request event.
sendEvent(APCRequestSource, Actor) - Method in class org.agilewiki.jactor.lpc.Request
Send a request event.
sendEvent(APCRequestSource, TARGET_TYPE) - Method in class org.agilewiki.jactor.lpc.Request
Send a request event.
sendPendingEvents() - Method in interface org.agilewiki.jactor.bufferedEvents.BufferedEventsQueue
Send any pending events.
sendPendingEvents() - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Send any pending events.
sendPendingMessages() - Method in interface org.agilewiki.jactor.apc.APCMailbox
Send any pending messages.
sendPendingMessages() - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Send any pending Messages.
sent - Variable in class org.agilewiki.jactor.parallel.JAResponseCounter2
The number of requests sent.
sent - Variable in class org.agilewiki.jactor.parallel.JAResponseCounter3
The number of requests sent.
setActiveEventProcessor(EventProcessor<E>) - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Specifies the object which will process the dispatched events.
setActiveEventProcessor(EventProcessor<E>) - Method in interface org.agilewiki.jactor.events.EventDispatcher
Specifies the object to which notificatins are sent and which processes events.
setActiveEventProcessor(EventProcessor<E>) - Method in class org.agilewiki.jactor.events.JAEventQueue
Specifies the object which will process the dispatched events.
setActorName(String) - Method in interface org.agilewiki.jactor.pubsub.actorName.ActorName
Assigns an actor name, unless already assigned.
setActorName(String) - Method in class org.agilewiki.jactor.pubsub.actorName.JActorName
Assigns an actor name, unless already assigned.
setCurrentRequest(JARequest) - Method in interface org.agilewiki.jactor.apc.APCMailbox
Assigns the request message to be processed.
setCurrentRequest(JARequest) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Assigns the request message to be processed.
setExceptionHandler(ExceptionHandler) - Method in interface org.agilewiki.jactor.apc.APCMailbox
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in interface org.agilewiki.jactor.apc.RequestProcessor
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in interface org.agilewiki.jactor.lpc.Internals
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in interface org.agilewiki.jactor.lpc.RequestSource
Assign an exception handler.
setExceptionHandler(ExceptionHandler) - Method in interface org.agilewiki.jactor.lpc.TargetActor
Assign an exception handler.
setInitialBufferCapacity(int) - Method in interface org.agilewiki.jactor.Actor
Set the initial capacity for buffered outgoing messages.
setInitialBufferCapacity(int) - Method in interface org.agilewiki.jactor.apc.APCMailbox
Set the initial capacity for buffered outgoing messages.
setInitialBufferCapacity(int) - Method in class org.agilewiki.jactor.apc.JAPCMailbox
Set the initial capacity for buffered outgoing messages.
setInitialBufferCapacity(int) - Method in interface org.agilewiki.jactor.bufferedEvents.BufferedEventsQueue
Set the initial capacity for buffered outgoing events.
setInitialBufferCapacity(int) - Method in class org.agilewiki.jactor.bufferedEvents.JABufferedEventsQueue
Set the initial capacity for buffered outgoing events.
setInitialBufferCapacity(int) - Method in class org.agilewiki.jactor.lpc.JLPCActor
Set the initial capacity for buffered outgoing messages.
setJAPCRequest(JARequest) - Method in class org.agilewiki.jactor.apc.JAResponse
Assign the request to which this is the response.
setProperty(Actor, String, Object) - Static method in class org.agilewiki.jactor.properties.JAProperties
 
setProperty(String, Object) - Method in class org.agilewiki.jactor.properties.JAProperties
Assign a value to a property.
setProperty(String, Object) - Method in interface org.agilewiki.jactor.properties.Properties
Assign a value to a property.
setup(RP) - Method in class org.agilewiki.jactor.parallel.JAResponseCounter3
Initialize.
SimpleMachine - Class in org.agilewiki.jactor.simpleMachine
A state machine.
SimpleMachine(_SMBuilder) - Constructor for class org.agilewiki.jactor.simpleMachine.SimpleMachine
Create a StateMachine.
sourceExceptionHandler - Variable in class org.agilewiki.jactor.apc.JARequest
 
sourceMailbox - Variable in class org.agilewiki.jactor.apc.JARequest
 
sourceRequest - Variable in class org.agilewiki.jactor.apc.JARequest
 
start(int, ThreadFactory) - Method in class org.agilewiki.jactor.concurrent.JAThreadManager
Create and start the concurrent.
start(int, ThreadFactory) - Method in interface org.agilewiki.jactor.concurrent.ThreadManager
Create and start the concurrent.
subscribe(Subscriber) - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
Subscribe to the publisher.
subscribe(Subscriber) - Method in interface org.agilewiki.jactor.pubsub.publisher.Publisher
Subscribe to the publisher.
Subscribe - Class in org.agilewiki.jactor.pubsub.publisher
Subscribe to a publisher.
Subscribe(Subscriber) - Constructor for class org.agilewiki.jactor.pubsub.publisher.Subscribe
Create a Subscribe request.
subscribed(Publisher) - Method in class org.agilewiki.jactor.pubsub.subscriber.JASubscriber
This actor has been granted a subscription.
Subscribed - Class in org.agilewiki.jactor.pubsub.subscriber
The target actor now has a subscription.
Subscribed(Publisher) - Constructor for class org.agilewiki.jactor.pubsub.subscriber.Subscribed
Create a Subscribed request.
subscribed(Publisher) - Method in interface org.agilewiki.jactor.pubsub.subscriber.Subscriber
This actor has been granted a subscription.
subscriber - Variable in class org.agilewiki.jactor.pubsub.publisher.Subscribe
The subscribing actor.
subscriber - Variable in class org.agilewiki.jactor.pubsub.publisher.Unsubscribe
The name of the subscribing actor.
Subscriber - Interface in org.agilewiki.jactor.pubsub.subscriber
An actor that can be given a subscription.
subscriberName - Variable in class org.agilewiki.jactor.pubsub.publisher.GetSubscriber
The name of the subscribing actor.
subscribers - Variable in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
Table of subscribers, keyed by actor name.
sync - Variable in class org.agilewiki.jactor.simpleMachine.ExtendedResponseProcessor
Set true when a response is received synchronously.

T

TargetActor - Interface in org.agilewiki.jactor.lpc
Used by Request to extend TARGET_TYPE instead of Actor as a means of avoiding ambiguous method signatures.
ThreadManager - Interface in org.agilewiki.jactor.concurrent
A ThreadManager is used to process a collection of Runnable tasks.
timer() - Method in class org.agilewiki.jactor.JAMailboxFactory
 
timer() - Method in interface org.agilewiki.jactor.MailboxFactory
 
TransparentException - Exception in org.agilewiki.jactor.lpc
A TransparentException wraps another exception.
TransparentException(Exception) - Constructor for exception org.agilewiki.jactor.lpc.TransparentException
Create a new TransparentException
TYPE - Static variable in class org.agilewiki.jactor.factory.JAFactoryFactory
The default name of the JFactory actor.
TYPE - Static variable in class org.agilewiki.jactor.nbLock.JNBLockFactory
The default type of the NBLock actor.
TYPE - Static variable in class org.agilewiki.jactor.properties.JAPropertiesFactory
The default name of the JFactory actor.
TYPE - Static variable in class org.agilewiki.jactor.pubsub.actorName.JActorNameFactory
The default name of the JFactory actor.
TYPE - Static variable in class org.agilewiki.jactor.pubsub.publisher.JAPublisherFactory
The default name of the JFactory actor.
TYPE - Static variable in class org.agilewiki.jactor.pubsub.subscriber.JASubscriberFactory
The default name of the JFactory actor.

U

unlock(RP) - Method in class org.agilewiki.jactor.nbLock.JANBLock
 
Unlock - Class in org.agilewiki.jactor.nbLock
Release exclusive use of a resource.
Unlock() - Constructor for class org.agilewiki.jactor.nbLock.Unlock
 
unsubscribe(Subscriber) - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
Unsubscribe from the publisher.
unsubscribe(Subscriber) - Method in interface org.agilewiki.jactor.pubsub.publisher.Publisher
Unsubscribe from the publisher.
Unsubscribe - Class in org.agilewiki.jactor.pubsub.publisher
Unsubscribe from a publisher.
Unsubscribe(Subscriber) - Constructor for class org.agilewiki.jactor.pubsub.publisher.Unsubscribe
Create a Subscribe request.
unsubscribed(Publisher, RP) - Method in class org.agilewiki.jactor.pubsub.publisher.JAPublisher
This actor's subscription has been dropped.
unsubscribed(Publisher, RP) - Method in class org.agilewiki.jactor.pubsub.subscriber.JASubscriber
This actor's subscription has been dropped.
unsubscribed(Publisher, RP) - Method in interface org.agilewiki.jactor.pubsub.subscriber.Subscriber
This actor's subscription has been dropped.
Unsubscribed - Class in org.agilewiki.jactor.pubsub.subscriber
The target actor no longer has a subscription.
Unsubscribed(Publisher) - Constructor for class org.agilewiki.jactor.pubsub.subscriber.Unsubscribed
Create a Unsubscribed request.

_

_ActorFactory - Class in org.agilewiki.jactor.factory
Creates a JLPCActor using a Constructor.
_ActorFactory(String, Constructor<JLPCActor>) - Constructor for class org.agilewiki.jactor.factory._ActorFactory
Create an ActorFactory.
_Call - Class in org.agilewiki.jactor.simpleMachine
Instantiate and execute a subordinate state machine.
_Call(_SMBuilder, _SMBuilder, ObjectFunc, String) - Constructor for class org.agilewiki.jactor.simpleMachine._Call
Create a _Call.
_call(_SMBuilder) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _Call.
_call(_SMBuilder, ObjectFunc, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _Call.
_Goto - Class in org.agilewiki.jactor.simpleMachine
Set the program counter of the state machine.
_Goto(_SMBuilder, String) - Constructor for class org.agilewiki.jactor.simpleMachine._Goto
Create a _Goto.
_goto(String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _Goto.
_if(boolean, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create an _IfV
_if(BooleanFunc, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create an _IfF
_IfF - Class in org.agilewiki.jactor.simpleMachine
If the (indirect) condition is true, set the program counter of the state machine.
_IfF(_SMBuilder, BooleanFunc, String) - Constructor for class org.agilewiki.jactor.simpleMachine._IfF
Create an _IfF
_IfV - Class in org.agilewiki.jactor.simpleMachine
If the condition is true, set the program counter of the state machine.
_IfV(_SMBuilder, boolean, String) - Constructor for class org.agilewiki.jactor.simpleMachine._IfV
Create an _IfV
_Iterator - Class in org.agilewiki.jactor.simpleMachine
A state machine compatible extension of JAIterator.
_Iterator(_SMBuilder) - Constructor for class org.agilewiki.jactor.simpleMachine._Iterator
Create an _Iterator
_Iterator(_SMBuilder, String) - Constructor for class org.agilewiki.jactor.simpleMachine._Iterator
Create an _Iterator
_label(String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Assign a label to the location of the next operation to be created.
_Operation - Interface in org.agilewiki.jactor.simpleMachine
An operation performed by a state machine.
_return(Object) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a_ReturnV.
_return(ObjectFunc) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a_ReturnF.
_ReturnF - Class in org.agilewiki.jactor.simpleMachine
Exit the state machine with the given (indirect) result.
_ReturnF(_SMBuilder, ObjectFunc) - Constructor for class org.agilewiki.jactor.simpleMachine._ReturnF
Create a_ReturnF.
_ReturnV - Class in org.agilewiki.jactor.simpleMachine
Exit the state machine with the given result.
_ReturnV(_SMBuilder, Object) - Constructor for class org.agilewiki.jactor.simpleMachine._ReturnV
Create a_ReturnV.
_Send - Class in org.agilewiki.jactor.simpleMachine
Send a request to an actor.
_Send() - Constructor for class org.agilewiki.jactor.simpleMachine._Send
 
_send(Actor, Request) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendVV.
_send(Actor, Request, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendVV.
_send(ActorFunc, ObjectFunc) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendFF.
_send(ActorFunc, ObjectFunc, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendFF.
_send(Actor, ObjectFunc) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendVF.
_send(Actor, ObjectFunc, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendVF.
_send(ActorFunc, Request) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendFV.
_send(ActorFunc, Request, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SendFV.
_SendFF - Class in org.agilewiki.jactor.simpleMachine
Send an (indirect) request to an (indirect) actor.
_SendFF(_SMBuilder, ActorFunc, ObjectFunc, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SendFF
Create a _SendFF.
_SendFV - Class in org.agilewiki.jactor.simpleMachine
Send an (indirect) request to an actor.
_SendFV(_SMBuilder, ActorFunc, Request, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SendFV
Create a _SendFV.
_SendVF - Class in org.agilewiki.jactor.simpleMachine
Send a request to an (indirect) actor.
_SendVF(_SMBuilder, Actor, ObjectFunc, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SendVF
Create a _SendVF.
_SendVV - Class in org.agilewiki.jactor.simpleMachine
Send a request to an actor.
_SendVV(_SMBuilder, Actor, Request, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SendVV
Create a _SendVV.
_set(ObjectFunc) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SetF.
_set(ObjectFunc, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SetF.
_set(Object) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SetV.
_set(Object, String) - Method in class org.agilewiki.jactor.simpleMachine._SMBuilder
Create a _SetV.
_SetF - Class in org.agilewiki.jactor.simpleMachine
Assign an (indirect) partial result.
_SetF(_SMBuilder, ObjectFunc, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SetF
Create a _SetF
_SetV - Class in org.agilewiki.jactor.simpleMachine
Assign a partial result.
_SetV(_SMBuilder, Object, String) - Constructor for class org.agilewiki.jactor.simpleMachine._SetV
Create a _SetV
_SMBuilder - Class in org.agilewiki.jactor.simpleMachine
Creates and runs a state machine.
_SMBuilder() - Constructor for class org.agilewiki.jactor.simpleMachine._SMBuilder
 
A B C D E F G H I J L M N O P R S T U _ 

Copyright © 2012. All Rights Reserved.