A KanbanLink is the simplest possible producer-consumer pair in a kanban-like
scenario as described in
- MAGIC - Field in BroadcastDiscovery
-
- makeConcurrent(Object) - Method in GParsPoolUtil
-
Overrides the iterative methods like each(), collect() and such, so that they call their parallel variants from the GParsPoolUtil class
like eachParallel(), collectParallel() and such.
- makeConcurrent(Object) - Method in GParsPoolUtilHelper
-
Overrides the iterative methods like each(), collect() and such, so that they call their parallel variants from the GParsPoolUtil class
like eachParallel(), collectParallel() and such.
- makeConcurrent(Object) - Method in Parallel
-
Overrides the iterative methods like each(), collect() and such, so that they call their parallel variants from the GParsPoolUtil class
like eachParallel(), collectParallel() and such.
- makeFair() - Method in AbstractLoopingActor
-
Makes the actor fair.
- makeFair() - Method in AgentCore
-
Makes the agent fair.
- makeFair() - Method in AsyncMessagingCore
-
Makes the agent fair.
- makeSequential(Object) - Method in GParsPoolUtil
-
Gives the iterative methods like each() or find() the original sequential semantics.
- makeSequential(Object) - Method in GParsPoolUtilHelper
-
Gives the iterative methods like each() or find() the original sequential semantics.
- makeSequential(Object) - Method in Parallel
-
Gives the iterative methods like each() or find() the original sequential semantics.
- manager - Field in SerialHandle
-
- map(Closure) - Method in AbstractPAWrapper
-
Applies concurrently the supplied function to all elements in the collection, returning a collection containing
the transformed values.
- map(K) - Method in CustomConcurrentHashMap.MappingFunction
-
Returns a value for the given key, or null if there is no
mapping.
- map(Closure) - Method in FList
-
- map(FList<T>, Closure, StreamCore<Object>) - Method in StreamCore
-
- MappedPAWrapper - Class in groovyx.gpars.pa
The ParallelArray wrapper used after the map() operation
- MappedPAWrapper(ParallelArrayWithMapping) - Constructor in MappedPAWrapper
-
- mask - Field in GuardedSelectRequest
-
- matchesMask(int) - Method in GuardedSelectRequest
-
Detects, whether the channel at the given index is guarded or not.
- matchesMask(int) - Method in SelectRequest
-
Checks, whether the given index should be queried for value or not.
- max(Closure) - Method in AbstractPAWrapper
-
Finds in parallel the maximum of all values in the collection.
- max - Field in CommonOps.NaturalDoubleMaxReducer
-
- max - Field in CommonOps.NaturalLongMaxReducer
-
- max - Field in CommonOps.RawMaxReducer
-
- MAX_FORKS - Field in DataflowProcessor
-
- max() - Method in ParallelArray
-
Returns the maximum element, or null if empty,
assuming that all elements are Comparables.
- max() - Method in ParallelArray.SummaryStatistics
-
Returns the maximum element, or null if empty
- max(DoubleComparator) - Method in ParallelArrayWithDoubleMapping
-
Returns the maximum element, or -Double.MAX_VALUE if empty.
- max(LongComparator) - Method in ParallelArrayWithLongMapping
-
Returns the maximum element, or Long.MIN_VALUE if empty.
- max() - Method in ParallelArrayWithMapping
-
Returns the maximum element, or null if empty,
assuming that all elements are Comparables.
- max() - Method in ParallelDoubleArray
-
Returns the maximum element, or -Double.MAX_VALUE if empty.
- max() - Method in ParallelDoubleArray.SummaryStatistics
-
Returns the maximum element, or -Double.MAX_VALUE if empty
- max(DoubleComparator) - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns the maximum element, or -Double.MAX_VALUE if empty.
- max(LongComparator) - Method in ParallelDoubleArrayWithLongMapping
-
Returns the maximum element, or Long.MIN_VALUE if empty.
- max() - Method in ParallelDoubleArrayWithMapping
-
Returns the maximum mapped element, or null if empty,
assuming that all elements are Comparables.
- max() - Method in ParallelLongArray
-
Returns the maximum element, or Long.MIN_VALUE if empty.
- max() - Method in ParallelLongArray.SummaryStatistics
-
Returns the maximum element, or Long.MIN_VALUE if empty
- max(DoubleComparator) - Method in ParallelLongArrayWithDoubleMapping
-
Returns the maximum element, or -Double.MAX_VALUE if empty.
- max(LongComparator) - Method in ParallelLongArrayWithLongMapping
-
Returns the maximum element, or Long.MIN_VALUE if empty.
- max() - Method in ParallelLongArrayWithMapping
-
Returns the maximum mapped element, or null if empty,
assuming that all elements are Comparables.
- max - Field in PAS.FJDStats
-
- max - Field in PAS.FJLStats
-
- max - Field in PAS.FJOStats
-
- MAX_SEGMENT_CAPACITY - Field in CustomConcurrentHashMap
-
- max() - Method in TransparentParallel
-
- maxForks - Field in ForkingDataflowOperatorActor
-
- maxForks - Field in ForkingDataflowSelectorActor
-
- maxForks - Property in ProcessingNode
-
- 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.
- maxReducer(Comparator<? super T>) - Method in CommonOps
-
Returns a reducer returning the maximum of two elements, using
the given comparator, and treating null as less than any
non-null element.
- maxSize - Field in LRUProtectionStorage
-
- memberHasValue(AnnotationNode, String, Object) - Method in AsyncFunASTTransformation
-
- MEMOIZE_NULL - Property in GParsPoolUtilHelper
-
- merge(CombineHolder, Closure<?>, Closure<?>) - Method in CombineHolder
-
- merge(PGroup, Map<String, Object>, List<DataflowReadChannel<Object>>, Closure<V>) - Method in DataflowExpression
-
- merge(PGroup, Map<String, Object>, List<DataflowReadChannel<Object>>, Closure<V>) - Method in DataflowQueue
-
- merge(PGroup, Map<String, Object>, List<DataflowReadChannel<Object>>, Closure<V>) - Method in DataflowReadChannel
-
Merges channels together as inputs for a single dataflow operator.
- merge(PGroup, Map<String, Object>, List<DataflowReadChannel<Object>>, Closure<V>) - Method in DataflowStreamReadAdapter
-
- merge(Map<String, Object>, List<DataflowReadChannel<Object>>, Closure) - Method in Pipeline
-
Merges channels together as inputs for a single dataflow operator.
- merge(PGroup, List<DataflowReadChannel<Object>>, Closure<V>) - Method in SyncDataflowQueue
-
- merge(PGroup, List<DataflowReadChannel<Object>>, Closure<V>) - Method in SyncDataflowStreamReadAdapter
-
- merge(PGroup, List<DataflowReadChannel<Object>>, Closure<V>) - Method in SyncDataflowVariable
-
- merger - Field in PAS.FJSubSorter
-
- message - Field in DataflowExpression.BindDataflow
-
- message - Field in MessageStream.SendTo
-
- message - Field in RemoteAgentSendMessage
-
- messageArrived(DataflowProcessor, DataflowReadChannel<Object>, int, Object) - Method in DataflowEventAdapter
-
Invoked when a message becomes available in an input channel.
- messageArrived(DataflowProcessor, DataflowReadChannel<Object>, int, Object) - Method in DataflowEventListener
-
Invoked when a message becomes available in an input channel.
- messageArrived(DataflowProcessor, DataflowReadChannel<Object>, int, Object) - Method in GracefulShutdownListener
-
Entering a non-idle state, so a notification needs to be sent to the monitor.
- messageHandler(Closure) - Method in Actors
-
Creates an instance of DynamicDispatchActor.
- messageHandler(Closure) - Method in PGroup
-
Creates an instance of DynamicDispatchActor.
- MessageQueue - Interface in groovyx.gpars.util
The high-performance actor message queue
- messageSentOut(DataflowProcessor, DataflowWriteChannel<Object>, int, Object) - Method in DataflowEventAdapter
-
Invoked when a message is being bound to an output channel.
- messageSentOut(DataflowProcessor, DataflowWriteChannel<Object>, int, Object) - Method in DataflowEventListener
-
Invoked when a message is being bound to an output channel.
- messagesInChannels - Field in GracefulShutdownListener
-
- MessageStream - Class in groovyx.gpars.actor.impl
Represents a stream of messages and forms the base class for actors
- MessageStream.RemoteMessageStream - Class in groovyx.gpars.actor.impl
- MessageStream.RemoteMessageStream(RemoteHost) - Constructor in MessageStream.RemoteMessageStream
-
- MessageStream.ResultWaiter - Class in groovyx.gpars.actor.impl
Represents a pending request for a reply from an actor.
- MessageStream.ResultWaiter() - Constructor in MessageStream.ResultWaiter
-
- MessageStream.SendTo - Class in groovyx.gpars.actor.impl
- MessageStream.SendTo(MessageStream, ActorMessage) - Constructor in MessageStream.SendTo
-
- MessageStream() - Constructor in MessageStream
-
- MESSAGING_RUNNABLE_NEED_EXACTLY_ONE_ARGUMENT_TO_RUN - Field in MessagingRunnable
-
- MessagingRunnable - Class in groovyx.gpars
Represents a single-argument Closure when using GPars agents, actors or dataflow concurrency through the Java API.
- MessagingRunnable(Object) - Constructor in MessagingRunnable
-
- metaClass - Field in DataflowExpression
-
The current metaclass
- METHOD_NAME_PREFIX - Field in InternalActor
-
- methodName - Field in DataflowInvocationExpression
-
- min(Closure) - Method in AbstractPAWrapper
-
Finds in parallel the minimum of all values in the collection.
- min - Field in CommonOps.NaturalDoubleMinReducer
-
- min - Field in CommonOps.NaturalLongMinReducer
-
- min - Field in CommonOps.RawMinReducer
-
- min() - Method in ParallelArray
-
Returns the minimum element, or null if empty,
assuming that all elements are Comparables.
- min() - Method in ParallelArray.SummaryStatistics
-
Returns the minimum element, or null if empty
- min(DoubleComparator) - Method in ParallelArrayWithDoubleMapping
-
Returns the minimum element, or Double.MAX_VALUE if empty.
- min(LongComparator) - Method in ParallelArrayWithLongMapping
-
Returns the minimum element, or Long.MAX_VALUE if empty.
- min() - Method in ParallelArrayWithMapping
-
Returns the minimum element, or null if empty,
assuming that all elements are Comparables.
- min() - Method in ParallelDoubleArray
-
Returns the minimum element, or Double.MAX_VALUE if empty.
- min() - Method in ParallelDoubleArray.SummaryStatistics
-
Returns the minimum element, or Double.MAX_VALUE if empty
- min(DoubleComparator) - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns the minimum element, or Double.MAX_VALUE if empty.
- min(LongComparator) - Method in ParallelDoubleArrayWithLongMapping
-
Returns the minimum element, or Long.MAX_VALUE if empty.
- min() - Method in ParallelDoubleArrayWithMapping
-
Returns the minimum mapped element, or null if empty,
assuming that all elements are Comparables.
- min() - Method in ParallelLongArray
-
Returns the minimum element, or Long.MAX_VALUE if empty.
- min() - Method in ParallelLongArray.SummaryStatistics
-
Returns the minimum element, or Long.MAX_VALUE if empty
- min(DoubleComparator) - Method in ParallelLongArrayWithDoubleMapping
-
Returns the minimum element, or Double.MAX_VALUE if empty.
- min(LongComparator) - Method in ParallelLongArrayWithLongMapping
-
Returns the minimum element, or Long.MAX_VALUE if empty.
- min() - Method in ParallelLongArrayWithMapping
-
Returns the minimum mapped element, or null if empty,
assuming that all elements are Comparables.
- min - Field in PAS.FJDStats
-
- min - Field in PAS.FJLStats
-
- min - Field in PAS.FJOStats
-
- MIN_SEGMENT_CAPACITY - Field in CustomConcurrentHashMap
-
- 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.
- minReducer(Comparator<? super T>) - Method in CommonOps
-
Returns a reducer returning the minimum of two elements, using
the given comparator, and treating null as greater than any
non-null element.
- minus(def) - Method in ChannelInputList
-
- minus(def) - Method in ChannelOutputList
-
- MobileAgent - Interface in groovyx.gpars.csp
- monitor - Field in GracefulShutdownListener
-
- moveAsyncHead() - Method in DataflowStreamReadAdapter
-
- moveHead() - Method in DataflowStreamReadAdapter
-
- msg - Field in SequentialProcessingActor.Node
-
- Multiplexer - Class in groovyx.gpars.csp.util
- Multiplexer() - Constructor in Multiplexer
-
- MY_TYPE - Field in AsyncFunASTTransformation
-
- myActor - Field in DefaultActorClosure
-
- myThread - Field in GParsPool.MyCancellableRecursiveTask
-
- pa - Property in AbstractPAWrapper
-
The wrapper ParallelArray instance
- PAGroovyUtils - Class in groovyx.gpars.util
@author Vaclav Pech
Date: 6th Sep 2010
- PAGroovyUtils() - Constructor in PAGroovyUtils
-
- pap - Field in PAS.FJBase
-
- pap - Field in PAS.FJRemoveAll
-
- pap - Field in PAS.FJRemoveAllDriver
-
- pap - Field in PAS.FJSearchBase
-
- pap - Field in PAS.FJSelectAllDriver
-
- pap - Field in PAS.UniquifierTable
-
- PAR - Class in groovyx.gpars.csp
PAR is used to create a Parallel
object
- PAR() - Constructor in PAR
-
- Parallel - Class in groovyx.gpars
The Parallel interface holds methods that ParallelEnhancer adds to classes or instances when they get enhanced.
- Parallel() - Constructor in Parallel
-
- ParallelArray - Class in groovyx.gpars.extra166y
An array supporting parallel operations.
- ParallelArray.AsList - Class in groovyx.gpars.extra166y
- ParallelArray.AsList() - Constructor in ParallelArray.AsList
-
- ParallelArray.ListIter - Class in groovyx.gpars.extra166y
- ParallelArray.ListIter(int) - Constructor in ParallelArray.ListIter
-
- ParallelArray.ParallelArrayIterator - Class in groovyx.gpars.extra166y
- ParallelArray.ParallelArrayIterator(T, int) - Constructor in ParallelArray.ParallelArrayIterator
-
- ParallelArray.SummaryStatistics - Interface in groovyx.gpars.extra166y
Summary statistics for a possibly bounded, filtered, and/or
mapped ParallelArray.
- ParallelArray(ForkJoinPool, T) - Constructor in ParallelArray
-
Trusted internal version of protected constructor.
- ParallelArrayWithBounds - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
only to elements within a given range.
- ParallelArrayWithBounds(ForkJoinPool, int, int, T) - Constructor in ParallelArrayWithBounds
-
- ParallelArrayWithDoubleMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelArrayWithDoubleMapping(ForkJoinPool, int, int, T) - Constructor in ParallelArrayWithDoubleMapping
-
- ParallelArrayWithFilter - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
only to elements for which a selector returns true.
- ParallelArrayWithFilter(ForkJoinPool, int, int, T) - Constructor in ParallelArrayWithFilter
-
- ParallelArrayWithLongMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelArrayWithLongMapping(ForkJoinPool, int, int, T) - Constructor in ParallelArrayWithLongMapping
-
- ParallelArrayWithMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelArrayWithMapping(ForkJoinPool, int, int, T) - Constructor in ParallelArrayWithMapping
-
- ParallelDoubleArray - Class in groovyx.gpars.extra166y
An array of doubles supporting parallel operations.
- ParallelDoubleArray.AsList - Class in groovyx.gpars.extra166y
- ParallelDoubleArray.AsList() - Constructor in ParallelDoubleArray.AsList
-
- ParallelDoubleArray.ListIter - Class in groovyx.gpars.extra166y
- ParallelDoubleArray.ListIter(int) - Constructor in ParallelDoubleArray.ListIter
-
- ParallelDoubleArray.ParallelDoubleArrayIterator - Class in groovyx.gpars.extra166y
- ParallelDoubleArray.ParallelDoubleArrayIterator(double[], int) - Constructor in ParallelDoubleArray.ParallelDoubleArrayIterator
-
- ParallelDoubleArray.SummaryStatistics - Interface in groovyx.gpars.extra166y
Summary statistics for a possibly bounded, filtered, and/or
mapped ParallelDoubleArray.
- ParallelDoubleArray(ForkJoinPool, double[]) - Constructor in ParallelDoubleArray
-
Trusted internal version of protected constructor.
- ParallelDoubleArrayWithBounds - Class in groovyx.gpars.extra166y
A prefix view of ParallelDoubleArray that causes operations to apply
only to elements within a given range.
- ParallelDoubleArrayWithBounds(ForkJoinPool, int, int, double[]) - Constructor in ParallelDoubleArrayWithBounds
-
- ParallelDoubleArrayWithDoubleMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelDoubleArrayWithDoubleMapping(ForkJoinPool, int, int, double[]) - Constructor in ParallelDoubleArrayWithDoubleMapping
-
- ParallelDoubleArrayWithFilter - Class in groovyx.gpars.extra166y
A prefix view of ParallelDoubleArray that causes operations to apply
only to elements for which a selector returns true.
- ParallelDoubleArrayWithFilter(ForkJoinPool, int, int, double[]) - Constructor in ParallelDoubleArrayWithFilter
-
- ParallelDoubleArrayWithLongMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelDoubleArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelDoubleArrayWithLongMapping(ForkJoinPool, int, int, double[]) - Constructor in ParallelDoubleArrayWithLongMapping
-
- ParallelDoubleArrayWithMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelDoubleArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelDoubleArrayWithMapping(ForkJoinPool, int, int, double[]) - Constructor in ParallelDoubleArrayWithMapping
-
- ParallelEnhancer - Class in groovyx.gpars
ParallelEnhancer allows classes or instances to be enhanced with parallel variants of iterative methods,
like eachParallel(), collectParallel(), findAllParallel() and others.
- ParallelEnhancer() - Constructor in ParallelEnhancer
-
- parallelGroup - Field in Actor
-
The parallel group to which the message stream belongs
- parallelGroup - Field in DataCallback
-
- ParallelLongArray - Class in groovyx.gpars.extra166y
An array of longs supporting parallel operations.
- ParallelLongArray.AsList - Class in groovyx.gpars.extra166y
- ParallelLongArray.AsList() - Constructor in ParallelLongArray.AsList
-
- ParallelLongArray.ListIter - Class in groovyx.gpars.extra166y
- ParallelLongArray.ListIter(int) - Constructor in ParallelLongArray.ListIter
-
- ParallelLongArray.ParallelLongArrayIterator - Class in groovyx.gpars.extra166y
- ParallelLongArray.ParallelLongArrayIterator(long[], int) - Constructor in ParallelLongArray.ParallelLongArrayIterator
-
- ParallelLongArray.SummaryStatistics - Interface in groovyx.gpars.extra166y
Summary statistics for a possibly bounded, filtered, and/or
mapped ParallelLongArray.
- ParallelLongArray(ForkJoinPool, long[]) - Constructor in ParallelLongArray
-
Trusted internal version of protected constructor.
- ParallelLongArrayWithBounds - Class in groovyx.gpars.extra166y
A prefix view of ParallelLongArray that causes operations to apply
only to elements within a given range.
- ParallelLongArrayWithBounds(ForkJoinPool, int, int, long[]) - Constructor in ParallelLongArrayWithBounds
-
- ParallelLongArrayWithDoubleMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelLongArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelLongArrayWithDoubleMapping(ForkJoinPool, int, int, long[]) - Constructor in ParallelLongArrayWithDoubleMapping
-
- ParallelLongArrayWithFilter - Class in groovyx.gpars.extra166y
A prefix view of ParallelLongArray that causes operations to apply
only to elements for which a selector returns true.
- ParallelLongArrayWithFilter(ForkJoinPool, int, int, long[]) - Constructor in ParallelLongArrayWithFilter
-
- ParallelLongArrayWithLongMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelLongArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelLongArrayWithLongMapping(ForkJoinPool, int, int, long[]) - Constructor in ParallelLongArrayWithLongMapping
-
- ParallelLongArrayWithMapping - Class in groovyx.gpars.extra166y
A prefix view of ParallelLongArray that causes operations to apply
to mappings of elements, not to the elements themselves.
- ParallelLongArrayWithMapping(ForkJoinPool, int, int, long[]) - Constructor in ParallelLongArrayWithMapping
-
- PARAMETER_TYPES - Field in CopyChannelsClosure
-
- PARAMETER_TYPES - Field in FilterClosure
-
- PARAMETER_TYPES - Field in MessagingRunnable
-
- PARAMETER_TYPES - Field in ReactorMessagingRunnable
-
- parent - Field in PAS.FJScan
-
- parties - Field in SyncDataflowStream
-
- parties - Field in SyncDataflowVariable
-
- PAS - Class in groovyx.gpars.extra166y
Shared internal execution support for ParallelArray and
specializations.
- PAS.FJBase - Class in groovyx.gpars.extra166y
Base for most divide-and-conquer tasks used for computing
ParallelArray operations.
- PAS.FJBase(AbstractParallelAnyArray, int, int, FJBase) - Constructor in PAS.FJBase
-
- PAS.FJCountSelected - Class in groovyx.gpars.extra166y
- PAS.FJCountSelected(AbstractParallelAnyArray, int, int, FJBase) - Constructor in PAS.FJCountSelected
-
- PAS.FJDAppendAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJDAppendAllDriver(AbstractParallelAnyArray, int, double[]) - Constructor in PAS.FJDAppendAllDriver
-
- PAS.FJDApply - Class in groovyx.gpars.extra166y
- PAS.FJDApply(AbstractParallelAnyArray, int, int, FJBase, DoubleProcedure) - Constructor in PAS.FJDApply
-
- PAS.FJDBinaryIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJDBinaryIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntAndDoubleToDouble) - Constructor in PAS.FJDBinaryIndexMap
-
- PAS.FJDCMerger - Class in groovyx.gpars.extra166y
- PAS.FJDCMerger(double[], double[], int, int, int, int, int, int, FJDCMerger) - Constructor in PAS.FJDCMerger
-
- PAS.FJDCombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJDCombineInPlace(AbstractParallelAnyArray, int, int, FJBase, double[], int, BinaryDoubleOp) - Constructor in PAS.FJDCombineInPlace
-
- PAS.FJDCSorter - Class in groovyx.gpars.extra166y
- PAS.FJDCSorter(double[], double[], int, int, int) - Constructor in PAS.FJDCSorter
-
- PAS.FJDCumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJDCumulateOp(DPap, DoubleReducer, double) - Constructor in PAS.FJDCumulateOp
-
- PAS.FJDCumulatePlusOp - Class in groovyx.gpars.extra166y
- PAS.FJDCumulatePlusOp(DPap) - Constructor in PAS.FJDCumulatePlusOp
-
- PAS.FJDFill - Class in groovyx.gpars.extra166y
- PAS.FJDFill(AbstractParallelAnyArray, int, int, FJBase, double) - Constructor in PAS.FJDFill
-
- PAS.FJDGenerate - Class in groovyx.gpars.extra166y
- PAS.FJDGenerate(AbstractParallelAnyArray, int, int, FJBase, DoubleGenerator) - Constructor in PAS.FJDGenerate
-
- PAS.FJDIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJDIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntToDouble) - Constructor in PAS.FJDIndexMap
-
- PAS.FJDIndexOf - Class in groovyx.gpars.extra166y
- PAS.FJDIndexOf(AbstractParallelAnyArray, int, int, FJSearchBase, AtomicInteger, double) - Constructor in PAS.FJDIndexOf
-
- PAS.FJDMap - Class in groovyx.gpars.extra166y
- PAS.FJDMap(AbstractParallelAnyArray, int, int, FJBase, double[], int) - Constructor in PAS.FJDMap
-
- PAS.FJDMerger - Class in groovyx.gpars.extra166y
- PAS.FJDMerger(DoubleComparator, double[], double[], int, int, int, int, int, int, FJDMerger) - Constructor in PAS.FJDMerger
-
- PAS.FJDPACombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJDPACombineInPlace(AbstractParallelAnyArray, int, int, FJBase, ParallelDoubleArrayWithDoubleMapping, int, BinaryDoubleOp) - Constructor in PAS.FJDPACombineInPlace
-
- PAS.FJDPrecumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJDPrecumulateOp(DPap, DoubleReducer, double) - Constructor in PAS.FJDPrecumulateOp
-
- PAS.FJDPrecumulatePlusOp - Class in groovyx.gpars.extra166y
- PAS.FJDPrecumulatePlusOp(DPap) - Constructor in PAS.FJDPrecumulatePlusOp
-
- PAS.FJDReduce - Class in groovyx.gpars.extra166y
- PAS.FJDReduce(AbstractParallelAnyArray, int, int, FJBase, DoubleReducer, double) - Constructor in PAS.FJDReduce
-
- PAS.FJDScan - Class in groovyx.gpars.extra166y
- PAS.FJDScan(FJScan, FJScanOp, int, int) - Constructor in PAS.FJDScan
-
- PAS.FJDScanOp - Class in groovyx.gpars.extra166y
- PAS.FJDScanOp(DPap, DoubleReducer, double) - Constructor in PAS.FJDScanOp
-
- PAS.FJDScanPlusOp - Class in groovyx.gpars.extra166y
- PAS.FJDScanPlusOp(DPap) - Constructor in PAS.FJDScanPlusOp
-
- PAS.FJDSelectAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJDSelectAllDriver(AbstractParallelAnyArray) - Constructor in PAS.FJDSelectAllDriver
-
- PAS.FJDSorter - Class in groovyx.gpars.extra166y
- PAS.FJDSorter(DoubleComparator, double[], double[], int, int, int) - Constructor in PAS.FJDSorter
-
- PAS.FJDStats - Class in groovyx.gpars.extra166y
- PAS.FJDStats(AbstractParallelAnyArray, int, int, FJBase, DoubleComparator) - Constructor in PAS.FJDStats
-
- PAS.FJDTransform - Class in groovyx.gpars.extra166y
- PAS.FJDTransform(AbstractParallelAnyArray, int, int, FJBase, DoubleOp) - Constructor in PAS.FJDTransform
-
- PAS.FJDUniquifier - Class in groovyx.gpars.extra166y
- PAS.FJDUniquifier(AbstractParallelAnyArray, int, int, FJBase, UniquifierTable) - Constructor in PAS.FJDUniquifier
-
- PAS.FJLAppendAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJLAppendAllDriver(AbstractParallelAnyArray, int, long[]) - Constructor in PAS.FJLAppendAllDriver
-
- PAS.FJLApply - Class in groovyx.gpars.extra166y
- PAS.FJLApply(AbstractParallelAnyArray, int, int, FJBase, LongProcedure) - Constructor in PAS.FJLApply
-
- PAS.FJLBinaryIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJLBinaryIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntAndLongToLong) - Constructor in PAS.FJLBinaryIndexMap
-
- PAS.FJLCMerger - Class in groovyx.gpars.extra166y
- PAS.FJLCMerger(long[], long[], int, int, int, int, int, int, FJLCMerger) - Constructor in PAS.FJLCMerger
-
- PAS.FJLCombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJLCombineInPlace(AbstractParallelAnyArray, int, int, FJBase, long[], int, BinaryLongOp) - Constructor in PAS.FJLCombineInPlace
-
- PAS.FJLCSorter - Class in groovyx.gpars.extra166y
- PAS.FJLCSorter(long[], long[], int, int, int) - Constructor in PAS.FJLCSorter
-
- PAS.FJLCumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJLCumulateOp(LPap, LongReducer, long) - Constructor in PAS.FJLCumulateOp
-
- PAS.FJLCumulatePlusOp - Class in groovyx.gpars.extra166y
- PAS.FJLCumulatePlusOp(LPap) - Constructor in PAS.FJLCumulatePlusOp
-
- PAS.FJLFill - Class in groovyx.gpars.extra166y
- PAS.FJLFill(AbstractParallelAnyArray, int, int, FJBase, long) - Constructor in PAS.FJLFill
-
- PAS.FJLGenerate - Class in groovyx.gpars.extra166y
- PAS.FJLGenerate(AbstractParallelAnyArray, int, int, FJBase, LongGenerator) - Constructor in PAS.FJLGenerate
-
- PAS.FJLIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJLIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntToLong) - Constructor in PAS.FJLIndexMap
-
- PAS.FJLIndexOf - Class in groovyx.gpars.extra166y
- PAS.FJLIndexOf(AbstractParallelAnyArray, int, int, FJSearchBase, AtomicInteger, long) - Constructor in PAS.FJLIndexOf
-
- PAS.FJLMap - Class in groovyx.gpars.extra166y
- PAS.FJLMap(AbstractParallelAnyArray, int, int, FJBase, long[], int) - Constructor in PAS.FJLMap
-
- PAS.FJLMerger - Class in groovyx.gpars.extra166y
- PAS.FJLMerger(LongComparator, long[], long[], int, int, int, int, int, int, FJLMerger) - Constructor in PAS.FJLMerger
-
- PAS.FJLPACombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJLPACombineInPlace(AbstractParallelAnyArray, int, int, FJBase, ParallelLongArrayWithLongMapping, int, BinaryLongOp) - Constructor in PAS.FJLPACombineInPlace
-
- PAS.FJLPrecumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJLPrecumulateOp(LPap, LongReducer, long) - Constructor in PAS.FJLPrecumulateOp
-
- PAS.FJLPrecumulatePlusOp - Class in groovyx.gpars.extra166y
- PAS.FJLPrecumulatePlusOp(LPap) - Constructor in PAS.FJLPrecumulatePlusOp
-
- PAS.FJLReduce - Class in groovyx.gpars.extra166y
- PAS.FJLReduce(AbstractParallelAnyArray, int, int, FJBase, LongReducer, long) - Constructor in PAS.FJLReduce
-
- PAS.FJLScan - Class in groovyx.gpars.extra166y
- PAS.FJLScan(FJScan, FJScanOp, int, int) - Constructor in PAS.FJLScan
-
- PAS.FJLScanOp - Class in groovyx.gpars.extra166y
- PAS.FJLScanOp(LPap, LongReducer, long) - Constructor in PAS.FJLScanOp
-
- PAS.FJLScanPlusOp - Class in groovyx.gpars.extra166y
- PAS.FJLScanPlusOp(LPap) - Constructor in PAS.FJLScanPlusOp
-
- PAS.FJLSelectAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJLSelectAllDriver(AbstractParallelAnyArray) - Constructor in PAS.FJLSelectAllDriver
-
- PAS.FJLSorter - Class in groovyx.gpars.extra166y
- PAS.FJLSorter(LongComparator, long[], long[], int, int, int) - Constructor in PAS.FJLSorter
-
- PAS.FJLStats - Class in groovyx.gpars.extra166y
- PAS.FJLStats(AbstractParallelAnyArray, int, int, FJBase, LongComparator) - Constructor in PAS.FJLStats
-
- PAS.FJLTransform - Class in groovyx.gpars.extra166y
- PAS.FJLTransform(AbstractParallelAnyArray, int, int, FJBase, LongOp) - Constructor in PAS.FJLTransform
-
- PAS.FJLUniquifier - Class in groovyx.gpars.extra166y
- PAS.FJLUniquifier(AbstractParallelAnyArray, int, int, FJBase, UniquifierTable) - Constructor in PAS.FJLUniquifier
-
- PAS.FJOAppendAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJOAppendAllDriver(AbstractParallelAnyArray, int, Object) - Constructor in PAS.FJOAppendAllDriver
-
- PAS.FJOApply - Class in groovyx.gpars.extra166y
- PAS.FJOApply(AbstractParallelAnyArray, int, int, FJBase, Procedure) - Constructor in PAS.FJOApply
-
- PAS.FJOBinaryIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJOBinaryIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntAndObjectToObject) - Constructor in PAS.FJOBinaryIndexMap
-
- PAS.FJOCMerger - Class in groovyx.gpars.extra166y
- PAS.FJOCMerger(Comparable, Comparable, int, int, int, int, int, int, FJOCMerger) - Constructor in PAS.FJOCMerger
-
- PAS.FJOCombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJOCombineInPlace(AbstractParallelAnyArray, int, int, FJBase, Object, int, BinaryOp) - Constructor in PAS.FJOCombineInPlace
-
- PAS.FJOCSorter - Class in groovyx.gpars.extra166y
- PAS.FJOCSorter(Comparable, Comparable, int, int, int) - Constructor in PAS.FJOCSorter
-
- PAS.FJOCumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJOCumulateOp(OPap, Reducer, Object) - Constructor in PAS.FJOCumulateOp
-
- PAS.FJOFill - Class in groovyx.gpars.extra166y
- PAS.FJOFill(AbstractParallelAnyArray, int, int, FJBase, Object) - Constructor in PAS.FJOFill
-
- PAS.FJOGenerate - Class in groovyx.gpars.extra166y
- PAS.FJOGenerate(AbstractParallelAnyArray, int, int, FJBase, Generator) - Constructor in PAS.FJOGenerate
-
- PAS.FJOIndexMap - Class in groovyx.gpars.extra166y
- PAS.FJOIndexMap(AbstractParallelAnyArray, int, int, FJBase, IntToObject) - Constructor in PAS.FJOIndexMap
-
- PAS.FJOIndexOf - Class in groovyx.gpars.extra166y
- PAS.FJOIndexOf(AbstractParallelAnyArray, int, int, FJSearchBase, AtomicInteger, Object) - Constructor in PAS.FJOIndexOf
-
- PAS.FJOMap - Class in groovyx.gpars.extra166y
- PAS.FJOMap(AbstractParallelAnyArray, int, int, FJBase, Object, int) - Constructor in PAS.FJOMap
-
- PAS.FJOMerger - Class in groovyx.gpars.extra166y
Performs merging for FJSorter.
- PAS.FJOMerger(Comparator, Object, Object, int, int, int, int, int, int, FJOMerger) - Constructor in PAS.FJOMerger
-
- PAS.FJOPACombineInPlace - Class in groovyx.gpars.extra166y
- PAS.FJOPACombineInPlace(AbstractParallelAnyArray, int, int, FJBase, ParallelArrayWithMapping, int, BinaryOp) - Constructor in PAS.FJOPACombineInPlace
-
- PAS.FJOPrecumulateOp - Class in groovyx.gpars.extra166y
- PAS.FJOPrecumulateOp(OPap, Reducer, Object) - Constructor in PAS.FJOPrecumulateOp
-
- PAS.FJOReduce - Class in groovyx.gpars.extra166y
- PAS.FJOReduce(AbstractParallelAnyArray, int, int, FJBase, Reducer, Object) - Constructor in PAS.FJOReduce
-
- PAS.FJOScan - Class in groovyx.gpars.extra166y
- PAS.FJOScan(FJScan, FJScanOp, int, int) - Constructor in PAS.FJOScan
-
- PAS.FJOScanOp - Class in groovyx.gpars.extra166y
- PAS.FJOScanOp(OPap, Reducer, Object) - Constructor in PAS.FJOScanOp
-
- PAS.FJOSelectAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJOSelectAllDriver(AbstractParallelAnyArray, Class) - Constructor in PAS.FJOSelectAllDriver
-
- PAS.FJOSorter - Class in groovyx.gpars.extra166y
Sorter classes based mainly on CilkSort
Cilk:
Basic algorithm:
if array size is small, just use a sequential quicksort
Otherwise:
1.
- PAS.FJOSorter(Comparator, Object, Object, int, int, int) - Constructor in PAS.FJOSorter
-
- PAS.FJOStats - Class in groovyx.gpars.extra166y
- PAS.FJOStats(AbstractParallelAnyArray, int, int, FJBase, Comparator) - Constructor in PAS.FJOStats
-
- PAS.FJOTransform - Class in groovyx.gpars.extra166y
- PAS.FJOTransform(AbstractParallelAnyArray, int, int, FJBase, Op) - Constructor in PAS.FJOTransform
-
- PAS.FJOUniquifier - Class in groovyx.gpars.extra166y
- PAS.FJOUniquifier(AbstractParallelAnyArray, int, int, FJBase, UniquifierTable) - Constructor in PAS.FJOUniquifier
-
- PAS.FJRemoveAll - Class in groovyx.gpars.extra166y
Basic FJ task for non-root FJRemoveAll nodes.
- PAS.FJRemoveAll(AbstractParallelAnyArray, int, int, FJRemoveAll, int[]) - Constructor in PAS.FJRemoveAll
-
- PAS.FJRemoveAllDriver - Class in groovyx.gpars.extra166y
Root node for FJRemoveAll.
- PAS.FJRemoveAllDriver(AbstractParallelAnyArray, int, int) - Constructor in PAS.FJRemoveAllDriver
-
- PAS.FJScan - Class in groovyx.gpars.extra166y
Cumulative scan
- PAS.FJScan(FJScan, FJScanOp, int, int) - Constructor in PAS.FJScan
-
- PAS.FJScanOp - Class in groovyx.gpars.extra166y
Computational operations for FJScan
- PAS.FJScanOp(AbstractParallelAnyArray) - Constructor in PAS.FJScanOp
-
- PAS.FJSearchBase - Class in groovyx.gpars.extra166y
Base for cancellable search tasks.
- PAS.FJSearchBase(AbstractParallelAnyArray, int, int, FJSearchBase, AtomicInteger) - Constructor in PAS.FJSearchBase
-
- PAS.FJSelectAll - Class in groovyx.gpars.extra166y
SelectAll proceeds in two passes.
- PAS.FJSelectAll(FJSelectAllDriver, int, int) - Constructor in PAS.FJSelectAll
-
- PAS.FJSelectAllDriver - Class in groovyx.gpars.extra166y
- PAS.FJSelectAllDriver(AbstractParallelAnyArray, int) - Constructor in PAS.FJSelectAllDriver
-
- PAS.FJSelectAny - Class in groovyx.gpars.extra166y
- PAS.FJSelectAny(AbstractParallelAnyArray, int, int, FJSearchBase, AtomicInteger) - Constructor in PAS.FJSelectAny
-
- PAS.FJSubSorter - Class in groovyx.gpars.extra166y
Utility class to sort half a partitioned array
- PAS.FJSubSorter(RecursiveAction, RecursiveAction, RecursiveAction) - Constructor in PAS.FJSubSorter
-
- PAS.UniquifierTable - Class in groovyx.gpars.extra166y
Base class of fixed-size hash tables for
uniquification.
- PAS.UniquifierTable(int, AbstractParallelAnyArray, boolean) - Constructor in PAS.UniquifierTable
-
- PAS() - Constructor in PAS
-
- passIndex - Field in DataflowSelectorActor
-
- PASSIVE - Field in AsyncMessagingCore
-
- pause() - Method in ProcessorPauseResume
-
Pauses the operator so that it blocks the next time it attempts to process a message.
- paused - Field in ProcessorPauseResume
-
- PAUtils - Class in groovyx.gpars.util
Handy methods build PA from different types
- PAUtils() - Constructor in PAUtils
-
- PAWrapper - Class in groovyx.gpars.pa
The default ParallelArray wrapper class
- PAWrapper(def) - Constructor in PAWrapper
-
- payLoad - Field in ActorMessage
-
- pendingRequests - Field in SelectBase
-
Unsatisfied requests for value, each holding a list of guards and a routine to invoke once a value is available
- PGroup - Class in groovyx.gpars.group
Provides a common super class of pooled parallel groups.
- PGroup(Pool) - Constructor in PGroup
-
Creates a group for actors, agents, tasks and operators.
- PGroupBuilder - Class in groovyx.gpars.group
Provides convenience factory methods to build PGroups from various types of thread pools
- PGroupBuilder() - Constructor in PGroupBuilder
-
- phase - Field in PAS.FJScan
-
- phase - Field in PAS.FJSelectAllDriver
-
- phaseUpdater - Field in PAS.FJScan
-
- Pipeline - Class in groovyx.gpars.dataflow.operator
A builder for operator pipelines.
- Pipeline(PGroup, DataflowReadChannel) - Constructor in Pipeline
-
- plus(def) - Method in ChannelInputList
-
- plus(def) - Method in ChannelOutputList
-
- plus(KanbanFlow) - Method in KanbanFlow
-
Composes two flows by adding a trailing one to the current one, returning a new one.
- PoisonPill - Class in groovyx.gpars.dataflow.operator
Represents the poison for dataflow operators.
- PoisonPill(boolean) - Constructor in PoisonPill
-
- PoisonTrackCounter - Class in groovyx.gpars.dataflow.operator
A helper class used by poison messages to count terminated dataflow processors
- poisonTrackCounter - Field in CountingPoisonPill
-
- poisonTrackCounter - Field in ImmediateCountingPoisonPill
-
- PoisonTrackCounter(int) - Constructor in PoisonTrackCounter
-
- POKE_INTERVAL - Field in Scheduler
-
- poll() - Method in DataflowExpression
-
Retrieves the bound value.
- poll() - Method in DataflowQueue
-
Retrieves the value at the head of the buffer.
- poll() - Method in DataflowStreamReadAdapter
-
- poll() - Method in DefaultMessageQueue
-
- poll() - Method in FQMessageQueue
-
- poll() - Method in MessageQueue
-
- poll() - Method in SelectableChannel
-
Retrieves the value at the head of the buffer.
- poll() - Method in SyncDataflowStreamReadAdapter
-
- pollFromInside() - Method in FQMessageQueue
-
- pollMessage() - Method in SequentialProcessingActor
-
Polls a message from the queues
- Pool - Interface in groovyx.gpars.scheduler
Represents an actor's thread pool
- pool - Field in DataCallbackWithPool
-
- pool - Field in DefaultPool
-
- pool - Field in FJPool
-
- POOL_SIZE_MUST_BE_A_POSITIVE_NUMBER - Field in Pool
-
- pooledGroup - Property in KanbanFlow
-
If adapted, this must be set before calling start()
- PoolFactory - Interface in groovyx.gpars.util
Used to create thread pools in hosted environment
- poolFactory - Field in GParsConfig
-
- poolFactoryFlag - Field in GParsConfig
-
- poolLock - Field in PAS
-
Lock for on-demand initialization of defaultExecutor
- PoolUtils - Class in groovyx.gpars.util
Provides a couple of utility methods to pools and schedulers.
- PoolUtils() - Constructor in PoolUtils
-
- pop() - Method in ThreadLocalPools
-
Removes the top (last) element
- PORT - Field in BroadcastDiscovery
-
- position - Field in SelectBase
-
- precumulate(DoubleReducer, double) - Method in AbstractParallelAnyArray.DUPap
-
- precumulate(LongReducer, long) - Method in AbstractParallelAnyArray.LUPap
-
- precumulate(Reducer<T>, T) - Method in AbstractParallelAnyArray.OUPap
-
- precumulate(Reducer<T>, T) - Method in ParallelArray
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulate(Reducer<T>, T) - Method in ParallelArrayWithBounds
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulate(DoubleReducer, double) - Method in ParallelDoubleArray
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulate(DoubleReducer, double) - Method in ParallelDoubleArrayWithBounds
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulate(LongReducer, long) - Method in ParallelLongArray
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulate(LongReducer, long) - Method in ParallelLongArrayWithBounds
-
Replaces each element with the cumulation of applying the given
reducer to all previous values, and returns the total
reduction.
- precumulateSum() - Method in AbstractParallelAnyArray.DUPap
-
- precumulateSum() - Method in AbstractParallelAnyArray.LUPap
-
- precumulateSum() - Method in ParallelDoubleArray
-
Replaces each element with its prefix sum.
- precumulateSum() - Method in ParallelDoubleArrayWithBounds
-
Replaces each element with its prefix sum.
- precumulateSum() - Method in ParallelLongArray
-
Replaces each element with its prefix sum.
- precumulateSum() - Method in ParallelLongArrayWithBounds
-
Replaces each element with its prefix sum.
- predicate - Field in CommonOps.DoubleEqualityPredicate
-
- predicate - Field in CommonOps.DoubleInequalityPredicate
-
- predicate - Field in CommonOps.EqualityPredicate
-
- predicate - Field in CommonOps.IdentityPredicate
-
- predicate - Field in CommonOps.InequalityPredicate
-
- predicate - Field in CommonOps.IntEqualityPredicate
-
- predicate - Field in CommonOps.IntInequalityPredicate
-
- predicate - Field in CommonOps.IsNonNullPredicate
-
- predicate - Field in CommonOps.IsNullPredicate
-
- predicate - Field in CommonOps.LongEqualityPredicate
-
- predicate - Field in CommonOps.LongInequalityPredicate
-
- predicate - Field in CommonOps.NonidentityPredicate
-
- prefixValue - Property in GPrefix
-
- prepareMessage(Object) - Method in RemoteAgentSendMessage
-
- previous - Field in DataflowExpression.WaitingThread
-
- previous() - Method in ParallelArray.ListIter
-
- previous() - Method in ParallelDoubleArray.ListIter
-
- previous() - Method in ParallelLongArray.ListIter
-
- previousIndex() - Method in ParallelArray.ListIter
-
- previousIndex() - Method in ParallelDoubleArray.ListIter
-
- previousIndex() - Method in ParallelLongArray.ListIter
-
- PriMultiplex - Class in groovyx.gpars.csp.util
- PriMultiplex() - Constructor in PriMultiplex
-
- printStackTrace() - Method in ActorReplyException
-
- prioritySelect(MessageStream, List<Boolean>) - Method in Select
-
Selects a value from a single input channel, which has a value available for read.
- prioritySelector(List, List) - Method in Dataflow
-
Creates a prioritizing selector using the default dataflow parallel group.
- prioritySelector(List, List) - Method in PGroup
-
Creates a prioritizing selector using the default dataflow parallel group.
- prioritySelectToPromise(List<Boolean>) - Method in Select
-
Selects asynchronously a value from a single input channel, which has a value available for read.
- procedure - Field in PAS.FJDApply
-
- procedure - Field in PAS.FJLApply
-
- procedure - Field in PAS.FJOApply
-
- processAnyResult(List<Closure>) - Method in GParsExecutorsPoolUtil
-
Used for methods such as findAnyParallel() or anyParallel(), which may stop some alternatives once the result is known
- ProcessingNode - Class in groovyx.gpars.dataflow
A ProcessingNode specifies a
DataflowOperator:
its input and output channels, maxForks and its body of processing logic.
- ProcessingNode() - Constructor in ProcessingNode
-
- processor - Field in GracefulShutdownListener
-
- ProcessorPauseResume - Class in groovyx.gpars.dataflow.operator.component
A listener to dataflow operators and selectors allowing them to be paused and resumed.
- ProcessorPauseResume() - Constructor in ProcessorPauseResume
-
- processResult(List<Future<Object>>) - Method in GParsExecutorsPoolUtil
-
- producer - Field in KanbanLink
-
- producerAlreadyStarted() - Method in KanbanLink
-
- producerSpec - Property in KanbanLink
-
- product - Property in KanbanTray
-
- Promise - Interface in groovyx.gpars.dataflow
A unifying future-like interface to dataflow variables, asynchronous functions and active objects.
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJDScanOp
-
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJDScanPlusOp
-
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJLScanOp
-
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJLScanPlusOp
-
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJOScanOp
-
- pushDown(FJScan, FJScan, FJScan) - Method in PAS.FJScanOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJDScanOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJDScanPlusOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJLScanOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJLScanPlusOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJOScanOp
-
- pushUp(FJScan, FJScan, FJScan) - Method in PAS.FJScanOp
-
- put(K, V) - Method in CustomConcurrentHashMap
-
Maps the specified key to the specified value in this map.
- putAll(Map<? extends K, ? extends V>) - Method in CustomConcurrentHashMap
-
Copies all of the mappings from the specified map to this one.
- putAt(def, def) - Method in ChannelInputList
-
- putAt(def, def) - Method in ChannelOutputList
-
- putAt(Object, Object) - Method in Dataflows
-
Binds the value to the DataflowVariable that is associated with the property "index".
- putIfAbsent(K, V) - Method in CustomConcurrentHashMap
-
{@inheritDoc}
- putNewUnderLock(Object) - Method in Dataflows
-
Utility method extracted just to help JIT
- range - Field in CommonOps.DoubleIntervalRandomGenerator
-
- range - Field in CommonOps.IntIntervalRandomGenerator
-
- range - Field in CommonOps.LongIntervalRandomGenerator
-
- react(long, Closure) - Method in 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 in ReactiveActor
-
- reactor(Closure) - Method in Actors
-
Creates a reactor around the supplied code.
- REACTOR_MESSAGING_RUNNABLE_NEED_EXACTLY_ONE_ARGUMENT_TO_RUN - Field in ReactorMessagingRunnable
-
- reactor(Closure) - Method in PGroup
-
Creates a reactor around the supplied code.
- ReactorMessagingRunnable - Class in groovyx.gpars
Represents a single-argument Closure when using GPars ReactiveActors (reactors) through the Java API.
- ReactorMessagingRunnable(Object) - Constructor in ReactorMessagingRunnable
-
- read() - Method in ChannelInputList
-
- readerIsReady(long) - Method in SyncDataflowVariable
-
- readObject(ObjectInputStream) - Method in CustomConcurrentHashMap
-
Reconstitutes the instance from a stream (that is, deserializes it).
- readResolve() - Method in LocalHandle
-
- readResolve() - Method in RemoteHandle
-
- receive(Duration, Closure) - Method in BlockingActor
-
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
- receive(BaseDuration) - Method in SequentialProcessingActor
-
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
- receiveImpl(long, TimeUnit) - Method in BlockingActor
-
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
- receiveImpl(long, TimeUnit) - Method in SequentialProcessingActor
-
Retrieves a message from the message queue, waiting, if necessary, for a message to arrive.
- receiver - Field in DataflowGetPropertyExpression
-
- receiver - Field in DataflowInvocationExpression
-
- receiveThread - Field in BroadcastDiscovery
-
- reduce(def, Closure) - Method in AbstractPAWrapper
-
Performs a parallel reduce operation.
- reduce(T, Closure) - Method in FList
-
- reduce(Reducer<T>, T) - Method in ParallelArray
-
Returns reduction of elements.
- reduce(DoubleReducer, double) - Method in ParallelArrayWithDoubleMapping
-
Returns reduction of mapped elements.
- reduce(LongReducer, long) - Method in ParallelArrayWithLongMapping
-
Returns reduction of mapped elements.
- reduce(Reducer<U>, U) - Method in ParallelArrayWithMapping
-
Returns reduction of elements.
- reduce(DoubleReducer, double) - Method in ParallelDoubleArray
-
Returns reduction of elements.
- reduce(DoubleReducer, double) - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns reduction of elements.
- reduce(LongReducer, long) - Method in ParallelDoubleArrayWithLongMapping
-
Returns reduction of mapped elements.
- reduce(Reducer<U>, U) - Method in ParallelDoubleArrayWithMapping
-
Returns reduction of mapped elements.
- reduce(LongReducer, long) - Method in ParallelLongArray
-
Returns reduction of elements.
- reduce(DoubleReducer, double) - Method in ParallelLongArrayWithDoubleMapping
-
Returns reduction of mapped elements.
- reduce(LongReducer, long) - Method in ParallelLongArrayWithLongMapping
-
Returns reduction of elements.
- reduce(Reducer<U>, U) - Method in ParallelLongArrayWithMapping
-
Returns reduction of mapped elements.
- reduce(T, FList<T>, Closure) - Method in StreamCore
-
- reducer - Field in PAS.FJDReduce
-
- reducer - Field in PAS.FJDScanOp
-
- reducer - Field in PAS.FJLReduce
-
- reducer - Field in PAS.FJLScanOp
-
- reducer - Field in PAS.FJOReduce
-
- reducer - Field in PAS.FJOScanOp
-
- refQueue - Field in CustomConcurrentHashMap
-
- register(String, PGroup) - Method in ActiveObjectRegistry
-
- registerChannelListenersToAllInputs(DataflowChannelListener<Object>) - Method in DataflowProcessor
-
Registers the provided handler to all input channels
- registerChannelListenersToAllInputs(DataflowChannelListener<Object>) - Method in DataflowProcessorActor
-
Registers the provided handler to all input channels
- registerCurrentActorWithThread(Actor) - Method in Actor
-
Registers the actor with the current thread
- registered(DataflowProcessor) - Method in DataflowEventAdapter
-
Invoked immediately after the listener has been attached to a dataflow processor.
- registered(DataflowProcessor) - Method in DataflowEventListener
-
Invoked immediately after the listener has been attached to a dataflow processor.
- registered(DataflowProcessor) - Method in GracefulShutdownListener
-
When hooked into an operator/selectors, the listener will tap to its input channels to get notified about all incoming messages.
- registerError(Throwable) - Method in AgentCore
-
Adds the exception to the list of thrown exceptions
- registerError(Throwable) - Method in AsyncMessagingCore
-
- registerProcessorListener(GracefulShutdownListener) - Method in GracefulShutdownMonitor
-
Invoked by GracefulShutdownListeners, which listen on operators/selectors for lifecycle events, to get registered with the monitor.
- registerProcessorListener(GracefulShutdownListener) - Method in OperatorStateMonitor
-
Invoked by GracefulShutdownListeners, which listen on operators/selectors for lifecycle events, to get registered with the monitor.
- registry - Field in ActiveObjectRegistry
-
- reInterrupt() - Method in MessageStream
-
- release() - Method in KanbanTray
-
Send the empty tray back upstream
- remap(K, V) - Method in CustomConcurrentHashMap.RemappingFunction
-
Returns a new value for the given key and its current, or
null if there is no mapping.
- RemoteActor - Class in groovyx.gpars.actor.remote
Proxy object for remote instance of Actor.
- RemoteActor.MyRemoteHandle - Class in groovyx.gpars.actor.remote
- RemoteActor.MyRemoteHandle(SerialHandle, SerialContext, DataflowExpression<Object>) - Constructor in RemoteActor.MyRemoteHandle
-
- RemoteActor.StopActorMsg - Class in groovyx.gpars.actor.remote
- RemoteActor.StopActorMsg(RemoteActor) - Constructor in RemoteActor.StopActorMsg
-
- RemoteActor.TerminateActorMsg - Class in groovyx.gpars.actor.remote
- RemoteActor.TerminateActorMsg(RemoteActor) - Constructor in RemoteActor.TerminateActorMsg
-
- RemoteActor(SerialContext, DataflowExpression<Object>) - Constructor in RemoteActor
-
- RemoteActorReplyMsg - Class in groovyx.gpars.remote.message
Message used to carry Actor.
- RemoteActorReplyMsg(String, Actor) - Constructor in RemoteActorReplyMsg
-
- RemoteActorRequestMsg - Class in groovyx.gpars.remote.message
Message used to carry remote Actor request.
- RemoteActorRequestMsg(UUID, String) - Constructor in RemoteActorRequestMsg
-
- RemoteAgentGetValMsg - Class in groovyx.gpars.remote.message
Message that carry current state of Agent
- RemoteAgentGetValMsg(AgentCore, DataflowVariable<T>) - Constructor in RemoteAgentGetValMsg
-
- RemoteAgentMock - Class in groovyx.gpars.agent.remote
Fake Agent to intercept closure calls.
- RemoteAgentMock() - Constructor in RemoteAgentMock
-
- RemoteAgentReplyMsg - Class in groovyx.gpars.remote.message
Message that carry Actor.
- RemoteAgentReplyMsg(String, Agent<?>) - Constructor in RemoteAgentReplyMsg
-
- RemoteAgentRequestMsg - Class in groovyx.gpars.remote.message
Message that carry remote Agent request.
- RemoteAgentRequestMsg(UUID, String) - Constructor in RemoteAgentRequestMsg
-
- RemoteAgentSendClosureMessage - Class in groovyx.gpars.remote.message
Message used to perform local closure execution.
- RemoteAgentSendClosureMessage(RemoteAgent<T>, DataflowVariable<T>, DataflowVariable<T>) - Constructor in RemoteAgentSendClosureMessage
-
- RemoteAgentSendMessage - Class in groovyx.gpars.remote.message
Message that carry message to Agent.
- RemoteAgentSendMessage(RemoteAgent, Object) - Constructor in RemoteAgentSendMessage
-
- RemoteConnection - Class in groovyx.gpars.remote
Represents connection to remote host
- remoteConnection - Field in NettyHandler
-
- RemoteConnection(LocalHost) - Constructor in RemoteConnection
-
- RemoteDataflowBroadcast - Class in groovyx.gpars.dataflow.remote
Proxy object for remote instance of Broadcast.
- RemoteDataflowBroadcast(RemoteHost) - Constructor in RemoteDataflowBroadcast
-
- RemoteDataflowBroadcastReplyMsg - Class in groovyx.gpars.remote.message
Message used to carry Broadcast stream.
- RemoteDataflowBroadcastReplyMsg(String, DataflowBroadcast) - Constructor in RemoteDataflowBroadcastReplyMsg
-
- RemoteDataflowBroadcastRequestMsg - Class in groovyx.gpars.remote.message
Message that carry Broadcast stream request.
- RemoteDataflowBroadcastRequestMsg(UUID, String) - Constructor in RemoteDataflowBroadcastRequestMsg
-
- RemoteDataflowExpression - Class in groovyx.gpars.dataflow.expression
@author Alex Tkachman
- RemoteDataflowExpression() - Constructor in RemoteDataflowExpression
-
- RemoteDataflowQueueEnqueueValueMsg - Class in groovyx.gpars.remote.message
Message that pushes new value into remote queue.
- RemoteDataflowQueueEnqueueValueMsg(RemoteDataflowQueue<T>, T) - Constructor in RemoteDataflowQueueEnqueueValueMsg
-
- RemoteDataflowQueueReplyMsg - Class in groovyx.gpars.remote.message
Message that carry DataflowQueue.
- RemoteDataflowQueueReplyMsg(String, DataflowQueue<?>) - Constructor in RemoteDataflowQueueReplyMsg
-
- RemoteDataflowQueueRequestMsg - Class in groovyx.gpars.remote.message
Message that carry remote Queue request.
- RemoteDataflowQueueRequestMsg(UUID, String) - Constructor in RemoteDataflowQueueRequestMsg
-
- RemoteDataflowQueueValueRequestMsg - Class in groovyx.gpars.remote.message
Message that carry item request to remote queue.
- RemoteDataflowQueueValueRequestMsg(RemoteDataflowQueue<T>, DataflowVariable<T>) - Constructor in RemoteDataflowQueueValueRequestMsg
-
- RemoteDataflowVariable - Class in groovyx.gpars.dataflow.remote
Proxy object for remote Variable instance.
- RemoteDataflowVariable(RemoteHost) - Constructor in RemoteDataflowVariable
-
- RemoteDataflowVariableReplyMsg - Class in groovyx.gpars.remote.message
Message that carry Variable.
- RemoteDataflowVariableReplyMsg(String, DataflowVariable) - Constructor in RemoteDataflowVariableReplyMsg
-
- RemoteDataflowVariableRequestMsg - Class in groovyx.gpars.remote.message
Message that carry remote Variable request.
- RemoteDataflowVariableRequestMsg(UUID, String) - Constructor in RemoteDataflowVariableRequestMsg
-
- RemoteHandle - Class in groovyx.gpars.serial
@author Alex Tkachman
- RemoteHandle(UUID, UUID) - Constructor in RemoteHandle
-
- remoteHost - Field in MessageStream.RemoteMessageStream
-
- remoteHost - Field in RemoteActor
-
- remoteHost - Field in RemoteDataflowExpression
-
- remoteHost - Field in RemoteDataflowVariable
-
- RemoteObjectDecoder - Class in groovyx.gpars.remote.netty
- RemoteObjectDecoder(RemoteConnection) - Constructor in RemoteObjectDecoder
-
Creates a new encoder.
- RemoteObjectEncoder - Class in groovyx.gpars.remote.netty
- RemoteObjectEncoder(RemoteConnection) - Constructor in RemoteObjectEncoder
-
Creates a new encoder.
- RemoteSerialized - Interface in groovyx.gpars.serial
Marker interface for objects, which are proxies to objects on other nodes.
- remove() - Method in AbstractParallelAnyArray.FilteredAsDoubleIterator
-
- remove() - Method in AbstractParallelAnyArray.FilteredAsLongIterator
-
- remove() - Method in AbstractParallelAnyArray.FilteredIterator
-
- remove() - Method in AbstractParallelAnyArray.UnfilteredAsDoubleIterator
-
- remove() - Method in AbstractParallelAnyArray.UnfilteredAsLongIterator
-
- remove() - Method in AbstractParallelAnyArray.UnfilteredIterator
-
- remove(def) - Method in ChannelInputList
-
- remove(def) - Method in ChannelOutputList
-
- remove(Object, Object) - Method in CustomConcurrentHashMap
-
{@inheritDoc}
- remove(Object) - Method in CustomConcurrentHashMap.EntrySet
-
- remove() - Method in CustomConcurrentHashMap.HashIterator
-
- remove(Object) - Method in CustomConcurrentHashMap.KeySet
-
Removes an element equivalent to the given element with
respect to this set's Equivalence, if one is present.
- remove(Object) - Method in CustomConcurrentHashMap.KeySetView
-
- remove(Object) - Method in Dataflows
-
Removes a DFV from the map and binds it to null, if it has not been bound yet
- remove() - Method in FListIterator
-
- remove(int) - Method in ParallelArray.AsList
-
- remove() - Method in ParallelArray.ListIter
-
- remove() - Method in ParallelArray.ParallelArrayIterator
-
- remove(int) - Method in ParallelDoubleArray.AsList
-
- remove() - Method in ParallelDoubleArray.ListIter
-
- remove() - Method in ParallelDoubleArray.ParallelDoubleArrayIterator
-
- remove(int) - Method in ParallelLongArray.AsList
-
- remove() - Method in ParallelLongArray.ListIter
-
- remove() - Method in ParallelLongArray.ParallelLongArrayIterator
-
- remove(SerialHandle) - Method in SerialContext
-
- remove(SerialHandle) - Method in SerialHandles
-
- removeAll(Predicate<? super T>) - Method in ParallelArray
-
Removes from the array all elements for which the given
selector holds.
- removeAll(DoublePredicate) - Method in ParallelDoubleArray
-
Removes from the array all elements for which the given
selector holds.
- removeAll(LongPredicate) - Method in ParallelLongArray
-
Removes from the array all elements for which the given
selector holds.
- removeBindErrorListener(BindErrorListener<T>) - Method in BindErrorListenerManager
-
- removeBindErrorListener(BindErrorListener<T>) - Method in DataflowChannelEventOrchestrator
-
- removeConsecutiveDuplicates() - Method in ParallelArray
-
Removes consecutive elements that are equal (or null),
shifting others leftward, and possibly decreasing size.
- removeConsecutiveDuplicates() - Method in ParallelDoubleArray
-
Removes consecutive elements that are equal,
shifting others leftward, and possibly decreasing size.
- removeConsecutiveDuplicates() - Method in ParallelLongArray
-
Removes consecutive elements that are equal,
shifting others leftward, and possibly decreasing size.
- removeDataflowChannelListener(DataflowChannelListener<T>) - Method in DataflowChannelEventListenerManager
-
- removeDataflowChannelListener(DataflowChannelListener<T>) - Method in DataflowChannelEventOrchestrator
-
- removeDataflowEventListener(DataflowEventListener) - Method in DataflowProcessor
-
- removeEldestEntry(Entry<Object, Object>) - Method in LRUProtectionStorage
-
- removeIfReclaimed(CustomConcurrentHashMap.Node) - Method in CustomConcurrentHashMap
-
Removes node if its key or value are null.
- removeNulls() - Method in ParallelArray
-
Removes null elements, shifting others leftward, and possibly
decreasing size.
- removeRange(int, int) - Method in ParallelArray.AsList
-
- removeRange(int, int) - Method in ParallelDoubleArray.AsList
-
- removeRange(int, int) - Method in ParallelLongArray.AsList
-
- removeSlotAt(int) - Method in ParallelArray
-
- removeSlotAt(int) - Method in ParallelDoubleArray
-
- removeSlotAt(int) - Method in ParallelLongArray
-
- removeSlotsAt(int, int) - Method in ParallelArray
-
- removeSlotsAt(int, int) - Method in ParallelDoubleArray
-
- removeSlotsAt(int, int) - Method in ParallelLongArray
-
- removeTray() - Method in KanbanLink
-
Removing a tray from the system by fetching the next one from the upstream
- replace(K, V, V) - Method in CustomConcurrentHashMap
-
{@inheritDoc}
- replaceElementsParallelLongArrayWith(long[]) - Method in ParallelLongArray
-
- replaceElementsWith(T) - Method in ParallelArray
-
- replaceWithGeneratedValue(Generator<? extends T>) - Method in ParallelArray
-
Replaces elements with the results of applying the given
generator.
- replaceWithGeneratedValue(Generator<? extends T>) - Method in ParallelArrayWithFilter
-
Replaces elements with results of applying the given generator.
- replaceWithGeneratedValue(DoubleGenerator) - Method in ParallelDoubleArray
-
Replaces elements with the results of applying the given
generator.
- replaceWithGeneratedValue(DoubleGenerator) - Method in ParallelDoubleArrayWithFilter
-
Replaces elements with results of applying the given generator.
- replaceWithGeneratedValue(LongGenerator) - Method in ParallelLongArray
-
Replaces elements with the results of applying the given
generator.
- replaceWithGeneratedValue(LongGenerator) - Method in ParallelLongArrayWithFilter
-
Replaces elements with results of applying the given
generator.
- replaceWithMappedIndex(IntAndObjectToObject<? super T, ? extends T>) - Method in ParallelArray
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMappedIndex(IntAndObjectToObject<? super T, ? extends T>) - Method in ParallelArrayWithFilter
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMappedIndex(IntAndDoubleToDouble) - Method in ParallelDoubleArray
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMappedIndex(IntAndDoubleToDouble) - Method in ParallelDoubleArrayWithFilter
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMappedIndex(IntAndLongToLong) - Method in ParallelLongArray
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMappedIndex(IntAndLongToLong) - Method in ParallelLongArrayWithFilter
-
Replaces elements with the results of applying the given
mapping to each index and current element value.
- replaceWithMapping(BinaryOp<T, T, T>, T) - Method in ParallelArray
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithMapping(BinaryOp<T, T, T>, T) - Method in ParallelArrayWithFilter
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithMapping(BinaryDoubleOp, double[]) - Method in ParallelDoubleArray
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithMapping(BinaryDoubleOp, double[]) - Method in ParallelDoubleArrayWithFilter
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithMapping(BinaryLongOp, long[]) - Method in ParallelLongArray
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithMapping(BinaryLongOp, long[]) - Method in ParallelLongArrayWithFilter
-
Replaces elements with results of applying
op(thisElement, otherElement)
.
- replaceWithValue(T) - Method in ParallelArray
-
Replaces elements with the given value.
- replaceWithValue(T) - Method in ParallelArrayWithFilter
-
Replaces elements with the given value.
- replaceWithValue(double) - Method in ParallelDoubleArray
-
Replaces elements with the given value.
- replaceWithValue(double) - Method in ParallelDoubleArrayWithFilter
-
Replaces elements with the given value.
- replaceWithValue(long) - Method in ParallelLongArray
-
Replaces elements with the given value.
- replaceWithValue(long) - Method in ParallelLongArrayWithFilter
-
Replaces elements with the given value.
- reply(Object) - Method in AbstractLoopingActor
-
Sends a reply to all currently processed messages.
- reply(Object) - Method in ReplyingMessageStream
-
Sends a reply to all currently processed messages.
- replyIfExists(Object) - Method in AbstractLoopingActor
-
Sends a reply to all currently processed messages, which have been sent by an actor.
- replyIfExists(Object) - Method in ReplyingMessageStream
-
Sends a reply to all currently processed messages, which have been sent by an actor.
- ReplyingMessageStream - Class in groovyx.gpars.actor.impl
@author Alex Tkachman, Vaclav Pech
- ReplyingMessageStream() - Constructor in ReplyingMessageStream
-
- reportError(Throwable) - Method in DataflowProcessor
-
Is invoked in case the actor throws an exception.
- reportException(Throwable) - Method in DataflowProcessorActor
-
- requests - Field in DataflowQueue
-
Stores unsatisfied requests for values
- 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 PGroup
-
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 PGroup
-
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
-
- ResizeableCountDownLatch - Class in groovyx.gpars.dataflow.impl
CountDownLatch with the ability to change the number of waiting parties
- ResizeableCountDownLatch.Sync - Class in groovyx.gpars.dataflow.impl
Synchronization control For CountDownLatch.
- ResizeableCountDownLatch.Sync(int) - Constructor in ResizeableCountDownLatch.Sync
-
- ResizeableCountDownLatch() - Constructor in ResizeableCountDownLatch
-
- ResizeablePool - Class in groovyx.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.
- resizeArray(int) - Method in ParallelArray
-
- resizeArray(int) - Method in ParallelDoubleArray
-
- resizeArray(int) - Method in ParallelLongArray
-
- resizeTable(CustomConcurrentHashMap) - Method in CustomConcurrentHashMap.Segment
-
See the similar code in ConcurrentHashMap for explanation.
- RESPONDS_TO - Field in Actor
-
- rest - Field in StreamCore
-
- RESULT - Field in DataflowExpression
-
- result - Field in GracefulShutdownMonitor
-
The final latch that indicates the network has been shutdown
- result - Field in PAS.FJDReduce
-
- result - Field in PAS.FJLReduce
-
- result - Field in PAS.FJOReduce
-
- result - Field in PAS.FJSearchBase
-
- result - Field in ThenMessagingRunnable
-
- results - Field in PAS.FJDAppendAllDriver
-
- results - Field in PAS.FJDSelectAllDriver
-
- results - Field in PAS.FJLAppendAllDriver
-
- results - Field in PAS.FJLSelectAllDriver
-
- results - Field in PAS.FJOAppendAllDriver
-
- results - Field in PAS.FJOSelectAllDriver
-
- resultSize - Field in PAS.FJSelectAllDriver
-
- resume() - Method in ProcessorPauseResume
-
Resumes the operator so that it can start processing messages again.
- rethrowException() - Method in MessageStream.ResultWaiter
-
- retrieveCurrentDFPGroup() - Method in Dataflow
-
Retrieves the thread-local value of the active PGroup or the default DataflowGroup
- retrieveCurrentPool() - Method in GParsExecutorsPool
-
Retrieves the pool assigned to the current thread.
- retrieveCurrentPool() - Method in GParsPool
-
Retrieves the pool assigned to the current thread.
- retrieveDefaultPool() - Method in GParsConfig
-
If a pool factory has been set, it will be used to create a new thread pool.
- retrieveDefaultPoolSize() - Method in PoolUtils
-
- retrieveDefaultTimer(String, boolean) - Method in GParsConfig
-
If a timer factory has been set, it will be used to create a timer.
- retrieveFJPool() - Method in GParsPoolUtilHelper
-
- retrieveForBind() - Method in DataflowQueue
-
Takes the first unsatisfied value request and binds a value on it.
- retrieveLocalPool() - Method in GParsExecutorsPoolUtil
-
- retrieveNextMessage() - Method in SequentialProcessingActor
-
Takes the next message from the outputQueue, decrements the counter and possibly throws control exceptions
- retrieveOrCreateVariable() - Method in DataflowQueue
-
Checks whether there's a DFV waiting in the queue and retrieves it.
- retrievePool() - Method in GParsPoolUtil
-
- right - Field in PAS.FJRemoveAll
-
- right - Field in PAS.FJScan
-
- right - Field in PAS.FJSelectAll
-
- right - Field in PAS.FJSubSorter
-
- rightShift(Closure<V>) - Method in DataflowExpression
-
Schedule closure to be executed by pooled actor after data became available.
- rightShift(Closure<V>) - Method in DataflowQueue
-
Schedule closure to be executed by pooled actor after data became available.
- rightShift(Closure<V>) - Method in DataflowReadChannel
-
Schedule closure to be executed after data became available.
- rightShift(Closure<V>) - Method in DataflowStreamReadAdapter
-
- rightShift(Closure<V>) - Method in Promise
-
Schedule closure to be executed after data became available.
- rightShift(Closure<V>) - Method in SyncDataflowStreamReadAdapter
-
- rn - Field in PAS.FJDCMerger
-
- rn - Field in PAS.FJDMerger
-
- rn - Field in PAS.FJLCMerger
-
- rn - Field in PAS.FJLMerger
-
- rn - Field in PAS.FJOCMerger
-
- rn - Field in PAS.FJOMerger
-
- ro - Field in PAS.FJDCMerger
-
- ro - Field in PAS.FJDMerger
-
- ro - Field in PAS.FJLCMerger
-
- ro - Field in PAS.FJLMerger
-
- ro - Field in PAS.FJOCMerger
-
- ro - Field in PAS.FJOMerger
-
- rsetIn(Object) - Method in PAS.FJOScan
-
- rsetIn(Object) - Method in PAS.FJScan
-
- rsetOut(Object) - Method in PAS.FJOScan
-
- rsetOut(Object) - Method in PAS.FJScan
-
- run() - Method in ActorTimerTask
-
- run() - Method in AsyncMessagingCore
-
Handles a single message from the message queue
- run() - Method in CustomConcurrentHashMap.ReclamationThread
-
- 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
-
- runAfterLoopCode(Closure) - Method in DefaultActor
-
- runChildDirectly(Object) - Method in FJWorker
-
- runEnhancedWithoutRepliesOnMessages(ActorMessage, Closure, Object) - Method in AbstractLoopingActor
-
- runForkJoin(ForkJoinPool, Object) - Method in ForkJoinUtils
-
- runForkJoin(Object) - Method in GParsPool
-
Starts a ForkJoin calculation with the supplied root worker and waits for the result.
- RunnableBackedBlockingActor - Class in groovyx.gpars.actor.impl
Utility class to implement a blocking actor backed by any Runnable (including Closure)
- RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate - Class in groovyx.gpars.actor.impl
- RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate(Object, Object) - Constructor in RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
-
- RunnableBackedBlockingActor(Runnable) - Constructor in RunnableBackedBlockingActor
-
- 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
-
- schedule() - Method in 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
- schedule(Runnable, long) - Method in GeneralTimer
-
- schedule() - Method in GracefulShutdownMonitor
-
Clears the notification flag so as we know whether some activity happens between subsequent checks.
- scheduleCallback(Object, MessageStream) - Method in DataflowExpression
-
Sends the result back to the actor, which is waiting asynchronously for the value to be bound.
- scheduleCallback(Object, MessageStream) - Method in SyncDataflowVariable
-
- Scheduler - Class in groovyx.gpars.scheduler
Prototype of self-regulated thread pooled scheduler
- Scheduler.WatchdogThread - Class in groovyx.gpars.scheduler
- Scheduler.WatchdogThread() - Constructor in Scheduler.WatchdogThread
-
- Scheduler.WorkerThread - Class in groovyx.gpars.scheduler
- Scheduler.WorkerThread() - Constructor in Scheduler.WorkerThread
-
- Scheduler(int) - Constructor in Scheduler
-
- schedulerTime - Field in Scheduler
-
- SDAClosure - Class in groovyx.gpars.actor.impl
Creates a SDA closure to invoke appropriate actor's message handlers based on message compile-type type
- SDAClosure() - Constructor in SDAClosure
-
- second - Field in AbstractParallelAnyArray.AndPredicate
-
- second - Field in ForwardingDelegate
-
- second - Field in RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
-
- SEGMENT_BITS - Field in CustomConcurrentHashMap
-
- SEGMENT_MASK - Field in CustomConcurrentHashMap
-
- SEGMENT_SHIFT - Field in CustomConcurrentHashMap
-
- segments - Field in CustomConcurrentHashMap
-
The segments, each of which acts as a hash table
- segmentsBase - Field in CustomConcurrentHashMap
-
- segmentsShift - Field in CustomConcurrentHashMap
-
- Select - 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(List<? extends SelectableChannel>) - Method in Dataflow
-
Creates a select using the default dataflow parallel group.
- select - Field in DataflowSelector
-
- select(List<? extends SelectableChannel>) - Method in PGroup
-
Creates a select using the current parallel group.
- Select(PGroup, List<SelectableChannel<? extends T>>) - Constructor in Select
-
@param pGroup The group, the thread pool of which should be used for notification message handlers
- SelectableChannel - Interface in groovyx.gpars.dataflow
Created with IntelliJ IDEA.
- SelectBase - Class in groovyx.gpars.dataflow.impl
The implementation of the core for all selects.
- selectBase - Field in Select
-
- SelectBase(PGroup, List<SelectableChannel<? extends T>>) - Constructor in SelectBase
-
Stores the input channel and registers for the wheneverBound() event on each
- SelectCallback - 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, SelectableChannel<? extends T>) - Constructor in SelectCallback
-
@param owner The SelectBase instance to notify
- selector - Field in AbstractParallelAnyArray.DFDCPap
-
- selector - Field in AbstractParallelAnyArray.DFDMPap
-
- selector - Field in AbstractParallelAnyArray.DFLCPap
-
- selector - Field in AbstractParallelAnyArray.DFLMPap
-
- selector - Field in AbstractParallelAnyArray.DFOCPap
-
- selector - Field in AbstractParallelAnyArray.DFOMPap
-
- selector - Field in AbstractParallelAnyArray.DFPap
-
- selector - Field in AbstractParallelAnyArray.DRDCPap
-
- selector - Field in AbstractParallelAnyArray.DRDMPap
-
- selector - Field in AbstractParallelAnyArray.DRLCPap
-
- selector - Field in AbstractParallelAnyArray.DRLMPap
-
- selector - Field in AbstractParallelAnyArray.DROCPap
-
- selector - Field in AbstractParallelAnyArray.DROMPap
-
- selector - Field in AbstractParallelAnyArray.DRPap
-
- selector - Field in AbstractParallelAnyArray.LFDCPap
-
- selector - Field in AbstractParallelAnyArray.LFDMPap
-
- selector - Field in AbstractParallelAnyArray.LFLCPap
-
- selector - Field in AbstractParallelAnyArray.LFLMPap
-
- selector - Field in AbstractParallelAnyArray.LFOCPap
-
- selector - Field in AbstractParallelAnyArray.LFOMPap
-
- selector - Field in AbstractParallelAnyArray.LFPap
-
- selector - Field in AbstractParallelAnyArray.LRDCPap
-
- selector - Field in AbstractParallelAnyArray.LRDMPap
-
- selector - Field in AbstractParallelAnyArray.LRLCPap
-
- selector - Field in AbstractParallelAnyArray.LRLMPap
-
- selector - Field in AbstractParallelAnyArray.LROCPap
-
- selector - Field in AbstractParallelAnyArray.LROMPap
-
- selector - Field in AbstractParallelAnyArray.LRPap
-
- selector - Field in AbstractParallelAnyArray.OFDCPap
-
- selector - Field in AbstractParallelAnyArray.OFDMPap
-
- selector - Field in AbstractParallelAnyArray.OFLCPap
-
- selector - Field in AbstractParallelAnyArray.OFLMPap
-
- selector - Field in AbstractParallelAnyArray.OFOCPap
-
- selector - Field in AbstractParallelAnyArray.OFOMPap
-
- selector - Field in AbstractParallelAnyArray.OFPap
-
- selector - Field in AbstractParallelAnyArray.ORDCPap
-
- selector - Field in AbstractParallelAnyArray.ORDMPap
-
- selector - Field in AbstractParallelAnyArray.ORLCPap
-
- selector - Field in AbstractParallelAnyArray.ORLMPap
-
- selector - Field in AbstractParallelAnyArray.OROCPap
-
- selector - Field in AbstractParallelAnyArray.OROMPap
-
- selector - Field in AbstractParallelAnyArray.ORPap
-
- selector(List, List) - Method in Dataflow
-
Creates a selector using the default dataflow parallel group.
- selector(List, List) - Method in PGroup
-
Creates a selector using this parallel group.
- SelectRequest - Interface in groovyx.gpars.dataflow.impl
Represents a request for value from a select.
- SelectResult - Class in groovyx.gpars.dataflow
A bean representing the result of the select operation on a Select.
- SelectResult(int, T) - Constructor in SelectResult
-
Stores the result of a select operation
- selectToPromise(int, List<Boolean>) - Method in Select
-
Invokes the internal select base with a SelectRequest instance ensuring a message is sent, once a value has been selected
- SELF_STRING - Field in CustomConcurrentHashMap
-
Config string for self-map (Set view) refs
- semaphore - Field in ForkingDataflowOperatorActor
-
- semaphore - Field in ForkingDataflowSelectorActor
-
- send(Object) - Method in AbstractLoopingActor
-
- 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 DataCallbackWithPool
-
Sends a message back to the DataCallback.
- send(Object) - Method in DataflowExpression.DataflowExpressionsCollector
-
- send(Object) - Method in DataflowProcessorActor
-
Sends the message, ignoring exceptions caused by the actor not being active anymore
- send(T, 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 RemoteActor
-
- send(Object) - Method in SequentialProcessingActor
-
- sendAndContinue(T, Closure) - Method in Actor
-
Sends a message and execute continuation when reply became available.
- sendAndPromise(T) - Method in Actor
-
Sends a message and returns a promise for the reply.
- sendAndWait(Closure) - Method in AgentBase
-
Submits the closure waiting for the result
- sendAndWait(T, Duration) - Method in MessageStream
-
Sends a message and waits for a reply.
- sender - Field in ActorMessage
-
- sender - Field in ReplyingMessageStream
-
A list of senders for the currently processed messages
- sendThread - Field in BroadcastDiscovery
-
- separate(PGroup, Map<String, Object>, List<DataflowWriteChannel<?>>, Closure<List<Object>>) - Method in DataflowExpression
-
- separate(PGroup, Map<String, Object>, List<DataflowWriteChannel<?>>, Closure<List<Object>>) - Method in DataflowQueue
-
- separate(PGroup, Map<String, Object>, List<DataflowWriteChannel<?>>, Closure<List<Object>>) - Method in DataflowReadChannel
-
Allows the closure to output different values to different output channels.
- separate(PGroup, Map<String, Object>, List<DataflowWriteChannel<?>>, Closure<List<Object>>) - Method in DataflowStreamReadAdapter
-
- separate(Map<String, Object>, List<DataflowWriteChannel<?>>, Closure<List<Object>>) - Method in Pipeline
-
Allows the closure to output different values to different output channels.
- SeparationClosure - Class in groovyx.gpars.dataflow.operator
Used by the chainWith() method to wrap the supplied closure inside the operator's body.
- SeparationClosure(Closure<List<Object>>) - Constructor in SeparationClosure
-
- seqIndexOf(Object) - Method in ParallelArray
-
- seqIndexOf(double) - Method in ParallelDoubleArray
-
- seqIndexOf(long) - Method in ParallelLongArray
-
- seqLastIndexOf(Object) - Method in ParallelArray
-
- seqLastIndexOf(double) - Method in ParallelDoubleArray
-
- seqLastIndexOf(long) - Method in ParallelLongArray
-
- sequentially() - Method in ParallelArrayWithDoubleMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelArrayWithLongMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelArrayWithMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelDoubleArrayWithLongMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelDoubleArrayWithMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelLongArrayWithDoubleMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelLongArrayWithLongMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- sequentially() - Method in ParallelLongArrayWithMapping
-
Returns an Iterable view to sequentially step through mapped
elements also obeying bound and filter constraints, without
performing computations to evaluate them in parallel.
- SequentialProcessingActor - Class in groovyx.gpars.actor.impl
@author Alex Tkachman, Vaclav Pech
- SequentialProcessingActor.Node - Class in groovyx.gpars.actor.impl
Represents an element in the message queue.
- SequentialProcessingActor.Node(ActorMessage) - Constructor in SequentialProcessingActor.Node
-
- SequentialProcessingActor() - Constructor in SequentialProcessingActor
-
Creates a new instance, sets the default actor group.
- SerialContext - Class in groovyx.gpars.serial
@author Alex Tkachman
- SerialContext(SerialHandles, UUID) - Constructor in SerialContext
-
- SerialHandle - Class in groovyx.gpars.serial
Weak reference to object, which was serialized to remote hosts.
- SerialHandle.LocalSerialHandle - Class in groovyx.gpars.serial
- SerialHandle.LocalSerialHandle(WithSerialId, UUID) - Constructor in SerialHandle.LocalSerialHandle
-
- SerialHandle.RemoteSerialHandle - Class in groovyx.gpars.serial
- SerialHandle.RemoteSerialHandle.ReleaseHandle - Class in groovyx.gpars.serial
- SerialHandle.RemoteSerialHandle.ReleaseHandle(UUID) - Constructor in SerialHandle.RemoteSerialHandle.ReleaseHandle
-
- SerialHandle.RemoteSerialHandle(WithSerialId, UUID) - Constructor in SerialHandle.RemoteSerialHandle
-
- SerialHandle(WithSerialId, UUID) - Constructor in SerialHandle
-
Construct handle for object with given id to it
- serialHandle - Field in WithSerialId
-
See SerialHandle class for details
- SerialHandles - Class in groovyx.gpars.serial
@author Alex Tkachman
- SerialHandles() - Constructor in SerialHandles
-
- serialId - Field in RemoteHandle
-
- serialId - Field in SerialHandle
-
serial id of the object
- serialId - Field in SerialHandle.RemoteSerialHandle.ReleaseHandle
-
- SerialMsg - Class in groovyx.gpars.serial
Base class for all messages
- SerialMsg(UUID) - Constructor in SerialMsg
-
- serialVersionUID - Field in AbstractLoopingActor
-
- serialVersionUID - Field in Actor
-
- serialVersionUID - Field in ActorException
-
- serialVersionUID - Field in ActorMessage
-
- serialVersionUID - Field in ActorReplyException
-
- serialVersionUID - Field in ActorStopException
-
- serialVersionUID - Field in ActorTerminationException
-
- serialVersionUID - Field in AgentBase.AwaitClosure
-
- serialVersionUID - Field in AsyncException
-
- serialVersionUID - Field in BlockingActor
-
- serialVersionUID - Field in CallClosure
-
- serialVersionUID - Field in CustomConcurrentHashMap
-
- serialVersionUID - Field in CustomConcurrentHashMap.EquivalenceUsingEquals
-
- serialVersionUID - Field in CustomConcurrentHashMap.EquivalenceUsingIdentity
-
- serialVersionUID - Field in CustomConcurrentHashMap.IntKeyIntValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.IntKeySelfValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.IntKeySoftValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.IntKeyStrongValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.IntKeyWeakValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.SoftKeyIntValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.SoftKeySelfValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.SoftKeySoftValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.SoftKeyStrongValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.SoftKeyWeakValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.StrongKeyIntValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.StrongKeySelfValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.StrongKeySoftValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.StrongKeyStrongValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.StrongKeyWeakValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WeakKeyIntValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WeakKeySelfValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WeakKeySoftValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WeakKeyStrongValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WeakKeyWeakValueNodeFactory
-
- serialVersionUID - Field in CustomConcurrentHashMap.WriteThroughEntry
-
- serialVersionUID - Field in DataCallback
-
- serialVersionUID - Field in DataCallbackWithPool
-
- serialVersionUID - Field in DataflowComplexExpression
-
- serialVersionUID - Field in DataflowExpression
-
- serialVersionUID - Field in DataflowExpression.BindDataflow
-
- serialVersionUID - Field in DataflowExpression.DataflowExpressionsCollector
-
- serialVersionUID - Field in DataflowExpression.TransformMany
-
- serialVersionUID - Field in DataflowExpression.TransformOne
-
- serialVersionUID - Field in DataflowExpression.WaitingThread
-
- serialVersionUID - Field in DataflowGetPropertyExpression
-
- serialVersionUID - Field in DataflowInvocationExpression
-
- serialVersionUID - Field in DataflowMessagingRunnable
-
- serialVersionUID - Field in DataflowVariable
-
- serialVersionUID - Field in DefaultActor
-
- serialVersionUID - Field in DefaultActorClosure
-
- serialVersionUID - Field in DefaultRemoteHandle
-
- serialVersionUID - Field in DynamicDispatchActor
-
- serialVersionUID - Field in EnhancedRWLock
-
- serialVersionUID - Field in EnhancedSemaphore
-
- serialVersionUID - Field in HostIdMsg
-
- serialVersionUID - Field in InternalActor
-
- serialVersionUID - Field in LocalHandle
-
- serialVersionUID - Field in LRUProtectionStorage
-
- serialVersionUID - Field in MessageStream
-
- serialVersionUID - Field in MessageStream.RemoteMessageStream
-
- serialVersionUID - Field in MessageStream.ResultWaiter
-
- serialVersionUID - Field in MessageStream.SendTo
-
- serialVersionUID - Field in MessagingRunnable
-
- serialVersionUID - Field in ReactiveActor
-
- serialVersionUID - Field in ReactorMessagingRunnable
-
- serialVersionUID - Field in RemoteActor
-
- serialVersionUID - Field in RemoteActor.MyRemoteHandle
-
- serialVersionUID - Field in RemoteActor.StopActorMsg
-
- serialVersionUID - Field in RemoteActor.TerminateActorMsg
-
- serialVersionUID - Field in RemoteDataflowExpression
-
- serialVersionUID - Field in RemoteDataflowVariable
-
- serialVersionUID - Field in RemoteHandle
-
- serialVersionUID - Field in ReplyingMessageStream
-
- serialVersionUID - Field in ResizeableCountDownLatch.Sync
-
- serialVersionUID - Field in RunnableBackedBlockingActor
-
- serialVersionUID - Field in SelectCallback
-
- serialVersionUID - Field in SequentialProcessingActor
-
- serialVersionUID - Field in SerialHandle.RemoteSerialHandle.ReleaseHandle
-
- serialVersionUID - Field in SerialMsg
-
- serialVersionUID - Field in StaticDispatchActor
-
- serialVersionUID - Field in SumClosure
-
- serialVersionUID - Field in WithSerialId
-
- set(int, T) - Method in ParallelArray
-
Sets the element of the array at the given index to the given value.
- set(int, T) - Method in ParallelArray.AsList
-
- set(T) - Method in ParallelArray.ListIter
-
- set(int, double) - Method in ParallelDoubleArray
-
Sets the element of the array at the given index to the given value.
- set(int, Double) - Method in ParallelDoubleArray.AsList
-
- set(Double) - Method in ParallelDoubleArray.ListIter
-
- set(int, long) - Method in ParallelLongArray
-
Sets the element of the array at the given index to the given value.
- set(int, Long) - Method in ParallelLongArray.AsList
-
- set(Long) - Method in ParallelLongArray.ListIter
-
- setAction(Runnable) - Method in RunnableBackedBlockingActor
-
- setConcurrencyActive(boolean) - Method in TransparentParallel
-
Turns concurrency on and off as needed
- setDelegate(Object) - Method in BinaryChoiceClosure
-
- setDelegate(Object) - Method in ChainWithClosure
-
- setDelegate(Object) - Method in ChoiceClosure
-
- setDelegate(Object) - Method in SeparationClosure
-
- setGuard(int, boolean) - Method in DataflowSelector
-
Used to enable/disable individual input channels from next selections
- setGuards(List<Boolean>) - Method in DataflowSelector
-
Used to enable/disable individual input channels from next selections
- setHost(RemoteHost) - Method in RemoteConnection
-
- setLimit(int) - Method in ParallelArray
-
Ensures that the underlying array can be accessed up to the
given upper bound, reallocating and copying the underlying
array to expand if necessary.
- setLimit(int) - Method in ParallelDoubleArray
-
Ensures that the underlying array can be accessed up to the
given upper bound, reallocating and copying the underlying
array to expand if necessary.
- setLimit(int) - Method in ParallelLongArray
-
Ensures that the underlying array can be accessed up to the
given upper bound, reallocating and copying the underlying
array to expand if necessary.
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedIntKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedIntKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedIntKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedIntKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedIntKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedSoftKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedSoftKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedSoftKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedSoftKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedSoftKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedStrongKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedStrongKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedStrongKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedStrongKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedStrongKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedWeakKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedWeakKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedWeakKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedWeakKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.LinkedWeakKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.Node
-
Records the linkage to be returned by the next call to getLinkage.
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalIntKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalIntKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalIntKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalIntKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalIntKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalSoftKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalSoftKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalSoftKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalSoftKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalSoftKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalStrongKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalStrongKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalStrongKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalStrongKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalStrongKeyWeakValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalWeakKeyIntValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalWeakKeySelfValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalWeakKeySoftValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalWeakKeyStrongValueNode
-
- setLinkage(Node) - Method in CustomConcurrentHashMap.TerminalWeakKeyWeakValueNode
-
- setMetaClass(MetaClass) - Method in DataflowExpression
-
- setParallelGroup(PGroup) - Method in AbstractLoopingActor
-
- setParallelGroup(PGroup) - Method in Actor
-
Sets the parallel group.
- setParallelGroup(PGroup) - Method in SequentialProcessingActor
-
Sets the actor's group.
- setPGroup(PGroup) - Method in AgentCore
-
Sets an actor group to use for task scheduling
- setPoolFactory(PoolFactory) - Method in GParsConfig
-
- setProperty(String, Object) - Method in DataflowExpression
-
- setProperty(String, Object) - Method in Dataflows
-
Binds the value to the DataflowVariable that is associated with the property "name".
- setProperty(String, Object) - Method in ForwardingDelegate
-
- setProperty(String, Object) - Method in RunnableBackedBlockingActor.RunnableBackedPooledActorDelegate
-
- setRawResult(Void) - Method in PAS.FJScan
-
- setResolveStrategy(int) - Method in BinaryChoiceClosure
-
- setResolveStrategy(int) - Method in ChainWithClosure
-
- setResolveStrategy(int) - Method in ChoiceClosure
-
- setResolveStrategy(int) - Method in SeparationClosure
-
- setSender(MessageStream) - Method in ReplyingMessageStream
-
- setTimeout(long) - Method in AbstractLoopingActor
-
- setTimerFactory(TimerFactory) - Method in GParsConfig
-
- setValue(Object) - Method in CustomConcurrentHashMap.IntKeyIntValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.IntKeySelfValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.IntKeySoftValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.IntKeyStrongValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.IntKeyWeakValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.Node
-
Nodes the value to be returned by the next call to getValue.
- setValue(Object) - Method in CustomConcurrentHashMap.SoftKeyIntValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.SoftKeySelfValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.SoftKeySoftValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.SoftKeyStrongValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.SoftKeyWeakValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.StrongKeyIntValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.StrongKeySelfValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.StrongKeySoftValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.StrongKeyStrongValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.StrongKeyWeakValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.WeakKeyIntValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.WeakKeySelfValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.WeakKeySoftValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.WeakKeyStrongValueNode
-
- setValue(Object) - Method in CustomConcurrentHashMap.WeakKeyWeakValueNode
-
- setValue(V) - Method in CustomConcurrentHashMap.WriteThroughEntry
-
- shallHandle(Closure<T>, Throwable) - Method in PGroup
-
- shallHandle(Closure<V>, Throwable) - Method in ThenMessagingRunnable
-
- SHOULD_NOT_REACH_HERE - Field in SequentialProcessingActor
-
- shouldBeMultiThreaded(Map<String, Object>) - Method in DataflowProcessor
-
- shouldReportTimeout() - Method in DataflowStreamReadAdapter
-
- shouldThrowTimeout() - Method in DataflowVariable
-
- shouldThrowTimeout() - Method in SyncDataflowVariable
-
- shutdown() - Method in DefaultPool
-
Gently stops the pool
- shutdown() - Method in FJPool
-
Gently stops the pool
- shutdown() - Method in GeneralTimer
-
- shutdown() - Method in GParsConfig
-
- shutdown() - Method in GParsExecutorsPool
-
- shutdown() - Method in GParsPool
-
- shutdown() - Method in PGroup
-
Gently stops the pool
- shutdown() - Method in Pool
-
Gently stops the pool
- shutdown() - Method in Scheduler
-
- SHUTDOWN_TIMEOUT - Field in DefaultPool
-
- shutdownFlag - Field in GracefulShutdownListener
-
- shutdownFlag - Field in GracefulShutdownMonitor
-
Indicates whether shutdown has been initialized
- shutdownNetwork() - Method in GracefulShutdownMonitor
-
Initializes the shutdown process.
- silentStart() - Method in AbstractLoopingActor
-
Starts the Actor without sending the START_MESSAGE message to speed the start-up.
- silentStart() - Method in Actor
-
Starts the Actor without sending the START_MESSAGE message to speed the start-up.
- silentStart() - Method in DefaultActor
-
Not supported by DefaultActor
- silentStart() - Method in RemoteActor
-
- silentStart() - Method in SequentialProcessingActor
-
- size() - Method in AbstractParallelAnyArray
-
Returns the number of elements selected using bound or
filter restrictions.
- size() - Method in AbstractPAWrapper
-
Size of the collection
- size() - Method in ChannelInputList
-
- size() - Method in ChannelOutputList
-
- size() - Method in CustomConcurrentHashMap
-
Returns the number of key-value mappings in this map.
- size() - Method in CustomConcurrentHashMap.EntrySet
-
- size() - Method in CustomConcurrentHashMap.KeySet
-
Returns the number of elements in this set (its cardinality).
- size() - Method in CustomConcurrentHashMap.KeySetView
-
- size() - Method in CustomConcurrentHashMap.Values
-
- size() - Method in ParallelArray
-
Returns the effective size of the underlying array.
- size() - Method in ParallelArray.AsList
-
- size() - Method in ParallelArray.SummaryStatistics
-
Returns the number of elements
- size() - Method in ParallelDoubleArray
-
Returns the effective size of the underlying array.
- size() - Method in ParallelDoubleArray.AsList
-
- size() - Method in ParallelDoubleArray.SummaryStatistics
-
Returns the number of elements
- size() - Method in ParallelLongArray
-
Returns the effective size of the underlying array.
- size() - Method in ParallelLongArray.AsList
-
- size() - Method in ParallelLongArray.SummaryStatistics
-
Returns the number of elements
- size - Field in PAS.FJDStats
-
- size - Field in PAS.FJLStats
-
- size - Field in PAS.FJOStats
-
- SLEEP_INTERVAL - Field in Scheduler.WatchdogThread
-
- socket - Field in BroadcastDiscovery
-
- SOFT - Field in CustomConcurrentHashMap
-
The strength of soft references
- soft - Enum Constant in CustomConcurrentHashMap.Strength
-
- sort() - Method in AbstractParallelAnyArray.DUPap
-
- sort() - Method in AbstractParallelAnyArray.LUPap
-
- sort() - Method in AbstractParallelAnyArray.OUPap
-
- sort(Closure) - Method in AbstractPAWrapper
-
Returns a sorted parallel collection
If the supplied closure takes two arguments it is used directly as a comparator.
- sort() - Method in ParallelArray
-
Sorts the array, assuming all elements are Comparable.
- sort() - Method in ParallelArrayWithBounds
-
Sorts the elements, assuming all elements are
Comparable.
- sort() - Method in ParallelDoubleArray
-
Sorts the array, assuming all elements are Comparable.
- sort() - Method in ParallelDoubleArrayWithBounds
-
Sorts the elements, assuming all elements are
Comparable.
- sort() - Method in ParallelLongArray
-
Sorts the array, assuming all elements are Comparable.
- sort() - Method in ParallelLongArrayWithBounds
-
Sorts the elements, assuming all elements are
Comparable.
- source - Field in ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
-
- speculate(Closure) - Method in GParsExecutorsPool
-
Runs the supplied closures asynchronously and in parallel, returning the first result obtained and cancelling the other (slower) calculations.
- speculate(Closure) - Method in GParsPool
-
Runs the supplied closures asynchronously and in parallel, returning the first result obtained and cancelling the other (slower) calculations.
- split(PGroup, Map<String, Object>, List<DataflowWriteChannel<T>>) - Method in DataflowExpression
-
- split(PGroup, Map<String, Object>, List<DataflowWriteChannel<T>>) - Method in DataflowQueue
-
- split(PGroup, Map<String, Object>, List<DataflowWriteChannel<T>>) - Method in DataflowReadChannel
-
Makes the output of the current channel to be an input for the specified channels
- split(PGroup, Map<String, Object>, List<DataflowWriteChannel<T>>) - Method in DataflowStreamReadAdapter
-
- split(Map<String, Object>, List<DataflowWriteChannel<V>>) - Method in Pipeline
-
Makes the output of the pipeline to be an input for the specified channels
- split(Closure) - Method in TransparentParallel
-
- splitParallel(Object, Object) - 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.
- splitter(DataflowReadChannel, List<DataflowWriteChannel>, int) - Method in Dataflow
-
Creates a splitter copying its single input channel into all of its output channels.
- splitter(DataflowReadChannel, List<DataflowWriteChannel>, int) - Method in PGroup
-
Creates a splitter copying its single input channel into all of its output channels.
- spreadHash(int) - Method in CustomConcurrentHashMap
-
Applies a supplemental hash function to a given hashCode, which
defends against poor quality hash functions.
- start() - Method in AbstractLoopingActor
-
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
- start() - Method in Actor
-
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
- start() - Method in BroadcastDiscovery
-
- start() - Method in DataflowExpression.DataflowExpressionsCollector
-
- start() - Method in DataflowProcessor
-
Starts a processor using the specified parallel group
- start() - Method in DefaultActor
-
Starts the Actor and sends it the START_MESSAGE to run any afterStart handlers.
- start() - Method in KanbanFlow
-
Start all
KanbanLinks of this flow with as many trays per link as what is considered optimal
- start() - Method in KanbanLink
-
Construct and start the operators if not already started.
- START_MESSAGE - Field in Actor
-
- start() - Method in NettyClient
-
Connects the client to server
Note: method does not block
- start() - Method in NettyServer
-
Starts the server.
- start() - Method in RemoteActor
-
- start() - Method in SequentialProcessingActor
-
Starts the Actor.
- started - Field in DefaultActor
-
- startEmpty() - Method in KanbanFlow
-
Start all
KanbanLinks of this flow without any trays
- startNewThread() - Method in Scheduler
-
- startReclamation() - Method in CustomConcurrentHashMap
-
- startTask(List<Object>) - Method in DataflowOperatorActor
-
- startTask(int, Object) - Method in DataflowSelectorActor
-
- startTask(List<Object>) - Method in ForkingDataflowOperatorActor
-
- startTask(int, Object) - Method in ForkingDataflowSelectorActor
-
- state - Field in DataflowExpression
-
Holds the current state of the variable
- STATE_OBJECT - Field in DataflowProcessor
-
- state - Field in RemoteAgentMock
-
- stateChanged() - Method in GracefulShutdownMonitor
-
Invoked whenever a processor changes state
- stateChanged() - Method in OperatorStateMonitor
-
Invoked whenever a processor changes state
- stateObject - Field in DataflowProcessor
-
May hold custom state provided at construction time and read within the body
- stateUpdater - Field in DataflowExpression
-
Updater for the state field
- StaticDispatchActor - Class in groovyx.gpars.actor
Offers a statically dispatched and thus slightly faster alternative to the DynamicDispatchActor class.
- StaticDispatchActor() - Constructor in StaticDispatchActor
-
Creates a new instance
- staticMessageHandler(Closure) - Method in Actors
-
Creates an instance of StaticDispatchActor.
- staticMessageHandler(Closure) - Method in PGroup
-
Creates an instance of StaticDispatchActor.
- stop() - Method in AbstractLoopingActor
-
- stop() - Method in Actor
-
Send message to stop to the Actor.
- STOP - Field in ActorException
-
- stop() - Method in BroadcastDiscovery
-
- stop() - Method in KanbanFlow
-
- stop() - Method in KanbanLink
-
Immediately terminating all producers and consumers
- STOP_MESSAGE - Field in Actor
-
- stop() - Method in NettyClient
-
Closes connection to server
Note: method does not block
- stop() - Method in NettyServer
-
Stops the server.
- stop() - Method in RemoteActor
-
- 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
-
- StopGently - Class in groovyx.gpars.dataflow.operator
A message to stop operators' actors once they handle the next round of messages.
- StopGently() - Constructor in StopGently
-
- stopped - Field in BroadcastDiscovery
-
- stoppedFlag - Field in AbstractLoopingActor
-
- stoppingGently - Field in DataflowProcessorActor
-
- store(Object) - Method in AsyncMessagingCore
-
Adds the message to the agent\s message queue
- storeNode(CustomConcurrentHashMap.Node, int, CustomConcurrentHashMap.Node) - Method in CustomConcurrentHashMap
-
- storeSegment(CustomConcurrentHashMap.Segment, int, CustomConcurrentHashMap.Segment) - Method in CustomConcurrentHashMap
-
- stream - Field in DataflowStreamWriteAdapter.BindDataflowStream
-
- stream - Field in RemoteDataflowBroadcastReplyMsg
-
- StreamCore - Class in groovyx.gpars.dataflow.stream
Represents a common base for publish-subscribe deterministic channels.
- StreamCore(DataflowVariable<T>, Collection<MessageStream>, Collection<DataflowChannelListener<T>>) - Constructor in StreamCore
-
- Strength(String) - Method in CustomConcurrentHashMap.Strength
-
- STRONG - Field in CustomConcurrentHashMap
-
The strength of ordinary references
- strong - Enum Constant in CustomConcurrentHashMap.Strength
-
- submit(Object) - Method in InternalActor
-
A DataflowVariable is passed to the actor, which will bind it once the result is known.
- submitAndWait(Object) - Method in InternalActor
-
A DataflowVariable is passed to the actor, which will bind it once the result is known.
- subscribe(DataflowExpressionsCollector) - Method in DataflowComplexExpression
-
Subscribes the listener to all the arguments
- subscribe(DataflowExpression.DataflowExpressionsCollector) - Method in DataflowExpression
-
- subscribe(Object) - Method in DataflowExpression.DataflowExpressionsCollector
-
- 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
- subscribers - Field in SerialHandle
-
remote hosts subscribed to this objects
- sum() - Method in AbstractPAWrapper
-
Summarizes all elements of the collection in parallel using the "plus()" operator of the elements
- sum() - Method in ParallelArrayWithDoubleMapping
-
Returns the sum of elements.
- sum() - Method in ParallelArrayWithLongMapping
-
Returns the sum of elements.
- sum() - Method in ParallelDoubleArray
-
Returns the sum of elements.
- sum() - Method in ParallelDoubleArray.SummaryStatistics
-
Returns the sum of all elements
- sum() - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns the sum of elements.
- sum() - Method in ParallelDoubleArrayWithLongMapping
-
Returns the sum of elements.
- sum() - Method in ParallelLongArray
-
Returns the sum of elements.
- sum() - Method in ParallelLongArray.SummaryStatistics
-
Returns the sum of all elements
- sum() - Method in ParallelLongArrayWithDoubleMapping
-
Returns the sum of elements.
- sum() - Method in ParallelLongArrayWithLongMapping
-
Returns the sum of elements.
- sum - Field in PAS.FJDStats
-
- sum - Field in PAS.FJLStats
-
- sum() - Method in TransparentParallel
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJDCumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJDCumulatePlusOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJDPrecumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJDPrecumulatePlusOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJLCumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJLCumulatePlusOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJLPrecumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJLPrecumulatePlusOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJOCumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJOPrecumulateOp
-
- sumAndCumulateLeaf(int, int, FJScan) - Method in PAS.FJScanOp
-
- SumClosure - Class in groovyx.gpars.pa
Represents a {a, b -> a + b} closure
- SumClosure() - Constructor in SumClosure
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJDCumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJDCumulatePlusOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJDPrecumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJDPrecumulatePlusOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJLCumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJLCumulatePlusOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJLPrecumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJLPrecumulatePlusOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJOCumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJOPrecumulateOp
-
- sumLeaf(int, int, FJScan) - Method in PAS.FJScanOp
-
- summary() - Method in ParallelArray
-
Returns summary statistics, assuming that all elements are
Comparables.
- summary() - Method in ParallelArrayWithDoubleMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelArrayWithLongMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelArrayWithMapping
-
Returns summary statistics, assuming that all elements are
Comparables.
- summary() - Method in ParallelDoubleArray
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelDoubleArrayWithLongMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelDoubleArrayWithMapping
-
Returns summary statistics, assuming that all elements are
Comparables.
- summary() - Method in ParallelLongArray
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelLongArrayWithDoubleMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelLongArrayWithLongMapping
-
Returns summary statistics, using natural comparator.
- summary() - Method in ParallelLongArrayWithMapping
-
Returns summary statistics, assuming that all elements are
Comparables.
- SUMMED - Field in PAS.FJScan
-
- 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.
- swap(LinkedList<Object>) - Method in DefaultMessageQueue
-
- sweepNextMessage() - Method in AbstractLoopingActor
-
Removes the head of the message queue
- sweepNextMessage() - Method in Actor
-
Removes the head of the message queue
- sweepNextMessage() - Method in AsyncMessagingCore
-
Removes the head of the message queue
- sweepNextMessage() - Method in RemoteActor
-
- sweepNextMessage() - Method in SequentialProcessingActor
-
Removes the head of the message queue
- sweepQueue() - Method in Actor
-
Clears the message queue returning all the messages it held.
- sync - Field in ResizeableCountDownLatch
-
- SyncDataflowBroadcast - Class in groovyx.gpars.dataflow
Offers a synchronous deterministic one-to-many and many-to-many messaging alternative to SyncDataflowQueue.
- SyncDataflowBroadcast() - Constructor in SyncDataflowBroadcast
-
Creates a new instance
- SyncDataflowQueue - Class in groovyx.gpars.dataflow
Represents a thread-safe synchronous data flow stream.
- SyncDataflowQueue() - Constructor in SyncDataflowQueue
-
- SyncDataflowStream - Class in groovyx.gpars.dataflow.stream
Represents a synchronous deterministic dataflow channel.
- SyncDataflowStream(int, Collection<MessageStream>, Collection<DataflowChannelListener<T>>) - Constructor in SyncDataflowStream
-
Creates an empty stream with the specified listeners set
- SyncDataflowStreamReadAdapter - Class in groovyx.gpars.dataflow
Provides a special implementation of DataflowStreamReadAdapter, which cooperates with SyncDataflowBroadcast subscription and un-subscription mechanism.
- SyncDataflowStreamReadAdapter(StreamCore<T>) - Constructor in SyncDataflowStreamReadAdapter
-
Creates a new adapter
- SyncDataflowVariable - Class in groovyx.gpars.dataflow
A synchronous variant of DataflowVariable, which blocks the writer as well as the readers.
- SyncDataflowVariable(int) - Constructor in SyncDataflowVariable
-
Creates a new variable blocking the specified number of readers.
- table - Field in CustomConcurrentHashMap.Segment
-
- table - Field in PAS.FJDUniquifier
-
- table - Field in PAS.FJLUniquifier
-
- table - Field in PAS.FJOUniquifier
-
- tableBase - Field in CustomConcurrentHashMap
-
- tableShift - Field in CustomConcurrentHashMap
-
- tableSizeFor(int) - Method in PAS.UniquifierTable
-
Returns a good size for table
- take() - Method in KanbanTray
-
Take the product from the tray and release the tray.
- takeMessage(long, TimeUnit) - Method in SequentialProcessingActor
-
Takes a message from the queues.
- tap(PGroup, Map<String, Object>, DataflowWriteChannel<T>) - Method in DataflowExpression
-
- tap(PGroup, Map<String, Object>, DataflowWriteChannel<T>) - Method in DataflowQueue
-
- tap(PGroup, Map<String, Object>, DataflowWriteChannel<T>) - Method in DataflowReadChannel
-
Taps into the pipeline.
- tap(PGroup, Map<String, Object>, DataflowWriteChannel<T>) - Method in DataflowStreamReadAdapter
-
- tap(Map<String, Object>, DataflowWriteChannel<V>) - Method in Pipeline
-
Taps into the pipeline at the current position, sending all data that pass through the pipeline also to the channel specified.
- tap(PGroup, DataflowWriteChannel<T>) - Method in SyncDataflowQueue
-
- tap(PGroup, DataflowWriteChannel<T>) - Method in SyncDataflowStreamReadAdapter
-
- tap(PGroup, DataflowWriteChannel<T>) - Method in SyncDataflowVariable
-
- target - Field in CallClosure
-
- target - Field in PAS.FJDIndexOf
-
- target - Field in PAS.FJLIndexOf
-
- target - Field in PAS.FJOIndexOf
-
- task(Runnable) - Method in Dataflow
-
Creates a new task assigned to a thread from the current parallel group.
- task(Runnable) - Method in PGroup
-
Creates a new task assigned to a thread from the current parallel group.
- terminate() - Method in AbstractLoopingActor
-
- terminate() - Method in Actor
-
Terminates the Actor.
- TERMINATE - Field in ActorException
-
- terminate() - Method in DataflowProcessor
-
Stops the processor immediately, potentially loosing unhandled messages
- TERMINATE_MESSAGE - Field in Actor
-
- terminate() - Method in RemoteActor
-
- TERMINATE - Field in Scheduler
-
- terminate() - Method in SequentialProcessingActor
-
Terminate the Actor.
- terminateAfterNextRun() - Method in DataflowProcessor
-
Gently stops the processor after the next set of messages is handled.
- terminatedFlag - Field in AbstractLoopingActor
-
- terminateProcessor() - Method in GracefulShutdownListener
-
Used by the monitor to terminate the underlying operator/selector
- terminating - Field in Scheduler
-
- terminatingFlag - Field in AbstractLoopingActor
-
- termination - Field in PoisonTrackCounter
-
- TestUtilities - Class in groovyx.gpars.csp.util
- TestUtilities() - Constructor in TestUtilities
-
- THE_ACTOR_HAS_BEEN_STOPPED - Field in BlockingActor
-
- THE_ACTOR_HAS_NOT_BEEN_STARTED - Field in BlockingActor
-
- THE_CODE_FOR_AN_ATOMIC_BLOCK_MUST_NOT_BE_NULL - Field in GParsStm
-
- then(PGroup, Closure<V>) - Method in DataflowExpression
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>) - Method in DataflowQueue
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>) - Method in DataflowReadChannel
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>) - Method in DataflowStreamReadAdapter
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>, Closure<V>) - Method in DataflowVariable
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>, Closure<V>) - Method in LazyDataflowVariable
-
Schedule closure to be executed after data becomes available.
- then(PGroup, Closure<V>, Closure<V>) - Method in Promise
-
Schedule closure to be executed after data becomes available.
- thenForkAndJoin(PGroup, Closure<? extends Object>) - Method in DataflowExpression
-
Schedule a set of closures to be executed after data became available on the current promise.
- thenForkAndJoin(PGroup, Closure<? extends Object>) - Method in Promise
-
Schedule a set of closures to be executed after data became available on the current promise.
- ThenMessagingRunnable - Class in groovyx.gpars.dataflow.impl
@author Vaclav Pech
- ThenMessagingRunnable(DataflowVariable<V>, Closure<V>, Closure<V>) - Constructor in ThenMessagingRunnable
-
- thread - Field in DataflowExpression.WaitingThread
-
- threadAssigned() - Method in AsyncMessagingCore
-
Informs about the thread being removed from the task
- threadBoundActor() - Method in Actor
-
Retrieves the actor registered with the current thread
- threadContext - Field in SerialContext
-
- threadCount - Field in DefaultPool
-
Unique counter for Actors' threads
- threadCount - Field in 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 in ThreadLocalPools
-
- threadPool - Field in AsyncMessagingCore
-
- threadPool - Field in ForkingDataflowOperatorActor
-
- threadPool - Field in ForkingDataflowSelectorActor
-
- threadPool - Field in GParsExecutorsPoolEnhancer
-
Holds the internal ExecutorService instance wrapped into a DefaultPool
- threadPool - Field in ParallelEnhancer
-
Holds the internal ForkJoinPool instance wrapped into a FJPool
- threadPool - Field in PGroup
-
Stores the group actors' thread pool
- threadUnassigned() - Method in AsyncMessagingCore
-
Informs about a new thread being assigned to process the next message
- threshold - Field in AbstractParallelAnyArray
-
- threshold - Field in PAS.FJRemoveAll
-
- threshold - Field in PAS.FJRemoveAllDriver
-
- threshold - Field in PAS.FJScanOp
-
- threshold - Field in PAS.FJSelectAll
-
- throwIfNeeded(ActorMessage) - Method in SequentialProcessingActor
-
Checks the supplied message and throws either STOP or TERMINATE, if the message is a Stop or Terminate message respectively.
- TimedMultiplex - Class in groovyx.gpars.csp.util
- TimedMultiplex() - Constructor in TimedMultiplex
-
- TIMEOUT - Field in Actor
-
- TIMEOUT_MESSAGE - Field in Actor
-
- TIMEOUT - Field in Select
-
A value that gets bound to timeout channels through the Select.createTimeout() method
- timeout - Property in TimedMultiplex
-
- timeoutCounter - Field in AbstractLoopingActor
-
- Timer - Class in groovyx.gpars.scheduler
A shared timer to run timeouts for various GPars services
- timer - Field in Actor
-
Timer holding timeouts for react methods
- timer - Field in GParsExecutorsPoolUtil
-
Allows timeouts for async operations
- timer - Field in GParsPoolUtil
-
Allows timeouts for async operations
- timer - Field in Timer
-
The actual scheduler instance
- TimerFactory - Interface in groovyx.gpars.util
Allows customized timers to be created in managed environments such as GAE
- timerFactory - Field in GParsConfig
-
- timerFactoryFlag - Field in GParsConfig
-
- timers - Field in GParsConfig
-
- to(ProcessingNode) - Method in KanbanLink
-
Second part of the sequence link producer to consumer
.
- to - Field in MessageStream.SendTo
-
- toArray() - Method in ChannelInputList
-
- toArray() - Method in ChannelOutputList
-
- toArray(V) - Method in ParallelArray.AsList
-
- toConsole - Property in GConsole
-
- toString() - Method in ActorMessage
-
- toString() - Method in ActorReplyException
-
- toString() - Method in AsyncException
-
- toString() - Method in DataflowBroadcast
-
- toString() - Method in DataflowExpression
-
- toString() - Method in DataflowQueue
-
- toString() - Method in DataflowStream
-
- toString() - Method in DataflowStreamReadAdapter
-
- toString() - Method in DataflowStreamWriteAdapter
-
- toString() - Method in KanbanTray
-
- toString() - Method in ParallelArray
-
Equivalent to asList().toString()
.
- toString() - Method in ParallelDoubleArray
-
Equivalent to asList().toString()
.
- toString() - Method in ParallelLongArray
-
Equivalent to asList().toString()
.
- toString() - Method in PAS.FJDStats
-
- toString() - Method in PAS.FJLStats
-
- toString() - Method in PAS.FJOStats
-
- toString() - Method in RemoteDataflowBroadcast
-
- toString() - Method in ResizeableCountDownLatch
-
Returns a string identifying this latch, as well as its state.
- toString() - Method in SelectResult
-
- toString() - Method in SyncDataflowBroadcast
-
- toString() - Method in SyncDataflowQueue
-
- toString() - Method in SyncDataflowStream
-
- touch() - Method in DataflowVariable
-
- touch() - Method in LazyDataflowVariable
-
- touch(Object, Object) - Method in 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 NullProtectionStorage
-
Does nothing
- touch() - Method in Promise
-
May be used by lazy implementations to warm up
- transactionFactory - Field in GParsStm
-
Gives access to multiverse TxnFactoryBuilder to allow customized creation of atomic blocks
- transferQueues() - Method in SequentialProcessingActor
-
Transfers messages from the input queue into the output queue, reverting the order of the elements.
- transform(Expression) - Method in ActiveObjectASTTransformation.MyClassCodeExpressionTransformer
-
- transform(Object, Closure) - Method in DataflowExpression
-
Transforms values bound eventually to dataflow variables using the supplied closure.
- transitionToCumulate() - Method in PAS.FJScan
-
Returns true if can CAS CUMULATE bit true
- TransparentParallel - Class in groovyx.gpars
Enhances objects by being mixed-in either within a GParsPool.withPool() block or after enhancement by
the ParallelEnhancer through the makeConcurrent() method.
- TransparentParallel() - Constructor in TransparentParallel
-
- tryAcquireShared(int) - Method in ResizeableCountDownLatch.Sync
-
- tryReleaseShared(int) - Method in ResizeableCountDownLatch.Sync
-
- w - Field in PAS.FJDCMerger
-
- w - Field in PAS.FJDCSorter
-
- w - Field in PAS.FJDMerger
-
- w - Field in PAS.FJDSorter
-
- w - Field in PAS.FJLCMerger
-
- w - Field in PAS.FJLCSorter
-
- w - Field in PAS.FJLMerger
-
- w - Field in PAS.FJLSorter
-
- w - Field in PAS.FJOCMerger
-
- w - Field in PAS.FJOCSorter
-
- w - Field in PAS.FJOMerger
-
- w - Field in PAS.FJOSorter
-
- waiting - Field in DataflowExpression
-
Points to the head of the chain of requests waiting for a value to be bound
- waitingThread - Field in SequentialProcessingActor
-
- waitingUpdater - Field in DataflowExpression
-
Updater for the waiting field
- WEAK - Field in CustomConcurrentHashMap
-
The strength of weak references
- weak - Enum Constant in CustomConcurrentHashMap.Strength
-
- when(def, def) - Method in DDAHelper
-
- when(Closure) - Method in DynamicDispatchActor
-
- whenAllBound(Promise, Promise, Promise, Promise, Closure<T>, Closure<T>) - Method in Dataflow
-
Without blocking the thread waits for all the promises to get bound and then passes them to the supplied closure.
- whenAllBound(List<Promise>, int, List<Object>, DataflowVariable<T>, Closure<T>, Closure<T>) - Method in PGroup
-
Waits for the promise identified by the index to be bound and then passes on to the next promise in the list
- whenBound(MessageStream) - Method in DataflowExpression
-
Send the bound data to provided stream when it becomes available
- whenBound(MessageStream) - Method in DataflowQueue
-
Send the next bound piece of data to the provided stream when it becomes available.
- whenBound(MessageStream) - Method in DataflowReadChannel
-
Send the bound data to provided stream when it becomes available
- whenBound(MessageStream) - Method in DataflowStreamReadAdapter
-
- whenBound(MessageStream) - Method in Promise
-
Send the bound data to provided stream when it becomes available
- whenBound(MessageStream) - Method in SyncDataflowStreamReadAdapter
-
- wheneverBound(MessageStream) - Method in DataflowExpression
-
Send all pieces of data bound in the future to the provided stream when it becomes available.
- wheneverBound(MessageStream) - Method in DataflowQueue
-
Send all pieces of data bound in the future to the provided stream when it becomes available.
- wheneverBound(MessageStream) - Method in DataflowStreamReadAdapter
-
- wheneverBound(MessageStream) - Method in SelectableChannel
-
Send all pieces of data bound in the future to the provided stream when it becomes available.
- wheneverBound(MessageStream) - Method in StreamCore
-
- wheneverBound(MessageStream) - Method in SyncDataflowStreamReadAdapter
-
- wheneverBoundListeners - Field in DataflowQueue
-
A collection of listeners who need to be informed each time the stream is bound to a value
- wheneverBoundListeners - Field in StreamCore
-
A collection of listeners who need to be informed each time the stream is bound to a value
- wheneverBoundSet - Field in SyncDataflowStreamReadAdapter
-
- wiseMan - Field in FilterClosure
-
- withBounds(int, int) - Method in AbstractParallelAnyArray.DUPap
-
- withBounds(int, int) - Method in AbstractParallelAnyArray.LUPap
-
- withBounds(int, int) - Method in AbstractParallelAnyArray.OUPap
-
- withBounds(int, int) - Method in ParallelArray
-
Returns an operation prefix that causes a method to
operate only on the elements of the array between
firstIndex (inclusive) and upperBound (exclusive).
- withBounds(int, int) - Method in ParallelArrayWithBounds
-
Returns an operation prefix that causes a method to operate
only on the elements of the array between firstIndex
(inclusive) and upperBound (exclusive).
- withBounds(int, int) - Method in ParallelDoubleArray
-
Returns an operation prefix that causes a method to
operate only on the elements of the array between
firstIndex (inclusive) and upperBound (exclusive).
- withBounds(int, int) - Method in ParallelDoubleArrayWithBounds
-
Returns an operation prefix that causes a method to operate
only on the elements of the array between firstIndex
(inclusive) and upperBound (exclusive).
- withBounds(int, int) - Method in ParallelLongArray
-
Returns an operation prefix that causes a method to
operate only on the elements of the array between
firstIndex (inclusive) and upperBound (exclusive).
- withBounds(int, int) - Method in ParallelLongArrayWithBounds
-
Returns an operation prefix that causes a method to operate
only on the elements of the array between firstIndex
(inclusive) and upperBound (exclusive).
- 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.
- withFilter(DoublePredicate) - Method in AbstractParallelAnyArray.DFPap
-
- withFilter(DoublePredicate) - Method in AbstractParallelAnyArray.DRPap
-
- withFilter(DoublePredicate) - Method in AbstractParallelAnyArray.DUPap
-
- withFilter(LongPredicate) - Method in AbstractParallelAnyArray.LFPap
-
- withFilter(LongPredicate) - Method in AbstractParallelAnyArray.LRPap
-
- withFilter(LongPredicate) - Method in AbstractParallelAnyArray.LUPap
-
- withFilter(Predicate<? super T>) - Method in AbstractParallelAnyArray.OFPap
-
- withFilter(Predicate<? super T>) - Method in AbstractParallelAnyArray.ORPap
-
- withFilter(Predicate<? super T>) - Method in AbstractParallelAnyArray.OUPap
-
- withFilter(BinaryPredicate<? super T, ? super V>, ParallelArrayWithMapping<W, V>) - Method in ParallelArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given binary selector returns
true.
- withFilter(BinaryPredicate<? super T, ? super V>, ParallelArrayWithMapping<W, V>) - Method in ParallelArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given binary selector returns true.
- withFilter(BinaryDoublePredicate, ParallelDoubleArrayWithDoubleMapping) - Method in ParallelDoubleArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given binary selector returns
true.
- withFilter(BinaryDoublePredicate, ParallelDoubleArrayWithDoubleMapping) - Method in ParallelDoubleArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given binary selector returns true.
- withFilter(BinaryLongPredicate, ParallelLongArrayWithLongMapping) - Method in ParallelLongArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given binary selector returns
true.
- withFilter(BinaryLongPredicate, ParallelLongArrayWithLongMapping) - Method in ParallelLongArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given binary selector returns true.
- withIndexedFilter(IntAndDoublePredicate) - Method in AbstractParallelAnyArray.DFPap
-
- withIndexedFilter(IntAndDoublePredicate) - Method in AbstractParallelAnyArray.DRPap
-
- withIndexedFilter(IntAndDoublePredicate) - Method in AbstractParallelAnyArray.DUPap
-
- withIndexedFilter(IntAndLongPredicate) - Method in AbstractParallelAnyArray.LFPap
-
- withIndexedFilter(IntAndLongPredicate) - Method in AbstractParallelAnyArray.LRPap
-
- withIndexedFilter(IntAndLongPredicate) - Method in AbstractParallelAnyArray.LUPap
-
- withIndexedFilter(IntAndObjectPredicate<? super T>) - Method in AbstractParallelAnyArray.OFPap
-
- withIndexedFilter(IntAndObjectPredicate<? super T>) - Method in AbstractParallelAnyArray.ORPap
-
- withIndexedFilter(IntAndObjectPredicate<? super T>) - Method in AbstractParallelAnyArray.OUPap
-
- withIndexedFilter(IntAndObjectPredicate<? super T>) - Method in ParallelArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given indexed selector returns
true.
- withIndexedFilter(IntAndObjectPredicate<? super T>) - Method in ParallelArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given indexed selector returns true.
- withIndexedFilter(IntAndDoublePredicate) - Method in ParallelDoubleArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given indexed selector returns
true.
- withIndexedFilter(IntAndDoublePredicate) - Method in ParallelDoubleArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given indexed selector returns true.
- withIndexedFilter(IntAndLongPredicate) - Method in ParallelLongArray
-
Returns an operation prefix that causes a method to operate
only on elements for which the given indexed selector returns
true.
- withIndexedFilter(IntAndLongPredicate) - Method in ParallelLongArrayWithFilter
-
Returns an operation prefix that causes a method to operate
only on elements for which the current selector (if
present) and the given indexed selector returns true.
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DFDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DFDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DFLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DFLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DFOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DFOMPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DFPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DRDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DRDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DRLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DRLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DROCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DROMPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DRPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DUDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DUDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DULCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.DULMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DUOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DUOMPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.DUPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LFDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LFDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LFLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LFLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LFOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LFOMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LFPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LRDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LRDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LRLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LRLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LROCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LROMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LRPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LUDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.LUDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LULCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LULMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LUOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LUOMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.LUPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.OFDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.OFDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.OFLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.OFLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OFOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OFOMPap
-
- withIndexedMapping(IntAndObjectToLong<? super T>) - Method in AbstractParallelAnyArray.OFPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.ORDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.ORDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.ORLCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.ORLMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OROCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OROMPap
-
- withIndexedMapping(IntAndObjectToLong<? super T>) - Method in AbstractParallelAnyArray.ORPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.OUDCPap
-
- withIndexedMapping(IntAndDoubleToLong) - Method in AbstractParallelAnyArray.OUDMPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.OULCPap
-
- withIndexedMapping(IntAndLongToLong) - Method in AbstractParallelAnyArray.OULMPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OUOCPap
-
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OUOMPap
-
- withIndexedMapping(IntAndObjectToLong<? super T>) - Method in AbstractParallelAnyArray.OUPap
-
- withIndexedMapping(IntAndObjectToLong<? super T>) - Method in ParallelArray
-
Returns an operation prefix that causes a method to operate on
mappings of this array using the given mapper that accepts as
arguments an element's current index and value, and produces a
new value.
- withIndexedMapping(IntAndDoubleToLong) - Method in ParallelArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndLongToLong) - Method in ParallelArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in ParallelArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndDoubleToLong) - Method in ParallelDoubleArray
-
Returns an operation prefix that causes a method to operate on
mappings of this array using the given mapper that accepts as
arguments an element's current index and value, and produces a
new value.
- withIndexedMapping(IntAndDoubleToLong) - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndLongToLong) - Method in ParallelDoubleArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in ParallelDoubleArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndLongToLong) - Method in ParallelLongArray
-
Returns an operation prefix that causes a method to operate on
mappings of this array using the given mapper that accepts as
arguments an element's current index and value, and produces a
new value.
- withIndexedMapping(IntAndDoubleToLong) - Method in ParallelLongArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndLongToLong) - Method in ParallelLongArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withIndexedMapping(IntAndObjectToLong<? super U>) - Method in ParallelLongArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on mappings of this array using the given mapper that
accepts as arguments an element's current index and value
(as mapped by preceding mappings, if any), and produces a
new value.
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DFDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DFDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DFLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DFLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DFOCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DFOMPap
-
- withMapping(DoubleToLong) - Method in AbstractParallelAnyArray.DFPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DRDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DRDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DRLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DRLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DROCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DROMPap
-
- withMapping(DoubleToLong) - Method in AbstractParallelAnyArray.DRPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DUDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.DUDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DULCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.DULMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DUOCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.DUOMPap
-
- withMapping(DoubleToLong) - Method in AbstractParallelAnyArray.DUPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LFDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LFDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LFLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LFLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LFOCPap
-
- withMapping(ObjectToDouble<? super U>) - Method in AbstractParallelAnyArray.LFOMPap
-
- withMapping(LongToDouble) - Method in AbstractParallelAnyArray.LFPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LRDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LRDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LRLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LRLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LROCPap
-
- withMapping(ObjectToDouble<? super U>) - Method in AbstractParallelAnyArray.LROMPap
-
- withMapping(LongToDouble) - Method in AbstractParallelAnyArray.LRPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LUDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.LUDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LULCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.LULMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.LUOCPap
-
- withMapping(ObjectToDouble<? super U>) - Method in AbstractParallelAnyArray.LUOMPap
-
- withMapping(LongToDouble) - Method in AbstractParallelAnyArray.LUPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.OFDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.OFDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.OFLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.OFLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OFOCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OFOMPap
-
- withMapping(ObjectToLong<? super T>) - Method in AbstractParallelAnyArray.OFPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.ORDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.ORDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.ORLCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.ORLMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OROCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OROMPap
-
- withMapping(ObjectToLong<? super T>) - Method in AbstractParallelAnyArray.ORPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.OUDCPap
-
- withMapping(DoubleToObject<? extends U>) - Method in AbstractParallelAnyArray.OUDMPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.OULCPap
-
- withMapping(LongToObject<? extends U>) - Method in AbstractParallelAnyArray.OULMPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OUOCPap
-
- withMapping(ObjectToLong<? super U>) - Method in AbstractParallelAnyArray.OUOMPap
-
- withMapping(ObjectToLong<? super T>) - Method in AbstractParallelAnyArray.OUPap
-
- withMapping(ObjectAndLongToLong<? super T>, ParallelLongArrayWithLongMapping) - Method in ParallelArray
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(DoubleAndLongToLong, ParallelLongArrayWithLongMapping) - Method in ParallelArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(BinaryLongOp, ParallelLongArrayWithLongMapping) - Method in ParallelArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(ObjectAndLongToLong<? super U>, ParallelLongArrayWithLongMapping) - Method in ParallelArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(DoubleAndLongToLong, ParallelLongArrayWithLongMapping) - Method in ParallelDoubleArray
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(DoubleAndLongToLong, ParallelLongArrayWithLongMapping) - Method in ParallelDoubleArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(BinaryLongOp, ParallelLongArrayWithLongMapping) - Method in ParallelDoubleArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(ObjectAndLongToLong<? super U>, ParallelLongArrayWithLongMapping) - Method in ParallelDoubleArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(BinaryLongOp, ParallelLongArrayWithLongMapping) - Method in ParallelLongArray
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(DoubleAndLongToLong, ParallelLongArrayWithLongMapping) - Method in ParallelLongArrayWithDoubleMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(BinaryLongOp, ParallelLongArrayWithLongMapping) - Method in ParallelLongArrayWithLongMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- withMapping(ObjectAndLongToLong<? super U>, ParallelLongArrayWithLongMapping) - Method in ParallelLongArrayWithMapping
-
Returns an operation prefix that causes a method to operate
on binary mappings of this array and the other array.
- 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 groovyx.gpars.serial
Base class for objects which can be exposed to remote nodes via serialization.
- WithSerialId() - Constructor in WithSerialId
-
- 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.
- wo - Field in PAS.FJDCMerger
-
- wo - Field in PAS.FJDMerger
-
- wo - Field in PAS.FJLCMerger
-
- wo - Field in PAS.FJLMerger
-
- wo - Field in PAS.FJOCMerger
-
- wo - Field in PAS.FJOMerger
-
- workerGroup - Field in NettyClient
-
- workerGroup - Field in NettyServer
-
- write(def) - Method in ChannelOutputList
-
- write(SerialMsg) - Method in NettyRemoteConnection
-
- write(SerialMsg) - Method in RemoteConnection
-
- write(SerialMsg) - Method in SerialContext
-
- writeObject(ObjectOutputStream) - Method in CustomConcurrentHashMap
-
Saves the state of the instance to a stream (i.e., serializes it).
- writeReplace() - Method in WithSerialId
-
Replace object by handle for serialization