Interface IntCacheStream
- All Superinterfaces:
- AutoCloseable,- BaseCacheStream<Integer,,- IntStream> - BaseStream<Integer,,- IntStream> - IntStream
- All Known Implementing Classes:
- DistributedIntCacheStream,- IntermediateIntCacheStream
IntStream that has additional methods to allow for Serializable instances.  Please see
 CacheStream for additional details about various methods.- Since:
- 9.0
- Author:
- wburns
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.infinispan.BaseCacheStreamBaseCacheStream.SegmentCompletionListenerNested classes/interfaces inherited from interface java.util.stream.IntStreamIntStream.Builder, IntStream.IntMapMultiConsumer
- 
Method SummaryModifier and TypeMethodDescriptiondefault booleanallMatch(SerializableIntPredicate predicate) Same asIntStream.allMatch(IntPredicate)except that the IntPredicate must also implementSerializabledefault booleananyMatch(SerializableIntPredicate predicate) Same asIntStream.anyMatch(IntPredicate)except that the IntPredicate must also implementSerializableboxed()default <R> Rcollect(SerializableSupplier<R> supplier, SerializableObjIntConsumer<R> accumulator, SerializableBiConsumer<R, R> combiner) Same asIntStream.collect(Supplier, ObjIntConsumer, BiConsumer)except that the arguments must also implementSerializableDisables 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(IntPredicate predicate) default IntCacheStreamfilter(SerializableIntPredicate predicate) Same asfilter(IntPredicate)except that the IntPredicate must also implementSerializablefilterKeys(Set<?> keys) Filters which entries are returned by only returning ones that map to the given key.flatMap(IntFunction<? extends IntStream> mapper) default IntCacheStreamflatMap(SerializableIntFunction<? extends IntStream> mapper) Same asflatMap(IntFunction)except that the IntFunction must also implementSerializable<K,V> void forEach(ObjIntConsumer<Cache<K, V>> action) Same asIntStream.forEach(IntConsumer)except that it takes anObjIntConsumerthat provides access to the underlyingCachethat is backing this stream.default voidforEach(SerializableIntConsumer action) Same asIntStream.forEach(IntConsumer)except that the IntConsumer must also implementSerializabledefault <K,V> void forEach(SerializableObjIntConsumer<Cache<K, V>> action) limit(long maxSize) map(IntUnaryOperator mapper) default IntCacheStreammap(SerializableIntUnaryOperator mapper) Same asmap(IntUnaryOperator)except that the IntUnaryOperator must also implementSerializablemapToDouble(IntToDoubleFunction mapper) default DoubleCacheStreamSame asmapToDouble(IntToDoubleFunction)except that the IntToIntFunction must also implementSerializablemapToLong(IntToLongFunction mapper) default LongCacheStreamSame asmapToLong(IntToLongFunction)except that the IntToLongFunction must also implementSerializable<U> CacheStream<U> mapToObj(IntFunction<? extends U> mapper) default <U> CacheStream<U> mapToObj(SerializableIntFunction<? extends U> mapper) Same asmapToObj(IntFunction)except that the IntFunction must also implementSerializabledefault booleannoneMatch(SerializableIntPredicate predicate) Same asIntStream.noneMatch(IntPredicate)except that the IntPredicate must also implementSerializableparallel()This would enable sending requests to all other remote nodes when a terminal operator is performed.peek(IntConsumer action) default IntCacheStreampeek(SerializableIntConsumer action) Same asflatMap(IntFunction)except that the IntFunction must also implementSerializabledefault intreduce(int identity, SerializableIntBinaryOperator op) Same asIntStream.reduce(int, IntBinaryOperator)except that the IntBinaryOperator must also implementSerializabledefault OptionalIntSame asIntStream.reduce(IntBinaryOperator)except that the IntBinaryOperator must also implementSerializableAllows 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()Sets a given time to wait for a remote operation to respond by.Methods inherited from interface org.infinispan.BaseCacheStreamfilterKeySegmentsMethods inherited from interface java.util.stream.BaseStreamclose, isParallel
- 
Method Details- 
sequentialDistributionIntCacheStream sequentialDistribution()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:
- sequentialDistributionin interface- BaseCacheStream<Integer,- IntStream> 
- Returns:
- a stream with parallel distribution disabled.
 
- 
parallelDistributionIntCacheStream parallelDistribution()Description 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<Integer,- IntStream> 
- Returns:
- a stream with parallel distribution enabled.
 
- 
filterKeysFilters 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<Integer,- IntStream> 
- Parameters:
- keys- The keys that this stream will only operate on.
- Returns:
- a stream with the keys filtered.
 
- 
distributedBatchSizeControls 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<Integer,- IntStream> 
- Parameters:
- batchSize- The size of each batch. This defaults to the state transfer chunk size.
- Returns:
- a stream with the batch size updated
 
- 
segmentCompletionListenerAllows 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<Integer,- IntStream> 
- Parameters:
- listener- The listener that will be called back as segments are completed.
- Returns:
- a stream with the listener registered.
 
- 
disableRehashAwareIntCacheStream disableRehashAware()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:
- disableRehashAwarein interface- BaseCacheStream<Integer,- IntStream> 
- Returns:
- a stream with rehash awareness disabled.
 
- 
timeoutSets 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<Integer,- IntStream> 
- Parameters:
- timeout- the maximum time to wait
- unit- the time unit of the timeout argument
- Returns:
- a stream with the timeout set
 
- 
filter
- 
filterSame asfilter(IntPredicate)except that the IntPredicate must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- predicate- a non-interfering, stateless predicate to apply to each element to determine if it should be included
- Returns:
- the new cache int stream
 
- 
map
- 
mapSame asmap(IntUnaryOperator)except that the IntUnaryOperator must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- mapper- a non-interfering, stateless function to apply to each element
- Returns:
- the new cache int stream
 
- 
mapToObj
- 
mapToObjSame asmapToObj(IntFunction)except that the IntFunction must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Type Parameters:
- U- the element type of the new stream
- Parameters:
- mapper- a non-interfering, stateless function to apply to each element
- Returns:
- the new cache stream
 
- 
mapToDouble- Specified by:
- mapToDoublein interface- IntStream
- Returns:
- the new cache double stream
 
- 
mapToDoubleSame asmapToDouble(IntToDoubleFunction)except that the IntToIntFunction must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- mapper- a non-interfering, stateless function to apply to each element
- Returns:
- the new cache double stream
 
- 
mapToLong
- 
mapToLongSame asmapToLong(IntToLongFunction)except that the IntToLongFunction must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- mapper- a non-interfering, stateless function to apply to each element
- Returns:
- the new cache long stream
 
- 
flatMap
- 
flatMapSame asflatMap(IntFunction)except that the IntFunction must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- mapper- a non-interfering, stateless function to apply to each element which produces a- IntStreamof new values
- Returns:
- the new cache int stream
 
- 
distinctIntCacheStream distinct()
- 
sortedIntCacheStream sorted()
- 
peek
- 
peekSame asflatMap(IntFunction)except that the IntFunction must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- action- a non-interfering action to perform on the elements as they are consumed from the stream
- Returns:
- the new cache int stream
 
- 
limit
- 
skip
- 
forEachSame asIntStream.forEach(IntConsumer)except that the IntConsumer must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- action- a non-interfering action to perform on the elements
 
- 
forEachSame asIntStream.forEach(IntConsumer)except that it takes anObjIntConsumerthat 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.- 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
 
- 
forEach- 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
 
- 
reduceSame asIntStream.reduce(int, IntBinaryOperator)except that the IntBinaryOperator must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- identity- the identity value for the accumulating function
- op- an associative, non-interfering, stateless function for combining two values
- Returns:
- the result of the reduction
 
- 
reduceSame asIntStream.reduce(IntBinaryOperator)except that the IntBinaryOperator must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- op- an associative, non-interfering, stateless function for combining two values
- Returns:
- the result of the reduction
 
- 
collectdefault <R> R collect(SerializableSupplier<R> supplier, SerializableObjIntConsumer<R> accumulator, SerializableBiConsumer<R, R> combiner) Same asIntStream.collect(Supplier, ObjIntConsumer, BiConsumer)except that the arguments must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Type Parameters:
- R- type of the result
- Parameters:
- supplier- a function that creates a new result container. For a parallel execution, this function may be called multiple times and must return a fresh value each time.
- accumulator- an associative, non-interfering, stateless function for incorporating an additional element into a result
- combiner- an associative, non-interfering, stateless function for combining two values, which must be compatible with the accumulator function
- Returns:
- the result of the reduction
 
- 
anyMatchSame asIntStream.anyMatch(IntPredicate)except that the IntPredicate must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- predicate- a non-interfering, stateless predicate to apply to elements of this stream
- Returns:
- trueif any elements of the stream match the provided predicate, otherwise- false
 
- 
allMatchSame asIntStream.allMatch(IntPredicate)except that the IntPredicate must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- predicate- a non-interfering, stateless predicate to apply to elements of this stream
- Returns:
- trueif either all elements of the stream match the provided predicate or the stream is empty, otherwise- false
 
- 
noneMatchSame asIntStream.noneMatch(IntPredicate)except that the IntPredicate must also implementSerializableThe compiler will pick this overload for lambda parameters, making them Serializable- Parameters:
- predicate- a non-interfering, stateless predicate to apply to elements of this stream
- Returns:
- trueif either no elements of the stream match the provided predicate or the stream is empty, otherwise- false
 
- 
boxedCacheStream<Integer> boxed()
- 
asDoubleStreamDoubleCacheStream asDoubleStream()- Specified by:
- asDoubleStreamin interface- IntStream
- Returns:
- the cache double stream
 
- 
asLongStreamLongCacheStream asLongStream()- Specified by:
- asLongStreamin interface- IntStream
- Returns:
- the cache long stream
 
- 
sequentialIntCacheStream sequential()- Specified by:
- sequentialin interface- BaseStream<Integer,- IntStream> 
- Specified by:
- sequentialin interface- IntStream
- Returns:
- a sequential cache int stream
 
- 
parallelIntCacheStream parallel()
- 
unorderedIntCacheStream unordered()- Specified by:
- unorderedin interface- BaseStream<Integer,- IntStream> 
- Returns:
- an unordered cache int stream
 
- 
onClose- Specified by:
- onClosein interface- BaseStream<Integer,- IntStream> 
- Returns:
- a cache int stream with the handler applied
 
 
-