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

A

AbstractForkJoinWorker<T> - Class in groovyx.gpars.forkjoin
Implements the ForkJoin worker contract.
AbstractForkJoinWorker() - Constructor for class groovyx.gpars.forkjoin.AbstractForkJoinWorker
 
AbstractLoopingActor - Class in groovyx.gpars.actor
Wraps all actors that repeatedly loop through incoming messages and hold no implicit state between subsequent messages.
AbstractLoopingActor() - Constructor for class groovyx.gpars.actor.AbstractLoopingActor
 
act() - Method in class groovyx.gpars.actor.DefaultActor
If no parameter is provided at construction time, the act() method becomes the actor's body
act() - Method in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor
 
act() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
This method represents the body of the actor.
action - Variable in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor
 
active - Variable in class groovyx.gpars.util.AsyncMessagingCore
Indicates, whether there's an active thread handling a message inside the agent's body
ACTIVE - Static variable in class groovyx.gpars.util.AsyncMessagingCore
 
ActiveMethod - Annotation Type in groovyx.gpars.activeobject
 
ActiveObject - Annotation Type in groovyx.gpars.activeobject
 
ActiveObjectASTTransformation - Class in groovyx.gpars.activeobject
Transforms active objects so that their active methods can be invoked asynchronously through an internal actor.
ActiveObjectASTTransformation() - Constructor for class groovyx.gpars.activeobject.ActiveObjectASTTransformation
 
ActiveObjectASTTransformation.MyClassCodeExpressionTransformer - Class in groovyx.gpars.activeobject
 
ActiveObjectASTTransformation.MyClassCodeExpressionTransformer(SourceUnit, String, String) - Constructor for class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
ActiveObjectRegistry - Class in groovyx.gpars.activeobject
Maps string identifiers to instances of PGroup.
ActiveObjectRegistry() - Constructor for class groovyx.gpars.activeobject.ActiveObjectRegistry
 
activeParallelGroup - Static variable in class groovyx.gpars.dataflow.Dataflow
Maps threads/tasks to parallel groups they belong to
activeUpdater - Static variable in class groovyx.gpars.util.AsyncMessagingCore
 
Actor - Class in groovyx.gpars.actor
Actors are active objects, which borrow a thread from a thread pool.
Actor() - Constructor for class groovyx.gpars.actor.Actor
 
Actor(DataflowExpression<Object>) - Constructor for class groovyx.gpars.actor.Actor
Constructor to be used by deserialization
Actor(DataflowExpression<Object>, PGroup) - Constructor for class groovyx.gpars.actor.Actor
 
actor - Variable in class groovyx.gpars.actor.Actor.RemoteActor.StopActorMsg
 
actor - Variable in class groovyx.gpars.actor.Actor.RemoteActor.TerminateActorMsg
 
actor(Runnable) - Static method in class groovyx.gpars.actor.Actors
Creates a new instance of DefaultActor, using the passed-in closure as the body of the actor's act() method.
actor - Variable in class groovyx.gpars.actor.ActorTimerTask
 
Actor.MyRemoteHandle - Class in groovyx.gpars.actor
 
Actor.MyRemoteHandle(SerialHandle, SerialContext, DataflowExpression<Object>) - Constructor for class groovyx.gpars.actor.Actor.MyRemoteHandle
 
Actor.RemoteActor - Class in groovyx.gpars.actor
 
Actor.RemoteActor(SerialContext, DataflowExpression<Object>) - Constructor for class groovyx.gpars.actor.Actor.RemoteActor
 
Actor.RemoteActor.StopActorMsg - Class in groovyx.gpars.actor
 
Actor.RemoteActor.StopActorMsg(Actor.RemoteActor) - Constructor for class groovyx.gpars.actor.Actor.RemoteActor.StopActorMsg
 
Actor.RemoteActor.TerminateActorMsg - Class in groovyx.gpars.actor
 
Actor.RemoteActor.TerminateActorMsg(Actor.RemoteActor) - Constructor for class groovyx.gpars.actor.Actor.RemoteActor.TerminateActorMsg
 
ACTOR_HAS_ALREADY_BEEN_STARTED - Static variable in class groovyx.gpars.actor.Actor
 
ActorException - Exception in groovyx.gpars.actor.impl
Pooled actors need to simulate continuations to create stacktrace-less chunks of work (ActorActions) to assign to the threads from the pool.
ActorException() - Constructor for exception groovyx.gpars.actor.impl.ActorException
 
actorFieldName - Variable in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
actorGroupName - Variable in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
ActorMessage - Class in groovyx.gpars.actor
An internal representation of received messages holding both the original message plus the sender actor reference.
ActorMessage(Object, MessageStream) - Constructor for class groovyx.gpars.actor.ActorMessage
Creates a new instance
ActorMessage() - Constructor for class groovyx.gpars.actor.ActorMessage
Constructor for serialization
actorNode - Variable in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
ActorReplyException - Exception in groovyx.gpars.actor.impl
Indicates problems sending replies to actors.
ActorReplyException(String) - Constructor for exception groovyx.gpars.actor.impl.ActorReplyException
 
ActorReplyException(String, List<Exception>) - Constructor for exception groovyx.gpars.actor.impl.ActorReplyException
 
Actors - Class in groovyx.gpars.actor
Provides handy helper methods to create pooled actors and customize the underlying thread pool.
Actors() - Constructor for class groovyx.gpars.actor.Actors
 
ActorStopException - Exception in groovyx.gpars.actor.impl
An exception indicating Actor stopping request.
ActorStopException() - Constructor for exception groovyx.gpars.actor.impl.ActorStopException
 
ActorTerminationException - Exception in groovyx.gpars.actor.impl
An exception indicating Actor termination request.
ActorTerminationException() - Constructor for exception groovyx.gpars.actor.impl.ActorTerminationException
 
ActorTimerTask - Class in groovyx.gpars.actor
Represents an ongoing timeout
ActorTimerTask(AbstractLoopingActor, int) - Constructor for class groovyx.gpars.actor.ActorTimerTask
 
add(SerialHandle) - Method in class groovyx.gpars.serial.SerialContext
 
add(SerialHandle) - Method in class groovyx.gpars.serial.SerialHandles
 
add(Object) - Method in class groovyx.gpars.util.DefaultMessageQueue
 
add(Object) - Method in class groovyx.gpars.util.FQMessageQueue
 
add(Object) - Method in interface groovyx.gpars.util.MessageQueue
 
addActiveMethod(FieldNode, ClassNode, MethodNode, boolean) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
addActorFieldToClass(ClassNode, String, String) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
addConnection(RemoteConnection) - Method in class groovyx.gpars.remote.RemoteHost
 
addDiscoveryListener(RemoteNodeDiscoveryListener) - Method in class groovyx.gpars.remote.LocalNode
 
addDiscoveryListener(Closure) - Method in class groovyx.gpars.remote.LocalNode
 
addError(String, ASTNode, SourceUnit) - Static method in class groovyx.gpars.util.ASTUtils
 
addListener(Closure) - Method in class groovyx.gpars.agent.AgentBase
Adds a listener interested in state updates A listener should be a closure accepting the old and the new value in this order plus optionally the agent reference as the first argument.
addLocalHost(LocalHost) - Static method in class groovyx.gpars.remote.LocalHostRegistry
 
addPoolActiveCount(int) - Method in class groovyx.gpars.scheduler.ForkJoinPoolEnhancer
 
address - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
address - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
addValidator(Closure) - Method in class groovyx.gpars.agent.AgentBase
Adds a validator checking the agent's state A listener should be a closure accepting the old and the new value in this order plus optionally the agent reference as the first argument.
AFTER_START - Static variable in class groovyx.gpars.actor.Actor
 
afterLoopCode - Variable in class groovyx.gpars.actor.DefaultActor
 
Agent<T> - Class in groovyx.gpars.agent
A special-purpose thread-safe non-blocking reference implementation inspired by Agents in Clojure.
Agent() - Constructor for class groovyx.gpars.agent.Agent
Creates a new Agent with the internal state set to null
Agent(T) - Constructor for class groovyx.gpars.agent.Agent
Creates a new Agent around the supplied modifiable object
Agent(T, Closure) - Constructor for class groovyx.gpars.agent.Agent
Creates a new Agent around the supplied modifiable object
agent(T) - Static method in class groovyx.gpars.agent.Agent
Creates an agent instance initialized with the given state.
agent(T, Closure) - Static method in class groovyx.gpars.agent.Agent
Creates an agent instance initialized with the given state.
AgentBase<T> - Class in groovyx.gpars.agent
Implements most of Agent's public method in Java
AgentBase(T) - Constructor for class groovyx.gpars.agent.AgentBase
 
AgentBase(T, Closure) - Constructor for class groovyx.gpars.agent.AgentBase
Creates a new Agent around the supplied modifiable object
AgentBase.AwaitClosure - Class in groovyx.gpars.agent
Returns the current value of the Agent's state
AgentBase.AwaitClosure() - Constructor for class groovyx.gpars.agent.AgentBase.AwaitClosure
 
AgentCore - Class in groovyx.gpars.agent
 
AgentCore() - Constructor for class groovyx.gpars.agent.AgentCore
 
AgentThreadFactory - Class in groovyx.gpars.agent
Creates daemon threads for the default agent thread pools
AgentThreadFactory() - Constructor for class groovyx.gpars.agent.AgentThreadFactory
 
AN_ACTOR_CAN_ONLY_RECEIVE_ONE_MESSAGE_AT_A_TIME - Static variable in class groovyx.gpars.actor.BlockingActor
 
AN_EXCEPTION_WAS_EXPECTED_TO_BE_THROWN_FROM_UNWRAP_STM_CONTROL_ERROR_FOR - Static variable in class groovyx.gpars.stm.GParsStm
 
anchor - Variable in class groovyx.gpars.serial.SerialHandle
 
appendingString() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
appendingString() - Method in interface groovyx.gpars.dataflow.stream.FList
 
apply(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Calls the supplied closure with the stream as a parameter
arg - Variable in class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
args - Variable in class groovyx.gpars.dataflow.DataflowComplexExpression
 
args - Variable in class groovyx.gpars.forkjoin.FJWorker
 
ASTUtils - Class in groovyx.gpars.util
Common functions for writing AST related code.
ASTUtils() - Constructor for class groovyx.gpars.util.ASTUtils
 
AsyncException - Exception in groovyx.gpars
This class wraps multiple exception, which occurred in concurrently run code inside one of the GParsExecutorsPoolUtil methods.
AsyncException(String, List<Throwable>) - Constructor for exception groovyx.gpars.AsyncException
 
AsyncFun - Annotation Type in groovyx.gpars
This annotation makes a field or local variable as an asynchronous function, and the field/variable should be evaluated only within the context of a ThreadPool.
AsyncFunASTTransformation - Class in groovyx.gpars.util
This transformation turns field initialExpressions into method calls to GParsPoolUtil.asyncFun(groovy.lang.Closure, boolean).
AsyncFunASTTransformation() - Constructor for class groovyx.gpars.util.AsyncFunASTTransformation
 
asyncHead - Variable in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
AsyncMessagingCore - Class in groovyx.gpars.util
 
AsyncMessagingCore(Pool) - Constructor for class groovyx.gpars.util.AsyncMessagingCore
 
atomic(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomic(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
atomicWithBoolean(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomicWithBoolean(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
atomicWithDouble(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomicWithDouble(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
atomicWithInt(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomicWithInt(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
atomicWithLong(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomicWithLong(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
atomicWithVoid(Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction.
atomicWithVoid(AtomicBlock, Closure) - Static method in class groovyx.gpars.stm.GParsStm
Performs the supplied code atomically within a transaction using the supplied atomic block.
ATTACHMENT - Static variable in class groovyx.gpars.dataflow.DataflowExpression
 
attachment - Variable in class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
 
attachToThreadPool(Pool) - Method in class groovyx.gpars.agent.AgentCore
Sets a new thread pool to be used by the agent
attachToThreadPool(Pool) - Method in class groovyx.gpars.util.AsyncMessagingCore
Sets a new thread pool to be used by the agent
await() - Method in class groovyx.gpars.agent.AgentBase
Blocks until all messages in the queue prior to call to await() complete.
awaitClosure - Static variable in class groovyx.gpars.agent.AgentBase
 
awaitNextMessage(long) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Holds common functionality for takeMessage() methods.

B

become(Closure) - Method in class groovyx.gpars.actor.DynamicDispatchActor
Executes the supplied closure in the context of the actor to set all when() handlers
bind(T) - Method in class groovyx.gpars.dataflow.DataflowExpression
Assigns a value to the variable.
bind(T) - Method in class groovyx.gpars.dataflow.DataflowQueue
Adds a DataflowVariable representing the passed in value to the buffer.
bind(T) - Method in interface groovyx.gpars.dataflow.DataflowWriteChannel
Assigns a value to the variable.
bind(T) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
bind(T) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
bindDFV(DataflowReadChannel<T>) - Method in class groovyx.gpars.dataflow.DataflowVariable
 
bindSafely(T) - Method in class groovyx.gpars.dataflow.DataflowExpression
Assigns a value to the variable.
bindUnique(T) - Method in class groovyx.gpars.dataflow.DataflowExpression
Assigns a value to the variable.
blockingActor(Runnable) - Static method in class groovyx.gpars.actor.Actors
Creates a new instance of BlockingActor, using the passed-in closure as the body of the actor's act() method.
BlockingActor - Class in groovyx.gpars.actor
 
BlockingActor() - Constructor for class groovyx.gpars.actor.BlockingActor
 
blockingMandated(String) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
bootstrap - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
boundNotification(int, DataflowReadChannel<? extends T>) - Method in class groovyx.gpars.dataflow.impl.SelectBase
Invoked by the SelectCallback instances, potentially concurrently to inform about new values being available for read from channels.
BroadcastDiscovery - Class in groovyx.gpars.remote
 
BroadcastDiscovery(UUID, InetSocketAddress) - Constructor for class groovyx.gpars.remote.BroadcastDiscovery
 
broadcastDiscovery - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider
 
build(T) - Static method in class groovyx.gpars.actor.ActorMessage
Factory method to create instances of ActorMessage with given payload.
buildClosureForMaps(Closure) - Static method in class groovyx.gpars.util.PAUtils
If the passed-in closure expects two arguments, it is considered to be a map-iterative code and is then wrapped with a single-argument closure, which unwraps the key:value pairs for the original closure.
buildClosureForMapsWithIndex(Closure) - Static method in class groovyx.gpars.util.PAUtils
If the passed-in closure expects three arguments, it is considered to be a map-iterative_with_index code and is then wrapped with a two-argument closure, which unwraps the key:value pairs for the original closure.
buildMessage() - Method in exception groovyx.gpars.AsyncException
 
buildResultMap(Collection<Map.Entry<K, V>>) - Static method in class groovyx.gpars.util.PAUtils
Builds a resulting map out of an map entry collection
bundle - Static variable in class groovyx.gpars.serial.SerialHandle
 

C

call(Object) - Method in class groovyx.gpars.actor.DefaultActorClosure
 
call(T) - Method in class groovyx.gpars.actor.impl.MessageStream
Same as send
call(Object) - Method in class groovyx.gpars.agent.AgentBase.AwaitClosure
 
call(Object) - Method in class groovyx.gpars.agent.AgentCore
Adds the message to the agent\s message queue
call(Object[]) - Method in class groovyx.gpars.dataflow.impl.SelectCallback
Invoked by the channel when a value has been bound to it and is available for consumption
call() - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
call(List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
call(MessageStream) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
call(MessageStream, List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
call() - Method in class groovyx.gpars.DataflowMessagingRunnable
 
call(Object[]) - Method in class groovyx.gpars.DataflowMessagingRunnable
 
call(Object) - Method in class groovyx.gpars.DataflowMessagingRunnable
 
call() - Method in class groovyx.gpars.MessagingRunnable
 
call(Object[]) - Method in class groovyx.gpars.MessagingRunnable
 
call(Object) - Method in class groovyx.gpars.MessagingRunnable
 
call(Object[]) - Method in class groovyx.gpars.pa.CallClosure
 
call() - Method in class groovyx.gpars.pa.CallClosure
 
call(Object) - Method in class groovyx.gpars.pa.CallClosure
 
call() - Method in class groovyx.gpars.ReactorMessagingRunnable
 
call(Object[]) - Method in class groovyx.gpars.ReactorMessagingRunnable
 
call(Object) - Method in class groovyx.gpars.ReactorMessagingRunnable
 
callback - Variable in class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
 
CallClosure - Class in groovyx.gpars.pa
A call-forwarding closure
CallClosure(Closure) - Constructor for class groovyx.gpars.pa.CallClosure
 
callDynamic(String, Object[]) - Method in class groovyx.gpars.actor.Actor
 
cancelCurrentTimeoutTask() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
CANNOT_CREATE_AN_ATOMIC_BLOCK_SOME_OF_THE_SPECIFIED_PARAMETERS_ARE_NOT_SUPPORTED - Static variable in class groovyx.gpars.stm.GParsStm
 
CANNOT_SEND_REPLIES_NO_SENDER_HAS_BEEN_REGISTERED - Static variable in class groovyx.gpars.actor.Actor
 
channel - Variable in class groovyx.gpars.dataflow.impl.SelectCallback
 
channel - Variable in class groovyx.gpars.remote.netty.NettyHandler
 
channel - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in class groovyx.gpars.remote.netty.NettyHandler
 
channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in class groovyx.gpars.remote.netty.NettyHandler
 
channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.ClientHandler
 
channelFuture - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Client
 
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in class groovyx.gpars.remote.netty.NettyHandler
 
channels - Variable in class groovyx.gpars.dataflow.impl.SelectBase
 
checkBlockingMethod(MethodNode, Iterable<AnnotationNode>) - Method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
checkClosure(Closure) - Method in class groovyx.gpars.agent.AgentBase
Only two-argument closures are allowed
checkForBodyArguments(Closure) - Static method in class groovyx.gpars.actor.DefaultActor
 
checkForMessageHandlerArguments(Closure) - Static method in class groovyx.gpars.actor.DefaultActor
 
checkForNull(Runnable) - Static method in class groovyx.gpars.actor.DefaultActor
 
checkStoppedFlags() - Method in class groovyx.gpars.actor.BlockingActor
 
checkStopTerminate() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
checkValidPoolSize(int) - Static method in class groovyx.gpars.util.PoolUtils
 
children - Variable in class groovyx.gpars.forkjoin.AbstractForkJoinWorker
Stores the child workers
clients - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider
 
clone() - Method in class groovyx.gpars.memoize.LRUProtectionStorage
Performs a shallow clone
clone() - Method in class groovyx.gpars.pa.CallClosure
 
closure - Variable in class groovyx.gpars.dataflow.DataflowExpression.TransformMany
 
closure - Variable in class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
closure - Variable in class groovyx.gpars.remote.RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
 
ClosureMapper - Class in groovyx.gpars.pa
A PA mapper built around a closure
ClosureMapper(Closure) - Constructor for class groovyx.gpars.pa.ClosureMapper
 
ClosurePredicate - Class in groovyx.gpars.pa
A PA predicate built around a closure
ClosurePredicate(Closure) - Constructor for class groovyx.gpars.pa.ClosurePredicate
 
ClosureReducer - Class in groovyx.gpars.pa
A PA reducer built around a closure
ClosureReducer(Closure) - Constructor for class groovyx.gpars.pa.ClosureReducer
 
code - Variable in class groovyx.gpars.dataflow.DataCallback
 
code - Variable in class groovyx.gpars.dataflow.DataCallbackWithPool
 
code - Variable in class groovyx.gpars.forkjoin.FJWorker
 
code - Variable in class groovyx.gpars.pa.ClosureMapper
 
code - Variable in class groovyx.gpars.pa.ClosurePredicate
 
code - Variable in class groovyx.gpars.pa.ClosureReducer
 
code - Variable in class groovyx.gpars.stm.GParsAtomicBlock
 
code - Variable in class groovyx.gpars.stm.GParsAtomicBooleanBlock
 
code - Variable in class groovyx.gpars.stm.GParsAtomicDoubleBlock
 
code - Variable in class groovyx.gpars.stm.GParsAtomicIntBlock
 
code - Variable in class groovyx.gpars.stm.GParsAtomicLongBlock
 
code - Variable in class groovyx.gpars.stm.GParsAtomicVoidBlock
 
compute() - Method in class groovyx.gpars.forkjoin.AbstractForkJoinWorker
 
computeTask() - Method in class groovyx.gpars.forkjoin.AbstractForkJoinWorker
 
computeTask() - Method in class groovyx.gpars.forkjoin.FJWorker
 
concurrentExceptions - Variable in exception groovyx.gpars.AsyncException
 
configuredPoolSize - Variable in class groovyx.gpars.scheduler.FJPool
 
connect(LocalNode) - Method in class groovyx.gpars.remote.LocalHost
Connect local node to the provider
connect(LocalNode) - Static method in class groovyx.gpars.remote.LocalHostRegistry
 
connect() - Method in class groovyx.gpars.remote.LocalNode
 
connect(LocalHost) - Method in class groovyx.gpars.remote.LocalNode
 
connect(LocalNode) - Method in class groovyx.gpars.remote.RemoteHost
 
connection - Variable in class groovyx.gpars.remote.netty.NettyHandler
 
connection - Variable in class groovyx.gpars.remote.netty.RemoteObjectDecoder
 
connection - Variable in class groovyx.gpars.remote.netty.RemoteObjectEncoder
 
connections - Variable in class groovyx.gpars.remote.RemoteHost
 
connectRemoteNode(UUID, SerialContext, Actor) - Method in class groovyx.gpars.remote.LocalHost
 
contains(Object) - Method in class groovyx.gpars.dataflow.Dataflows
Checks whether a certain key is contained in the map.
context - Variable in class groovyx.gpars.serial.SerialHandle
local host
continueProcessingMessages() - Method in class groovyx.gpars.util.AsyncMessagingCore
Informs about a new thread being assigned to process the next message
copy - Variable in class groovyx.gpars.agent.AgentBase
Function converting the internal state during read to prevent internal state escape from the protected boundary of the agent
copyDFV(Queue<DataflowVariable<T>>, Queue<DataflowVariable<T>>) - Method in class groovyx.gpars.dataflow.DataflowQueue
 
core - Variable in class groovyx.gpars.actor.AbstractLoopingActor
Holds the particular instance of async messaging core to use
core - Variable in class groovyx.gpars.agent.AgentCore
 
count - Variable in class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
create(Object) - Static method in class groovyx.gpars.activeobject.InternalActor
 
create(WithSerialId, UUID) - Static method in class groovyx.gpars.serial.SerialHandle
 
createActorMessage(Object) - Method in class groovyx.gpars.actor.Actor
 
createArray(CharSequence) - Static method in class groovyx.gpars.util.PAUtils
 
createArray(Map<Object, Object>) - Static method in class groovyx.gpars.util.PAUtils
 
createAtomicBlock() - Static method in class groovyx.gpars.stm.GParsStm
A factory method to create custom atomic blocks.
createAtomicBlock(Map<String, Object>) - Static method in class groovyx.gpars.stm.GParsStm
A factory method to create custom atomic blocks allowing the caller to set desired transactional characteristics.
createCollection(Iterable<Object>) - Static method in class groovyx.gpars.util.PAUtils
 
createCollection(Iterator<Object>) - Static method in class groovyx.gpars.util.PAUtils
 
createComparator(Closure) - Static method in class groovyx.gpars.util.PAUtils
Builds a comparator depending on the number of arguments accepted by the supplied closure.
createGroupByClosure(Closure, ConcurrentMap<Object, List<Object>>) - Static method in class groovyx.gpars.util.PAUtils
Creates a closure that will insert elements in the appropriate group
createObject(SerialContext) - Method in class groovyx.gpars.actor.Actor.MyRemoteHandle
 
createObject(SerialContext) - Method in class groovyx.gpars.serial.DefaultRemoteHandle
 
createObject(SerialContext) - Method in class groovyx.gpars.serial.RemoteHandle
 
createPool(boolean, int) - Static method in class groovyx.gpars.scheduler.DefaultPool
Creates a fixed-thread pool of given size.
createPool(int) - Static method in class groovyx.gpars.scheduler.FJPool
Creates a fork/join pool of given size.
createReadChannel() - Method in class groovyx.gpars.dataflow.DataflowBroadcast
Retrieves an implementation of DataflowReadChannel to read all messages submitted to the broadcast chanel.
createRemoteHandle(SerialHandle, SerialContext) - Method in class groovyx.gpars.actor.Actor
 
createRemoteHandle(SerialHandle, SerialContext) - Method in class groovyx.gpars.serial.WithSerialId
 
createResizeablePool(boolean, int) - Static method in class groovyx.gpars.scheduler.ResizeablePool
Creates a fixed-thread pool of given size.
createThreadName() - Static method in class groovyx.gpars.scheduler.DefaultPool
Created a JVM-unique name for Actors' threads.
current - Variable in class groovyx.gpars.dataflow.stream.FListIterator
 
currentActorPerThread - Static variable in class groovyx.gpars.actor.Actor
Maps each thread to the actor it currently processes.
currentSender - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 
currentThread - Variable in class groovyx.gpars.actor.Actor
 
currentTimerTask - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 

D

data - Variable in class groovyx.gpars.agent.AgentBase
Holds the internal mutable state
DATA_FLOW_GROUP - Static variable in class groovyx.gpars.dataflow.Dataflow
The parallel group used by all Dataflow Concurrency actors by default.
DataCallback - Class in groovyx.gpars.dataflow
A helper class enabling the 'whenBound()' or 'getValAsync' functionality of a DataflowVariable and DataflowQueue, as well as 'sendAndContinue()' on actors.
DataCallback(Closure, PGroup) - Constructor for class groovyx.gpars.dataflow.DataCallback
 
DataCallbackWithPool - Class in groovyx.gpars.dataflow
A helper class enabling the 'whenBound()' or 'getValAsync' functionality of a DataflowVariable and DataflowQueue, whenever a thread pool instead of a PGroup is specified..
DataCallbackWithPool(Pool, Closure) - Constructor for class groovyx.gpars.dataflow.DataCallbackWithPool
 
Dataflow - Class in groovyx.gpars.dataflow
Contains factory methods to create dataflow actors and starting them.
Dataflow() - Constructor for class groovyx.gpars.dataflow.Dataflow
 
DataflowBroadcast<T> - Class in groovyx.gpars.dataflow
Offers a deterministic one-to-many and many-to-many messaging alternative to DataflowQueue.
DataflowBroadcast() - Constructor for class groovyx.gpars.dataflow.DataflowBroadcast
Creates a new adapter
DataflowChannel<T> - Interface in groovyx.gpars.dataflow
A common interface for all dataflow variables, streams or queues
DataflowComplexExpression<T> - Class in groovyx.gpars.dataflow
 
DataflowComplexExpression(Object...) - Constructor for class groovyx.gpars.dataflow.DataflowComplexExpression
 
DataflowExpression<T> - Class in groovyx.gpars.dataflow
The base class for all dataflow elements.
DataflowExpression() - Constructor for class groovyx.gpars.dataflow.DataflowExpression
Creates a new unbound Dataflow Expression
DataflowExpression.BindDataflow<T> - Class in groovyx.gpars.dataflow
Represents a remote message binding a value to a remoted DataflowExpression
DataflowExpression.BindDataflow(DataflowExpression<T>, T, UUID) - Constructor for class groovyx.gpars.dataflow.DataflowExpression.BindDataflow
 
DataflowExpression.DataflowExpressionsCollector - Class in groovyx.gpars.dataflow
Listener for availability of data flow expressions we depend from
DataflowExpression.DataflowExpressionsCollector() - Constructor for class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
DataflowExpression.TransformMany<V> - Class in groovyx.gpars.dataflow
 
DataflowExpression.TransformMany(Collection<?>, Closure) - Constructor for class groovyx.gpars.dataflow.DataflowExpression.TransformMany
 
DataflowExpression.TransformOne<V> - Class in groovyx.gpars.dataflow
 
DataflowExpression.TransformOne(Object, Closure) - Constructor for class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
DataflowExpression.WaitingThread - Class in groovyx.gpars.dataflow
A logical representation of a synchronous or asynchronous request to read the value once it is bound.
DataflowExpression.WaitingThread(Thread, DataflowExpression.WaitingThread, Object, MessageStream) - Constructor for class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
Creates a representation of the request to read the value once it is bound
DataflowGetPropertyExpression<T> - Class in groovyx.gpars.dataflow
DFE which evaluate property when receiver became available
DataflowGetPropertyExpression(DataflowExpression<T>, String) - Constructor for class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
DataflowInvocationExpression - Class in groovyx.gpars.dataflow
Data flow expression which invokes method of object after receiver and all arguments became available
DataflowInvocationExpression(Object, String, Object[]) - Constructor for class groovyx.gpars.dataflow.DataflowInvocationExpression
 
DataflowMessagingRunnable - Class in groovyx.gpars
Represents a multi-argument Closure when using GPars dataflow operators and selectors through the Java API.
DataflowMessagingRunnable(int) - Constructor for class groovyx.gpars.DataflowMessagingRunnable
 
DataflowMessagingRunnable(Object, int) - Constructor for class groovyx.gpars.DataflowMessagingRunnable
 
DataflowQueue<T> - Class in groovyx.gpars.dataflow
Represents a thread-safe data flow stream.
DataflowQueue() - Constructor for class groovyx.gpars.dataflow.DataflowQueue
 
DataflowReadChannel<T> - Interface in groovyx.gpars.dataflow
A common interface for all dataflow variables, streams or queues
Dataflows - Class in groovyx.gpars.dataflow
Convenience class that makes working with DataflowVariables more comfortable.
Dataflows(int, float, int) - Constructor for class groovyx.gpars.dataflow.Dataflows
Constructor that supports the various constructors of the underlying ConcurrentHashMap (unless the one with Map parameter).
Dataflows() - Constructor for class groovyx.gpars.dataflow.Dataflows
Constructor with default values for building the underlying ConcurrentHashMap
DataflowStream<T> - Class in groovyx.gpars.dataflow.stream
Represents a deterministic dataflow channel.
DataflowStream() - Constructor for class groovyx.gpars.dataflow.stream.DataflowStream
Creates an empty stream
DataflowStream(Closure) - Constructor for class groovyx.gpars.dataflow.stream.DataflowStream
Creates a stream while applying the supplied initialization closure to it
DataflowStream(Collection<MessageStream>) - Constructor for class groovyx.gpars.dataflow.stream.DataflowStream
 
DataflowStreamReadAdapter<T> - Class in groovyx.gpars.dataflow.stream
Adapts a DataflowStream to accommodate for the DataflowReadChannel interface.
DataflowStreamReadAdapter(DataflowStream<T>) - Constructor for class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
Creates a new adapter
DataflowStreamWriteAdapter<T> - Class in groovyx.gpars.dataflow.stream
Adapts a DataflowStream to accommodate for the DataflowWriteChannel interface.
DataflowStreamWriteAdapter(DataflowStream<T>) - Constructor for class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
Creates a new adapter
DataflowVariable<T> - Class in groovyx.gpars.dataflow
Represents a thread-safe single-assignment, multi-read variable.
DataflowVariable() - Constructor for class groovyx.gpars.dataflow.DataflowVariable
Creates a new unbound Dataflow Variable
DataflowVariable.RemoteDataflowVariable<T> - Class in groovyx.gpars.dataflow
 
DataflowVariable.RemoteDataflowVariable(RemoteHost) - Constructor for class groovyx.gpars.dataflow.DataflowVariable.RemoteDataflowVariable
 
DataflowWriteChannel<T> - Interface in groovyx.gpars.dataflow
A common interface for all writable dataflow variables, streams or queues
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in class groovyx.gpars.remote.netty.RemoteObjectDecoder
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class groovyx.gpars.dataflow.Dataflows
 
DEFAULT_INITIAL_CAPACITY - Static variable in class groovyx.gpars.dataflow.Dataflows
 
DEFAULT_LOAD_FACTOR - Static variable in class groovyx.gpars.dataflow.Dataflows
 
DEFAULT_SHUTDOWN_TIMEOUT - Static variable in class groovyx.gpars.scheduler.FJPool
 
DefaultActor - Class in groovyx.gpars.actor
The DefaultActor class is the base for all stateful actors, who need to maintain implicit state between subsequent message arrivals.
DefaultActor() - Constructor for class groovyx.gpars.actor.DefaultActor
Creates an actor, which will execute its act() methods
DefaultActor(Runnable) - Constructor for class groovyx.gpars.actor.DefaultActor
Creates an actor, which will execute the supplied code
DefaultActorClosure - Class in groovyx.gpars.actor
Represents the DDA closure to invoke appropriate message handlers based on message runtime type
DefaultActorClosure(DefaultActor) - Constructor for class groovyx.gpars.actor.DefaultActorClosure
 
defaultActorPGroup - Static variable in class groovyx.gpars.actor.Actors
The default actor group to share by all actors created through the Actors class.
defaultAtomicBlock - Static variable in class groovyx.gpars.stm.GParsStm
The atomic block to use when no block is specified explicitly
DefaultMessageQueue - Class in groovyx.gpars.util
An implementation of the message queue for actor and agent messaging.
DefaultMessageQueue() - Constructor for class groovyx.gpars.util.DefaultMessageQueue
 
defaultParamTypes - Variable in class groovyx.gpars.DataflowMessagingRunnable
 
DefaultPGroup - Class in groovyx.gpars.group
Provides logical grouping for actors, agents and dataflow tasks and operators.
DefaultPGroup(Pool) - Constructor for class groovyx.gpars.group.DefaultPGroup
Creates a group for actors, agents, tasks and operators.
DefaultPGroup() - Constructor for class groovyx.gpars.group.DefaultPGroup
Creates a group for actors, agents, tasks and operators.
DefaultPGroup(int) - Constructor for class groovyx.gpars.group.DefaultPGroup
Creates a group for actors, agents, tasks and operators.
DefaultPool - Class in groovyx.gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
DefaultPool() - Constructor for class groovyx.gpars.scheduler.DefaultPool
Creates the pool with default number of daemon threads.
DefaultPool(boolean) - Constructor for class groovyx.gpars.scheduler.DefaultPool
Creates the pool with default number of threads.
DefaultPool(boolean, int) - Constructor for class groovyx.gpars.scheduler.DefaultPool
Creates the pool with specified number of threads.
DefaultPool(ThreadPoolExecutor) - Constructor for class groovyx.gpars.scheduler.DefaultPool
Creates the pool around the given executor service
DefaultRemoteHandle - Class in groovyx.gpars.serial
 
DefaultRemoteHandle(UUID, UUID, Class<?>) - Constructor for class groovyx.gpars.serial.DefaultRemoteHandle
 
deregisterCurrentActorWithThread() - Static method in class groovyx.gpars.actor.Actor
Deregisters the actor registered from the thread
disabledDFVs - Variable in class groovyx.gpars.dataflow.impl.SelectBase
Since DataflowVariables should be only read once, they need to be disabled after selecting their value The array stores a boolean flag for each index, indicating, whether the channel/variable has been disabled
disableDFV(int, DataflowReadChannel<? extends T>) - Method in class groovyx.gpars.dataflow.impl.SelectBase
Sets the flag in the disabledDFVs array, if the channel is a DFV
disconnect(LocalNode) - Method in class groovyx.gpars.remote.LocalHost
Disconnect local node from the provider
disconnect() - Method in class groovyx.gpars.remote.LocalHost
 
disconnect(LocalNode) - Static method in class groovyx.gpars.remote.LocalHostRegistry
 
disconnect() - Method in class groovyx.gpars.remote.LocalNode
 
disconnect() - Method in class groovyx.gpars.remote.netty.NettyRemoteConnection
 
disconnect() - Method in class groovyx.gpars.remote.netty.NettyTransportProvider
 
disconnect() - Method in class groovyx.gpars.remote.RemoteConnection
 
disconnect() - Method in class groovyx.gpars.remote.RemoteHost
 
disconnect(LocalNode) - Method in class groovyx.gpars.remote.RemoteHost
 
disconnected - Variable in class groovyx.gpars.dataflow.DataflowVariable.RemoteDataflowVariable
 
disconnectRemoteNode(UUID) - Method in class groovyx.gpars.remote.LocalHost
 
doBind(T) - Method in class groovyx.gpars.dataflow.DataflowExpression
Performs the actual bind operation, unblocks all blocked threads and informs all asynchronously waiting actors.
doBindImpl(T) - Method in class groovyx.gpars.dataflow.DataflowExpression
 
doBindRemote(UUID, T) - Method in class groovyx.gpars.dataflow.DataflowExpression
Binds the value after receiving a bing message over the wire
doLoop(Callable<Boolean>, Closure, Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
doRun(Object[]) - Method in class groovyx.gpars.DataflowMessagingRunnable
Defines the action performed by the Runnable
doRun(T) - Method in class groovyx.gpars.MessagingRunnable
Defines the action performed by the Runnable
doRun(T) - Method in class groovyx.gpars.ReactorMessagingRunnable
Defines the action performed by the Runnable
doSelect(int, SelectRequest<T>) - Method in class groovyx.gpars.dataflow.impl.SelectBase
Invoked whenever the Select is asked for the next value.
doStart() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
DUMMY - Static variable in class groovyx.gpars.dataflow.Dataflows
 
dummyWaitingThread - Static variable in class groovyx.gpars.dataflow.DataflowExpression
A request chain terminator
DynamicDispatchActor - Class in groovyx.gpars.actor
A pooled actor allowing for an alternative structure of the message handling code.
DynamicDispatchActor() - Constructor for class groovyx.gpars.actor.DynamicDispatchActor
Creates a new instance without any when handlers registered

E

empty - Variable in class groovyx.gpars.util.DefaultMessageQueue
 
EMPTY_ARGUMENTS - Static variable in class groovyx.gpars.actor.Actor
 
EMPTY_OBJECTS - Static variable in class groovyx.gpars.forkjoin.FJWorker
 
encode(ChannelHandlerContext, Channel, Object) - Method in class groovyx.gpars.remote.netty.RemoteObjectEncoder
 
enhanceAndUnwrap(ActorMessage) - Method in class groovyx.gpars.actor.BlockingActor
 
enhanceClosure(Closure) - Method in class groovyx.gpars.actor.DefaultActor
 
EnhancedRWLock - Class in groovyx.gpars.util
Extends ReentrantReadWriteLock with handy withReadLock(Closure) and withWriteLock(Closure) methods to safely lock and unlock the lock for the passed-in closure.
EnhancedRWLock() - Constructor for class groovyx.gpars.util.EnhancedRWLock
 
EnhancedRWLock(boolean) - Constructor for class groovyx.gpars.util.EnhancedRWLock
 
EnhancedSemaphore - Class in groovyx.gpars.util
Extends Semaphore with a handy withSemaphore(Closure) method to safely acquire and release the Semaphore for the passed-in closure.
EnhancedSemaphore(int) - Constructor for class groovyx.gpars.util.EnhancedSemaphore
Creates a new EnhancedSemaphore, delegating to the Semaphore class constructor.
enhanceReplies(ActorMessage) - Method in class groovyx.gpars.actor.BlockingActor
Adds reply and replyIfExists methods to the current Actor and the message.
ensureToContainVariable(Object) - Method in class groovyx.gpars.dataflow.Dataflows
The idea is following: - we try to putIfAbsent dummy DFV in to map - if something real already there we are done - if not we obtain lock and put new DFV with double check

Unfortunately we have to sync on this as there is no better option (God forbid to sync on name)

enter() - Method in class groovyx.gpars.serial.SerialContext
Enter to the context
eos() - Static method in class groovyx.gpars.dataflow.stream.DataflowStream
 
equals(Object) - Method in class groovyx.gpars.dataflow.SelectResult
 
equals(Object) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
equals(Object) - Method in class groovyx.gpars.memoize.NullValue
 
errors - Variable in class groovyx.gpars.agent.AgentCore
Holds agent errors
eval(Object) - Static method in class groovyx.gpars.dataflow.stream.DataflowStream
 
evalLoopCondition() - Method in class groovyx.gpars.actor.DefaultActor
 
evaluate() - Method in class groovyx.gpars.dataflow.DataflowComplexExpression
 
evaluate() - Method in class groovyx.gpars.dataflow.DataflowExpression
Evaluate expression after the ones we depend on are ready
evaluate() - Method in class groovyx.gpars.dataflow.DataflowExpression.TransformMany
 
evaluate() - Method in class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
evaluate() - Method in class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
evaluate() - Method in class groovyx.gpars.dataflow.DataflowInvocationExpression
 
evaluate() - Method in class groovyx.gpars.dataflow.RemoteDataflowExpression
 
evaluateArguments(Pool, Object[], int, List<Object>, DataflowVariable<Object>, Closure, boolean) - Static method in class groovyx.gpars.util.PAUtils
Performs a single step in the evaluation of parameters passed into an asynchronous function
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class groovyx.gpars.remote.netty.NettyHandler
 
execute(RemoteConnection) - Method in class groovyx.gpars.actor.Actor.RemoteActor.StopActorMsg
 
execute(RemoteConnection) - Method in class groovyx.gpars.actor.Actor.RemoteActor.TerminateActorMsg
 
execute(RemoteConnection) - Method in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
execute(RemoteConnection) - Method in class groovyx.gpars.dataflow.DataflowExpression.BindDataflow
Performs the actual bind on the remote host
execute(RemoteConnection) - Method in class groovyx.gpars.remote.message.NodeConnectedMsg
 
execute(RemoteConnection) - Method in class groovyx.gpars.remote.message.NodeDisconnectedMsg
 
execute(Runnable) - Method in class groovyx.gpars.scheduler.DefaultPool
schedules a new task for processing with the pool
execute(Runnable) - Method in class groovyx.gpars.scheduler.FJPool
schedules a new task for processing with the pool
execute(Runnable) - Method in interface groovyx.gpars.scheduler.Pool
schedules a new task for processing with the pool
execute(Runnable) - Method in class groovyx.gpars.scheduler.Scheduler
 
execute(RemoteConnection) - Method in class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle.ReleaseHandle
 
execute(RemoteConnection) - Method in class groovyx.gpars.serial.SerialMsg
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicBlock
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicBooleanBlock
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicDoubleBlock
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicIntBlock
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicLongBlock
 
execute(Transaction) - Method in class groovyx.gpars.stm.GParsAtomicVoidBlock
 
EXPECTED - Static variable in class groovyx.gpars.actor.DefaultActor
 
expr - Variable in class groovyx.gpars.dataflow.DataflowExpression.BindDataflow
 

F

factory - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Client
 
factory - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
fair - Variable in class groovyx.gpars.util.AsyncMessagingCore
Fair agents give up the thread after processing each message, non-fair agents keep a thread until their message queue is empty.
fairActor(Runnable) - Static method in class groovyx.gpars.actor.Actors
Creates a new instance of PooledActor, using the passed-in closure as the body of the actor's act() method.
fairAgent(T) - Static method in class groovyx.gpars.agent.Agent
Creates an agent instance initialized with the given state, which will cooperate in thread sharing with other Agent instances in a fair manner.
fairAgent(T, Closure) - Static method in class groovyx.gpars.agent.Agent
Creates an agent instance initialized with the given state, which will cooperate in thread sharing with other agents and actors in a fair manner.
fairMessageHandler(Closure) - Static method in class groovyx.gpars.actor.Actors
Creates an instance of DynamicDispatchActor, which will cooperate in thread sharing with other actors in a fair manner.
fairReactor(Closure) - Static method in class groovyx.gpars.actor.Actors
Creates a reactor around the supplied code, which will cooperate in thread sharing with other actors in a fair manner.
filter(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Builds a filtered stream using the supplied filter closure
filter(DataflowStream<T>, Closure, DataflowStream<T>) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
filter(Closure) - Method in interface groovyx.gpars.dataflow.stream.FList
 
finalizeHandle(SerialHandle) - Method in class groovyx.gpars.serial.SerialContext
 
finalizeHandle(SerialHandle) - Method in class groovyx.gpars.serial.SerialHandles
 
finalizeReference() - Method in class groovyx.gpars.serial.SerialHandle
 
finalizeReference() - Method in class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle
 
findGroupById(String) - Method in class groovyx.gpars.activeobject.ActiveObjectRegistry
 
findSuitablePrivateMethodName(ClassNode, MethodNode) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
first - Variable in class groovyx.gpars.actor.ForwardingDelegate
 
first - Variable in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 
first - Variable in class groovyx.gpars.dataflow.stream.DataflowStream
 
FJPool - Class in groovyx.gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
FJPool() - Constructor for class groovyx.gpars.scheduler.FJPool
Creates the pool with default number of threads.
FJPool(int) - Constructor for class groovyx.gpars.scheduler.FJPool
Creates the pool with specified number of threads.
FJPool(ForkJoinPool) - Constructor for class groovyx.gpars.scheduler.FJPool
Creates the pool wrapping the provided ForkJoinPool
FJWorker<T> - Class in groovyx.gpars.forkjoin
Represents a recursive task for the builder-style fork/join algorithm.
FJWorker(Object...) - Constructor for class groovyx.gpars.forkjoin.FJWorker
 
FList<T> - Interface in groovyx.gpars.dataflow.stream
Represents a list implemented as a Functional Queue.
FListIterator<T> - Class in groovyx.gpars.dataflow.stream
 
FListIterator(FList<T>) - Constructor for class groovyx.gpars.dataflow.stream.FListIterator
 
ForkJoinPoolEnhancer - Class in groovyx.gpars.scheduler
Enhanced the ForkJoinPool class with the resizing capability
ForkJoinPoolEnhancer() - Constructor for class groovyx.gpars.scheduler.ForkJoinPoolEnhancer
 
ForkJoinPoolEnhancer(int) - Constructor for class groovyx.gpars.scheduler.ForkJoinPoolEnhancer
 
ForkJoinPoolEnhancer(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class groovyx.gpars.scheduler.ForkJoinPoolEnhancer
 
ForkJoinUtils - Class in groovyx.gpars.forkjoin
 
ForkJoinUtils() - Constructor for class groovyx.gpars.forkjoin.ForkJoinUtils
 
forkOffChild(AbstractForkJoinWorker<T>) - Method in class groovyx.gpars.forkjoin.AbstractForkJoinWorker
Forks a child task.
forkOffChild(Object...) - Method in class groovyx.gpars.forkjoin.FJWorker
 
ForwardingDelegate - Class in groovyx.gpars.actor
 
ForwardingDelegate(Object, Object) - Constructor for class groovyx.gpars.actor.ForwardingDelegate
 
FQMessageQueue - Class in groovyx.gpars.util
An implementation of the message queue for actor and agent messaging using functional queues.
FQMessageQueue() - Constructor for class groovyx.gpars.util.FQMessageQueue
 
FQMessageQueue.EmptyNode - Class in groovyx.gpars.util
 
FQMessageQueue.EmptyNode() - Constructor for class groovyx.gpars.util.FQMessageQueue.EmptyNode
 
FQMessageQueue.Node - Class in groovyx.gpars.util
 
FQMessageQueue.Node(FQMessageQueue.Node, Object) - Constructor for class groovyx.gpars.util.FQMessageQueue.Node
 

G

generate(T, Closure, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Populates the stream with generated values
generateNext(T, DataflowStream<T>, Closure, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
get() - Method in class groovyx.gpars.dataflow.DataflowVariable
Retrieves the value of the variable, blocking until a value is available
get(long, TimeUnit) - Method in class groovyx.gpars.dataflow.DataflowVariable
Retrieves the value of the variable, blocking up to given timeout, if the value has not been assigned yet.
get() - Method in interface groovyx.gpars.dataflow.Promise
Retrieves the value of the variable, blocking until a value is available
get(long, TimeUnit) - Method in interface groovyx.gpars.dataflow.Promise
Retrieves the value of the variable, blocking up to given timeout, if the value has not been assigned yet.
get(Object) - Method in class groovyx.gpars.memoize.LRUProtectionStorage
 
get() - Static method in class groovyx.gpars.serial.SerialContext
 
get(UUID) - Method in class groovyx.gpars.serial.SerialContext
 
get(UUID) - Method in class groovyx.gpars.serial.SerialHandles
 
getAddress() - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
getAt(int) - Method in class groovyx.gpars.dataflow.Dataflows
Retrieves the DFV associated with the given index
getChannel() - Method in class groovyx.gpars.remote.netty.NettyHandler
 
getChildrenResults() - Method in class groovyx.gpars.forkjoin.AbstractForkJoinWorker
Waits for and returns the results of the child tasks.
getConcurrentExceptions() - Method in exception groovyx.gpars.AsyncException
 
getConfiguredPoolSize() - Method in class groovyx.gpars.scheduler.FJPool
 
getConnection() - Method in class groovyx.gpars.remote.RemoteHost
 
getCore() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
getCurrent() - Method in class groovyx.gpars.ThreadLocalPools
Gives the current element
getErrors() - Method in class groovyx.gpars.agent.AgentCore
Retrieves a list of exception thrown within the agent's body.
getExecutorService() - Method in class groovyx.gpars.scheduler.DefaultPool
Retrieves the internal executor service.
getFirst() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Retrieved the first element in the stream, blocking until a value is available
getFirst() - Method in interface groovyx.gpars.dataflow.stream.FList
 
getFirstDFV() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
getForkJoinPool() - Method in class groovyx.gpars.scheduler.FJPool
Retrieves the internal executor service.
getHead() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
getHost() - Method in class groovyx.gpars.remote.RemoteConnection
 
getHostId() - Method in class groovyx.gpars.serial.SerialContext
 
getId() - Method in class groovyx.gpars.actor.ActorTimerTask
 
getId() - Method in class groovyx.gpars.remote.LocalNode
 
getId() - Method in class groovyx.gpars.remote.RemoteNode
 
getId() - Method in class groovyx.gpars.serial.LocalHandle
 
getId() - Method in class groovyx.gpars.serial.SerialHandles
Getter for provider id
getIndex() - Method in class groovyx.gpars.dataflow.SelectResult
 
getInstance() - Static method in class groovyx.gpars.activeobject.ActiveObjectRegistry
 
getInstantVal() - Method in class groovyx.gpars.agent.AgentBase
A shorthand method for safe message-based retrieval of the internal state.
getIssues() - Method in exception groovyx.gpars.actor.impl.ActorReplyException
 
getJoinLatch() - Method in class groovyx.gpars.actor.Actor
Join-point for this actor
getLocalHost() - Method in class groovyx.gpars.remote.LocalNode
 
getLocalHost() - Method in class groovyx.gpars.remote.RemoteHost
 
getLocalHostId() - Method in class groovyx.gpars.serial.SerialContext
 
getMainActor() - Method in class groovyx.gpars.remote.LocalNode
 
getMainActor() - Method in class groovyx.gpars.remote.RemoteNode
 
getMaximumNumberOfParameters() - Method in class groovyx.gpars.DataflowMessagingRunnable
 
getMaximumNumberOfParameters() - Method in class groovyx.gpars.MessagingRunnable
 
getMaximumNumberOfParameters() - Method in class groovyx.gpars.ReactorMessagingRunnable
 
getMessage() - Method in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
getMessage() - Method in exception groovyx.gpars.AsyncException
 
getMetaClass() - Method in class groovyx.gpars.dataflow.DataflowExpression
 
getOrCreateSerialHandle() - Method in class groovyx.gpars.serial.WithSerialId
Gets serial handle for the object If needed new handle created and serialization host subscribed for the object handle
getOwningProcessor() - Method in class groovyx.gpars.DataflowMessagingRunnable
Retrieves the owning processor (operator or selector) giving the DataflowMessagingRunnable a way to call methods like bindOutput()
getParallelGroup() - Method in class groovyx.gpars.actor.Actor
Retrieves the group to which the actor belongs
getParameterTypes() - Method in class groovyx.gpars.DataflowMessagingRunnable
Returns types expected by the Runnable.
getParameterTypes() - Method in class groovyx.gpars.MessagingRunnable
 
getParameterTypes() - Method in class groovyx.gpars.ReactorMessagingRunnable
 
getPayLoad() - Method in class groovyx.gpars.actor.ActorMessage
 
getPipeline() - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.ServerPipelineFactory
 
getPoolSize() - Method in class groovyx.gpars.scheduler.DefaultPool
Retrieves the current thread pool size
getPoolSize() - Method in class groovyx.gpars.scheduler.FJPool
Retrieves the current thread pool size
getPoolSize() - Method in interface groovyx.gpars.scheduler.Pool
Retrieves the current thread pool size
getPoolSize() - Method in class groovyx.gpars.scheduler.Scheduler
Retrieves the current thread pool size
getProperty(String) - Method in class groovyx.gpars.actor.ForwardingDelegate
 
getProperty(String) - Method in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 
getProperty(String) - Method in class groovyx.gpars.dataflow.DataflowExpression
Returns either standard property of expression or creates expression, which will request given property when receiver became available
getProperty(String) - Method in class groovyx.gpars.dataflow.Dataflows
 
getRemoteClass() - Method in class groovyx.gpars.actor.impl.MessageStream
 
getRemoteClass() - Method in class groovyx.gpars.dataflow.DataflowVariable
 
getRemoteClass() - Method in class groovyx.gpars.serial.WithSerialId
Class of remote object to be created
getRemoteHost() - Method in class groovyx.gpars.remote.RemoteNode
 
getRest() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Retrieves a DataflowStream representing the rest of this Stream after removing the first element
getRest() - Method in interface groovyx.gpars.dataflow.stream.FList
 
getResult() - Method in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
Retrieves the response blocking until a message arrives
getResult(long, TimeUnit) - Method in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
Retrieves the response blocking until a message arrives
getScheduler() - Method in class groovyx.gpars.remote.LocalNode
 
getSender() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Retrieves the sender actor of the currently processed message.
getSender() - Method in class groovyx.gpars.actor.ActorMessage
 
getSender() - Method in class groovyx.gpars.actor.impl.ReplyingMessageStream
 
getSerialHost(UUID, Object) - Method in class groovyx.gpars.remote.LocalHost
 
getSerialHost(UUID, Object) - Method in class groovyx.gpars.serial.SerialContext
 
getSerialHost(UUID, Object) - Method in class groovyx.gpars.serial.SerialHandles
 
getSerialId() - Method in class groovyx.gpars.serial.SerialHandle
Serial id of the object
getSourceUnit() - Method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
getSubscribers() - Method in class groovyx.gpars.serial.SerialHandle
Getter for subscribers
getThreadPool() - Method in class groovyx.gpars.util.AsyncMessagingCore
 
getTo() - Method in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
getVal() - Method in class groovyx.gpars.agent.AgentBase
A shorthand method for safe message-based retrieval of the internal state.
getVal() - Method in class groovyx.gpars.dataflow.DataflowExpression
Reads the value of the variable.
getVal(long, TimeUnit) - Method in class groovyx.gpars.dataflow.DataflowExpression
Reads the value of the variable.
getVal() - Method in class groovyx.gpars.dataflow.DataflowQueue
Retrieves the value at the head of the buffer.
getVal(long, TimeUnit) - Method in class groovyx.gpars.dataflow.DataflowQueue
Retrieves the value at the head of the buffer.
getVal() - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Reads the current value of the channel.
getVal(long, TimeUnit) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Reads the current value of the channel.
getVal() - Method in interface groovyx.gpars.dataflow.Promise
Reads the current value of the channel.
getVal(long, TimeUnit) - Method in interface groovyx.gpars.dataflow.Promise
Reads the current value of the channel.
getVal() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
getVal(long, TimeUnit) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
getValAsync(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowExpression
Asynchronously retrieves the value of the variable.
getValAsync(Object, MessageStream) - Method in class groovyx.gpars.dataflow.DataflowExpression
Used by Dataflow operators.
getValAsync(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowQueue
Asynchronously retrieves the value at the head of the buffer.
getValAsync(Object, MessageStream) - Method in class groovyx.gpars.dataflow.DataflowQueue
Asynchronously retrieves the value at the head of the buffer.
getValAsync(MessageStream) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Asynchronously retrieves the value from the channel.
getValAsync(Object, MessageStream) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Asynchronously retrieves the value from the channel.
getValAsync(MessageStream) - Method in interface groovyx.gpars.dataflow.Promise
Asynchronously retrieves the value from the channel.
getValAsync(Object, MessageStream) - Method in interface groovyx.gpars.dataflow.Promise
Asynchronously retrieves the value from the channel.
getValAsync(MessageStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
getValAsync(Object, MessageStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
getValue() - Method in class groovyx.gpars.dataflow.SelectResult
 
GPARS_POOLSIZE - Static variable in class groovyx.gpars.util.PoolUtils
 
GParsAtomicBlock<T> - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicClosure properly handling exception propagation
GParsAtomicBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicBlock
 
GParsAtomicBooleanBlock - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicBooleanClosure properly handling exception propagation
GParsAtomicBooleanBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicBooleanBlock
 
GParsAtomicDoubleBlock - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicDoubleClosure properly handling exception propagation
GParsAtomicDoubleBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicDoubleBlock
 
GParsAtomicIntBlock - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicIntClosure properly handling exception propagation
GParsAtomicIntBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicIntBlock
 
GParsAtomicLongBlock - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicLongClosure properly handling exception propagation
GParsAtomicLongBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicLongBlock
 
GParsAtomicVoidBlock - Class in groovyx.gpars.stm
A default implementation of org.multiverse.api.closures.AtomicVoidClosure properly handling exception propagation
GParsAtomicVoidBlock(Closure) - Constructor for class groovyx.gpars.stm.GParsAtomicVoidBlock
 
GParsStm - Class in groovyx.gpars.stm
Provides access to GPars Stm services.
GParsStm() - Constructor for class groovyx.gpars.stm.GParsStm
 
groovyx.gpars - package groovyx.gpars
This package holds classes for asynchronous collection processing.
groovyx.gpars.activeobject - package groovyx.gpars.activeobject
 
groovyx.gpars.actor - package groovyx.gpars.actor
This package holds classes forming the public actor API.
groovyx.gpars.actor.impl - package groovyx.gpars.actor.impl
This package holds classes some non-public aspects of actor implementation.
groovyx.gpars.agent - package groovyx.gpars.agent
 
groovyx.gpars.dataflow - package groovyx.gpars.dataflow
This package holds classes for basic dataflow concurrency constructs, like dataflow variables, streams and threads.
groovyx.gpars.dataflow.impl - package groovyx.gpars.dataflow.impl
 
groovyx.gpars.dataflow.stream - package groovyx.gpars.dataflow.stream
 
groovyx.gpars.forkjoin - package groovyx.gpars.forkjoin
 
groovyx.gpars.group - package groovyx.gpars.group
 
groovyx.gpars.memoize - package groovyx.gpars.memoize
 
groovyx.gpars.pa - package groovyx.gpars.pa
 
groovyx.gpars.remote - package groovyx.gpars.remote
This package holds classes implementing the remote actors functionality.
groovyx.gpars.remote.message - package groovyx.gpars.remote.message
This package holds message classes for the remote actors implementation.
groovyx.gpars.remote.netty - package groovyx.gpars.remote.netty
This package holds implementation-specific classes implementing the remote actors functionality on top of Netty.
groovyx.gpars.scheduler - package groovyx.gpars.scheduler
This package holds thread pools / schedulers used by actors and dataflow concurrency.
groovyx.gpars.serial - package groovyx.gpars.serial
This package holds classes used for actor identification in the network.
groovyx.gpars.stm - package groovyx.gpars.stm
 
groovyx.gpars.util - package groovyx.gpars.util
Various utility classes enhancing basic Java concurrency constructs.
group - Static variable in class groovyx.gpars.remote.BroadcastDiscovery
 
GuardedSelectRequest<T> - Class in groovyx.gpars.dataflow.impl
The base implementation of the SelectRequest interface, providing a useful default masking (guarding) functionality.
GuardedSelectRequest(List<Boolean>) - Constructor for class groovyx.gpars.dataflow.impl.GuardedSelectRequest
 

H

handleCurrentMessage(Object) - Static method in class groovyx.gpars.activeobject.InternalActor
 
handleException(Throwable) - Method in class groovyx.gpars.actor.Actor
 
handleInterrupt(InterruptedException) - Method in class groovyx.gpars.actor.Actor
 
handleInterruption(AtomicBoolean) - Static method in class groovyx.gpars.dataflow.DataflowExpression
 
handleMessage(Object) - Method in class groovyx.gpars.agent.Agent
Dynamically dispatches the method call
handleMessage(Object) - Method in class groovyx.gpars.agent.AgentCore
Dynamically dispatches the method call
handleMessage(Object) - Method in class groovyx.gpars.util.AsyncMessagingCore
 
handler - Variable in class groovyx.gpars.remote.netty.NettyRemoteConnection
 
handler - Variable in class groovyx.gpars.remote.netty.NettyRemoteConnection.MyChannelFutureListener
 
handleStart() - Method in class groovyx.gpars.actor.Actor
 
handleStart() - Method in class groovyx.gpars.actor.BlockingActor
 
handleStart() - Method in class groovyx.gpars.actor.DefaultActor
Called once the START_MESSAGE arrives.
handleTermination() - Method in class groovyx.gpars.actor.Actor
 
handleTermination() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
handleTimeout() - Method in class groovyx.gpars.actor.Actor
 
hasBeenStopped() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
hasBeenStopped() - Method in class groovyx.gpars.actor.Actor
 
hasBeenStopped() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
hasBeenStopped() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
hasErrors() - Method in class groovyx.gpars.agent.AgentCore
Indicates whether there have been exception thrown within the agent's body.
hashCode() - Method in class groovyx.gpars.dataflow.SelectResult
 
hashCode() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
hashCode() - Method in class groovyx.gpars.memoize.NullValue
 
hasNext() - Method in class groovyx.gpars.dataflow.stream.FListIterator
 
head - Variable in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
head - Variable in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
hookWheneverBoundListeners(DataflowExpression<T>) - Method in class groovyx.gpars.dataflow.DataflowQueue
Hooks the registered when bound handlers to the supplied dataflow expression
hookWheneverBoundListeners(DataflowExpression<T>) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Hooks the registered when bound handlers to the supplied dataflow expression
host - Variable in class groovyx.gpars.remote.RemoteConnection
 
hostId - Variable in class groovyx.gpars.serial.RemoteHandle
 
hostId - Variable in class groovyx.gpars.serial.SerialContext
 
hostId - Variable in class groovyx.gpars.serial.SerialMsg
 
HostIdMsg - Class in groovyx.gpars.remote.message
Message sent by NetTransportProvider immediately after connection to another host is set up
HostIdMsg(UUID) - Constructor for class groovyx.gpars.remote.message.HostIdMsg
Construct message representing current state of the transport provider

I

id - Variable in class groovyx.gpars.actor.ActorTimerTask
 
id - Variable in class groovyx.gpars.remote.LocalNode
 
id - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.ClientHandler
 
id - Variable in class groovyx.gpars.remote.RemoteNode
 
id - Variable in class groovyx.gpars.serial.LocalHandle
 
id - Variable in class groovyx.gpars.serial.SerialHandles
Unique id of the provider
index - Variable in class groovyx.gpars.dataflow.impl.SelectCallback
 
index - Variable in class groovyx.gpars.dataflow.SelectResult
 
init(ASTNode[]) - Static method in class groovyx.gpars.util.AsyncFunASTTransformation
 
initialize(Closure) - Method in class groovyx.gpars.actor.AbstractLoopingActor
Builds the async messaging core using the supplied code handler
initialValue() - Method in class groovyx.gpars.ThreadLocalPools
 
inputQueue - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
Stored incoming messages.
inputQueueUpdater - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
inside - Variable in class groovyx.gpars.util.DefaultMessageQueue
 
inside - Variable in class groovyx.gpars.util.FQMessageQueue
 
instance - Static variable in class groovyx.gpars.remote.netty.NettyTransportProvider.MyThreadFactory
 
INTERNAL_ACTIVE_OBJECT_ACTOR - Static variable in annotation type groovyx.gpars.activeobject.ActiveObject
 
InternalActor - Class in groovyx.gpars.activeobject
Backs active objects and invokes all object's active methods.
InternalActor() - Constructor for class groovyx.gpars.activeobject.InternalActor
Just like DynamicDispatchActor, except that the actual method dispatch is static through the closure passed to the initialize() method.
invokeMethod(String, Object) - Method in class groovyx.gpars.actor.ForwardingDelegate
 
invokeMethod(String, Object) - Method in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 
invokeMethod(String, Object) - Method in class groovyx.gpars.dataflow.DataflowExpression
 
invokeMethod(String, Object) - Method in class groovyx.gpars.dataflow.Dataflows
Invokes the given method.
isActive() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
isActive() - Method in class groovyx.gpars.actor.Actor
Checks the current status of the Actor.
isActive() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
isActive() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Checks the current status of the Actor.
isActorThread() - Method in class groovyx.gpars.actor.Actor
Checks whether the current thread is the actor's current thread.
isBound() - Method in class groovyx.gpars.dataflow.DataflowExpression
Check if value has been set already for this expression
isBound() - Method in class groovyx.gpars.dataflow.DataflowQueue
Check if value has been set already for this expression
isBound() - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Check if value has been set already for this expression
isBound() - Method in interface groovyx.gpars.dataflow.Promise
Check if value has been set already for this expression
isBound() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
isConnected() - Method in class groovyx.gpars.remote.RemoteHost
 
isEmpty() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Indicates, whether the first element in the stream is an eos
isEmpty() - Method in interface groovyx.gpars.dataflow.stream.FList
 
isEmpty() - Method in class groovyx.gpars.util.DefaultMessageQueue
 
isEmpty() - Method in class groovyx.gpars.util.FQMessageQueue.EmptyNode
 
isEmpty() - Method in class groovyx.gpars.util.FQMessageQueue
 
isEmpty() - Method in class groovyx.gpars.util.FQMessageQueue.Node
 
isEmpty() - Method in interface groovyx.gpars.util.MessageQueue
 
isFair() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Retrieves the actor's fairness flag Fair actors give up the thread after processing each message, non-fair actors keep a thread until their message queue is empty.
isFair() - Method in class groovyx.gpars.agent.AgentCore
Retrieves the agent's fairness flag Fair agents give up the thread after processing each message, non-fair agents keep a thread until their message queue is empty.
isFair() - Method in class groovyx.gpars.util.AsyncMessagingCore
Retrieves the agent's fairness flag Fair agents give up the thread after processing each message, non-fair agents keep a thread until their message queue is empty.
isRootActiveObject(ClassNode) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation
 
isSet - Variable in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
 
issues - Variable in exception groovyx.gpars.actor.impl.ActorReplyException
 
iterator() - Method in class groovyx.gpars.dataflow.DataflowQueue
Returns an iterator over a current snapshot of the buffer's content.
iterator() - Method in class groovyx.gpars.dataflow.Dataflows
Convenience method to play nicely with Groovy object iteration methods.
iterator() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Builds an iterator to iterate over the stream
iterator() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 

J

join() - Method in class groovyx.gpars.actor.Actor
Joins the actor.
join(MessageStream) - Method in class groovyx.gpars.actor.Actor
Notify listener when finished
join(long, TimeUnit) - Method in class groovyx.gpars.actor.Actor
Joins the actor.
join(BaseDuration) - Method in class groovyx.gpars.actor.Actor
Joins the actor.
join() - Method in class groovyx.gpars.dataflow.DataflowExpression
Blocks, if the value has not been assigned yet to the DataflowVariable
join(long, TimeUnit) - Method in class groovyx.gpars.dataflow.DataflowExpression
Blocks, if the value has not been assigned yet to the DataflowVariable
joinLatch - Variable in class groovyx.gpars.actor.Actor
 
joinLatch - Variable in class groovyx.gpars.actor.Actor.MyRemoteHandle
 

K

KEEP_ALIVE_TIME - Static variable in class groovyx.gpars.scheduler.ResizeablePool
 
klazz - Variable in class groovyx.gpars.serial.DefaultRemoteHandle
 

L

lastTaskPoke - Variable in class groovyx.gpars.scheduler.Scheduler
 
leave() - Method in class groovyx.gpars.serial.SerialContext
Leave this context
leftShift(T) - Method in class groovyx.gpars.actor.impl.MessageStream
Same as send
leftShift(Object) - Method in class groovyx.gpars.agent.AgentCore
Adds the message to the agent\s message queue
leftShift(DataflowReadChannel<T>) - Method in class groovyx.gpars.dataflow.DataflowQueue
Adds a DataflowVariable to the buffer.
leftShift(T) - Method in class groovyx.gpars.dataflow.DataflowQueue
Adds a DataflowVariable representing the passed in value to the buffer.
leftShift(T) - Method in class groovyx.gpars.dataflow.DataflowVariable
Assigns a value to the variable.
leftShift(DataflowReadChannel<T>) - Method in class groovyx.gpars.dataflow.DataflowVariable
Assigns a value from one DataflowVariable instance to this variable.
leftShift(T) - Method in interface groovyx.gpars.dataflow.DataflowWriteChannel
Assigns a value to the variable.
leftShift(DataflowReadChannel<T>) - Method in interface groovyx.gpars.dataflow.DataflowWriteChannel
Assigns a value from one DataflowVariable instance to this variable.
leftShift(DataflowReadChannel<T>) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Adds a dataflow variable value to the stream, once the value is available
leftShift(T) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Adds a value to the stream
leftShift(T) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
leftShift(DataflowReadChannel<T>) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
leftShift(Object) - Method in class groovyx.gpars.ThreadLocalPools
Adds a new element
length() - Method in class groovyx.gpars.dataflow.DataflowQueue
Returns the current size of the buffer
listeners - Variable in class groovyx.gpars.agent.AgentBase
Holds all listeners interested in state updates A listener should be a closure accepting the old and the new value in this order.
listeners - Variable in class groovyx.gpars.remote.LocalNode
 
LocalHandle - Class in groovyx.gpars.serial
 
LocalHandle(UUID) - Constructor for class groovyx.gpars.serial.LocalHandle
 
localHandles - Variable in class groovyx.gpars.serial.SerialHandles
Table of local objects serialized out to remote nodes
LocalHost - Class in groovyx.gpars.remote
Represents communication point with other local hosts.
LocalHost() - Constructor for class groovyx.gpars.remote.LocalHost
 
localHost - Variable in class groovyx.gpars.remote.LocalNode
 
localHost - Variable in class groovyx.gpars.remote.RemoteConnection
 
localHost - Variable in class groovyx.gpars.serial.SerialContext
 
LocalHostRegistry - Class in groovyx.gpars.remote
Registry of local hosts
LocalHostRegistry() - Constructor for class groovyx.gpars.remote.LocalHostRegistry
 
localHosts - Static variable in class groovyx.gpars.remote.LocalHostRegistry
 
LocalNode - Class in groovyx.gpars.remote
Representation of local node
LocalNode() - Constructor for class groovyx.gpars.remote.LocalNode
 
LocalNode(Runnable) - Constructor for class groovyx.gpars.remote.LocalNode
 
LocalNode(LocalHost) - Constructor for class groovyx.gpars.remote.LocalNode
 
LocalNode(LocalHost, Runnable) - Constructor for class groovyx.gpars.remote.LocalNode
 
localNodes - Variable in class groovyx.gpars.remote.LocalHost
Local nodes known to the provider
lock - Variable in class groovyx.gpars.agent.AgentBase
Allows reads not to wait in the message queue.
lock - Variable in class groovyx.gpars.dataflow.Dataflows
 
lookupActorFieldName(AnnotationNode) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation
 
lookupActorGroupName(AnnotationNode) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation
 
loop(Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loop(int, Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loop(int, Closure, Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loop(Closure, Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loop(Closure, Closure, Runnable) - Method in class groovyx.gpars.actor.DefaultActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loop(Runnable) - Method in class groovyx.gpars.scheduler.Scheduler
 
loopClosure - Variable in class groovyx.gpars.actor.DefaultActor
 
loopCode - Variable in class groovyx.gpars.actor.DefaultActor
Misused also for the code to run at start-up
loopCondition - Variable in class groovyx.gpars.actor.DefaultActor
 
LRUProtectionStorage - Class in groovyx.gpars.memoize
Protects stored resources from eviction from memory following the LRU (Last Recently Used) strategy.
LRUProtectionStorage(int) - Constructor for class groovyx.gpars.memoize.LRUProtectionStorage
 

M

MAGIC - Static variable in class groovyx.gpars.remote.BroadcastDiscovery
 
mainActor - Variable in class groovyx.gpars.remote.LocalNode
 
mainActor - Variable in class groovyx.gpars.remote.message.NodeConnectedMsg
 
mainActor - Variable in class groovyx.gpars.remote.RemoteNode
 
makeFair() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Makes the actor fair.
makeFair() - Method in class groovyx.gpars.agent.AgentCore
Makes the agent fair.
makeFair() - Method in class groovyx.gpars.util.AsyncMessagingCore
Makes the agent fair.
manager - Static variable in class groovyx.gpars.serial.SerialHandle
 
map(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Builds a modified stream using the supplied map closure
map(FList<T>, Closure, DataflowStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
map(Closure) - Method in interface groovyx.gpars.dataflow.stream.FList
 
mask - Variable in class groovyx.gpars.dataflow.impl.GuardedSelectRequest
 
matchesMask(int) - Method in class groovyx.gpars.dataflow.impl.GuardedSelectRequest
Detects, whether the channel at the given index is guarded or not.
matchesMask(int) - Method in interface groovyx.gpars.dataflow.impl.SelectRequest
Checks, whether the given index should be queried for value or not.
maxSize - Variable in class groovyx.gpars.memoize.LRUProtectionStorage
 
memberHasValue(AnnotationNode, String, Object) - Static method in class groovyx.gpars.util.AsyncFunASTTransformation
 
message - Variable in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
message - Variable in class groovyx.gpars.dataflow.DataflowExpression.BindDataflow
 
messageHandler(Closure) - Static method in class groovyx.gpars.actor.Actors
Creates an instance of DynamicDispatchActor.
MessageQueue - Interface in groovyx.gpars.util
The high-performance actor message queue
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class groovyx.gpars.remote.netty.NettyHandler
 
MessageStream - Class in groovyx.gpars.actor.impl
Represents a stream of messages and forms the base class for actors
MessageStream() - Constructor for class groovyx.gpars.actor.impl.MessageStream
 
MessageStream.RemoteMessageStream - Class in groovyx.gpars.actor.impl
 
MessageStream.RemoteMessageStream(RemoteHost) - Constructor for class groovyx.gpars.actor.impl.MessageStream.RemoteMessageStream
 
MessageStream.ResultWaiter<V> - Class in groovyx.gpars.actor.impl
Represents a pending request for a reply from an actor.
MessageStream.ResultWaiter() - Constructor for class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
 
MessageStream.SendTo - Class in groovyx.gpars.actor.impl
 
MessageStream.SendTo(MessageStream, ActorMessage) - Constructor for class groovyx.gpars.actor.impl.MessageStream.SendTo
 
MESSAGING_RUNNABLE_NEED_EXACTLY_ONE_ARGUMENT_TO_RUN - Static variable in class groovyx.gpars.MessagingRunnable
 
MessagingRunnable<T> - Class in groovyx.gpars
Represents a single-argument Closure when using GPars agents, actors or dataflow concurrency through the Java API.
MessagingRunnable() - Constructor for class groovyx.gpars.MessagingRunnable
 
MessagingRunnable(Object) - Constructor for class groovyx.gpars.MessagingRunnable
 
metaClass - Variable in class groovyx.gpars.dataflow.DataflowExpression
The current metaclass
METHOD_NAME_PREFIX - Static variable in class groovyx.gpars.activeobject.InternalActor
 
methodName - Variable in class groovyx.gpars.dataflow.DataflowInvocationExpression
 
moveAsyncHead() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
moveHead() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
msg - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor.Node
 
MY_TYPE - Static variable in class groovyx.gpars.util.AsyncFunASTTransformation
 
myActor - Variable in class groovyx.gpars.actor.DefaultActorClosure
 

N

name - Variable in class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
NettyHandler - Class in groovyx.gpars.remote.netty
 
NettyHandler(NettyTransportProvider) - Constructor for class groovyx.gpars.remote.netty.NettyHandler
 
NettyRemoteConnection - Class in groovyx.gpars.remote.netty
Connection using Netty
NettyRemoteConnection(NettyTransportProvider, NettyHandler) - Constructor for class groovyx.gpars.remote.netty.NettyRemoteConnection
 
NettyRemoteConnection.MyChannelFutureListener - Class in groovyx.gpars.remote.netty
 
NettyRemoteConnection.MyChannelFutureListener() - Constructor for class groovyx.gpars.remote.netty.NettyRemoteConnection.MyChannelFutureListener
 
NettyTransportProvider - Class in groovyx.gpars.remote.netty
Transport provider using Netty
NettyTransportProvider() - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider
 
NettyTransportProvider.Client - Class in groovyx.gpars.remote.netty
 
NettyTransportProvider.Client(NettyTransportProvider, SocketAddress, UUID) - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider.Client
 
NettyTransportProvider.ClientHandler - Class in groovyx.gpars.remote.netty
 
NettyTransportProvider.ClientHandler(NettyTransportProvider, UUID) - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider.ClientHandler
 
NettyTransportProvider.MyThreadFactory - Class in groovyx.gpars.remote.netty
 
NettyTransportProvider.MyThreadFactory() - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider.MyThreadFactory
 
NettyTransportProvider.Server - Class in groovyx.gpars.remote.netty
 
NettyTransportProvider.Server() - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
NettyTransportProvider.ServerPipelineFactory - Class in groovyx.gpars.remote.netty
 
NettyTransportProvider.ServerPipelineFactory(NettyTransportProvider) - Constructor for class groovyx.gpars.remote.netty.NettyTransportProvider.ServerPipelineFactory
 
newThread(Runnable) - Method in class groovyx.gpars.agent.AgentThreadFactory
 
newThread(Runnable) - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.MyThreadFactory
 
next - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor.Node
 
next() - Method in class groovyx.gpars.dataflow.stream.FListIterator
 
next - Variable in class groovyx.gpars.util.FQMessageQueue.Node
 
nextContinuation - Variable in class groovyx.gpars.actor.DefaultActor
 
No_ARGS - Static variable in class groovyx.gpars.activeobject.InternalActor
 
NodeConnectedMsg - Class in groovyx.gpars.remote.message
Message sent when local node connected to remote host
NodeConnectedMsg(LocalNode) - Constructor for class groovyx.gpars.remote.message.NodeConnectedMsg
 
NodeDisconnectedMsg - Class in groovyx.gpars.remote.message
Message sent when local node disconnected from remote host
NodeDisconnectedMsg(LocalNode) - Constructor for class groovyx.gpars.remote.message.NodeDisconnectedMsg
 
nodeId - Variable in class groovyx.gpars.remote.message.NodeConnectedMsg
Id of node connected
nodeId - Variable in class groovyx.gpars.remote.message.NodeDisconnectedMsg
Id of node disconnected
NonDaemonPGroup - Class in groovyx.gpars.group
Provides logical grouping for actors, agents and dataflow tasks and operators.
NonDaemonPGroup() - Constructor for class groovyx.gpars.group.NonDaemonPGroup
Creates a group for actors, agents, tasks and operators.
NonDaemonPGroup(int) - Constructor for class groovyx.gpars.group.NonDaemonPGroup
Creates a group for actors, agents, tasks and operators.
nonGeneric(ClassNode) - Static method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
notifyRemote(UUID) - Method in class groovyx.gpars.dataflow.DataflowExpression
Sends notifications to all subscribers
NullProtectionStorage - Class in groovyx.gpars.memoize
Doesn't protect any resources.
NullProtectionStorage() - Constructor for class groovyx.gpars.memoize.NullProtectionStorage
 
NullValue - Class in groovyx.gpars.memoize
Represents a null or void return value in the cache.
NullValue() - Constructor for class groovyx.gpars.memoize.NullValue
 
numberOfChannels - Variable in class groovyx.gpars.dataflow.impl.SelectBase
 
numberOfParameters - Variable in class groovyx.gpars.DataflowMessagingRunnable
 

O

ON_DELIVERY_ERROR - Static variable in class groovyx.gpars.actor.Actor
 
onConnect(RemoteNode) - Method in class groovyx.gpars.remote.LocalNode
 
onConnect() - Method in class groovyx.gpars.remote.RemoteConnection
 
onConnect(RemoteNode) - Method in class groovyx.gpars.remote.RemoteNodeDiscoveryListener
 
onConnect(RemoteNode) - Method in class groovyx.gpars.remote.RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
 
onDeliveryError(Object) - Method in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
Handle cases when the message sent to the actor doesn't get delivered
onDisconnect(SerialContext) - Method in class groovyx.gpars.remote.LocalHost
 
onDisconnect(RemoteNode) - Method in class groovyx.gpars.remote.LocalNode
 
onDisconnect() - Method in class groovyx.gpars.remote.RemoteConnection
 
onDisconnect(RemoteNode) - Method in class groovyx.gpars.remote.RemoteNodeDiscoveryListener
 
onDisconnect(RemoteNode) - Method in class groovyx.gpars.remote.RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
 
onDisconnectForLocalNodes(RemoteNode) - Method in class groovyx.gpars.remote.LocalHost
 
onDiscovery(UUID, SocketAddress) - Method in class groovyx.gpars.remote.BroadcastDiscovery
 
onException(Throwable) - Method in class groovyx.gpars.remote.RemoteConnection
 
ongoingThreadTermination - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
onMessage(Object[]) - Method in class groovyx.gpars.activeobject.InternalActor
Handles incoming messages
onMessage(Object) - Method in class groovyx.gpars.actor.DefaultActor
Handles all incoming messages
onMessage(NullObject) - Method in class groovyx.gpars.agent.AgentBase
Accepts a NullObject instance and sets the internal state to null
onMessage(Closure) - Method in class groovyx.gpars.agent.AgentBase
Accepts and invokes the closure
onMessage(T) - Method in class groovyx.gpars.agent.AgentBase
Other messages than closures are accepted as new values for the internal state
onMessage(SerialMsg) - Method in class groovyx.gpars.remote.RemoteConnection
 
onStop - Variable in class groovyx.gpars.actor.Actor
 
onStop(Closure) - Method in class groovyx.gpars.actor.Actor
Set on stop handler for this actor
op(Object) - Method in class groovyx.gpars.pa.ClosureMapper
 
op(Object) - Method in class groovyx.gpars.pa.ClosurePredicate
 
op(Object, Object) - Method in class groovyx.gpars.pa.ClosureReducer
 
operationComplete(ChannelFuture) - Method in class groovyx.gpars.remote.netty.NettyRemoteConnection.MyChannelFutureListener
 
operator(Map, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates an operator using the default dataflow parallel group
operator(List, List, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates an operator using the current parallel group
operator(List, List, int, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates an operator using the current parallel group
operator(DataflowReadChannel, DataflowWriteChannel, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates an operator using the current parallel group
operator(DataflowReadChannel, DataflowWriteChannel, int, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates an operator using the current parallel group
ourInstance - Static variable in class groovyx.gpars.activeobject.ActiveObjectRegistry
 
outputQueue - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
Stores messages ready for processing by the actor.
outside - Variable in class groovyx.gpars.util.DefaultMessageQueue
 
outside - Variable in class groovyx.gpars.util.FQMessageQueue
 
outsideUpdater - Variable in class groovyx.gpars.util.FQMessageQueue
 

P

parallelGroup - Variable in class groovyx.gpars.actor.Actor
The parallel group to which the message stream belongs
parallelGroup - Variable in class groovyx.gpars.dataflow.DataCallback
 
PARAMETER_TYPES - Static variable in class groovyx.gpars.MessagingRunnable
 
PARAMETER_TYPES - Static variable in class groovyx.gpars.ReactorMessagingRunnable
 
PASSIVE - Static variable in class groovyx.gpars.util.AsyncMessagingCore
 
PAUtils - Class in groovyx.gpars.util
Handy methods build PA from different types
PAUtils() - Constructor for class groovyx.gpars.util.PAUtils
 
payLoad - Variable in class groovyx.gpars.actor.ActorMessage
 
pendingRequests - Variable in class groovyx.gpars.dataflow.impl.SelectBase
Unsatisfied requests for value, each holding a list of guards and a routine to invoke once a value is available
pipelineFactory - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
POKE_INTERVAL - Static variable in class groovyx.gpars.scheduler.Scheduler
 
poll() - Method in class groovyx.gpars.dataflow.DataflowExpression
Retrieves the bound value.
poll() - Method in class groovyx.gpars.dataflow.DataflowQueue
Retrieves the value at the head of the buffer.
poll() - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Retrieves the value at the head of the buffer.
poll() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
poll() - Method in class groovyx.gpars.util.DefaultMessageQueue
 
poll() - Method in class groovyx.gpars.util.FQMessageQueue
 
poll() - Method in interface groovyx.gpars.util.MessageQueue
 
pollFromInside() - Method in class groovyx.gpars.util.FQMessageQueue
 
pollMessage() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Polls a message from the queues
pool - Variable in class groovyx.gpars.dataflow.DataCallbackWithPool
 
pool - Variable in class groovyx.gpars.scheduler.DefaultPool
 
pool - Variable in class groovyx.gpars.scheduler.FJPool
 
Pool - Interface in groovyx.gpars.scheduler
Represents an actor's thread pool
POOL_SIZE_MUST_BE_A_POSITIVE_NUMBER - Static variable in interface groovyx.gpars.scheduler.Pool
 
PoolUtils - Class in groovyx.gpars.util
Provides a couple of utility methods to pools and schedulers.
PoolUtils() - Constructor for class groovyx.gpars.util.PoolUtils
 
pop() - Method in class groovyx.gpars.ThreadLocalPools
Removes the top (last) element
PORT - Static variable in class groovyx.gpars.remote.BroadcastDiscovery
 
position - Variable in class groovyx.gpars.dataflow.impl.SelectBase
 
previous - Variable in class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
 
printStackTrace() - Method in exception groovyx.gpars.actor.impl.ActorReplyException
 
prioritySelect() - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single input channel, which has a value available for read.
prioritySelect(List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single input channel, which has a value available for read.
prioritySelect(MessageStream) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single input channel, which has a value available for read.
prioritySelect(MessageStream, List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single input channel, which has a value available for read.
prioritySelector(Map, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a prioritizing selector using the default dataflow parallel group Input with lower position index have higher priority.
prioritySelector(List, List, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a prioritizing selector using the default dataflow parallel group Input with lower position index have higher priority.
prioritySelector(Map) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a prioritizing selector using the default dataflow parallel group.
prioritySelector(List, List) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a prioritizing selector using the default dataflow parallel group.
Promise<T> - Interface in groovyx.gpars.dataflow
A unifying future-like interface to dataflow variables, asynchronous functions and active objects.
provider - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.Client
 
provider - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.ClientHandler
 
provider - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider.ServerPipelineFactory
 
putAt(Object, Object) - Method in class groovyx.gpars.dataflow.Dataflows
Binds the value to the DataflowVariable that is associated with the property "index".
putNewUnderLock(Object) - Method in class groovyx.gpars.dataflow.Dataflows
Utility method extracted just to help JIT

Q

queue - Variable in class groovyx.gpars.dataflow.DataflowQueue
Stores the received DataflowVariables in the buffer.
queue - Variable in class groovyx.gpars.scheduler.Scheduler
 
queue - Static variable in class groovyx.gpars.serial.SerialHandle
 
queue - Variable in class groovyx.gpars.util.AsyncMessagingCore
Incoming messages
queueLock - Variable in class groovyx.gpars.dataflow.DataflowQueue
Internal lock

R

react(Closure) - Method in class groovyx.gpars.actor.DefaultActor
Schedules an ActorAction to take the next message off the message queue and to pass it on to the supplied closure.
react(Duration, Closure) - Method in class groovyx.gpars.actor.DefaultActor
Schedules an ActorAction to take the next message off the message queue and to pass it on to the supplied closure.
react(long, TimeUnit, Closure) - Method in class groovyx.gpars.actor.DefaultActor
Schedules an ActorAction to take the next message off the message queue and to pass it on to the supplied closure.
react(long, Closure) - Method in class groovyx.gpars.actor.DefaultActor
Schedules an ActorAction to take the next message off the message queue and to pass it on to the supplied closure.
ReactiveActor - Class in groovyx.gpars.actor
An actor representing a reactor.
ReactiveActor(Closure) - Constructor for class groovyx.gpars.actor.ReactiveActor
 
reactor(Closure) - Static method in class groovyx.gpars.actor.Actors
Creates a reactor around the supplied code.
REACTOR_MESSAGING_RUNNABLE_NEED_EXACTLY_ONE_ARGUMENT_TO_RUN - Static variable in class groovyx.gpars.ReactorMessagingRunnable
 
ReactorMessagingRunnable<T,V> - Class in groovyx.gpars
Represents a single-argument Closure when using GPars ReactiveActors (reactors) through the Java API.
ReactorMessagingRunnable() - Constructor for class groovyx.gpars.ReactorMessagingRunnable
 
ReactorMessagingRunnable(Object) - Constructor for class groovyx.gpars.ReactorMessagingRunnable
 
readResolve() - Method in class groovyx.gpars.serial.LocalHandle
 
readResolve() - Method in class groovyx.gpars.serial.RemoteHandle
 
receive(Closure) - Method in class groovyx.gpars.actor.BlockingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive(long, TimeUnit, Closure) - Method in class groovyx.gpars.actor.BlockingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive(Duration, Closure) - Method in class groovyx.gpars.actor.BlockingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive(long, TimeUnit) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive(BaseDuration) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl() - Method in class groovyx.gpars.actor.BlockingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl(long, TimeUnit) - Method in class groovyx.gpars.actor.BlockingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl(long, TimeUnit) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiver - Variable in class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
receiver - Variable in class groovyx.gpars.dataflow.DataflowInvocationExpression
 
receiveThread - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
reduce(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Reduces all elements in the stream using the supplied closure
reduce(T, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
Reduces all elements in the stream using the supplied closure
reduce(T, FList<T>, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
reduce(Closure) - Method in interface groovyx.gpars.dataflow.stream.FList
 
reduce(T, Closure) - Method in interface groovyx.gpars.dataflow.stream.FList
 
register(String, PGroup) - Method in class groovyx.gpars.activeobject.ActiveObjectRegistry
 
registerCurrentActorWithThread(Actor) - Static method in class groovyx.gpars.actor.Actor
Registers the actor with the current thread
registerError(Throwable) - Method in class groovyx.gpars.agent.AgentCore
Adds the exception to the list of thrown exceptions
registerError(Throwable) - Method in class groovyx.gpars.util.AsyncMessagingCore
 
registry - Variable in class groovyx.gpars.activeobject.ActiveObjectRegistry
 
reInterrupt() - Static method in class groovyx.gpars.actor.impl.MessageStream
 
RemoteConnection - Class in groovyx.gpars.remote
Represents connection to remote host
RemoteConnection(LocalHost) - Constructor for class groovyx.gpars.remote.RemoteConnection
 
RemoteDataflowExpression<T> - Class in groovyx.gpars.dataflow
 
RemoteDataflowExpression() - Constructor for class groovyx.gpars.dataflow.RemoteDataflowExpression
 
RemoteHandle - Class in groovyx.gpars.serial
 
RemoteHandle(UUID, UUID) - Constructor for class groovyx.gpars.serial.RemoteHandle
 
remoteHost - Variable in class groovyx.gpars.actor.Actor.RemoteActor
 
remoteHost - Variable in class groovyx.gpars.actor.impl.MessageStream.RemoteMessageStream
 
remoteHost - Variable in class groovyx.gpars.dataflow.DataflowVariable.RemoteDataflowVariable
 
remoteHost - Variable in class groovyx.gpars.dataflow.RemoteDataflowExpression
 
RemoteHost - Class in groovyx.gpars.remote
Representation of remote host connected to transport provider
RemoteHost(LocalHost, UUID) - Constructor for class groovyx.gpars.remote.RemoteHost
 
remoteHost - Variable in class groovyx.gpars.remote.RemoteNode
 
remoteHosts - Variable in class groovyx.gpars.remote.LocalHost
Hosts known to the provider
RemoteNode - Class in groovyx.gpars.remote
Representation of remote node
RemoteNode(UUID, SerialContext, Actor) - Constructor for class groovyx.gpars.remote.RemoteNode
 
RemoteNodeDiscoveryListener - Class in groovyx.gpars.remote
Listener for remote node events
RemoteNodeDiscoveryListener() - Constructor for class groovyx.gpars.remote.RemoteNodeDiscoveryListener
 
RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure - Class in groovyx.gpars.remote
Discovery listener backed by closure with two params - node - "connected" | "disconnected"
RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure(Closure) - Constructor for class groovyx.gpars.remote.RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
 
remoteNodes - Variable in class groovyx.gpars.remote.LocalHost
Registry of remote nodes known to the provider
RemoteObjectDecoder - Class in groovyx.gpars.remote.netty
 
RemoteObjectDecoder(RemoteConnection) - Constructor for class groovyx.gpars.remote.netty.RemoteObjectDecoder
Creates a new encoder.
RemoteObjectEncoder - Class in groovyx.gpars.remote.netty
 
RemoteObjectEncoder(RemoteConnection) - Constructor for class groovyx.gpars.remote.netty.RemoteObjectEncoder
Creates a new encoder.
RemoteSerialized - Interface in groovyx.gpars.serial
Marker interface for objects, which are proxies to objects on other nodes.
remove(Object) - Method in class groovyx.gpars.dataflow.Dataflows
Removes a DFV from the map and binds it to null, if it has not been bound yet
remove() - Method in class groovyx.gpars.dataflow.stream.FListIterator
 
remove(SerialHandle) - Method in class groovyx.gpars.serial.SerialContext
 
remove(SerialHandle) - Method in class groovyx.gpars.serial.SerialHandles
 
removeConnection(RemoteConnection) - Method in class groovyx.gpars.remote.RemoteHost
 
removeDiscoveryListener(RemoteNodeDiscoveryListener) - Method in class groovyx.gpars.remote.LocalNode
 
removeEldestEntry(Map.Entry<Object, Object>) - Method in class groovyx.gpars.memoize.LRUProtectionStorage
 
removeLocalHost(LocalHost) - Static method in class groovyx.gpars.remote.LocalHostRegistry
 
reply(Object) - Method in class groovyx.gpars.actor.AbstractLoopingActor
Sends a reply to all currently processed messages.
reply(Object) - Method in class groovyx.gpars.actor.impl.ReplyingMessageStream
Sends a reply to all currently processed messages.
replyIfExists(Object) - Method in class groovyx.gpars.actor.AbstractLoopingActor
Sends a reply to all currently processed messages, which have been sent by an actor.
replyIfExists(Object) - Method in class groovyx.gpars.actor.impl.ReplyingMessageStream
Sends a reply to all currently processed messages, which have been sent by an actor.
ReplyingMessageStream - Class in groovyx.gpars.actor.impl
 
ReplyingMessageStream() - Constructor for class groovyx.gpars.actor.impl.ReplyingMessageStream
 
requests - Variable in class groovyx.gpars.dataflow.DataflowQueue
Stores unsatisfied requests for values
resetDefaultSize() - Method in class groovyx.gpars.scheduler.DefaultPool
Sets the pool size to the default
resetDefaultSize() - Method in class groovyx.gpars.scheduler.FJPool
Sets the pool size to the default
resetDefaultSize() - Method in interface groovyx.gpars.scheduler.Pool
Sets the pool size to the default
resetDefaultSize() - Method in class groovyx.gpars.scheduler.Scheduler
 
resize(int) - Method in class groovyx.gpars.scheduler.DefaultPool
Resizes the thread pool to the specified value
resize(int) - Method in class groovyx.gpars.scheduler.FJPool
Resizes the thread pool to the specified value
resize(int) - Method in interface groovyx.gpars.scheduler.Pool
Resizes the thread pool to the specified value
resize(int) - Method in class groovyx.gpars.scheduler.Scheduler
 
ResizeablePool - Class in groovyx.gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
ResizeablePool(boolean) - Constructor for class groovyx.gpars.scheduler.ResizeablePool
Creates the pool with default number of threads.
ResizeablePool(boolean, int) - Constructor for class groovyx.gpars.scheduler.ResizeablePool
Creates the pool with specified number of threads.
RESPONDS_TO - Static variable in class groovyx.gpars.actor.Actor
 
rest - Variable in class groovyx.gpars.dataflow.stream.DataflowStream
 
RESULT - Static variable in class groovyx.gpars.dataflow.DataflowExpression
 
rethrowException() - Method in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
 
retrieveCurrentDFPGroup() - Static method in class groovyx.gpars.dataflow.Dataflow
Retrieves the thread-local value of the active PGroup or the default DataflowGroup
retrieveDefaultPoolSize() - Static method in class groovyx.gpars.util.PoolUtils
 
retrieveForBind() - Method in class groovyx.gpars.dataflow.DataflowQueue
Takes the first unsatisfied value request and binds a value on it.
retrieveNextMessage() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Takes the next message from the outputQueue, decrements the counter and possibly throws control exceptions
retrieveOrCreateVariable() - Method in class groovyx.gpars.dataflow.DataflowQueue
Checks whether there's a DFV waiting in the queue and retrieves it.
rightShift(Closure) - Method in class groovyx.gpars.dataflow.DataflowExpression
Schedule closure to be executed by pooled actor after data became available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled
rightShift(Closure) - Method in class groovyx.gpars.dataflow.DataflowQueue
Schedule closure to be executed by pooled actor after data became available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled
rightShift(Closure) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Schedule closure to be executed by pooled actor after data became available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled
rightShift(Closure) - Method in interface groovyx.gpars.dataflow.Promise
Schedule closure to be executed by pooled actor after data became available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled
rightShift(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
run() - Method in class groovyx.gpars.actor.ActorTimerTask
 
run() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
run() - Method in class groovyx.gpars.scheduler.Scheduler.WatchdogThread
 
run() - Method in class groovyx.gpars.scheduler.Scheduler.WorkerThread
 
run() - Method in class groovyx.gpars.util.AsyncMessagingCore
Handles a single message from the message queue
runAfterLoopCode(Closure) - Method in class groovyx.gpars.actor.DefaultActor
 
runChildDirectly(Object...) - Method in class groovyx.gpars.forkjoin.FJWorker
 
runEnhancedWithoutRepliesOnMessages(ActorMessage, Closure, Object) - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
runForkJoin(ForkJoinPool, ForkJoinTask<T>) - Static method in class groovyx.gpars.forkjoin.ForkJoinUtils
 
runForkJoin(ForkJoinPool, Object...) - Static method in class groovyx.gpars.forkjoin.ForkJoinUtils
 
RunnableBackedBlockingActor - Class in groovyx.gpars.actor.impl
Utility class to implement a blocking actor backed by any Runnable (including Closure)
RunnableBackedBlockingActor(Runnable) - Constructor for class groovyx.gpars.actor.impl.RunnableBackedBlockingActor
 
RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate - Class in groovyx.gpars.actor.impl
 
RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate(Object, Object) - Constructor for class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 

S

S_ACTIVE_MASK - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_FINISHED_MASK - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_FINISHING_MASK - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_INITIALIZED - Static variable in class groovyx.gpars.dataflow.DataflowExpression
 
S_INITIALIZING - Static variable in class groovyx.gpars.dataflow.DataflowExpression
 
S_NOT_INITIALIZED - Static variable in class groovyx.gpars.dataflow.DataflowExpression
Possible states
S_NOT_STARTED - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_RUNNING - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_STOP_TERMINATE_MASK - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_STOPPED - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_STOPPING - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_TERMINATED - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
S_TERMINATING - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
schedule() - Method in class groovyx.gpars.util.AsyncMessagingCore
Schedules processing of a next message, if there are some and if there isn't an active thread handling a message at the moment
scheduleCallback(Object, MessageStream) - Method in class groovyx.gpars.dataflow.DataflowExpression
Sends the result back to the actor, which is waiting asynchronously for the value to be bound.
scheduler - Variable in class groovyx.gpars.remote.LocalNode
 
Scheduler - Class in groovyx.gpars.scheduler
Prototype of self-regulated thread pooled scheduler

Self regulation happened according to following rules - worker thread, which had nothing to do 10 seconds dies - if no tasks were taken for processing during last 0.5sec new worker starts

Scheduler() - Constructor for class groovyx.gpars.scheduler.Scheduler
 
Scheduler(int) - Constructor for class groovyx.gpars.scheduler.Scheduler
 
Scheduler.WatchdogThread - Class in groovyx.gpars.scheduler
 
Scheduler.WatchdogThread() - Constructor for class groovyx.gpars.scheduler.Scheduler.WatchdogThread
 
Scheduler.WorkerThread - Class in groovyx.gpars.scheduler
 
Scheduler.WorkerThread() - Constructor for class groovyx.gpars.scheduler.Scheduler.WorkerThread
 
schedulerTime - Variable in class groovyx.gpars.scheduler.Scheduler
 
second - Variable in class groovyx.gpars.actor.ForwardingDelegate
 
second - Variable in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 
select(DataflowReadChannel<?>...) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a select using the default dataflow parallel group.
select(List<DataflowReadChannel>) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a select using the default dataflow parallel group.
Select<T> - Class in groovyx.gpars.dataflow
A Select allows the user to select a value from multiple channels, which have a value available for read at the moment.
Select(PGroup, DataflowReadChannel<? extends T>...) - Constructor for class groovyx.gpars.dataflow.Select
 
Select(PGroup, List<DataflowReadChannel<? extends T>>) - Constructor for class groovyx.gpars.dataflow.Select
 
select() - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
select(List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
select(MessageStream) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
select(MessageStream, List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Selects a value from a single randomly chosen input channel, which has a value available for read.
select(MessageStream, int, List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Invokes the internal select base with a SelectRequest instance ensuring a message is sent, once a value has been selected
select(int, List<Boolean>) - Method in class groovyx.gpars.dataflow.Select
Invokes the internal select base with a SelectRequest instance ensuring the current thread can continue returning the correct value, once a value has been selected
SelectBase<T> - Class in groovyx.gpars.dataflow.impl
The implementation of the core for all selects.
SelectBase(PGroup, List<DataflowReadChannel<? extends T>>) - Constructor for class groovyx.gpars.dataflow.impl.SelectBase
Stores the input channel and registers for the wheneverBound() event on each
selectBase - Variable in class groovyx.gpars.dataflow.Select
 
SelectCallback<T> - Class in groovyx.gpars.dataflow.impl
A closure registered with all the input channels on the wheneverBound() event to inform the Select about a value being available in a particular channel.
SelectCallback(Object, int, DataflowReadChannel<? extends T>) - Constructor for class groovyx.gpars.dataflow.impl.SelectCallback
 
selector(Map, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a selector using the default dataflow parallel group
selector(List, List, Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a selector using the default dataflow parallel group
selector(Map) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a selector using the default dataflow parallel group.
selector(List, List) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a selector using the default dataflow parallel group.
SelectRequest<T> - Interface in groovyx.gpars.dataflow.impl
Represents a request for value from a select.
SelectResult<T> - Class in groovyx.gpars.dataflow
A bean representing the result of the select operation on a Select.
SelectResult(int, T) - Constructor for class groovyx.gpars.dataflow.SelectResult
Stores the result of a select operation
send(Object) - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
send(Object) - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
send(Object) - Method in class groovyx.gpars.actor.impl.MessageStream.RemoteMessageStream
 
send(Object) - Method in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
Accepts the message as a reply and wakes up the sleeping thread.
send(Object) - Method in class groovyx.gpars.actor.impl.MessageStream
Send message to stream and return immediately
send() - Method in class groovyx.gpars.actor.impl.MessageStream
Convenience method for send(new Object()).
send(T, MessageStream) - Method in class groovyx.gpars.actor.impl.MessageStream
Send message to stream and return immediately.
send(Object) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
send(Object) - Method in class groovyx.gpars.agent.AgentCore
Adds the message to the agent\s message queue
send(Object) - Method in class groovyx.gpars.dataflow.DataCallback
Sends a message back to the DataCallback.
send(Object) - Method in class groovyx.gpars.dataflow.DataCallbackWithPool
Sends a message back to the DataCallback.
send(Object) - Method in class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
sendAndContinue(T, Closure) - Method in class groovyx.gpars.actor.Actor
Sends a message and execute continuation when reply became available.
sendAndWait(T) - Method in class groovyx.gpars.actor.impl.MessageStream
Sends a message and waits for a reply.
sendAndWait(T, long, TimeUnit) - Method in class groovyx.gpars.actor.impl.MessageStream
Sends a message and waits for a reply.
sendAndWait(T, Duration) - Method in class groovyx.gpars.actor.impl.MessageStream
Sends a message and waits for a reply.
sendAndWait(Closure) - Method in class groovyx.gpars.agent.AgentBase
Submits the closure waiting for the result
sender - Variable in class groovyx.gpars.actor.ActorMessage
 
sender - Variable in class groovyx.gpars.actor.impl.ReplyingMessageStream
A list of senders for the currently processed messages
sendThread - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
SequentialProcessingActor - Class in groovyx.gpars.actor.impl
 
SequentialProcessingActor() - Constructor for class groovyx.gpars.actor.impl.SequentialProcessingActor
Creates a new instance, sets the default actor group.
SequentialProcessingActor.Node - Class in groovyx.gpars.actor.impl
Represents an element in the message queue.
SequentialProcessingActor.Node(ActorMessage) - Constructor for class groovyx.gpars.actor.impl.SequentialProcessingActor.Node
 
SerialContext - Class in groovyx.gpars.serial
 
SerialContext(SerialHandles, UUID) - Constructor for class groovyx.gpars.serial.SerialContext
 
SerialHandle - Class in groovyx.gpars.serial
Weak reference to object, which was serialized to remote hosts.
SerialHandle(WithSerialId, UUID) - Constructor for class groovyx.gpars.serial.SerialHandle
Construct handle for object with given id to it
serialHandle - Variable in class groovyx.gpars.serial.WithSerialId
See SerialHandle class for details
SerialHandle.LocalSerialHandle - Class in groovyx.gpars.serial
 
SerialHandle.LocalSerialHandle(WithSerialId, UUID) - Constructor for class groovyx.gpars.serial.SerialHandle.LocalSerialHandle
 
SerialHandle.RemoteSerialHandle - Class in groovyx.gpars.serial
 
SerialHandle.RemoteSerialHandle(WithSerialId, UUID) - Constructor for class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle
 
SerialHandle.RemoteSerialHandle.ReleaseHandle - Class in groovyx.gpars.serial
 
SerialHandle.RemoteSerialHandle.ReleaseHandle(UUID) - Constructor for class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle.ReleaseHandle
 
SerialHandles - Class in groovyx.gpars.serial
 
SerialHandles() - Constructor for class groovyx.gpars.serial.SerialHandles
 
serialId - Variable in class groovyx.gpars.serial.RemoteHandle
 
serialId - Variable in class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle.ReleaseHandle
 
serialId - Variable in class groovyx.gpars.serial.SerialHandle
serial id of the object
SerialMsg - Class in groovyx.gpars.serial
Base class for all messages
SerialMsg() - Constructor for class groovyx.gpars.serial.SerialMsg
 
SerialMsg(UUID) - Constructor for class groovyx.gpars.serial.SerialMsg
 
serialVersionUID - Static variable in class groovyx.gpars.activeobject.InternalActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.AbstractLoopingActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.Actor.MyRemoteHandle
 
serialVersionUID - Static variable in class groovyx.gpars.actor.Actor.RemoteActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.Actor.RemoteActor.StopActorMsg
 
serialVersionUID - Static variable in class groovyx.gpars.actor.Actor.RemoteActor.TerminateActorMsg
 
serialVersionUID - Static variable in class groovyx.gpars.actor.Actor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.ActorMessage
 
serialVersionUID - Static variable in class groovyx.gpars.actor.BlockingActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.DefaultActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.DefaultActorClosure
 
serialVersionUID - Static variable in class groovyx.gpars.actor.DynamicDispatchActor
 
serialVersionUID - Static variable in exception groovyx.gpars.actor.impl.ActorException
 
serialVersionUID - Static variable in exception groovyx.gpars.actor.impl.ActorReplyException
 
serialVersionUID - Static variable in exception groovyx.gpars.actor.impl.ActorStopException
 
serialVersionUID - Static variable in exception groovyx.gpars.actor.impl.ActorTerminationException
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.MessageStream.RemoteMessageStream
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.MessageStream
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.ReplyingMessageStream
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
serialVersionUID - Static variable in class groovyx.gpars.actor.ReactiveActor
 
serialVersionUID - Static variable in class groovyx.gpars.agent.AgentBase.AwaitClosure
 
serialVersionUID - Static variable in exception groovyx.gpars.AsyncException
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataCallback
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataCallbackWithPool
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowComplexExpression
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression.BindDataflow
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression.TransformMany
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowInvocationExpression
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowVariable.RemoteDataflowVariable
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.DataflowVariable
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.impl.SelectCallback
 
serialVersionUID - Static variable in class groovyx.gpars.dataflow.RemoteDataflowExpression
 
serialVersionUID - Static variable in class groovyx.gpars.DataflowMessagingRunnable
 
serialVersionUID - Static variable in class groovyx.gpars.memoize.LRUProtectionStorage
 
serialVersionUID - Static variable in class groovyx.gpars.MessagingRunnable
 
serialVersionUID - Static variable in class groovyx.gpars.pa.CallClosure
 
serialVersionUID - Static variable in class groovyx.gpars.ReactorMessagingRunnable
 
serialVersionUID - Static variable in class groovyx.gpars.remote.message.HostIdMsg
 
serialVersionUID - Static variable in class groovyx.gpars.remote.message.NodeConnectedMsg
 
serialVersionUID - Static variable in class groovyx.gpars.remote.message.NodeDisconnectedMsg
 
serialVersionUID - Static variable in class groovyx.gpars.remote.netty.NettyRemoteConnection.MyChannelFutureListener
 
serialVersionUID - Static variable in class groovyx.gpars.serial.DefaultRemoteHandle
 
serialVersionUID - Static variable in class groovyx.gpars.serial.LocalHandle
 
serialVersionUID - Static variable in class groovyx.gpars.serial.RemoteHandle
 
serialVersionUID - Static variable in class groovyx.gpars.serial.SerialHandle.RemoteSerialHandle.ReleaseHandle
 
serialVersionUID - Static variable in class groovyx.gpars.serial.SerialMsg
 
serialVersionUID - Static variable in class groovyx.gpars.serial.WithSerialId
 
serialVersionUID - Static variable in class groovyx.gpars.util.EnhancedRWLock
 
serialVersionUID - Static variable in class groovyx.gpars.util.EnhancedSemaphore
 
server - Variable in class groovyx.gpars.remote.netty.NettyTransportProvider
 
setAction(Runnable) - Method in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor
 
setHost(RemoteHost) - Method in class groovyx.gpars.remote.RemoteConnection
 
setMetaClass(MetaClass) - Method in class groovyx.gpars.dataflow.DataflowExpression
 
setParallelGroup(PGroup) - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
setParallelGroup(PGroup) - Method in class groovyx.gpars.actor.Actor
Sets the parallel group.
setParallelGroup(PGroup) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Sets the actor's group.
setPGroup(PGroup) - Method in class groovyx.gpars.agent.AgentCore
Sets an actor group to use for task scheduling
setProperty(String, Object) - Method in class groovyx.gpars.actor.ForwardingDelegate
 
setProperty(String, Object) - Method in class groovyx.gpars.actor.impl.RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
 
setProperty(String, Object) - Method in class groovyx.gpars.dataflow.DataflowExpression
 
setProperty(String, Object) - Method in class groovyx.gpars.dataflow.Dataflows
Binds the value to the DataflowVariable that is associated with the property "name".
setSender(MessageStream) - Method in class groovyx.gpars.actor.impl.ReplyingMessageStream
 
setTimeout(long) - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
SHOULD_NOT_REACH_HERE - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
shutdown() - Method in class groovyx.gpars.scheduler.DefaultPool
Gently stops the pool
shutdown() - Method in class groovyx.gpars.scheduler.FJPool
Gently stops the pool
shutdown() - Method in interface groovyx.gpars.scheduler.Pool
Gently stops the pool
shutdown() - Method in class groovyx.gpars.scheduler.Scheduler
 
SHUTDOWN_TIMEOUT - Static variable in class groovyx.gpars.scheduler.DefaultPool
 
silentStart() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Starts the Actor without sending the START_MESSAGE message to speed the start-up.
silentStart() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
silentStart() - Method in class groovyx.gpars.actor.Actor
Starts the Actor without sending the START_MESSAGE message to speed the start-up.
silentStart() - Method in class groovyx.gpars.actor.DefaultActor
Not supported by DefaultActor
silentStart() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
SLEEP_INTERVAL - Static variable in class groovyx.gpars.scheduler.Scheduler.WatchdogThread
 
socket - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
source - Variable in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
splitter(DataflowReadChannel, List<DataflowWriteChannel>) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a splitter copying its single input channel into all of its output channels.
splitter(DataflowReadChannel, List<DataflowWriteChannel>, int) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a splitter copying its single input channel into all of its output channels.
start() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
start() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
start() - Method in class groovyx.gpars.actor.Actor
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
start() - Method in class groovyx.gpars.actor.DefaultActor
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
start() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Starts the Actor.
start() - Method in class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
start() - Method in class groovyx.gpars.remote.BroadcastDiscovery
 
start(NettyTransportProvider) - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
START_MESSAGE - Static variable in class groovyx.gpars.actor.Actor
 
started - Variable in class groovyx.gpars.actor.DefaultActor
 
startNewThread() - Method in class groovyx.gpars.scheduler.Scheduler
 
state - Variable in class groovyx.gpars.dataflow.DataflowExpression
Holds the current state of the variable
stateUpdater - Static variable in class groovyx.gpars.dataflow.DataflowExpression
Updater for the state field
stop() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
stop() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
stop() - Method in class groovyx.gpars.actor.Actor
Send message to stop to the Actor.
STOP - Static variable in exception groovyx.gpars.actor.impl.ActorException
 
stop() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Send message to stop to the actor.
stop() - Method in class groovyx.gpars.remote.BroadcastDiscovery
 
stop() - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.Client
 
stop() - Method in class groovyx.gpars.remote.netty.NettyTransportProvider.Server
 
STOP_MESSAGE - Static variable in class groovyx.gpars.actor.Actor
 
stopFlag - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
Indicates whether the actor should terminate
stopFlagUpdater - Static variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
stopped - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
stoppedFlag - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 
store(Object) - Method in class groovyx.gpars.util.AsyncMessagingCore
Adds the message to the agent\s message queue
submit(Object...) - Method in class groovyx.gpars.activeobject.InternalActor
A DataflowVariable is passed to the actor, which will bind it once the result is known.
submitAndWait(Object...) - Method in class groovyx.gpars.activeobject.InternalActor
A DataflowVariable is passed to the actor, which will bind it once the result is known.
subscribe(DataflowExpression<T>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.DataflowComplexExpression
 
subscribe(Object) - Method in class groovyx.gpars.dataflow.DataflowExpression.DataflowExpressionsCollector
 
subscribe() - Method in class groovyx.gpars.dataflow.DataflowExpression
Utility method to call at the very end of constructor of derived expressions.
subscribe(DataflowExpression<T>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.DataflowExpression
 
subscribe(DataflowExpression<V>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.DataflowExpression.TransformOne
 
subscribe(DataflowExpression<T>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.DataflowGetPropertyExpression
 
subscribe(DataflowExpression<Object>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.DataflowInvocationExpression
 
subscribe(DataflowExpression<T>.DataflowExpressionsCollector) - Method in class groovyx.gpars.dataflow.RemoteDataflowExpression
 
subscribe(SerialContext) - Method in class groovyx.gpars.serial.SerialHandle
Subscribes host as interested in the object
subscribers - Variable in class groovyx.gpars.serial.SerialHandle
remote hosts subscribed to this objects
swap(LinkedList<Object>) - Method in class groovyx.gpars.util.DefaultMessageQueue
 
sweepNextMessage() - Method in class groovyx.gpars.actor.AbstractLoopingActor
Removes the head of the message queue
sweepNextMessage() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
sweepNextMessage() - Method in class groovyx.gpars.actor.Actor
Removes the head of the message queue
sweepNextMessage() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Removes the head of the message queue
sweepNextMessage() - Method in class groovyx.gpars.util.AsyncMessagingCore
Removes the head of the message queue
sweepQueue() - Method in class groovyx.gpars.actor.Actor
Clears the message queue returning all the messages it held.

T

takeMessage() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Takes a message from the queues.
takeMessage(long, TimeUnit) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Takes a message from the queues.
target - Variable in class groovyx.gpars.pa.CallClosure
 
task(Closure) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a new task assigned to a thread from the default dataflow parallel group.
task(Callable) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a new task assigned to a thread from the current parallel group.
task(Runnable) - Static method in class groovyx.gpars.dataflow.Dataflow
Creates a new task assigned to a thread from the current parallel group.
terminate() - Method in class groovyx.gpars.actor.AbstractLoopingActor
 
terminate() - Method in class groovyx.gpars.actor.Actor.RemoteActor
 
terminate() - Method in class groovyx.gpars.actor.Actor
Terminates the Actor.
TERMINATE - Static variable in exception groovyx.gpars.actor.impl.ActorException
 
terminate() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Terminate the Actor.
TERMINATE - Static variable in class groovyx.gpars.scheduler.Scheduler
 
TERMINATE_MESSAGE - Static variable in class groovyx.gpars.actor.Actor
 
terminatedFlag - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 
terminating - Variable in class groovyx.gpars.scheduler.Scheduler
 
terminatingFlag - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 
THE_ACTOR_HAS_BEEN_STOPPED - Static variable in class groovyx.gpars.actor.BlockingActor
 
THE_ACTOR_HAS_NOT_BEEN_STARTED - Static variable in class groovyx.gpars.actor.BlockingActor
 
THE_CODE_FOR_AN_ATOMIC_BLOCK_MUST_NOT_BE_NULL - Static variable in class groovyx.gpars.stm.GParsStm
 
thread - Variable in class groovyx.gpars.dataflow.DataflowExpression.WaitingThread
 
threadAssigned() - Method in class groovyx.gpars.util.AsyncMessagingCore
Informs about the thread being removed from the task
threadBoundActor() - Static method in class groovyx.gpars.actor.Actor
Retrieves the actor registered with the current thread
threadContext - Static variable in class groovyx.gpars.serial.SerialContext
 
threadCount - Static variable in class groovyx.gpars.scheduler.DefaultPool
Unique counter for Actors' threads
threadCount - Variable in class groovyx.gpars.scheduler.Scheduler
 
ThreadLocalPools - Class in groovyx.gpars
Holds a thread-local stack of pools to allow for nested calls to ForkJoinPool.withPool() or GParsExecutorsPool.withPool()
ThreadLocalPools() - Constructor for class groovyx.gpars.ThreadLocalPools
 
threadPool - Variable in class groovyx.gpars.util.AsyncMessagingCore
 
threadUnassigned() - Method in class groovyx.gpars.util.AsyncMessagingCore
Informs about a new thread being assigned to process the next message
throwIfNeeded(ActorMessage) - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Checks the supplied message and throws either STOP or TERMINATE, if the message is a Stop or Terminate message respectively.
TIMEOUT - Static variable in class groovyx.gpars.actor.Actor
 
TIMEOUT_MESSAGE - Static variable in class groovyx.gpars.actor.Actor
 
timeoutCounter - Variable in class groovyx.gpars.actor.AbstractLoopingActor
 
timer - Static variable in class groovyx.gpars.actor.Actor
Timer holding timeouts for react methods
to - Variable in class groovyx.gpars.actor.impl.MessageStream.SendTo
 
toString() - Method in class groovyx.gpars.actor.ActorMessage
 
toString() - Method in exception groovyx.gpars.actor.impl.ActorReplyException
 
toString() - Method in exception groovyx.gpars.AsyncException
 
toString() - Method in class groovyx.gpars.dataflow.DataflowBroadcast
 
toString() - Method in class groovyx.gpars.dataflow.DataflowExpression
 
toString() - Method in class groovyx.gpars.dataflow.DataflowQueue
 
toString() - Method in class groovyx.gpars.dataflow.SelectResult
 
toString() - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
toString() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
toString() - Method in class groovyx.gpars.dataflow.stream.DataflowStreamWriteAdapter
 
toString() - Method in class groovyx.gpars.remote.LocalNode
 
toString() - Method in class groovyx.gpars.remote.RemoteNode
 
touch(Object, Object) - Method in class groovyx.gpars.memoize.LRUProtectionStorage
The touch method can be used to renew an element and move it to the from of the LRU queue.
touch(Object, Object) - Method in class groovyx.gpars.memoize.NullProtectionStorage
Does nothing
transactionFactory - Static variable in class groovyx.gpars.stm.GParsStm
Gives access to multiverse TransactionFactoryBuilder to allow customized creation of atomic blocks
transferQueues() - Method in class groovyx.gpars.actor.impl.SequentialProcessingActor
Transfers messages from the input queue into the output queue, reverting the order of the elements.
transform(Expression) - Method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 
transform(Object, Closure) - Static method in class groovyx.gpars.dataflow.DataflowExpression
 

U

uid - Variable in class groovyx.gpars.remote.BroadcastDiscovery
 
UNCAUGHT_EXCEPTION_OCCURRED_IN_ACTOR_POOL - Static variable in interface groovyx.gpars.scheduler.Pool
 
unsubscribe(SerialContext) - Method in class groovyx.gpars.serial.SerialHandle
 
unwrapMessage(Object) - Static method in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
unwrapStmControlError(InvokerInvocationException) - Static method in class groovyx.gpars.stm.GParsStm
Unwraps the multiverse control exceptions from Groovy exceptions
updateValue(T) - Method in class groovyx.gpars.agent.AgentBase
Allows closures to set the new internal state as a whole Do not call this method directly from the outside.

V

valAsync(Closure) - Method in class groovyx.gpars.agent.AgentBase
A shorthand method for safe asynchronous message-based retrieval of the internal state.
validatePoolClass(Expression, AnnotatedNode, SourceUnit) - Static method in class groovyx.gpars.util.AsyncFunASTTransformation
 
validators - Variable in class groovyx.gpars.agent.AgentBase
Holds all validators checking the agent's state A validator should be a closure accepting the old and the new value in this order.
value - Variable in class groovyx.gpars.actor.impl.MessageStream.ResultWaiter
Holds a reference to the calling thread, while waiting, and the received reply message, once it has arrived.
value - Variable in class groovyx.gpars.dataflow.DataflowExpression
Holds the actual value.
value - Variable in class groovyx.gpars.dataflow.SelectResult
 
value - Variable in class groovyx.gpars.util.FQMessageQueue.Node
 
valueFound(int, T) - Method in interface groovyx.gpars.dataflow.impl.SelectRequest
Invoked, when a value has been found bound to any of the input channels monitored by the select.
variables - Variable in class groovyx.gpars.dataflow.Dataflows
 
visit(ASTNode[], SourceUnit) - Method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation
 
visit(ASTNode[], SourceUnit) - Method in class groovyx.gpars.util.AsyncFunASTTransformation
 
visitClass(ClassNode) - Method in class groovyx.gpars.activeobject.ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
 

W

waiting - Variable in class groovyx.gpars.dataflow.DataflowExpression
Points to the head of the chain of requests waiting for a value to be bound
waitingThread - Variable in class groovyx.gpars.actor.impl.SequentialProcessingActor
 
waitingUpdater - Static variable in class groovyx.gpars.dataflow.DataflowExpression
Updater for the waiting field
when(Closure) - Method in class groovyx.gpars.actor.DynamicDispatchActor
 
whenBound(Closure) - Method in class groovyx.gpars.dataflow.DataflowExpression
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(Pool, Closure) - Method in class groovyx.gpars.dataflow.DataflowExpression
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(PGroup, Closure) - Method in class groovyx.gpars.dataflow.DataflowExpression
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowExpression
Send the bound data to provided stream when it becomes available
whenBound(Closure) - Method in class groovyx.gpars.dataflow.DataflowQueue
Schedule closure to be executed by pooled actor after the next data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(Pool, Closure) - Method in class groovyx.gpars.dataflow.DataflowQueue
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(PGroup, Closure) - Method in class groovyx.gpars.dataflow.DataflowQueue
 
whenBound(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowQueue
Send the next bound piece of data to the provided stream when it becomes available
whenBound(Closure) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(Pool, Closure) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(PGroup, Closure) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(MessageStream) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Send the bound data to provided stream when it becomes available
whenBound(Closure) - Method in interface groovyx.gpars.dataflow.Promise
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(Pool, Closure) - Method in interface groovyx.gpars.dataflow.Promise
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(PGroup, Closure) - Method in interface groovyx.gpars.dataflow.Promise
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(MessageStream) - Method in interface groovyx.gpars.dataflow.Promise
Send the bound data to provided stream when it becomes available
whenBound(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
whenBound(Pool, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
Schedule closure to be executed by pooled actor after data becomes available It is important to notice that even if data already available the execution of closure will not happen immediately but will be scheduled.
whenBound(PGroup, Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
whenBound(MessageStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
wheneverBound(Closure) - Method in class groovyx.gpars.dataflow.DataflowExpression
Send all pieces of data bound in the future to the provided stream when it becomes available *
wheneverBound(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowExpression
Send all pieces of data bound in the future to the provided stream when it becomes available
wheneverBound(Closure) - Method in class groovyx.gpars.dataflow.DataflowQueue
Send all pieces of data bound in the future to the provided stream when it becomes available *
wheneverBound(MessageStream) - Method in class groovyx.gpars.dataflow.DataflowQueue
Send all pieces of data bound in the future to the provided stream when it becomes available
wheneverBound(Closure) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Send all pieces of data bound in the future to the provided stream when it becomes available *
wheneverBound(MessageStream) - Method in interface groovyx.gpars.dataflow.DataflowReadChannel
Send all pieces of data bound in the future to the provided stream when it becomes available
wheneverBound(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
wheneverBound(MessageStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStream
 
wheneverBound(Closure) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
wheneverBound(MessageStream) - Method in class groovyx.gpars.dataflow.stream.DataflowStreamReadAdapter
 
wheneverBoundListeners - Variable in class groovyx.gpars.dataflow.DataflowQueue
A collection of listeners who need to be informed each time the stream is bound to a value
wheneverBoundListeners - Variable in class groovyx.gpars.dataflow.stream.DataflowStream
A collection of listeners who need to be informed each time the stream is bound to a value
withReadLock(Closure) - Method in class groovyx.gpars.util.EnhancedRWLock
Performs the passed-in closure with the read lock locked and unlocks the read lock automatically after the closure finishes.
withSemaphore(Closure) - Method in class groovyx.gpars.util.EnhancedSemaphore
Performs the passed-in closure with the Semaphore acquired and releases the Semaphore automatically after the closure finishes.
WithSerialId - Class in groovyx.gpars.serial
Base class for objects which can be exposed to remote nodes via serialization.
WithSerialId() - Constructor for class groovyx.gpars.serial.WithSerialId
 
withWriteLock(Closure) - Method in class groovyx.gpars.util.EnhancedRWLock
Performs the passed-in closure with the write lock locked and unlocks the write lock automatically after the closure finishes.
write(SerialMsg) - Method in class groovyx.gpars.remote.netty.NettyRemoteConnection
 
write(SerialMsg) - Method in class groovyx.gpars.remote.RemoteConnection
 
write(SerialMsg) - Method in class groovyx.gpars.remote.RemoteHost
 
write(SerialMsg) - Method in class groovyx.gpars.serial.SerialContext
 
writeListener - Variable in class groovyx.gpars.remote.netty.NettyRemoteConnection
 
writeReplace() - Method in class groovyx.gpars.serial.WithSerialId
Replace object by handle for serialization

A B C D E F G H I J K L M N O P Q R S T U V W
Copyright © 2008–2010 Václav Pech. All Rights Reserved.