Class IntermediateIntCacheStream
- java.lang.Object
-
- org.infinispan.stream.impl.IntermediateIntCacheStream
-
- All Implemented Interfaces:
AutoCloseable
,BaseStream<Integer,IntStream>
,IntStream
,BaseCacheStream<Integer,IntStream>
,IntCacheStream
public class IntermediateIntCacheStream extends Object implements IntCacheStream
An intermediate int cache stream used when an intermediate operation that requires both a remote and local portion
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.infinispan.BaseCacheStream
BaseCacheStream.SegmentCompletionListener
-
Nested classes/interfaces inherited from interface java.util.stream.IntStream
IntStream.Builder
-
-
Constructor Summary
Constructors Constructor Description IntermediateIntCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalIntCacheStream localIntStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier)
IntermediateIntCacheStream(DistributedIntCacheStream remoteStream)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
allMatch(IntPredicate predicate)
boolean
anyMatch(IntPredicate predicate)
DoubleCacheStream
asDoubleStream()
LongCacheStream
asLongStream()
OptionalDouble
average()
CacheStream<Integer>
boxed()
void
close()
<R> R
collect(Supplier<R> supplier, ObjIntConsumer<R> accumulator, BiConsumer<R,R> combiner)
long
count()
IntCacheStream
disableRehashAware()
Disables tracking of rehash events that could occur to the underlying cache.IntCacheStream
distinct()
IntCacheStream
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.IntCacheStream
filter(IntPredicate predicate)
IntCacheStream
filterKeys(Set<?> keys)
Filters which entries are returned by only returning ones that map to the given key.IntCacheStream
filterKeySegments(Set<Integer> segments)
Filters which entries are returned by what segment they are present in.IntCacheStream
filterKeySegments(org.infinispan.commons.util.IntSet segments)
Filters which entries are returned by what segment they are present in.OptionalInt
findAny()
OptionalInt
findFirst()
IntCacheStream
flatMap(IntFunction<? extends IntStream> mapper)
void
forEach(IntConsumer action)
<K,V>
voidforEach(ObjIntConsumer<Cache<K,V>> action)
Same asIntStream.forEach(IntConsumer)
except that it takes anObjIntConsumer
that provides access to the underlyingCache
that is backing this stream.void
forEachOrdered(IntConsumer action)
boolean
isParallel()
PrimitiveIterator.OfInt
iterator()
IntCacheStream
limit(long maxSize)
IntCacheStream
map(IntUnaryOperator mapper)
DoubleCacheStream
mapToDouble(IntToDoubleFunction mapper)
LongCacheStream
mapToLong(IntToLongFunction mapper)
<U> CacheStream<U>
mapToObj(IntFunction<? extends U> mapper)
OptionalInt
max()
OptionalInt
min()
boolean
noneMatch(IntPredicate predicate)
IntCacheStream
onClose(Runnable closeHandler)
IntCacheStream
parallel()
IntCacheStream
parallelDistribution()
This would enable sending requests to all other remote nodes when a terminal operator is performed.IntCacheStream
peek(IntConsumer action)
int
reduce(int identity, IntBinaryOperator op)
OptionalInt
reduce(IntBinaryOperator op)
IntCacheStream
segmentCompletionListener(BaseCacheStream.SegmentCompletionListener listener)
Allows registration of a segment completion listener that is notified when a segment has completed processing.IntCacheStream
sequential()
IntCacheStream
sequentialDistribution()
This would disable sending requests to all other remote nodes compared to one at a time.IntCacheStream
skip(long n)
IntCacheStream
sorted()
Spliterator.OfInt
spliterator()
int
sum()
IntSummaryStatistics
summaryStatistics()
IntCacheStream
timeout(long timeout, TimeUnit unit)
Sets a given time to wait for a remote operation to respond by.int[]
toArray()
IntCacheStream
unordered()
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
-
-
-
Constructor Detail
-
IntermediateIntCacheStream
public IntermediateIntCacheStream(DistributedIntCacheStream remoteStream)
-
IntermediateIntCacheStream
public IntermediateIntCacheStream(BaseCacheStream remoteStream, IntermediateType type, org.infinispan.stream.impl.local.LocalIntCacheStream localIntStream, org.infinispan.stream.impl.IntermediateCacheStreamSupplier supplier)
-
-
Method Detail
-
sequentialDistribution
public IntCacheStream sequentialDistribution()
Description copied from interface:IntCacheStream
This 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:
sequentialDistribution
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
sequentialDistribution
in interfaceIntCacheStream
- Returns:
- a stream with parallel distribution disabled.
-
parallelDistribution
public IntCacheStream parallelDistribution()
Description copied from interface:BaseCacheStream
This 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:
parallelDistribution
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
parallelDistribution
in interfaceIntCacheStream
- Returns:
- a stream with parallel distribution enabled.
-
filterKeySegments
public IntCacheStream filterKeySegments(Set<Integer> segments)
Description copied from interface:IntCacheStream
Filters 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:
filterKeySegments
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
filterKeySegments
in interfaceIntCacheStream
- 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.
-
filterKeySegments
public IntCacheStream filterKeySegments(org.infinispan.commons.util.IntSet segments)
Description copied from interface:BaseCacheStream
Filters 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:
filterKeySegments
in interfaceBaseCacheStream<Integer,IntStream>
- 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
public IntCacheStream filterKeys(Set<?> keys)
Description copied from interface:IntCacheStream
Filters 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:
filterKeys
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
filterKeys
in interfaceIntCacheStream
- Parameters:
keys
- The keys that this stream will only operate on.- Returns:
- a stream with the keys filtered.
-
distributedBatchSize
public IntCacheStream distributedBatchSize(int batchSize)
Description copied from interface:IntCacheStream
Controls 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:
distributedBatchSize
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
distributedBatchSize
in interfaceIntCacheStream
- 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 IntCacheStream segmentCompletionListener(BaseCacheStream.SegmentCompletionListener listener)
Description copied from interface:IntCacheStream
Allows 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:
segmentCompletionListener
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
segmentCompletionListener
in interfaceIntCacheStream
- Parameters:
listener
- The listener that will be called back as segments are completed.- Returns:
- a stream with the listener registered.
-
disableRehashAware
public IntCacheStream disableRehashAware()
Description copied from interface:IntCacheStream
Disables 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:
disableRehashAware
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
disableRehashAware
in interfaceIntCacheStream
- Returns:
- a stream with rehash awareness disabled.
-
timeout
public IntCacheStream timeout(long timeout, TimeUnit unit)
Description copied from interface:IntCacheStream
Sets 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
TimeoutException
is thrown from the terminal operation invoking thread or on the next call to theIterator
orSpliterator
.Note that if a rehash occurs this timeout value is reset for the subsequent retry if rehash aware is enabled.
- Specified by:
timeout
in interfaceBaseCacheStream<Integer,IntStream>
- Specified by:
timeout
in interfaceIntCacheStream
- 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:
isParallel
in interfaceBaseStream<Integer,IntStream>
-
sorted
public IntCacheStream sorted()
Description copied from interface:IntCacheStream
- Specified by:
sorted
in interfaceIntCacheStream
- Specified by:
sorted
in interfaceIntStream
- Returns:
- the new cache int stream
-
limit
public IntCacheStream limit(long maxSize)
Description copied from interface:IntCacheStream
- Specified by:
limit
in interfaceIntCacheStream
- Specified by:
limit
in interfaceIntStream
- Returns:
- the new cache int stream
-
skip
public IntCacheStream skip(long n)
Description copied from interface:IntCacheStream
- Specified by:
skip
in interfaceIntCacheStream
- Specified by:
skip
in interfaceIntStream
- Returns:
- the new cache int stream
-
peek
public IntCacheStream peek(IntConsumer action)
Description copied from interface:IntCacheStream
- Specified by:
peek
in interfaceIntCacheStream
- Specified by:
peek
in interfaceIntStream
- Returns:
- the new cache int stream
-
distinct
public IntCacheStream distinct()
Description copied from interface:IntCacheStream
- Specified by:
distinct
in interfaceIntCacheStream
- Specified by:
distinct
in interfaceIntStream
- Returns:
- the new cache int stream
-
filter
public IntCacheStream filter(IntPredicate predicate)
Description copied from interface:IntCacheStream
- Specified by:
filter
in interfaceIntCacheStream
- Specified by:
filter
in interfaceIntStream
- Returns:
- the new cache int stream
-
map
public IntCacheStream map(IntUnaryOperator mapper)
Description copied from interface:IntCacheStream
- Specified by:
map
in interfaceIntCacheStream
- Specified by:
map
in interfaceIntStream
- Returns:
- the new cache int stream
-
mapToObj
public <U> CacheStream<U> mapToObj(IntFunction<? extends U> mapper)
Description copied from interface:IntCacheStream
- Specified by:
mapToObj
in interfaceIntCacheStream
- Specified by:
mapToObj
in interfaceIntStream
- Returns:
- the new cache stream
-
mapToLong
public LongCacheStream mapToLong(IntToLongFunction mapper)
Description copied from interface:IntCacheStream
- Specified by:
mapToLong
in interfaceIntCacheStream
- Specified by:
mapToLong
in interfaceIntStream
- Returns:
- the new cache long stream
-
mapToDouble
public DoubleCacheStream mapToDouble(IntToDoubleFunction mapper)
Description copied from interface:IntCacheStream
- Specified by:
mapToDouble
in interfaceIntCacheStream
- Specified by:
mapToDouble
in interfaceIntStream
- Returns:
- the new cache double stream
-
flatMap
public IntCacheStream flatMap(IntFunction<? extends IntStream> mapper)
Description copied from interface:IntCacheStream
- Specified by:
flatMap
in interfaceIntCacheStream
- Specified by:
flatMap
in interfaceIntStream
- Returns:
- the new cache int stream
-
parallel
public IntCacheStream parallel()
Description copied from interface:IntCacheStream
- Specified by:
parallel
in interfaceBaseStream<Integer,IntStream>
- Specified by:
parallel
in interfaceIntCacheStream
- Specified by:
parallel
in interfaceIntStream
- Returns:
- a parallel cache int stream
-
iterator
public PrimitiveIterator.OfInt iterator()
-
spliterator
public Spliterator.OfInt spliterator()
- Specified by:
spliterator
in interfaceBaseStream<Integer,IntStream>
- Specified by:
spliterator
in interfaceIntStream
-
sequential
public IntCacheStream sequential()
Description copied from interface:IntCacheStream
- Specified by:
sequential
in interfaceBaseStream<Integer,IntStream>
- Specified by:
sequential
in interfaceIntCacheStream
- Specified by:
sequential
in interfaceIntStream
- Returns:
- a sequential cache int stream
-
unordered
public IntCacheStream unordered()
Description copied from interface:IntCacheStream
- Specified by:
unordered
in interfaceBaseStream<Integer,IntStream>
- Specified by:
unordered
in interfaceIntCacheStream
- Returns:
- an unordered cache int stream
-
forEach
public void forEach(IntConsumer action)
-
forEach
public <K,V> void forEach(ObjIntConsumer<Cache<K,V>> action)
Description copied from interface:IntCacheStream
Same asIntStream.forEach(IntConsumer)
except that it takes anObjIntConsumer
that provides access to the underlyingCache
that is backing this stream.Note that the
CacheAware
interface is not supported for injection using this method as the cache is provided in the consumer directly.- Specified by:
forEach
in interfaceIntCacheStream
- 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
public void forEachOrdered(IntConsumer action)
- Specified by:
forEachOrdered
in interfaceIntStream
-
reduce
public int reduce(int identity, IntBinaryOperator op)
-
reduce
public OptionalInt reduce(IntBinaryOperator op)
-
collect
public <R> R collect(Supplier<R> supplier, ObjIntConsumer<R> accumulator, BiConsumer<R,R> combiner)
-
min
public OptionalInt min()
-
max
public OptionalInt max()
-
average
public OptionalDouble average()
-
summaryStatistics
public IntSummaryStatistics summaryStatistics()
- Specified by:
summaryStatistics
in interfaceIntStream
-
anyMatch
public boolean anyMatch(IntPredicate predicate)
-
allMatch
public boolean allMatch(IntPredicate predicate)
-
noneMatch
public boolean noneMatch(IntPredicate predicate)
-
findFirst
public OptionalInt findFirst()
-
findAny
public OptionalInt findAny()
-
boxed
public CacheStream<Integer> boxed()
Description copied from interface:IntCacheStream
- Specified by:
boxed
in interfaceIntCacheStream
- Specified by:
boxed
in interfaceIntStream
- Returns:
- the new cache stream containing integers
-
asDoubleStream
public DoubleCacheStream asDoubleStream()
Description copied from interface:IntCacheStream
- Specified by:
asDoubleStream
in interfaceIntCacheStream
- Specified by:
asDoubleStream
in interfaceIntStream
- Returns:
- the cache double stream
-
asLongStream
public LongCacheStream asLongStream()
Description copied from interface:IntCacheStream
- Specified by:
asLongStream
in interfaceIntCacheStream
- Specified by:
asLongStream
in interfaceIntStream
- Returns:
- the cache long stream
-
onClose
public IntCacheStream onClose(Runnable closeHandler)
Description copied from interface:IntCacheStream
- Specified by:
onClose
in interfaceBaseStream<Integer,IntStream>
- Specified by:
onClose
in interfaceIntCacheStream
- Returns:
- a cache int stream with the handler applied
-
close
public void close()
- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceBaseStream<Integer,IntStream>
-
-