Class IntermediateDoubleCacheStream
- All Implemented Interfaces:
AutoCloseable,BaseStream<Double, DoubleStream>,DoubleStream,BaseCacheStream<Double, DoubleStream>,DoubleCacheStream
-
Nested Class Summary
Nested classes/interfaces inherited from interface org.infinispan.BaseCacheStream
BaseCacheStream.SegmentCompletionListenerNested classes/interfaces inherited from interface java.util.stream.DoubleStream
DoubleStream.Builder, DoubleStream.DoubleMapMultiConsumer -
Constructor Summary
ConstructorsConstructorDescriptionIntermediateDoubleCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalDoubleCacheStream localDoubleStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier) IntermediateDoubleCacheStream(DistributedDoubleCacheStream remoteStream) -
Method Summary
Modifier and TypeMethodDescriptionbooleanallMatch(DoublePredicate predicate) booleananyMatch(DoublePredicate predicate) average()boxed()voidclose()<R> Rcollect(Supplier<R> supplier, ObjDoubleConsumer<R> accumulator, BiConsumer<R, R> combiner) longcount()Disables tracking of rehash events that could occur to the underlying cache.distinct()distributedBatchSize(int batchSize) Controls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream.filter(DoublePredicate predicate) filterKeys(Set<?> keys) Filters which entries are returned by only returning ones that map to the given key.filterKeySegments(IntSet segments) Filters which entries are returned by what segment they are present in.findAny()flatMap(DoubleFunction<? extends DoubleStream> mapper) voidforEach(DoubleConsumer action) <K,V> void forEach(ObjDoubleConsumer<Cache<K, V>> action) Same asDoubleStream.forEach(DoubleConsumer)except that it takes anObjDoubleConsumerthat provides access to the underlyingCachethat is backing this stream.voidforEachOrdered(DoubleConsumer action) booleaniterator()limit(long maxSize) map(DoubleUnaryOperator mapper) mapToInt(DoubleToIntFunction mapper) mapToLong(DoubleToLongFunction mapper) <U> CacheStream<U> mapToObj(DoubleFunction<? extends U> mapper) max()min()booleannoneMatch(DoublePredicate predicate) parallel()This would enable sending requests to all other remote nodes when a terminal operator is performed.peek(DoubleConsumer action) doublereduce(double identity, DoubleBinaryOperator op) Allows registration of a segment completion listener that is notified when a segment has completed processing.This would disable sending requests to all other remote nodes compared to one at a time.skip(long n) sorted()doublesum()Sets a given time to wait for a remote operation to respond by.double[]toArray()Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.infinispan.DoubleCacheStream
allMatch, anyMatch, collect, filter, flatMap, forEach, forEach, map, mapToInt, mapToLong, mapToObj, noneMatch, peek, reduce, reduceMethods inherited from interface java.util.stream.DoubleStream
dropWhile, mapMulti, takeWhile
-
Constructor Details
-
IntermediateDoubleCacheStream
-
IntermediateDoubleCacheStream
public IntermediateDoubleCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalDoubleCacheStream localDoubleStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier)
-
-
Method Details
-
sequentialDistribution
Description copied from interface:DoubleCacheStreamThis would disable sending requests to all other remote nodes compared to one at a time. This can reduce memory pressure on the originator node at the cost of performance.Parallel distribution is enabled by default except for
CacheStream.iterator()andCacheStream.spliterator()- Specified by:
sequentialDistributionin interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
sequentialDistributionin interfaceDoubleCacheStream- Returns:
- a stream with parallel distribution disabled.
-
parallelDistribution
Description copied from interface:DoubleCacheStreamThis would enable sending requests to all other remote nodes when a terminal operator is performed. This requires additional overhead as it must process results concurrently from various nodes, but should perform faster in the majority of cases.Parallel distribution is enabled by default except for
CacheStream.iterator()andCacheStream.spliterator()- Specified by:
parallelDistributionin interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
parallelDistributionin interfaceDoubleCacheStream- Returns:
- a stream with parallel distribution enabled.
-
filterKeySegments
Description copied from interface:BaseCacheStreamFilters which entries are returned by what segment they are present in. This method can be substantially more efficient than using a regularCacheStream.filter(Predicate)method as this can control what nodes are asked for data and what entries are read from the underlying CacheStore if present.- Specified by:
filterKeySegmentsin interfaceBaseCacheStream<Double, DoubleStream>- Parameters:
segments- The segments to use for this stream operation. Any segments not in this set will be ignored.- Returns:
- a stream with the segments filtered.
-
filterKeys
Description copied from interface:DoubleCacheStreamFilters which entries are returned by only returning ones that map to the given key. This method will be faster than a regularCacheStream.filter(Predicate)if the filter is holding references to the same keys.- Specified by:
filterKeysin interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
filterKeysin interfaceDoubleCacheStream- Parameters:
keys- The keys that this stream will only operate on.- Returns:
- a stream with the keys filtered.
-
distributedBatchSize
Description copied from interface:DoubleCacheStreamControls how many keys are returned from a remote node when using a stream terminal operation with a distributed cache to back this stream. This value is ignored when terminal operators that don't track keys are used. Key tracking terminal operators areCacheStream.iterator(),CacheStream.spliterator(),CacheStream.forEach(Consumer). Please see those methods for additional information on how this value may affect them.This value may be used in the case of a a terminal operator that doesn't track keys if an intermediate operation is performed that requires bringing keys locally to do computations. Examples of such intermediate operations are
CacheStream.sorted(),CacheStream.sorted(Comparator),CacheStream.distinct(),CacheStream.limit(long),CacheStream.skip(long)This value is always ignored when this stream is backed by a cache that is not distributed as all values are already local.
- Specified by:
distributedBatchSizein interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
distributedBatchSizein interfaceDoubleCacheStream- Parameters:
batchSize- The size of each batch. This defaults to the state transfer chunk size.- Returns:
- a stream with the batch size updated
-
segmentCompletionListener
public DoubleCacheStream segmentCompletionListener(BaseCacheStream.SegmentCompletionListener listener) Description copied from interface:DoubleCacheStreamAllows registration of a segment completion listener that is notified when a segment has completed processing. If the terminal operator has a short circuit this listener may never be called.This method is designed for the sole purpose of use with the
CacheStream.iterator()to allow for a user to track completion of segments as they are returned from the iterator. Behavior of other methods is not specified. Please seeCacheStream.iterator()for more information.Multiple listeners may be registered upon multiple invocations of this method. The ordering of notified listeners is not specified.
This is only used if this stream did not invoke
BaseCacheStream.disableRehashAware()and has no flat map based operations. If this is done no segments will be notified.- Specified by:
segmentCompletionListenerin interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
segmentCompletionListenerin interfaceDoubleCacheStream- Parameters:
listener- The listener that will be called back as segments are completed.- Returns:
- a stream with the listener registered.
-
disableRehashAware
Description copied from interface:DoubleCacheStreamDisables tracking of rehash events that could occur to the underlying cache. If a rehash event occurs while a terminal operation is being performed it is possible for some values that are in the cache to not be found. Note that you will never have an entry duplicated when rehash awareness is disabled, only lost values.Most terminal operations will run faster with rehash awareness disabled even without a rehash occuring. However if a rehash occurs with this disabled be prepared to possibly receive only a subset of values.
- Specified by:
disableRehashAwarein interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
disableRehashAwarein interfaceDoubleCacheStream- Returns:
- a stream with rehash awareness disabled.
-
timeout
Description copied from interface:DoubleCacheStreamSets a given time to wait for a remote operation to respond by. This timeout does nothing if the terminal operation does not go remote.If a timeout does occur then a
TimeoutExceptionis thrown from the terminal operation invoking thread or on the next call to theIteratororSpliterator.Note that if a rehash occurs this timeout value is reset for the subsequent retry if rehash aware is enabled.
- Specified by:
timeoutin interfaceBaseCacheStream<Double, DoubleStream>- Specified by:
timeoutin interfaceDoubleCacheStream- Parameters:
timeout- the maximum time to waitunit- the time unit of the timeout argument- Returns:
- a stream with the timeout set
-
isParallel
public boolean isParallel()- Specified by:
isParallelin interfaceBaseStream<Double, DoubleStream>
-
sorted
Description copied from interface:DoubleCacheStream- Specified by:
sortedin interfaceDoubleCacheStream- Specified by:
sortedin interfaceDoubleStream- Returns:
- the new cache double stream
-
limit
Description copied from interface:DoubleCacheStream- Specified by:
limitin interfaceDoubleCacheStream- Specified by:
limitin interfaceDoubleStream- Returns:
- the new cache double stream
-
skip
Description copied from interface:DoubleCacheStream- Specified by:
skipin interfaceDoubleCacheStream- Specified by:
skipin interfaceDoubleStream- Returns:
- the new cache double stream
-
peek
Description copied from interface:DoubleCacheStream- Specified by:
peekin interfaceDoubleCacheStream- Specified by:
peekin interfaceDoubleStream- Returns:
- the new cache double stream
-
distinct
Description copied from interface:DoubleCacheStream- Specified by:
distinctin interfaceDoubleCacheStream- Specified by:
distinctin interfaceDoubleStream- Returns:
- the new cache double stream
-
filter
Description copied from interface:DoubleCacheStream- Specified by:
filterin interfaceDoubleCacheStream- Specified by:
filterin interfaceDoubleStream- Returns:
- the new cache double stream
-
map
Description copied from interface:DoubleCacheStream- Specified by:
mapin interfaceDoubleCacheStream- Specified by:
mapin interfaceDoubleStream- Returns:
- the new cache double stream
-
mapToObj
Description copied from interface:DoubleCacheStream- Specified by:
mapToObjin interfaceDoubleCacheStream- Specified by:
mapToObjin interfaceDoubleStream- Returns:
- the new cache stream
-
mapToInt
Description copied from interface:DoubleCacheStream- Specified by:
mapToIntin interfaceDoubleCacheStream- Specified by:
mapToIntin interfaceDoubleStream- Returns:
- the new cache int stream
-
mapToLong
Description copied from interface:DoubleCacheStream- Specified by:
mapToLongin interfaceDoubleCacheStream- Specified by:
mapToLongin interfaceDoubleStream- Returns:
- the new cache long stream
-
flatMap
Description copied from interface:DoubleCacheStream- Specified by:
flatMapin interfaceDoubleCacheStream- Specified by:
flatMapin interfaceDoubleStream- Returns:
- the new cache double stream
-
parallel
Description copied from interface:DoubleCacheStream- Specified by:
parallelin interfaceBaseStream<Double, DoubleStream>- Specified by:
parallelin interfaceDoubleCacheStream- Specified by:
parallelin interfaceDoubleStream- Returns:
- a parallel cache double stream
-
iterator
- Specified by:
iteratorin interfaceBaseStream<Double, DoubleStream>- Specified by:
iteratorin interfaceDoubleStream
-
spliterator
- Specified by:
spliteratorin interfaceBaseStream<Double, DoubleStream>- Specified by:
spliteratorin interfaceDoubleStream
-
sequential
Description copied from interface:DoubleCacheStream- Specified by:
sequentialin interfaceBaseStream<Double, DoubleStream>- Specified by:
sequentialin interfaceDoubleCacheStream- Specified by:
sequentialin interfaceDoubleStream- Returns:
- a sequential cache double stream
-
unordered
Description copied from interface:DoubleCacheStream- Specified by:
unorderedin interfaceBaseStream<Double, DoubleStream>- Specified by:
unorderedin interfaceDoubleCacheStream- Returns:
- an unordered cache double stream
-
forEach
- Specified by:
forEachin interfaceDoubleStream
-
forEach
Description copied from interface:DoubleCacheStreamSame asDoubleStream.forEach(DoubleConsumer)except that it takes anObjDoubleConsumerthat provides access to the underlyingCachethat is backing this stream.Note that the
CacheAwareinterface is not supported for injection using this method as the cache is provided in the consumer directly.- Specified by:
forEachin interfaceDoubleCacheStream- Type Parameters:
K- key type of the cacheV- value type of the cache- Parameters:
action- consumer to be ran for each element in the stream
-
forEachOrdered
- Specified by:
forEachOrderedin interfaceDoubleStream
-
toArray
public double[] toArray()- Specified by:
toArrayin interfaceDoubleStream
-
reduce
- Specified by:
reducein interfaceDoubleStream
-
reduce
- Specified by:
reducein interfaceDoubleStream
-
collect
public <R> R collect(Supplier<R> supplier, ObjDoubleConsumer<R> accumulator, BiConsumer<R, R> combiner) - Specified by:
collectin interfaceDoubleStream
-
sum
public double sum()- Specified by:
sumin interfaceDoubleStream
-
min
- Specified by:
minin interfaceDoubleStream
-
max
- Specified by:
maxin interfaceDoubleStream
-
count
public long count()- Specified by:
countin interfaceDoubleStream
-
average
- Specified by:
averagein interfaceDoubleStream
-
summaryStatistics
- Specified by:
summaryStatisticsin interfaceDoubleStream
-
anyMatch
- Specified by:
anyMatchin interfaceDoubleStream
-
allMatch
- Specified by:
allMatchin interfaceDoubleStream
-
noneMatch
- Specified by:
noneMatchin interfaceDoubleStream
-
findFirst
- Specified by:
findFirstin interfaceDoubleStream
-
findAny
- Specified by:
findAnyin interfaceDoubleStream
-
boxed
Description copied from interface:DoubleCacheStream- Specified by:
boxedin interfaceDoubleCacheStream- Specified by:
boxedin interfaceDoubleStream- Returns:
- the new cache stream containing doubles
-
onClose
Description copied from interface:DoubleCacheStream- Specified by:
onClosein interfaceBaseStream<Double, DoubleStream>- Specified by:
onClosein interfaceDoubleCacheStream- Returns:
- a cache double stream with the handler applied
-
close
public void close()- Specified by:
closein interfaceAutoCloseable- Specified by:
closein interfaceBaseStream<Double, DoubleStream>
-