Groovy Documentation
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z _

A

AbstractForkJoinWorker - Class in gpars
Implements the ForkJoin worker contract.
AbstractForkJoinWorker() - Constructor in AbstractForkJoinWorker
AbstractPAWrapper - Class in gpars
Wraps a ParallelArray instance in map/reduce operation chains.
AbstractPAWrapper(def) - Constructor in AbstractPAWrapper
Creates an instance wrapping the supplied instance of ParallelArray
AbstractPooledActor - Class in gpars.actor
AbstractPooledActor provides the default Actor implementation.
act() - Method in AbstractPooledActor
This method represents the body of the actor.
act() - Method in DataFlowOperatorActor
act() - Method in DefaultPooledActor
act() - Method in DynamicDispatchActor
Loops reading messages using the react() method and dispatches to the corresponding onMessage() method.
act() - Method in RunnableBackedPooledActor
act() - Method in SingleRunActor
Actor - Class in gpars.actor
Actors are active objects, which borrow a thread from a thread pool.
Actor.MyRemoteHandle - Class in gpars.actor
Actor.MyRemoteHandle(SerialHandle, SerialContext, DataFlowExpression) - Constructor in Actor.MyRemoteHandle
Actor.RemoteActor - Class in gpars.actor
Actor.RemoteActor.StopActorMsg - Class in gpars.actor
Actor.RemoteActor.StopActorMsg(RemoteActor) - Constructor in Actor.RemoteActor.StopActorMsg
Actor.RemoteActor.TerminateActorMsg - Class in gpars.actor
Actor.RemoteActor.TerminateActorMsg(RemoteActor) - Constructor in Actor.RemoteActor.TerminateActorMsg
Actor.RemoteActor(SerialContext, DataFlowExpression) - Constructor in Actor.RemoteActor
Actor(DataFlowExpression) - Constructor in Actor
Constructor to be used by deserialization
actor(Runnable) - Method in Actors
Creates a new instance of PooledActor, using the passed-in closure as the body of the actor's act() method.
actor(Runnable) - Method in PGroup
Creates a new instance of PooledActor, using the passed-in runnable/closure as the body of the actor's act() method.
ActorContinuationException - Class in gpars.actor.impl
An exception indicating end of a work chunk (ActorAction) allowing other ActorAction to get scheduled.
ActorException - Class in 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.
actorGroup - Field in SequentialProcessingActor
The actor group to which the actor belongs
ActorMessage - Class in gpars.actor
An internal representation of received messages holding both the original message plus the sender actor reference.
ActorMessage() - Constructor in ActorMessage
Constructor for serialization
ActorReplyException - Class in gpars.actor.impl
Indicates problems sending replies to actors.
ActorReplyException(String, List) - Constructor in ActorReplyException
Actors - Class in gpars.actor
Provides handy helper methods to create pooled actors and customize the underlying thread pool.
ActorStopException - Class in gpars.actor.impl
An exception indicating Actor stopping request.
ActorTerminationException - Class in gpars.actor.impl
An exception indicating Actor termination request.
ActorTimeoutException - Class in gpars.actor.impl
An exception indicating Actor react timeout.
add(SerialHandle) - Method in SerialContext
add(SerialHandle) - Method in SerialHandles
addConnection(RemoteConnection) - Method in RemoteHost
addDiscoveryListener(Closure) - Method in LocalNode
addLocalHost(LocalHost) - Method in LocalHostRegistry
Agent - Class in gpars.agent
A special-purpose thread-safe non-blocking reference implementation inspired by Agents in Clojure.
Agent(Object, Closure) - Constructor in Agent
Creates a new Agent around the supplied modifiable object
agent(def, Closure) - Method in PGroup
Creates an agent instance initialized with the given state
AgentCore - Class in gpars.agent
@author Vaclav Pech Date: 13.4.2010
ALT - Class in gpars.csp
ALT is used to create an Alternative object
ALT(List) - Constructor in ALT
any(Closure) - Method in TransparentParallel
anyParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the any() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
anyParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the any() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
anyParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied closure as the filter predicate.
anyParallel(Closure) - Method in Parallel
Performs the any() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
append(def) - Method in ChannelInputList
append(def) - Method in ChannelOutputList
args - Field in DataFlowComplexExpression
async(Closure) - Method in GParsExecutorsPoolUtil
Creates an asynchronous variant of the supplied closure, which, when invoked returns a future for the potential return value
async(Closure) - Method in GParsPoolUtil
Creates an asynchronous variant of the supplied closure, which, when invoked returns a future for the potential return value
AsyncException - Class in gpars
This class wraps multiple exception, which occurred in concurrently run code inside one of the GParsExecutorsPoolUtil methods.
AsyncException(String, List) - Constructor in AsyncException
attachToThreadPool(Pool) - Method in AgentCore
Sets a new thread pool to be used by the agent
await() - Method in Agent
Blocks until all messages in the queue prior to call to await() complete.

B

bind(Object) - Method in DataFlowExpression
Assigns a value to the variable.
bindOutput(def) - Method in DataFlowOperator
Used by the operator's body to send a value to the first / only output channel
bindSafely(Object) - Method in DataFlowExpression
Assigns a value to the variable.
BroadcastDiscovery - Class in gpars.remote
BroadcastDiscovery(UUID, InetSocketAddress) - Constructor in BroadcastDiscovery
build(Object) - Method in ActorMessage
Factory method to create instances of ActorMessage with given payload.

C

call(Object) - Method in AgentCore
Adds the message to the agent\s message queue
call(Object) - Method in MessageStream
Same as send
callAsync(Closure, Object) - Method in GParsExecutorsPoolUtil
Calls a closure in a separate thread supplying the given arguments, returning a future for the potential return value,
callAsync(Closure, Object) - Method in GParsPoolUtil
Calls a closure in a separate thread supplying the given arguments, returning a future for the potential return value,
channelConnected(ChannelHandlerContext, ChannelStateEvent) - Method in NettyHandler
channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in NettyHandler
channelDisconnected(ChannelHandlerContext, ChannelStateEvent) - Method in NettyTransportProvider.ClientHandler
ChannelInputList - Class in gpars.csp
ChannelInputList is used to create a list of ChannelInputEnds
ChannelInputList() - Constructor in ChannelInputList
ChannelInputList uses the ArrayList class of java This constructor creates an empty ArrayList to be populated with NetChannelInputs
channelOpen(ChannelHandlerContext, ChannelStateEvent) - Method in NettyHandler
ChannelOutputList - Class in gpars.csp
ChannelOutputList is used to create a list of ChannelOUTPUTEnds
ChannelOutputList() - Constructor in ChannelOutputList
ChannelOutputList uses the ArrayList class of java This constructor creates an empty ArrayList to be populated with NetChannelOUTPUTs
checkStopTerminate() - Method in SequentialProcessingActor
checkValidPoolSize(int) - Method in PoolUtils
collect(Closure) - Method in TransparentParallel
collectParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Iterates over a collection/object with the collect() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
collectParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Iterates over a collection/object with the collect() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
collectParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied closure as the transformation operation.
collectParallel(Closure) - Method in Parallel
Iterates over a collection/object with the collect() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
compute() - Method in AbstractForkJoinWorker
compute() - Method in FJRunnableTask
computeTask() - Method in AbstractForkJoinWorker
computeTask() - Method in FJWorker
connect(def) - Method in GroovyMobileProcess
connect(LocalNode) - Method in LocalHost
Connect local node to the provider
connect(LocalNode) - Method in LocalHostRegistry
connect(LocalHost) - Method in LocalNode
connect(List) - Method in MobileAgent
connect(LocalNode) - Method in RemoteHost
connectRemoteNode(UUID, SerialContext, Actor) - Method in LocalHost
contains(def) - Method in ChannelInputList
contains(def) - Method in ChannelOutputList
contains(def) - Method in DataFlows
Checks whether a certain key is contained in the map.
context - Field in SerialHandle
local host
CONTINUE - Field in ActorException
copy() - Method in JCSPCopy
The interface JCSPCopy is used to define a copy method that is used to make a deep copy of an object.
count(def) - Method in TransparentParallel
countParallel(Object, def) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied rule as the filter predicate.
countParallel(Object) - Method in Parallel
Performs the count() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
create(WithSerialId, UUID) - Method in SerialHandle
createCollection(Object) - Method in GParsPoolUtil
createComparator(Closure) - Method in GParsPoolUtil
Builds a comparator depending on the number of arguments accepted by the supplied closure.
createObject(SerialContext) - Method in Actor.MyRemoteHandle
createObject(SerialContext) - Method in DefaultRemoteHandle
createObject(SerialContext) - Method in RemoteHandle
createRemoteHandle(SerialHandle, SerialContext) - Method in Actor
createRemoteHandle(SerialHandle, SerialContext) - Method in WithSerialId
createThreadName() - Method in DefaultPool
Created a JVM-unique name for Actors' threads.

D

data - Field in Agent
Holds the internal mutable state
DATA_FLOW_GROUP - Field in DataFlow
The actor group used by all Dataflow Concurrency actors by default.
DataCallback - Class in gpars.dataflow
A helper class enabling the 'whenBound()' functionality of a DataFlowVariable.
DataCallback(Closure) - Constructor in DataCallback
@param code The closure to run
DataFlow - Class in gpars.dataflow
Contains factory methods to create dataflow actors and starting them.
DataFlowActor - Class in gpars.dataflow
A parent actor for all actors used in Dataflow Concurrency implementation
DataFlowActor() - Constructor in DataFlowActor
Sets the default Dataflow Concurrency actor group on the actor.
DataFlowComplexExpression - Class in gpars.dataflow
@author Alex Tkachman
DataFlowComplexExpression(Object) - Constructor in DataFlowComplexExpression
DataFlowExpression - Class in gpars.dataflow
The base class for all dataflow elements.
DataFlowExpression.BindDataFlow - Class in gpars.dataflow
Represents a remote message binding a value to a remoted DataFlowExpression
DataFlowExpression.BindDataFlow(DataFlowExpression, Object, UUID) - Constructor in DataFlowExpression.BindDataFlow
@param expr The local DataFlowExpression instance
DataFlowExpression() - Method in DataFlowExpression
Creates a new unbound Dataflow Expression
DataFlowGetPropertyExpression - Class in gpars.dataflow
DFE which evaluate property when receiver became available
DataFlowGetPropertyExpression(DataFlowExpression, String) - Constructor in DataFlowGetPropertyExpression
DataFlowInvocationExpression - Class in gpars.dataflow
Data flow expression which invokes method of object after receiver and all arguments became available
DataFlowInvocationExpression(Object, String, Object) - Constructor in DataFlowInvocationExpression
DataFlowOperator - Class in gpars.dataflow.operator
Dataflow operators form the basic units in dataflow networks.
DataFlowOperatorActor(def, def, def, def) - Constructor in DataFlowOperatorActor
DataFlowPGroup - Class in gpars.dataflow
Groups all dataflow threads, tasks and operators.
DataFlowPGroup(int) - Constructor in DataFlowPGroup
Creates a default group for dataflow tasks and operators.
DataFlows - Class in gpars.dataflow
Convenience class that makes working with DataFlowVariables more comfortable.
DataFlows(int, float, int) - Constructor in DataFlows
Constructor that supports the various constructors of the underlying ConcurrentHashMap (unless the one with Map parameter).
DataFlowStream - Class in gpars.dataflow
Represents a thread-safe data flow stream.
DataFlowVariable - Class in gpars.dataflow
Represents a thread-safe single-assignment, multi-read variable.
DataFlowVariable.RemoteDataFlowVariable - Class in gpars.dataflow
DataFlowVariable.RemoteDataFlowVariable(RemoteHost) - Constructor in DataFlowVariable.RemoteDataFlowVariable
DataFlowVariable() - Constructor in DataFlowVariable
Creates a new unbound Dataflow Variable
decode(ChannelHandlerContext, Channel, ChannelBuffer) - Method in RemoteObjectDecoder
defaultActorPGroup - Field in Actors
The default actor group to share by all actors created through the Actors class.
DefaultPGroup - Class in gpars.group
Provides logical grouping for actors, agents and dataflow tasks and operators.
DefaultPGroup(int) - Constructor in DefaultPGroup
Creates a group for actors, agents, tasks and operators.
DefaultPool - Class in gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
DefaultPool(ThreadPoolExecutor) - Constructor in DefaultPool
Creates the pool around the given executor service
DefaultPooledActor - Class in gpars.actor
Default non-abstract AbstractPooledActor subclass for use in e.g. mixins.
DefaultRemoteHandle - Class in gpars.serial
@author Alex Tkachman
DefaultRemoteHandle(UUID, UUID, Class) - Constructor in DefaultRemoteHandle
deregisterCurrentActorWithThread() - Method in Actor
Deregisters the actor registered from the thread
disconnect() - Method in GroovyMobileProcess
disconnect() - Method in LocalHost
disconnect(LocalNode) - Method in LocalHostRegistry
disconnect() - Method in LocalNode
disconnect() - Method in MobileAgent
disconnect() - Method in NettyRemoteConnection
disconnect() - Method in NettyTransportProvider
disconnect() - Method in RemoteConnection
disconnect(LocalNode) - Method in RemoteHost
disconnectRemoteNode(UUID) - Method in LocalHost
doBindRemote(UUID, Object) - Method in DataFlowExpression
Binds the value after receiving a bing message over the wire
doCall(Object) - Method in SequentialProcessingActor.MultiMessageReaction
doOnException(Throwable) - Method in AbstractPooledActor
doOnException(Throwable) - Method in SequentialProcessingActor
Allows subclasses to add behavior to run after exception in actor's body
doOnInterrupt(InterruptedException) - Method in AbstractPooledActor
doOnInterrupt(InterruptedException) - Method in SequentialProcessingActor
Allows subclasses to add behavior to run after actor's interruption
doOnStart() - Method in AbstractPooledActor
doOnStart() - Method in SequentialProcessingActor
Allows subclasses to add behavior to run after actor's start
doOnTermination() - Method in AbstractPooledActor
doOnTermination() - Method in SequentialProcessingActor
Allows subclasses to add behavior to run after actor's termination
doOnTimeout() - Method in AbstractPooledActor
doOnTimeout() - Method in SequentialProcessingActor
Allows subclasses to add behavior to run after actor's timeout
DynamicDispatchActor - Class in gpars.actor
A pooled actor allowing for an alternative structure of the message handling code.
DynamicDispatchActor(Closure) - Constructor in DynamicDispatchActor
Creates an instance, processing all when{} calls in the supplied closure

E

each(Closure) - Method in TransparentParallel
eachParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Iterates over a collection/object with the each() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
eachParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Iterates over a collection/object with the each() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
eachParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied closure as the transformation operation.
eachParallel(Closure) - Method in Parallel
Iterates over a collection/object with the each() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
eachWithIndex(Closure) - Method in TransparentParallel
eachWithIndexParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Iterates over a collection/object with the eachWithIndex() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
eachWithIndexParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Iterates over a collection/object with the eachWithIndex() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
eachWithIndexParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied closure as the transformation operation.
eachWithIndexParallel(Closure) - Method in Parallel
Iterates over a collection/object with the eachWithIndex() method using an asynchronous variant of the supplied closure to evaluate each collection's element.
encode(ChannelHandlerContext, Channel, Object) - Method in RemoteObjectEncoder
enhanceClass(Class) - Method in GParsExecutorsPoolEnhancer
Enhances a class and so all instances created in the future by mixing-in an instance of GParsExecutorsPoolEnhancer.
enhanceClass(Class) - Method in ParallelEnhancer
Enhances a class and so all instances created in the future by mixing-in an instance of Parallel.
EnhancedRWLock - Class in 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(boolean) - Constructor in EnhancedRWLock
EnhancedSemaphore - Class in 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 in EnhancedSemaphore
Creates a new EnhancedSemaphore, delegating to the Semaphore class constructor.
enhanceInstance(Object) - Method in GParsExecutorsPoolEnhancer
Enhances a single instance by mixing-in an instance of GParsExecutorsPoolEnhancer.
enhanceInstance(Object) - Method in ParallelEnhancer
Enhances a single instance by mixing-in an instance of Parallel.
ensurePool(ForkJoinPool, Closure) - Method in GParsPool
Just like withExistingPool() registers a thread pool, but doesn't install the GParsPoolUtil category.
enter() - Method in SerialContext
Enter to the context
evaluate() - Method in DataFlowComplexExpression
evaluate() - Method in DataFlowExpression
Evaluate expression after the ones we depend on are ready
evaluate() - Method in DataFlowExpression.TransformMany
evaluate() - Method in DataFlowExpression.TransformOne
evaluate() - Method in DataFlowGetPropertyExpression
evaluate() - Method in DataFlowInvocationExpression
evaluate() - Method in RemoteDataFlowExpression
every(Closure) - Method in TransparentParallel
everyParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the all() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
everyParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the all() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
everyParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied closure as the filter predicate.
everyParallel(Closure) - Method in Parallel
Performs the all() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in NettyHandler
execute(RemoteConnection) - Method in Actor.RemoteActor.StopActorMsg
execute(RemoteConnection) - Method in Actor.RemoteActor.TerminateActorMsg
execute(RemoteConnection) - Method in DataFlowExpression.BindDataFlow
Performs the actual bind on the remote host
execute(Runnable) - Method in DefaultPool
schedules a new task for processing with the pool
execute(Runnable) - Method in FJPool
schedules a new task for processing with the pool
execute(RemoteConnection) - Method in MessageStream.SendTo
execute(RemoteConnection) - Method in NodeConnectedMsg
execute(RemoteConnection) - Method in NodeDisconnectedMsg
execute(Runnable) - Method in Pool
schedules a new task for processing with the pool
execute(Runnable) - Method in ResizeableFJPool
schedules a new task for processing with the pool
execute(Runnable) - Method in Scheduler
execute(RemoteConnection) - Method in SerialHandle.RemoteSerialHandle.ReleaseHandle
execute(RemoteConnection) - Method in SerialMsg
executeAsync(List) - Method in GParsExecutorsPool
Starts multiple closures in separate threads, collecting Futures for their return values If an exception is thrown from the closure when called on any of the collection's elements, it will be re-thrown in the calling thread when it calls the Future.get() method.
executeAsync(List) - Method in GParsPool
Starts multiple closures in separate threads, collecting Futures for their return values Reuses the pool defined by the surrounding withPool() call.
executeAsyncAndWait(List) - Method in GParsExecutorsPool
Starts multiple closures in separate threads, collecting their return values If an exception is thrown from the closure when called on any of the collection's elements, it will be re-thrown in the calling thread when it calls the Future.get() method.
executeAsyncAndWait(List) - Method in GParsPool
Starts multiple closures in separate threads, collecting their return values Reuses the pool defined by the surrounding withPool() call.

F

fairAgent(def, Closure) - Method in 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(def, Closure) - Method in PGroup
Creates an agent instance initialized with the given state, which will cooperate in thread sharing with other Agent instances in a fair manner.
FairMultiplex - Class in gpars.csp.util
filter(Closure) - Method in AbstractPAWrapper
Filters concurrently elements in the collection based on the outcome of the supplied function on each of the elements.
filter(Closure) - Method in MappedPAWrapper
Filters concurrently elements in the collection based on the outcome of the supplied function on each of the elements.
filter(Closure) - Method in PAWrapper
Filters concurrently elements in the collection based on the outcome of the supplied function on each of the elements.
finalizeHandle(SerialHandle) - Method in SerialContext
finalizeHandle(SerialHandle) - Method in SerialHandles
finalizeReference() - Method in SerialHandle
finalizeReference() - Method in SerialHandle.RemoteSerialHandle
find(Closure) - Method in TransparentParallel
findAll(Closure) - Method in TransparentParallel
findAllParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the findAll() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findAllParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the findAll() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findAllParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied closure as the filter predicate.
findAllParallel(Closure) - Method in Parallel
Performs the findAll() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findAny(Closure) - Method in TransparentParallel
findAnyParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the find() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findAnyParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied closure as the filter predicate.
findAnyParallel(Closure) - Method in Parallel
Performs the find() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the find() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the find() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
findParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied closure as the filter predicate.
findParallel(Closure) - Method in Parallel
Performs the find() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
FJPool - Class in gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
FJPool(int) - Constructor in FJPool
Creates the pool with specified number of threads.
FJWorker - Class in gpars
FJWorker(Object) - Constructor in FJWorker
fold(def, Closure) - Method in TransparentParallel
foldParallel(Object, def, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes its reduce() method using the supplied closure as the reduction operation.
foldParallel(def, Closure) - Method in Parallel
Creates a Parallel Array out of the supplied collection/object and invokes its reduce() method using the supplied closure as the reduction operation.
ForkingDataFlowOperatorActor(def, def, def, def, def) - Constructor in ForkingDataFlowOperatorActor
forkOffChild(AbstractForkJoinWorker) - Method in AbstractForkJoinWorker
Forks a child task.
forkOffChild(Object) - Method in FJWorker

G

GConsole - Class in gpars.csp.plugAndPlay
GConsoleStringToInteger - Class in gpars.csp.plugAndPlay
GDelta2 - Class in gpars.csp.plugAndPlay
get(UUID) - Method in SerialContext
get(UUID) - Method in SerialHandles
getActorGroup() - Method in SequentialProcessingActor
Retrieves the group to which the actor belongs
getAddress() - Method in NettyTransportProvider.Server
getAt(def) - Method in ChannelInputList
getAt(def) - Method in ChannelOutputList
getAt(def) - Method in DataFlows
Returns:
the value of the DataFlowVariable associated with the property "name".
getChannel() - Method in NettyHandler
getChildrenResults() - Method in AbstractForkJoinWorker
Waits for and returns the results of the child tasks.
getCollection() - Method in AbstractPAWrapper
Reconstructs a collection from the wrapped ParallelArray instance
getConcurrentExceptions() - Method in AsyncException
getConfiguredPoolSize() - Method in FJPool
getConnection() - Method in RemoteHost
getCurrent() - Method in ThreadLocalPools
Gives the current element
getErrors() - Method in AgentCore
Retrieves a list of exception thrown within the agent's body.
getExecutorService() - Method in DefaultPool
Retrieves the internal executor service.
getForkJoinPool() - Method in FJPool
Retrieves the internal executor service.
getHost() - Method in RemoteConnection
getHostId() - Method in SerialContext
getId() - Method in LocalHandle
getId() - Method in LocalNode
getId() - Method in RemoteNode
getId() - Method in SerialHandles
Getter for provider id
getInstantVal() - Method in Agent
A shorthand method for safe message-based retrieval of the internal state.
getIssues() - Method in ActorReplyException
getJoinLatch() - Method in Actor
Join-point for this actor
getLocalHost() - Method in LocalNode
getLocalHost() - Method in RemoteHost
getLocalHostId() - Method in SerialContext
getMainActor() - Method in LocalNode
getMainActor() - Method in RemoteNode
getMaximumNumberOfParameters() - Method in SequentialProcessingActor.MultiMessageReaction
getMessage() - Method in AsyncException
getMessage() - Method in MessageStream.SendTo
getMetaClass() - Method in DataFlowExpression
getOrCreateSerialHandle() - Method in WithSerialId
Gets serial handle for the object If needed new handle created and serialization host subscribed for the object handle
getOutput() - Method in DataFlowOperator
The operator's first / only output channel
getOutputs() - Method in DataFlowOperator
The operator's output channel of the given index
getParallel(Object) - Method in GParsPoolUtil
Creates a PAWrapper around a ParallelArray wrapping te elements of the original collection.
getParallel() - Method in Parallel
Creates a PAWrapper around a ParallelArray wrapping te elements of the original collection.
getParameterTypes() - Method in SequentialProcessingActor.MultiMessageReaction
getPayLoad() - Method in ActorMessage
getPipeline() - Method in NettyTransportProvider.ServerPipelineFactory
getProperty(String) - Method in DataFlowExpression
Returns either standard property of expression or creates expression, which will request given property when receiver became available
getProperty(String) - Method in DataFlows
Returns:
the value of the DataFlowVariable associated with the property "name".
getProperty(String) - Method in RunnableBackedPooledActor.RunnableBackedPooledActorDelegate
getRemoteClass() - Method in DataFlowVariable
getRemoteClass() - Method in MessageStream
getRemoteClass() - Method in WithSerialId
Class of remote object to be created
getRemoteHost() - Method in RemoteNode
getResult(long, TimeUnit) - Method in MessageStream.ResultWaiter
Retrieves the response blocking until a message arrives
getScheduler() - Method in LocalNode
getSender() - Method in ActorMessage
getSender(Object) - Method in ReceivingMessageStream.ReplyCategory
Retrieves the originator of a message
getSenders() - Method in ReceivingMessageStream
getSerialHost(UUID, Object) - Method in LocalHost
getSerialHost(UUID, Object) - Method in SerialContext
getSerialHost(UUID, Object) - Method in SerialHandles
getSerialId() - Method in SerialHandle
Serial id of the object
getSubscribers() - Method in SerialHandle
Getter for subscribers
getThreadPool() - Method in AgentCore
Retrieves the thread pool used by the agent
getThreadPool() - Method in GParsExecutorsPoolEnhancer
Retrieves the underlying pool
getThreadPool() - Method in ParallelEnhancer
Retrieves the underlying pool
getThreadPool() - Method in PGroup
getTo() - Method in MessageStream.SendTo
getVal() - Method in Agent
A shorthand method for safe message-based retrieval of the internal state.
getVal(long, TimeUnit) - Method in DataFlowExpression
Reads the value of the variable.
getVal() - Method in DataFlowStream
Retrieves the value at the head of the buffer.
getValAsync(MessageStream) - Method in DataFlowExpression
Asynchronously retrieves the value of the variable.
getValAsync(Object, MessageStream) - Method in DataFlowStream
Asynchronously retrieves the value at the head of the buffer.
GFixedDelay - Class in gpars.csp.plugAndPlay
GIdentity - Class in gpars.csp.plugAndPlay
GIntegrate - Class in gpars.csp.plugAndPlay
GNumbers - Class in gpars.csp.plugAndPlay
GObjectToConsoleString - Class in gpars.csp.plugAndPlay
GPairs - Class in gpars.csp.plugAndPlay
GParPrint - Class in gpars.csp.plugAndPlay
GParsExecutorsPool - Class in gpars
Enables a ExecutorService-based DSL on closures, objects and collections.
GParsExecutorsPoolEnhancer - Class in gpars
GParsExecutorsPoolEnhancer allows classes or instances to be enhanced with asynchronous variants of iterative methods, like eachParallel(), collectParallel(), findAllParallel() and others.
GParsExecutorsPoolUtil - Class in gpars
This class forms the core of the DSL initialized by GParsExecutorsPool.
GParsPool - Class in gpars
Enables a ParallelArray-based (from JSR-166y) DSL on collections.
GParsPoolUtil - Class in gpars
This class forms the core of the DSL initialized by GParsPool.
GPCopy - Class in gpars.csp.plugAndPlay
GPlus - Class in gpars.csp.plugAndPlay
GPrefix - Class in gpars.csp.plugAndPlay
GPrint - Class in gpars.csp.plugAndPlay
grep(def) - Method in TransparentParallel
grepParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the grep()() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
grepParallel(Object, def) - Method in GParsExecutorsPoolUtil
Performs the grep()() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
grepParallel(Object, def) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied rule as the filter predicate.
grepParallel(Object) - Method in Parallel
Performs the grep() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
GroovyMobileProcess - Class in gpars.csp
groupBy(Closure) - Method in TransparentParallel
groupByParallel(Closure) - Method in GParsExecutorsPoolEnhancer
Performs the groupBy() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
groupByParallel(Object, Closure) - Method in GParsExecutorsPoolUtil
Performs the groupBy() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
groupByParallel(Object, Closure) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied closure as the mapping predicate.
groupByParallel(Closure) - Method in Parallel
Performs the groupBy() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
GSquares - Class in gpars.csp.plugAndPlay
GStatePairs - Class in gpars.csp.plugAndPlay
GSuccessor - Class in gpars.csp.plugAndPlay
GTail - Class in gpars.csp.plugAndPlay

H

handleMessage(Object) - Method in Agent
Dynamically dispatches the method call
handler - Field in NettyRemoteConnection.MyChannelFutureListener
handleValueMessage(Map, def) - Method in DataFlowOperatorActor
Calls itself recursively within a react() call, if more input values are still needed.
hostId - Field in RemoteHandle
hostId - Field in SerialContext
hostId - Field in SerialMsg
HostIdMsg - Class in gpars.remote.message
Message sent by NetTransportProvider immediately after connection to another host is set up
HostIdMsg(UUID) - Constructor in HostIdMsg
Construct message representing current state of the transport provider

I

id - Field in SerialHandles
Unique id of the provider
initialValue() - Method in ThreadLocalPools
invokeMethod(String, Object) - Method in DataFlowExpression
invokeMethod(String, Object) - Method in DataFlows
Invokes the given method.
invokeMethod(String, Object) - Method in RunnableBackedPooledActor.RunnableBackedPooledActorDelegate
isActive() - Method in Actor
Checks the current status of the Actor.
isActive() - Method in Actor.RemoteActor
isActive() - Method in SequentialProcessingActor
Checks the current status of the Actor.
isActorThread() - Method in Actor
Checks whether the current thread is the actor's worker thread.
isActorThread() - Method in Actor.RemoteActor
isActorThread() - Method in SequentialProcessingActor
Checks whether the current thread is the actor's current thread.
isBound() - Method in DataFlowExpression
Check if value has been set already for this expression
isConnected() - Method in RemoteHost
isFair() - Method in 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.
isReady() - Method in SequentialProcessingActor.Reaction
Indicates whether a message or a timeout has arrived.
isTransparent(Object) - Method in GParsPoolUtil
Indicates whether the iterative methods like each() or collect() work have been altered to work concurrently.
isTransparent() - Method in Parallel
Indicates, whether the iterative methods like each() or collect() have been made parallel.
isTransparent() - Method in TransparentParallel
Indicates, whether the iterative methods like each() or collect() have been made parallel.
iterator() - Method in DataFlows
Convenience method to play nicely with Groovy object iteration methods.
iterator() - Method in DataFlowStream
Returns an iterator over a current snapshot of the buffer's content.

J

JCSPCopy - Interface in gpars.csp
join(BaseDuration) - Method in Actor
Joins the actor.
join() - Method in DataFlowOperator
Joins the operator waiting for it to finish

K


L

leave() - Method in SerialContext
Leave this context
leftShift(Object) - Method in AgentCore
Adds the message to the agent\s message queue
leftShift(Object) - Method in DataFlowStream
Adds a DataFlowVariable representing the passed in value to the buffer.
leftShift(DataFlowExpression) - Method in DataFlowVariable
Assigns a value from one DataFlowVariable instance to this variable.
leftShift(ExecutorService, Closure) - Method in GParsExecutorsPoolUtil
Submits the task for asynchronous processing returning the Future received from the executor service.
leftShift(ForkJoinPool, Closure) - Method in GParsPoolUtil
Submits the task for asynchronous processing returning the Future received from the executor service.
leftShift(Object) - Method in MessageStream
Same as send
leftShift(def) - Method in ThreadLocalPools
Adds a new element
length() - Method in DataFlowStream
Returns the current size of the buffer
list1GEList2(def, def) - Method in TestUtilities
listContains(def, def) - Method in TestUtilities
LocalHandle - Class in gpars.serial
@author Alex Tkachman
LocalHandle(UUID) - Constructor in LocalHandle
LocalHost - Class in gpars.remote
Represents communication point with other local hosts.
localHost - Field in SerialContext
LocalHostRegistry - Class in gpars.remote
Registry of local hosts
localHosts - Field in LocalHostRegistry
LocalNode - Class in gpars.remote
Representation of local node
LocalNode(LocalHost, Runnable) - Constructor in LocalNode
localNodes - Field in LocalHost
Local nodes known to the provider
loop(Runnable) - Method in Scheduler
loop(Runnable) - Method in SequentialProcessingActor
Ensures that the supplied closure will be invoked repeatedly in a loop.
loopCode - Field in SequentialProcessingActor
Code for the loop, if any

M

mainActor - Field in NodeConnectedMsg
makeFair() - Method in AgentCore
Makes the agent fair.
makeTransparent(Object) - Method in GParsPoolUtil
Creates a TransparentParallel class instance and mixes it in the object it is invoked on.
makeTransparent(Object) - Method in Parallel
Creates a TransparentParallel class instance and mixes it in the object it is invoked on.
map(Closure) - Method in AbstractPAWrapper
Applies concurrently the supplied function to all elements in the collection, returning a collection containing the transformed values.
MappedPAWrapper - Class in gpars
The ParallelArray wrapper used after the map() operation
MappedPAWrapper(WithMapping) - Constructor in MappedPAWrapper
max(Closure) - Method in AbstractPAWrapper
Finds in parallel the maximum of all values in the collection.
max() - Method in TransparentParallel
maxParallel(Object) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes its max() method using the default comparator.
maxParallel() - Method in Parallel
Creates a Parallel Array out of the supplied collection/object and invokes its max() method using the default comparator.
messageHandler(Closure) - Method in Actors
Creates an instance of DynamicDispatchActor.
messageHandler(Closure) - Method in PGroup
Creates an instance of DynamicDispatchActor.
messageReceived(ChannelHandlerContext, MessageEvent) - Method in NettyHandler
MessageStream - Class in gpars.actor.impl
Stream of abstract messages
MessageStream.RemoteMessageStream - Class in gpars.actor.impl
MessageStream.RemoteMessageStream(RemoteHost) - Constructor in MessageStream.RemoteMessageStream
MessageStream.SendTo - Class in gpars.actor.impl
MessageStream.SendTo(MessageStream, ActorMessage) - Constructor in MessageStream.SendTo
min(Closure) - Method in AbstractPAWrapper
Finds in parallel the minimum of all values in the collection.
min() - Method in TransparentParallel
minParallel(Object) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes its min() method using the default comparator.
minParallel() - Method in Parallel
Creates a Parallel Array out of the supplied collection/object and invokes its min() method using the default comparator.
minus(def) - Method in ChannelInputList
minus(def) - Method in ChannelOutputList
MobileAgent - Interface in gpars.csp
Multiplexer - Class in gpars.csp.util

N

NettyHandler - Class in gpars.remote.netty
@author Alex Tkachman
NettyHandler(NettyTransportProvider) - Constructor in NettyHandler
NettyRemoteConnection - Class in gpars.remote.netty
Connection using Netty
NettyRemoteConnection(NettyTransportProvider, NettyHandler) - Constructor in NettyRemoteConnection
NettyTransportProvider - Class in gpars.remote.netty
Transport provider using Netty
NettyTransportProvider.Client - Class in gpars.remote.netty
NettyTransportProvider.Client(NettyTransportProvider, SocketAddress, UUID) - Constructor in NettyTransportProvider.Client
NettyTransportProvider.ClientHandler - Class in gpars.remote.netty
NettyTransportProvider.ClientHandler(NettyTransportProvider, UUID) - Constructor in NettyTransportProvider.ClientHandler
NettyTransportProvider.Server - Class in gpars.remote.netty
NettyTransportProvider.Server() - Constructor in NettyTransportProvider.Server
NettyTransportProvider.ServerPipelineFactory - Class in gpars.remote.netty
NettyTransportProvider.ServerPipelineFactory(NettyTransportProvider) - Constructor in NettyTransportProvider.ServerPipelineFactory
NettyTransportProvider() - Constructor in NettyTransportProvider
newThread(Runnable) - Method in AgentThreadFactory
newThread(Runnable) - Method in NettyTransportProvider.MyThreadFactory
NodeConnectedMsg - Class in gpars.remote.message
Message sent when local node connected to remote host
NodeConnectedMsg(LocalNode) - Constructor in NodeConnectedMsg
NodeDisconnectedMsg - Class in gpars.remote.message
Message sent when local node disconnected from remote host
NodeDisconnectedMsg(LocalNode) - Constructor in NodeDisconnectedMsg
nodeId - Field in NodeConnectedMsg
Id of node connected
nodeId - Field in NodeDisconnectedMsg
Id of node disconnected
NonDaemonPGroup - Class in gpars.group
Provides logical grouping for actors, agents and dataflow tasks and operators.
NonDaemonPGroup(int) - Constructor in NonDaemonPGroup
Creates a group for actors, agents, tasks and operators.

O

obj2Sender - Field in ReceivingMessageStream
offer(ActorMessage) - Method in SequentialProcessingActor.Reaction
onConnect(RemoteNode) - Method in LocalNode
onConnect() - Method in RemoteConnection
onConnect(RemoteNode) - Method in RemoteNodeDiscoveryListener
onConnect(RemoteNode) - Method in RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
onDeliveryError() - Method in MessageStream.ResultWaiter
Handle cases when the message sent to the actor doesn't get delivered
onDisconnect(SerialContext) - Method in LocalHost
onDisconnect(RemoteNode) - Method in LocalNode
onDisconnect() - Method in RemoteConnection
onDisconnect(RemoteNode) - Method in RemoteNodeDiscoveryListener
onDisconnect(RemoteNode) - Method in RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
onDiscovery(UUID, SocketAddress) - Method in BroadcastDiscovery
onException(Throwable) - Method in RemoteConnection
onMessage(Object) - Method in Agent
Other messages than closures are accepted as new values for the internal state
onMessage(SerialMsg) - Method in RemoteConnection
onStop(Closure) - Method in AbstractPooledActor
Set on stop handler for this actor
operationComplete(ChannelFuture) - Method in NettyRemoteConnection.MyChannelFutureListener
operator(Map, Closure) - Method in DataFlow
Creates an operator using the default operator actor group
operator(Map, Closure) - Method in PGroup
Creates an operator using the current actor group

P

PAR - Class in gpars.csp
PAR is used to create a Parallel object
PAR() - Constructor in PAR
Parallel - Class in gpars
The Parallel interface holds methods that ParallelEnhancer adds to classes or instances when they get enhanced.
ParallelEnhancer - Class in gpars
ParallelEnhancer allows classes or instances to be enhanced with parallel variants of iterative methods, like eachParallel(), collectParallel(), findAllParallel() and others.
PAWrapper - Class in gpars
The default ParallelArray wrapper class
PAWrapper(def) - Constructor in PAWrapper
PGroup - Class in gpars.group
Provides a common super class of pooled actor groups.
PGroup(Pool) - Constructor in PGroup
Creates a group for actors, agents, tasks and operators.
plus(def) - Method in ChannelInputList
plus(def) - Method in ChannelOutputList
pollMessage() - Method in SequentialProcessingActor
Polls a message from the queues
Pool - Interface in gpars.scheduler
Represents an actor's thread pool
pool - Field in FJPool
POOL_SIZE_MUST_BE_A_POSITIVE_NUMBER - Field in Pool
PoolUtils - Class in gpars.util
Provides a couple of utility methods to pools and schedulers.
pop() - Method in ThreadLocalPools
Removes the top (last) element
PriMultiplex - Class in gpars.csp.util
printStackTrace() - Method in ActorReplyException
processResult(List) - Method in GParsExecutorsPoolUtil
putAt(def, def) - Method in ChannelInputList
putAt(def, def) - Method in ChannelOutputList
putAt(def, def) - Method in DataFlows
Binds the value to the DataFlowVariable that is associated with the property "index".

Q


R

react(long, Closure) - Method in SequentialProcessingActor
Schedules an ActorAction to take the next message off the message queue and to pass it on to the supplied closure.
ReactiveActor - Class in gpars.actor
An actor representing a reactor.
ReactiveActor(Closure) - Constructor in ReactiveActor
reactor(Closure) - Method in Actors
Creates a reactor around the supplied code.
reactor(Closure) - Method in PGroup
Creates a reactor around the supplied code.
read() - Method in ChannelInputList
readResolve() - Method in LocalHandle
readResolve() - Method in RemoteHandle
receive(Duration, Closure) - Method in AbstractPooledActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receive(BaseDuration) - Method in ReceivingMessageStream
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl(long, TimeUnit) - Method in AbstractPooledActor
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
receiveImpl(long, TimeUnit) - Method in Actor.RemoteActor
receiveImpl(long, TimeUnit) - Method in ReceivingMessageStream
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
ReceivingMessageStream - Class in gpars.actor.impl
@author Alex Tkachman, Vaclav Pech
ReceivingMessageStream.ReplyCategory - Class in gpars.actor.impl
Enhances objects with the ability to send replies and detect message originators.
reduce(def, Closure) - Method in AbstractPAWrapper
Performs a parallel reduce operation.
registerCurrentActorWithThread(Actor) - Method in Actor
Registers the actor with the current thread
RemoteConnection - Class in gpars.remote
Represents connection to remote host
RemoteConnection(LocalHost) - Constructor in RemoteConnection
RemoteDataFlowExpression - Class in gpars.dataflow
@author Alex Tkachman
RemoteDataFlowExpression() - Constructor in RemoteDataFlowExpression
RemoteHandle - Class in gpars.serial
@author Alex Tkachman
RemoteHandle(UUID, UUID) - Constructor in RemoteHandle
RemoteHost - Class in gpars.remote
Representation of remote host connected to transport provider
RemoteHost(LocalHost, UUID) - Constructor in RemoteHost
remoteHosts - Field in LocalHost
Hosts known to the provider
RemoteNode - Class in gpars.remote
Representation of remote node
RemoteNode(UUID, SerialContext, Actor) - Constructor in RemoteNode
RemoteNodeDiscoveryListener - Class in gpars.remote
Listener for remote node events
RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure - Class in gpars.remote
Discovery listener backed by closure with two params - node - "connected" | "disconnected"
RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure(Closure) - Constructor in RemoteNodeDiscoveryListener.RemoteNodeDiscoveryListenerClosure
remoteNodes - Field in LocalHost
Registry of remote nodes known to the provider
RemoteObjectDecoder - Class in gpars.remote.netty
RemoteObjectDecoder(RemoteConnection) - Constructor in RemoteObjectDecoder
Creates a new encoder.
RemoteObjectEncoder - Class in gpars.remote.netty
RemoteObjectEncoder(RemoteConnection) - Constructor in RemoteObjectEncoder
Creates a new encoder.
RemoteSerialized - Interface in gpars.serial
Marker interface for objects, which are proxies to objects on other nodes.
remove(def) - Method in ChannelInputList
remove(def) - Method in ChannelOutputList
remove(def) - Method in DataFlows
Removes a DFV from the map and binds it to null, if it has not been bound yet
remove(SerialHandle) - Method in SerialContext
remove(SerialHandle) - Method in SerialHandles
removeConnection(RemoteConnection) - Method in RemoteHost
removeDiscoveryListener(RemoteNodeDiscoveryListener) - Method in LocalNode
removeLocalHost(LocalHost) - Method in LocalHostRegistry
reply(Object) - Method in ReceivingMessageStream
Sends a reply to all currently processed messages.
reply(Object, Object) - Method in ReceivingMessageStream.ReplyCategory
replyIfExists(Object) - Method in ReceivingMessageStream
Sends a reply to all currently processed messages, which have been sent by an actor.
replyIfExists(Object, Object) - Method in ReceivingMessageStream.ReplyCategory
reportError(Throwable) - Method in DataFlowOperator
Is invoked in case the actor throws an exception.
reportException(Throwable) - Method in DataFlowOperatorActor
resetDefaultSize() - Method in DefaultPool
Sets the pool size to the default
resetDefaultSize() - Method in FJPool
Sets the pool size to the default
resetDefaultSize() - Method in Pool
Sets the pool size to the default
resetDefaultSize() - Method in Scheduler
resize(int) - Method in DefaultPool
Resizes the thread pool to the specified value
resize(int) - Method in FJPool
Resizes the thread pool to the specified value
resize(int) - Method in Pool
Resizes the thread pool to the specified value
resize(int) - Method in Scheduler
ResizeableFJPool - Class in gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
ResizeableFJPool(int) - Constructor in ResizeableFJPool
Creates the pool with specified number of threads.
ResizeablePool - Class in gpars.scheduler
Represents the actors' thread pool, which performs tasks on behalf of the actors.
ResizeablePool(boolean, int) - Constructor in ResizeablePool
Creates the pool with specified number of threads.
retrieveCurrentPool() - Method in GParsExecutorsPool
Retrieves the pool assigned to the current thread.
retrieveCurrentPool() - Method in GParsPool
Retrieves the pool assigned to the current thread.
retrieveDefaultPoolSize() - Method in PoolUtils
rightShift(Closure) - Method in 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 DataFlowStream
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
run() - Method in AgentCore
Handles a single message from the message queue
run() - Method in FairMultiplex
run() - Method in GConsole
run() - Method in GConsoleStringToInteger
run() - Method in GDelta2
run() - Method in GFixedDelay
run() - Method in GIdentity
run() - Method in GIntegrate
run() - Method in GNumbers
run() - Method in GObjectToConsoleString
run() - Method in GPairs
run() - Method in GParPrint
run() - Method in GPCopy
run() - Method in GPlus
run() - Method in GPrefix
run() - Method in GPrint
run() - Method in GSquares
run() - Method in GStatePairs
run() - Method in GSuccessor
run() - Method in GTail
run() - Method in Multiplexer
run() - Method in PriMultiplex
run() - Method in Scheduler.WatchdogThread
run() - Method in Scheduler.WorkerThread
run() - Method in SequentialProcessingActor
run() - Method in TimedMultiplex
runForkJoin(Object) - Method in GParsPool
Starts a ForkJoin calculation with the supplied root worker and waits for the result.
RunnableBackedPooledActor - Class in gpars.actor.impl
Utility class to implement AbstractPooledActor backed by any Runnable (including Closure)
RunnableBackedPooledActor(Runnable) - Constructor in RunnableBackedPooledActor

S

S_ACTIVE_MASK - Field in SequentialProcessingActor
S_FINISHED_MASK - Field in SequentialProcessingActor
S_FINISHING_MASK - Field in SequentialProcessingActor
S_INITIALIZED - Field in DataFlowExpression
S_INITIALIZING - Field in DataFlowExpression
S_NOT_INITIALIZED - Field in DataFlowExpression
Possible states
S_NOT_STARTED - Field in SequentialProcessingActor
S_RUNNING - Field in SequentialProcessingActor
S_STOP_TERMINATE_MASK - Field in SequentialProcessingActor
S_STOPPED - Field in SequentialProcessingActor
S_STOPPING - Field in SequentialProcessingActor
S_TERMINATED - Field in SequentialProcessingActor
S_TERMINATING - Field in SequentialProcessingActor
scheduleLoop() - Method in SequentialProcessingActor
Scheduler - Class in 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(int) - Constructor in Scheduler
send(Object) - Method in Actor.RemoteActor
send(Object) - Method in AgentCore
Adds the message to the agent\s message queue
send(Object) - Method in DataCallback
Sends a message back to the DataCallback.
send(Object) - Method in DataFlowExpression.DataFlowExpressionsCollector
send(Object, MessageStream) - Method in MessageStream
Send message to stream and return immediately.
send(Object) - Method in MessageStream.RemoteMessageStream
send(Object) - Method in MessageStream.ResultWaiter
Accepts the message as a reply and wakes up the sleeping thread.
send(Object) - Method in SequentialProcessingActor
sendAndContinue(Object, Closure) - Method in MessageStream
Sends a message and execute continuation when reply became available.
sendAndWait(Closure) - Method in Agent
Submits the closure waiting for the result
sendAndWait(Object, Duration) - Method in MessageStream
Sends a message and waits for a reply.
SequentialProcessingActor - Class in gpars.actor.impl
@author Alex Tkachman, Vaclav Pech
SequentialProcessingActor() - Constructor in SequentialProcessingActor
Creates a new instance, sets the default actor group.
SerialContext - Class in gpars.serial
@author Alex Tkachman
SerialContext(SerialHandles, UUID) - Constructor in SerialContext
SerialHandle - Class in gpars.serial
Weak reference to object, which was serialized to remote hosts.
SerialHandle.LocalSerialHandle(WithSerialId, UUID) - Constructor in SerialHandle.LocalSerialHandle
SerialHandle.RemoteSerialHandle.ReleaseHandle - Class in gpars.serial
SerialHandle.RemoteSerialHandle.ReleaseHandle(UUID) - Constructor in SerialHandle.RemoteSerialHandle.ReleaseHandle
serialHandle - Field in WithSerialId
See SerialHandle class for details
SerialHandles - Class in gpars.serial
@author Alex Tkachman
serialId - Field in RemoteHandle
serialId - Field in SerialHandle
serial id of the object
SerialMsg - Class in gpars.serial
Base class for all messages
SerialMsg(UUID) - Constructor in SerialMsg
setActorGroup(PGroup) - Method in SequentialProcessingActor
Sets the actor's group.
setHost(RemoteHost) - Method in RemoteConnection
setMetaClass(MetaClass) - Method in DataFlowExpression
setPGroup(PGroup) - Method in AgentCore
Sets an actor group to use for task scheduling
setProperty(String, Object) - Method in DataFlowExpression
setProperty(String, def) - Method in DataFlows
Binds the value to the DataFlowVariable that is associated with the property "name".
setProperty(String, Object) - Method in RunnableBackedPooledActor.RunnableBackedPooledActorDelegate
setTimeout(long) - Method in SequentialProcessingActor.Reaction
shutdown() - Method in DefaultPool
Gently stops the pool
shutdown() - Method in FJPool
Gently stops the pool
shutdown() - Method in Pool
Gently stops the pool
shutdown() - Method in Scheduler
SingleRunActor - Class in gpars.dataflow
An actor representing a dataflow thread.
size() - Method in AbstractPAWrapper
Size of the collection
size() - Method in ChannelInputList
size() - Method in ChannelOutputList
split(Closure) - Method in TransparentParallel
splitParallel(Object, def) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied rule as the filter predicate.
splitParallel(Closure) - Method in Parallel
Performs the split() operation using an asynchronous variant of the supplied closure to evaluate each collection's/object's element.
start() - Method in Actor
Starts the Actor.
start() - Method in Actor.RemoteActor
start() - Method in BroadcastDiscovery
start(Closure) - Method in DataFlow
Creates a new instance of SingleRunActor to run the supplied code.
start(PGroup) - Method in DataFlowOperator
Starts an operator using the specified operator actor group
start(NettyTransportProvider) - Method in NettyTransportProvider.Server
start() - Method in SequentialProcessingActor
Starts the Actor.
startTask(def) - Method in DataFlowOperatorActor
startTask(def) - Method in ForkingDataFlowOperatorActor
state - Field in DataFlowExpression
Holds the current state of the variable
stateUpdater - Field in DataFlowExpression
Updater for the state field
stop() - Method in Actor
Send message to stop to the Actor.
stop() - Method in Actor.RemoteActor
STOP - Field in ActorException
stop() - Method in BroadcastDiscovery
stop() - Method in DataFlowOperator
Stops the operator
stop() - Method in NettyTransportProvider.Client
stop() - Method in NettyTransportProvider.Server
stop() - Method in SequentialProcessingActor
Send message to stop to the actor.
stopFlag - Field in SequentialProcessingActor
Indicates whether the actor should terminate
stopFlagUpdater - Field in SequentialProcessingActor
subscribe(DataFlowExpressionsCollector) - Method in DataFlowComplexExpression
subscribe(DataFlowExpression.DataFlowExpressionsCollector) - Method in DataFlowExpression
subscribe(DataFlowExpressionsCollector) - Method in DataFlowExpression.TransformOne
subscribe(DataFlowExpressionsCollector) - Method in DataFlowGetPropertyExpression
subscribe(DataFlowExpressionsCollector) - Method in DataFlowInvocationExpression
subscribe(DataFlowExpressionsCollector) - Method in RemoteDataFlowExpression
subscribe(SerialContext) - Method in SerialHandle
Subscribes host as interested in the object
sum() - Method in AbstractPAWrapper
Summarizes all elements of the collection in parallel using the "plus()" operator of the elements
sum() - Method in TransparentParallel
sumParallel(Object) - Method in GParsPoolUtil
Creates a Parallel Array out of the supplied collection/object and summarizes its elements using the foldParallel() method with the + operator and the reduction operation.
sumParallel() - Method in Parallel
Creates a Parallel Array out of the supplied collection/object and summarizes its elements using the foldParallel() method with the + operator and the reduction operation.

T

takeMessage(long, TimeUnit) - Method in SequentialProcessingActor
Takes a message from the queues.
task(Closure) - Method in DataFlow
Creates a new task assigned to a thread from the default dataflow actor group.
task(Closure) - Method in PGroup
Creates a new task assigned to a thread from the current actor group.
terminate() - Method in Actor
Terminates the Actor.
terminate() - Method in Actor.RemoteActor
TERMINATE - Field in ActorException
terminate() - Method in SequentialProcessingActor
Terminate the Actor.
TestUtilities - Class in gpars.csp.util
threadBoundActor() - Method in Actor
Retrieves the actor registered with the current thread
ThreadLocalPools - Class in gpars
Holds a thread-local stack of pools to allow for nested calls to ForkJoinPool.withPool() or GParsExecutorsPool.withPool()
TimedMultiplex - Class in gpars.csp.util
TIMEOUT - Field in ActorException
toArray() - Method in ChannelInputList
toArray() - Method in ChannelOutputList
toString() - Method in ActorMessage
toString() - Method in ActorReplyException
toString() - Method in AsyncException
toString() - Method in DataFlowExpression
toString() - Method in DataFlowStream
toString() - Method in LocalNode
toString() - Method in RemoteNode
transform(Object, Closure) - Method in DataFlowExpression
TransparentParallel - Class in gpars
Enhances objects by being mixed-in either within a GParsPool.withPool() block or after enhancement by the ParallelEnhancer through the makeTransparent() method.

U

UNCAUGHT_EXCEPTION_OCCURRED_IN_ACTOR_POOL - Field in Pool
unsubscribe(SerialContext) - Method in SerialHandle
updateValue(Object) - Method in Agent
Allows closures to set the new internal state as a whole

V

valAsync(Closure) - Method in Agent
A shorthand method for safe asynchronous message-based retrieval of the internal state.
value - Field in DataFlowExpression
Holds the actual value.

W

waitingUpdater - Field in DataFlowExpression
Updater for the waiting field
when(Closure) - Method in DynamicDispatchActor
whenBound(MessageStream) - Method in DataFlowExpression
Send the bound data to provided stream when it becomes available
whenBound(MessageStream) - Method in DataFlowStream
Send all pieces of data bound in the future to the provided stream when it becomes available
whenNextBound(MessageStream) - Method in DataFlowStream
Send the next bound piece of data to the provided stream when it becomes available
withExistingPool(ExecutorService, Closure) - Method in GParsExecutorsPool
Creates a new instance of ExecutorService, binds it to the current thread, enables the ExecutorService DSL and runs the supplied closure.
withExistingPool(ForkJoinPool, Closure) - Method in GParsPool
Reuses an instance of ForkJoinPool, binds it to the current thread, enables the ParallelArray DSL and runs the supplied closure.
withPool(int, ThreadFactory, Closure) - Method in GParsExecutorsPool
Creates a new instance of ExecutorService, binds it to the current thread, enables the ExecutorService DSL and runs the supplied closure.
withPool(int, UncaughtExceptionHandler, Closure) - Method in GParsPool
Creates a new instance of ForkJoinPool, binds it to the current thread, enables the ParallelArray DSL and runs the supplied closure.
withReadLock(Closure) - Method in 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 EnhancedSemaphore
Performs the passed-in closure with the Semaphore acquired and releases the Semaphore automatically after the closure finishes.
WithSerialId - Class in gpars.serial
Base class for objects which can be exposed to remote nodes via serialization.
withWriteLock(Closure) - Method in EnhancedRWLock
Performs the passed-in closure with the write lock locked and unlocks the write lock automatically after the closure finishes.
write(def) - Method in ChannelOutputList
write(SerialMsg) - Method in NettyRemoteConnection
write(SerialMsg) - Method in RemoteConnection
write(SerialMsg) - Method in RemoteHost
write(SerialMsg) - Method in SerialContext
writeReplace() - Method in WithSerialId
Replace object by handle for serialization

X


Y


Z


_


Groovy Documentation