data:image/s3,"s3://crabby-images/02ace/02ace956f9868cf2a1a780bd2c0a517cd3a46077" alt="JAR search and dependency download from the Maven repository"
groovyx.gpars.GParsPoolUtil Maven / Gradle / Ivy
Go to download
Show more of this group Show more artifacts with this name
Show all versions of gpars Show documentation
Show all versions of gpars Show documentation
The Groovy and Java high-level concurrency library offering actors, dataflow, CSP, agents, parallel collections, fork/join and more
// GPars - Groovy Parallel Systems
//
// Copyright © 2008--2011 The original author or authors
//
// Licensed under the Apache License, Version 2.0 (the "License");
// you may not use this file except in compliance with the License.
// You may obtain a copy of the License at
//
// http://www.apache.org/licenses/LICENSE-2.0
//
// Unless required by applicable law or agreed to in writing, software
// distributed under the License is distributed on an "AS IS" BASIS,
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
// See the License for the specific language governing permissions and
// limitations under the License.
package groovyx.gpars;
import extra166y.Ops;
import extra166y.ParallelArray;
import groovy.lang.Closure;
import groovy.time.Duration;
import groovyx.gpars.memoize.LRUProtectionStorage;
import groovyx.gpars.pa.CallAsyncTask;
import groovyx.gpars.pa.CallClosure;
import groovyx.gpars.pa.ClosureMapper;
import groovyx.gpars.pa.ClosureNegationPredicate;
import groovyx.gpars.pa.ClosurePredicate;
import groovyx.gpars.pa.ClosureReducer;
import groovyx.gpars.pa.GParsPoolUtilHelper;
import groovyx.gpars.pa.PAWrapper;
import groovyx.gpars.pa.SumClosure;
import groovyx.gpars.util.PAUtils;
import jsr166y.ForkJoinPool;
import jsr166y.RecursiveTask;
import java.util.ArrayList;
import java.util.Collection;
import java.util.Collections;
import java.util.List;
import java.util.Map;
import java.util.Timer;
import java.util.TimerTask;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.Future;
import static groovyx.gpars.util.PAGroovyUtils.createCollection;
import static groovyx.gpars.util.PAUtils.buildClosureForMaps;
import static groovyx.gpars.util.PAUtils.buildClosureForMapsWithIndex;
import static groovyx.gpars.util.PAUtils.buildResultMap;
import static groovyx.gpars.util.PAUtils.createComparator;
import static groovyx.gpars.util.PAUtils.createGroupByClosure;
import static java.util.Arrays.asList;
/**
* This class forms the core of the DSL initialized by GParsPool. The static methods of GParsPoolUtil
* get attached to their first arguments (the Groovy Category mechanism) and can be then invoked as if they were part of
* the argument classes.
*
* @author Vaclav Pech
* @author Robert Fischer
* Date: Mar 10, 2010
* @see groovyx.gpars.GParsPool
*/
public class GParsPoolUtil {
/**
* Allows timeouts for async operations
*/
private static final Timer timer = new Timer("GParsTimeoutTimer", true);
private static ForkJoinPool retrievePool() {
final ForkJoinPool pool = (ForkJoinPool) GParsPool.retrieveCurrentPool();
if (pool == null) throw new IllegalStateException("No ForkJoinPool available for the current thread");
return pool;
}
/**
* schedules the supplied closure for processing in the underlying thread pool.
*/
public static Future callParallel(final Closure task) {
final ForkJoinPool pool = (ForkJoinPool) GParsPool.retrieveCurrentPool();
if (pool == null) throw new IllegalStateException("No ForkJoinPool available for the current thread.");
return pool.submit(new CallAsyncTask(task));
}
/**
* Calls a closure in a separate thread supplying the given arguments, returning a future for the potential return value.
*/
public static Future callAsync(final Closure cl, final Object... args) {
return GParsPoolUtilHelper.callAsync(cl, args);
}
/**
* Calls a closure in a separate thread supplying the given arguments, returning a future for the potential return value.
* Also allows the asynchronous calculation to be cancelled after a given timeout.
* In order to allow cancellation, the asynchronously running code must keep checking the _interrupted_ flag of its
* own thread and cease the calculation once the flag is set to true.
*
* @param timeout The timeout in milliseconds to wait before the calculation gets cancelled.
*/
public static Future callTimeoutAsync(final Closure cl, final long timeout, final Object... args) {
final Future f = callAsync(cl, args);
timer.schedule(new TimerTask() {
@Override
public void run() {
f.cancel(true);
}
}, timeout);
return f;
}
/**
* Calls a closure in a separate thread supplying the given arguments, returning a future for the potential return value.
* Also allows the asynchronous calculation to be cancelled after a given timeout.
* In order to allow cancellation, the asynchronously running code must keep checking the _interrupted_ flag of its
* own thread and cease the calculation once the flag is set to true.
*
* @param timeout The timeout to wait before the calculation gets cancelled.
*/
public static Future callTimeoutAsync(final Closure cl, final Duration timeout, final Object... args) {
return callTimeoutAsync(cl, timeout.toMilliseconds(), args);
}
/**
* Submits the task for asynchronous processing returning the Future received from the executor service.
* Allows for the following syntax:
*
* executorService << {println 'Inside parallel task'}*
*/
public static Future leftShift(final ForkJoinPool pool, final Closure task) {
return pool.submit(new RecursiveTask() {
@Override
protected T compute() {
return task.call();
}
});
}
/**
* Creates an asynchronous variant of the supplied closure, which, when invoked returns a future for the potential return value
*/
public static Closure async(final Closure cl) {
return GParsPoolUtilHelper.async(cl);
}
/**
* Creates an asynchronous and composable variant of the supplied closure, which, when invoked returns a DataflowVariable for the potential return value
*/
public static Closure asyncFun(final Closure original) {
return asyncFun(original, false);
}
/**
* Creates an asynchronous and composable variant of the supplied closure, which, when invoked returns a DataflowVariable for the potential return value
*/
public static Closure asyncFun(final Closure original, final boolean blocking) {
return GParsPoolUtilHelper.asyncFun(original, blocking);
}
/**
* Creates a caching variant of the supplied closure.
* Whenever the closure is called, the mapping between the parameters and the return value is preserved in cache
* making subsequent calls with the same arguments fast.
* This variant will keep all values forever, i.e. till the closure gets garbage-collected.
* The returned function can be safely used concurrently from multiple threads, however, the implementation
* values high average-scenario performance and so concurrent calls on the memoized function with identical argument values
* may not necessarily be able to benefit from each other's cached return value. With this having been mentioned,
* the performance trade-off still makes concurrent use of memoized functions safe and highly recommended.
*
* The cache gets garbage-collected together with the memoized closure.
*
* @return A new function forwarding to the original one while caching the results
*/
public static Closure gmemoize(final Closure cl) {
return GParsPoolUtilHelper.buildMemoizeFunction(new ConcurrentHashMap(), cl);
}
/**
* Creates a caching variant of the supplied closure with upper limit on the cache size.
* Whenever the closure is called, the mapping between the parameters and the return value is preserved in cache
* making subsequent calls with the same arguments fast.
* This variant will keep all values until the upper size limit is reached. Then the values in the cache start rotating
* using the LRU (Last Recently Used) strategy.
* The returned function can be safely used concurrently from multiple threads, however, the implementation
* values high average-scenario performance and so concurrent calls on the memoized function with identical argument values
* may not necessarily be able to benefit from each other's cached return value. With this having been mentioned,
* the performance trade-off still makes concurrent use of memoized functions safe and highly recommended.
*
* The cache gets garbage-collected together with the memoized closure.
*
* @param maxCacheSize The maximum size the cache can grow to
* @return A new function forwarding to the original one while caching the results
*/
public static Closure gmemoizeAtMost(final Closure cl, final int maxCacheSize) {
if (maxCacheSize < 0)
throw new IllegalArgumentException("A non-negative number is required as the maxCacheSize parameter for gmemoizeAtMost.");
return GParsPoolUtilHelper.buildMemoizeFunction(Collections.synchronizedMap(new LRUProtectionStorage(maxCacheSize)), cl);
}
/**
* Creates a caching variant of the supplied closure with automatic cache size adjustment and lower limit
* on the cache size.
* Whenever the closure is called, the mapping between the parameters and the return value is preserved in cache
* making subsequent calls with the same arguments fast.
* This variant allows the garbage collector to release entries from the cache and at the same time allows
* the user to specify how many entries should be protected from the eventual gc-initiated eviction.
* Cached entries exceeding the specified preservation threshold are made available for eviction based on
* the LRU (Last Recently Used) strategy.
* Given the non-deterministic nature of garbage collector, the actual cache size may grow well beyond the limits
* set by the user if memory is plentiful.
* The returned function can be safely used concurrently from multiple threads, however, the implementation
* values high average-scenario performance and so concurrent calls on the memoized function with identical argument values
* may not necessarily be able to benefit from each other's cached return value. Also the protectedCacheSize parameter
* might not be respected accurately in such scenarios for some periods of time. With this having been mentioned,
* the performance trade-off still makes concurrent use of memoized functions safe and highly recommended.
*
* The cache gets garbage-collected together with the memoized closure.
*/
public static Closure gmemoizeAtLeast(final Closure cl, final int protectedCacheSize) {
if (protectedCacheSize < 0)
throw new IllegalArgumentException("A non-negative number is required as the protectedCacheSize parameter for gmemoizeAtLeast.");
return GParsPoolUtilHelper.buildSoftReferenceMemoizeFunction(protectedCacheSize, new ConcurrentHashMap(), cl);
}
/**
* Creates a caching variant of the supplied closure with automatic cache size adjustment and lower and upper limits
* on the cache size.
* Whenever the closure is called, the mapping between the parameters and the return value is preserved in cache
* making subsequent calls with the same arguments fast.
* This variant allows the garbage collector to release entries from the cache and at the same time allows
* the user to specify how many entries should be protected from the eventual gc-initiated eviction.
* Cached entries exceeding the specified preservation threshold are made available for eviction based on
* the LRU (Last Recently Used) strategy.
* Given the non-deterministic nature of garbage collector, the actual cache size may grow well beyond the protected
* size limits set by the user, if memory is plentiful.
* Also, this variant will never exceed in size the upper size limit. Once the upper size limit has been reached,
* the values in the cache start rotating using the LRU (Last Recently Used) strategy.
* The returned function can be safely used concurrently from multiple threads, however, the implementation
* values high average-scenario performance and so concurrent calls on the memoized function with identical argument values
* may not necessarily be able to benefit from each other's cached return value. Also the protectedCacheSize parameter
* might not be respected accurately in such scenarios for some periods of time. With this having been mentioned,
* the performance trade-off still makes concurrent use of memoized functions safe and highly recommended.
*
* The cache gets garbage-collected together with the memoized closure.
*/
public static Closure gmemoizeBetween(final Closure cl, final int protectedCacheSize, final int maxCacheSize) {
if (protectedCacheSize < 0)
throw new IllegalArgumentException("A non-negative number is required as the protectedCacheSize parameter for gmemoizeBetween.");
if (maxCacheSize < 0)
throw new IllegalArgumentException("A non-negative number is required as the maxCacheSize parameter for gmemoizeBetween.");
if (protectedCacheSize > maxCacheSize)
throw new IllegalArgumentException("The maxCacheSize parameter to gmemoizeBetween is required to be greater or equal to the protectedCacheSize parameter.");
return GParsPoolUtilHelper.buildSoftReferenceMemoizeFunction(protectedCacheSize, Collections.synchronizedMap(new LRUProtectionStorage(maxCacheSize)), cl);
}
private static ParallelArray> createPA(final Map collection, final ForkJoinPool pool) {
return GParsPoolUtilHelper.createPAFromArray(PAUtils.createArray(collection), pool);
}
/**
* 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.
* The first time it is invoked on a collection the method creates a TransparentParallel class instance and mixes it
* in the object it is invoked on. After mixing-in, the isConcurrent() method will return true.
* Delegates to GParsPoolUtil.makeConcurrent().
*
* @param collection The object to make transparent
* @return The instance of the TransparentParallel class wrapping the original object and overriding the iterative methods with new parallel behavior
*/
public static Object makeConcurrent(final Object collection) {
return GParsPoolUtilHelper.makeConcurrent(collection);
}
/**
* Gives the iterative methods like each() or find() the original sequential semantics.
*
* @param collection The collection to apply the change to
* @return The collection itself
*/
public static Object makeSequential(final Object collection) {
return GParsPoolUtilHelper.makeSequential(collection);
}
/**
* Makes the collection concurrent for the passed-in block of code.
* The iterative methods like each or collect are given concurrent semantics inside the passed-in closure.
* Once the closure finishes, the original sequential semantics of the methods is restored.
* Must be invoked inside a withPool block.
*
* @param collection The collection to enhance
* @param code The closure to run with the collection enhanced.
*/
public static void asConcurrent(final Object collection, final Closure code) {
makeConcurrent(collection);
try {
code.call(collection);
} finally {
makeSequential(collection);
}
}
/**
* Indicates whether the iterative methods like each() or collect() work have been altered to work concurrently.
*/
public static boolean isConcurrent(final Object collection) {
return false;
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new eachParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = new ConcurrentSkipListSet()
* [1, 2, 3, 4, 5].eachParallel {Number number -> result.add(number * 10)}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
* Note that the result variable is synchronized to prevent race conditions between multiple threads.
*/
public static Collection eachParallel(final Collection collection, final Closure cl) {
GParsPoolUtilHelper.eachParallelPA(GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()), cl);
return collection;
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new eachParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = new ConcurrentSkipListSet()
* [1, 2, 3, 4, 5].eachParallel {Number number -> result.add(number * 10)}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
* Note that the result variable is synchronized to prevent race conditions between multiple threads.
*/
public static T eachParallel(final T collection, final Closure cl) {
GParsPoolUtilHelper.eachParallelPA(GParsPoolUtilHelper.createPA(collection, retrievePool()), cl);
return collection;
}
/**
* Creates a Parallel Array out of the supplied map and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new eachParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = new ConcurrentSkipListSet()
* [1, 2, 3, 4, 5].eachParallel {Number number -> result.add(number * 10)}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
* Note that the result variable is synchronized to prevent race conditions between multiple threads.
*/
public static Map eachParallel(final Map collection, final Closure cl) {
GParsPoolUtilHelper.eachParallelPA(createPA(collection, retrievePool()), buildClosureForMaps(cl));
return collection;
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new eachWithIndexParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = new ConcurrentSkipListSet()
* [1, 2, 3, 4, 5].eachWithIndexParallel {Number number, int index -> result.add(number * 10)}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
* Note that the result variable is synchronized to prevent race conditions between multiple threads.
*/
public static Collection eachWithIndexParallel(final Collection collection, final Closure cl) {
final List> indexedCollection = new ArrayList>();
int index = 0;
for (final T element : collection) {
indexedCollection.add(asList(element, index));
index++;
}
final ParallelArray> paFromCollection = GParsPoolUtilHelper.createPAFromCollection(indexedCollection, retrievePool());
GParsPoolUtilHelper.eachWithIndex(paFromCollection, cl).all();
return collection;
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new eachWithIndexParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = new ConcurrentSkipListSet()
* [1, 2, 3, 4, 5].eachWithIndexParallel {Number number, int index -> result.add(number * 10)}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
* Note that the result variable is synchronized to prevent race conditions between multiple threads.
*/
public static T eachWithIndexParallel(final T collection, final Closure cl) {
eachWithIndexParallel(createCollection(collection), cl);
return collection;
}
/**
* Does parallel eachWithIndex on maps
*/
public static Map eachWithIndexParallel(final Map collection, final Closure cl) {
eachWithIndexParallel(createCollection(collection), buildClosureForMapsWithIndex(cl));
return collection;
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].collectParallel {Number number -> number * 10}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
*/
public static Collection collectParallel(final Collection collection, final Closure extends T> cl) {
return GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withMapping(new ClosureMapper(new CallClosure(cl))).all().asList();
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].collectParallel {Number number -> number * 10}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
*/
public static Collection collectParallel(final Object collection, final Closure extends T> cl) {
return GParsPoolUtilHelper.createPA(collection, retrievePool()).withMapping(new ClosureMapper(new CallClosure(cl))).all().asList();
}
/**
* Creates a Parallel Array out of the supplied map and invokes the withMapping() method using the supplied
* closure as the transformation operation.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].collectParallel {Number number -> number * 10}* assertEquals(new HashSet([10, 20, 30, 40, 50]), result)
* }*
*/
public static Collection collectParallel(final Map collection, final Closure extends T> cl) {
return createPA(collection, retrievePool()).withMapping(new ClosureMapper(buildClosureForMaps(cl))).all().asList();
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* projection
closure as the transformation operation. The projection
closure should return a
* (possibly empty) collection of items which are subsequently flattened to produce a new collection.
* The projection
closure will be effectively invoked concurrently on the elements of the original collection.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectManyParallel(Closure projection) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def squaresAndCubesOfOdds = [1, 2, 3, 4, 5].collectManyParallel { Number number ->
* number % 2 ? [number ** 2, number ** 3] : []
* }* assert squaresAndCubesOfOdds == [1, 1, 9, 27, 25, 125]
* }*
*/
public static List collectManyParallel(final Collection collection, final Closure> projection) {
return (List) GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withMapping(new ClosureMapper(new CallClosure(projection))).reduce(new ClosureReducer(SumClosure.getInstance()), null);
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* projection
closure as the transformation operation. The projection
closure should return a
* (possibly empty) collection of items which are subsequently flattened to produce a new collection.
* The projection
closure will be effectively invoked concurrently on the elements of the original collection.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectManyParallel(Closure projection) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def squaresAndCubesOfOdds = [1, 2, 3, 4, 5].collectManyParallel { Number number ->
* number % 2 ? [number ** 2, number ** 3] : []
* }* assert squaresAndCubesOfOdds == [1, 1, 9, 27, 25, 125]
* }*
*/
public static List collectManyParallel(final Object collection, final Closure> projection) {
return (List) GParsPoolUtilHelper.createPA(collection, retrievePool()).withMapping(new ClosureMapper(new CallClosure(projection))).reduce(new ClosureReducer(SumClosure.getInstance()), null);
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied
* projection
closure as the transformation operation. The projection
closure should return a
* (possibly empty) collection of items which are subsequently flattened to produce a new collection.
* The projection
closure will be effectively invoked concurrently on the elements of the original collection.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new collectManyParallel(Closure projection) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def squaresAndCubesOfOdds = [1, 2, 3, 4, 5].collectManyParallel { Number number ->
* number % 2 ? [number ** 2, number ** 3] : []
* }* assert squaresAndCubesOfOdds == [1, 1, 9, 27, 25, 125]
* }*
*/
public static List collectManyParallel(final Map collection, final Closure> projection) {
return (List) createPA(collection, retrievePool()).withMapping(new ClosureMapper(buildClosureForMaps(projection))).reduce(new ClosureReducer(SumClosure.getInstance()), null);
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied
* closure as the filter predicate.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new findAllParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].findAllParallel {Number number -> number > 3}* assertEquals(new HashSet([4, 5]), result)
* }*
*/
public static Collection findAllParallel(final Collection collection, final Closure cl) {
return GParsPoolUtilHelper.findAllParallelPA(GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()), cl);
}
/**
* Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied
* closure as the filter predicate.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new findAllParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
*
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].findAllParallel {Number number -> number > 3}* assertEquals(new HashSet([4, 5]), result)
* }*
*/
public static Collection
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].findAnyParallel {Number number -> number > 3}* assert (result in [4, 5])
* }*
*/
public static Object findAnyParallel(final Object collection, final Closure cl) {
return GParsPoolUtilHelper.findAnyParallelPA(GParsPoolUtilHelper.createPA(collection, retrievePool()), cl);
}
/**
* Creates a Parallel Array out of the supplied map and invokes the withFilter() method using the supplied
* closure as the filter predicate.
* Unlike with the find method, findAnyParallel() does not guarantee
* that the matching element with the lowest index is returned.
* The findAnyParallel() method evaluates elements lazily and stops processing further elements of the collection once a match has been found.
* The closure will be effectively invoked concurrently on the elements of the collection.
* After all the elements have been processed, the method returns a random value from the resulting Parallel Array.
* It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access.
* Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block
* have a new findParallel(Closure cl) method, which delegates to the GParsPoolUtil class.
* Example:
* * GParsPool.withPool {* def result = [1, 2, 3, 4, 5].findAnyParallel {Number number -> number > 3}* assert (result in [4, 5]) * }**/ public static
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].grepParallel(4..6) * assertEquals(new HashSet([4, 5]), result) * }**/ public static
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].grepParallel(4..6) * assertEquals(new HashSet([4, 5]), result) * }**/ public static Object grepParallel(final Object collection, Object filter) { return (Collection
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].grepParallel(4..6) * assertEquals(new HashSet([4, 5]), result) * }**/ public static
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].splitParallel(4..6) * assert [3, 4, 5] as Set == result[0] as Set * assert [1, 2] as Set == result[1] as Set * }**/ public static Object splitParallel(Object collection, Object filter) { final Map groups = groupByParallelPA(GParsPoolUtilHelper.createPA(collection, retrievePool()), (Closure) filter); return asList(groups.containsKey(Boolean.TRUE) ? groups.get(Boolean.TRUE) : new ArrayList
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].countParallel(4) * assertEquals(1, result) * }**/ public static int countParallel(final Collection collection, final Object filter) { return GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withFilter(new Ops.Predicate
* GParsPool.withPool {* def result = [1, 2, 3, 4, 5].countParallel(4) * assertEquals(1, result) * }**/ public static int countParallel(final Object collection, final Object filter) { return GParsPoolUtilHelper.createPA(collection, retrievePool()).withFilter(new Ops.Predicate
* GParsPool.withPool {* def isOdd = { it % 2 }* def result = [1, 2, 3, 4, 5].countParallel(isOdd) * assert result == 3 * }**/ public static int countParallel(final Collection collection, final Closure filter) { return GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withFilter(new ClosurePredicate(filter)).size(); } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied * rule as the filter predicate. * The filter will be effectively used concurrently on the elements of the collection. * After all the elements have been processed, the method returns a collection of values from the resulting Parallel Array. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new grepParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool {* def isEven = { it % 2 == 0 }* def result = [1, 2, 3, 4, 5].countParallel(isEven) * assert result == 2 * }**/ public static int countParallel(final Object collection, final Closure filter) { return GParsPoolUtilHelper.createPA(collection, retrievePool()).withFilter(new ClosurePredicate(filter)).size(); } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * The anyParallel() method is lazy and once a positive answer has been given by at least one element, it avoids running * the supplied closure on subsequent elements. * After all the elements have been processed, the method returns a boolean value indicating, whether at least * one element of the collection meets the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new anyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool {* assert [1, 2, 3, 4, 5].anyParallel {Number number -> number > 3}* assert ![1, 2, 3].anyParallel {Number number -> number > 3}*}**/ public static boolean anyParallel(Collection collection, Closure cl) { return GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withFilter(new ClosurePredicate(cl)).any() != null; } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * The anyParallel() method is lazy and once a positive answer has been given by at least one element, it avoids running * the supplied closure on subsequent elements. * After all the elements have been processed, the method returns a boolean value indicating, whether at least * one element of the collection meets the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new anyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool {* assert [1, 2, 3, 4, 5].anyParallel {Number number -> number > 3}* assert ![1, 2, 3].anyParallel {Number number -> number > 3}*}**/ public static boolean anyParallel(Object collection, Closure cl) { return GParsPoolUtilHelper.createPA(collection, retrievePool()).withFilter(new ClosurePredicate(cl)).any() != null; } /** * Creates a Parallel Array out of the supplied map and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * The anyParallel() method is lazy and once a positive answer has been given by at least one element, it avoids running * the supplied closure on subsequent elements. * After all the elements have been processed, the method returns a boolean value indicating, whether at least * one element of the collection meets the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new anyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool {* assert [1, 2, 3, 4, 5].anyParallel {Number number -> number > 3}* assert ![1, 2, 3].anyParallel {Number number -> number > 3}*}**/ public static boolean anyParallel(Map collection, Closure cl) { final Closure mapClosure = buildClosureForMaps(cl); return createPA(collection, retrievePool()).withFilter(new ClosurePredicate(mapClosure)).any() != null; } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * After all the elements have been processed, the method returns a boolean value indicating, whether all the elements * of the collection meet the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new everyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool(5) {* assert ![1, 2, 3, 4, 5].everyParallel {Number number -> number > 3}* assert [1, 2, 3].everyParallel() {Number number -> number <= 3}*}**/ public static boolean everyParallel(Collection collection, Closure cl) { return GParsPoolUtilHelper.createPAFromCollection(collection, retrievePool()).withFilter(new ClosureNegationPredicate(cl)).any() == null; } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * After all the elements have been processed, the method returns a boolean value indicating, whether all the elements * of the collection meet the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new everyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool(5) {* assert ![1, 2, 3, 4, 5].everyParallel {Number number -> number > 3}* assert [1, 2, 3].everyParallel() {Number number -> number <= 3}*}**/ public static boolean everyParallel(Object collection, Closure cl) { return GParsPoolUtilHelper.createPA(collection, retrievePool()).withFilter(new ClosureNegationPredicate(cl)).any() == null; } /** * Creates a Parallel Array out of the supplied map and invokes the withFilter() method using the supplied * closure as the filter predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * After all the elements have been processed, the method returns a boolean value indicating, whether all the elements * of the collection meet the predicate. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new everyParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool(5) {* assert ![1, 2, 3, 4, 5].everyParallel {Number number -> number > 3}* assert [1, 2, 3].everyParallel() {Number number -> number <= 3}*}**/ public static boolean everyParallel(Map collection, Closure cl) { Closure mapClosure = buildClosureForMaps(cl); return createPA(collection, retrievePool()).withFilter(new ClosureNegationPredicate(mapClosure)).any() == null; } /** * Creates a Parallel Array out of the supplied collection/object and invokes the withMapping() method using the supplied * closure as the mapping predicate. * The closure will be effectively invoked concurrently on the elements of the collection. * After all the elements have been processed, the method returns a map of groups of the original elements. * Elements in the same group gave identical results when the supplied closure was invoked on them. * It's important to protect any shared resources used by the supplied closure from race conditions caused by multi-threaded access. * Alternatively a DSL can be used to simplify the code. All collections/objects within the withPool block * have a new groupByParallel(Closure cl) method, which delegates to the GParsPoolUtil class. * Example: *
* GParsPool.withPool {* assert ([1, 2, 3, 4, 5].groupByParallel {Number number -> number % 2}).size() == 2 * }**/ public static
* GParsPool.withPool {* assert ([1, 2, 3, 4, 5].groupByParallel {Number number -> number % 2}).size() == 2 * }**/ public static
© 2015 - 2025 Weber Informatics LLC | Privacy Policy