Class IntermediateLongCacheStream
- All Implemented Interfaces:
- AutoCloseable,- BaseStream<Long,,- LongStream> - LongStream,- BaseCacheStream<Long,,- LongStream> - LongCacheStream
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.infinispan.BaseCacheStreamBaseCacheStream.SegmentCompletionListenerNested classes/interfaces inherited from interface java.util.stream.LongStreamLongStream.Builder
- 
Constructor SummaryConstructorsConstructorDescriptionIntermediateLongCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalLongCacheStream localLongStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier) IntermediateLongCacheStream(DistributedLongCacheStream remoteStream) 
- 
Method SummaryModifier and TypeMethodDescriptionbooleanallMatch(LongPredicate predicate) booleananyMatch(LongPredicate predicate) average()boxed()voidclose()<R> Rcollect(Supplier<R> supplier, ObjLongConsumer<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(LongPredicate predicate) filterKeys(Set<?> keys) Filters which entries are returned by only returning ones that map to the given key.filterKeySegments(Set<Integer> segments) Filters which entries are returned by what segment they are present in.filterKeySegments(IntSet segments) Filters which entries are returned by what segment they are present in.findAny()flatMap(LongFunction<? extends LongStream> mapper) voidforEach(LongConsumer action) <K,V> void forEach(ObjLongConsumer<Cache<K, V>> action) Same asLongStream.forEach(LongConsumer)except that it takes anObjLongConsumerthat provides access to the underlyingCachethat is backing this stream.voidforEachOrdered(LongConsumer action) booleaniterator()limit(long maxSize) map(LongUnaryOperator mapper) mapToDouble(LongToDoubleFunction mapper) mapToInt(LongToIntFunction mapper) <U> CacheStream<U>mapToObj(LongFunction<? extends U> mapper) max()min()booleannoneMatch(LongPredicate predicate) parallel()This would enable sending requests to all other remote nodes when a terminal operator is performed.peek(LongConsumer action) longreduce(long identity, LongBinaryOperator 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()longsum()Sets a given time to wait for a remote operation to respond by.long[]toArray()Methods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.infinispan.LongCacheStreamallMatch, anyMatch, collect, filter, flatMap, forEach, forEach, map, mapToDouble, mapToInt, mapToObj, noneMatch, peek, reduce, reduceMethods inherited from interface java.util.stream.LongStreamdropWhile, takeWhile
- 
Constructor Details- 
IntermediateLongCacheStream
- 
IntermediateLongCacheStreampublic IntermediateLongCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalLongCacheStream localLongStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier) 
 
- 
- 
Method Details- 
sequentialDistributionDescription copied from interface:LongCacheStreamThis 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- sequentialDistributionin interface- LongCacheStream
- Returns:
- a stream with parallel distribution disabled.
 
- 
parallelDistributionDescription copied from interface:BaseCacheStreamThis 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- parallelDistributionin interface- LongCacheStream
- Returns:
- a stream with parallel distribution enabled.
 
- 
filterKeySegmentsDescription copied from interface:LongCacheStreamFilters 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- filterKeySegmentsin interface- LongCacheStream
- 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.
 
- 
filterKeySegmentsDescription 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 interface- BaseCacheStream<Long,- LongStream> 
- 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.
 
- 
filterKeysDescription copied from interface:LongCacheStreamFilters 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- filterKeysin interface- LongCacheStream
- Parameters:
- keys- The keys that this stream will only operate on.
- Returns:
- a stream with the keys filtered.
 
- 
distributedBatchSizeDescription copied from interface:LongCacheStreamControls 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- distributedBatchSizein interface- LongCacheStream
- Parameters:
- batchSize- The size of each batch. This defaults to the state transfer chunk size.
- Returns:
- a stream with the batch size updated
 
- 
segmentCompletionListenerpublic LongCacheStream segmentCompletionListener(BaseCacheStream.SegmentCompletionListener listener) Description copied from interface:LongCacheStreamAllows 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- segmentCompletionListenerin interface- LongCacheStream
- Parameters:
- listener- The listener that will be called back as segments are completed.
- Returns:
- a stream with the listener registered.
 
- 
disableRehashAwareDescription copied from interface:LongCacheStreamDisables 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- disableRehashAwarein interface- LongCacheStream
- Returns:
- a stream with rehash awareness disabled.
 
- 
timeoutDescription copied from interface:LongCacheStreamSets 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 interface- BaseCacheStream<Long,- LongStream> 
- Specified by:
- timeoutin interface- LongCacheStream
- Parameters:
- timeout- the maximum time to wait
- unit- the time unit of the timeout argument
- Returns:
- a stream with the timeout set
 
- 
isParallelpublic boolean isParallel()- Specified by:
- isParallelin interface- BaseStream<Long,- LongStream> 
 
- 
sortedDescription copied from interface:LongCacheStream- Specified by:
- sortedin interface- LongCacheStream
- Specified by:
- sortedin interface- LongStream
- Returns:
- the new cache long stream
 
- 
limitDescription copied from interface:LongCacheStream- Specified by:
- limitin interface- LongCacheStream
- Specified by:
- limitin interface- LongStream
- Returns:
- the new cache long stream
 
- 
skipDescription copied from interface:LongCacheStream- Specified by:
- skipin interface- LongCacheStream
- Specified by:
- skipin interface- LongStream
- Returns:
- the new cache long stream
 
- 
peekDescription copied from interface:LongCacheStream- Specified by:
- peekin interface- LongCacheStream
- Specified by:
- peekin interface- LongStream
- Returns:
- the new cache long stream
 
- 
distinctDescription copied from interface:LongCacheStream- Specified by:
- distinctin interface- LongCacheStream
- Specified by:
- distinctin interface- LongStream
- Returns:
- the new cache long stream
 
- 
filterDescription copied from interface:LongCacheStream- Specified by:
- filterin interface- LongCacheStream
- Specified by:
- filterin interface- LongStream
- Returns:
- the new cache long stream
 
- 
mapDescription copied from interface:LongCacheStream- Specified by:
- mapin interface- LongCacheStream
- Specified by:
- mapin interface- LongStream
- Returns:
- the new cache long stream
 
- 
mapToObjDescription copied from interface:LongCacheStream- Specified by:
- mapToObjin interface- LongCacheStream
- Specified by:
- mapToObjin interface- LongStream
- Returns:
- the new cache stream
 
- 
mapToIntDescription copied from interface:LongCacheStream- Specified by:
- mapToIntin interface- LongCacheStream
- Specified by:
- mapToIntin interface- LongStream
- Returns:
- the new cache int stream
 
- 
mapToDoubleDescription copied from interface:LongCacheStream- Specified by:
- mapToDoublein interface- LongCacheStream
- Specified by:
- mapToDoublein interface- LongStream
- Returns:
- the new cache double stream
 
- 
flatMapDescription copied from interface:LongCacheStream- Specified by:
- flatMapin interface- LongCacheStream
- Specified by:
- flatMapin interface- LongStream
- Returns:
- the new cache long stream
 
- 
parallelDescription copied from interface:LongCacheStream- Specified by:
- parallelin interface- BaseStream<Long,- LongStream> 
- Specified by:
- parallelin interface- LongCacheStream
- Specified by:
- parallelin interface- LongStream
- Returns:
- a parallel cache long stream
 
- 
iterator- Specified by:
- iteratorin interface- BaseStream<Long,- LongStream> 
- Specified by:
- iteratorin interface- LongStream
 
- 
spliterator- Specified by:
- spliteratorin interface- BaseStream<Long,- LongStream> 
- Specified by:
- spliteratorin interface- LongStream
 
- 
sequentialDescription copied from interface:LongCacheStream- Specified by:
- sequentialin interface- BaseStream<Long,- LongStream> 
- Specified by:
- sequentialin interface- LongCacheStream
- Specified by:
- sequentialin interface- LongStream
- Returns:
- a sequential cache long stream
 
- 
unorderedDescription copied from interface:LongCacheStream- Specified by:
- unorderedin interface- BaseStream<Long,- LongStream> 
- Specified by:
- unorderedin interface- LongCacheStream
- Returns:
- an unordered cache long stream
 
- 
forEach- Specified by:
- forEachin interface- LongStream
 
- 
forEachDescription copied from interface:LongCacheStreamSame asLongStream.forEach(LongConsumer)except that it takes anObjLongConsumerthat 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 interface- LongCacheStream
- Type Parameters:
- K- key type of the cache
- V- value type of the cache
- Parameters:
- action- consumer to be ran for each element in the stream
 
- 
forEachOrdered- Specified by:
- forEachOrderedin interface- LongStream
 
- 
toArraypublic long[] toArray()- Specified by:
- toArrayin interface- LongStream
 
- 
reduce- Specified by:
- reducein interface- LongStream
 
- 
reduce- Specified by:
- reducein interface- LongStream
 
- 
collectpublic <R> R collect(Supplier<R> supplier, ObjLongConsumer<R> accumulator, BiConsumer<R, R> combiner) - Specified by:
- collectin interface- LongStream
 
- 
sumpublic long sum()- Specified by:
- sumin interface- LongStream
 
- 
min- Specified by:
- minin interface- LongStream
 
- 
max- Specified by:
- maxin interface- LongStream
 
- 
countpublic long count()- Specified by:
- countin interface- LongStream
 
- 
average- Specified by:
- averagein interface- LongStream
 
- 
summaryStatistics- Specified by:
- summaryStatisticsin interface- LongStream
 
- 
anyMatch- Specified by:
- anyMatchin interface- LongStream
 
- 
allMatch- Specified by:
- allMatchin interface- LongStream
 
- 
noneMatch- Specified by:
- noneMatchin interface- LongStream
 
- 
findFirst- Specified by:
- findFirstin interface- LongStream
 
- 
findAny- Specified by:
- findAnyin interface- LongStream
 
- 
boxedDescription copied from interface:LongCacheStream- Specified by:
- boxedin interface- LongCacheStream
- Specified by:
- boxedin interface- LongStream
- Returns:
- the new cache stream containing longs
 
- 
asDoubleStreamDescription copied from interface:LongCacheStream- Specified by:
- asDoubleStreamin interface- LongCacheStream
- Specified by:
- asDoubleStreamin interface- LongStream
- Returns:
- the cache double stream
 
- 
onCloseDescription copied from interface:LongCacheStream- Specified by:
- onClosein interface- BaseStream<Long,- LongStream> 
- Specified by:
- onClosein interface- LongCacheStream
- Returns:
- a cache long stream with the handler applied
 
- 
closepublic void close()- Specified by:
- closein interface- AutoCloseable
- Specified by:
- closein interface- BaseStream<Long,- LongStream> 
 
 
-