Interface IntCacheStream

All Superinterfaces:
AutoCloseable, BaseCacheStream<Integer,IntStream>, BaseStream<Integer,IntStream>, IntStream
All Known Implementing Classes:
DistributedIntCacheStream, IntermediateIntCacheStream

public interface IntCacheStream extends IntStream, BaseCacheStream<Integer,IntStream>
A IntStream that has additional methods to allow for Serializable instances. Please see CacheStream for additional details about various methods.
Since:
9.0
Author:
wburns
  • Method Details

    • sequentialDistribution

      IntCacheStream 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() and CacheStream.spliterator()

      Specified by:
      sequentialDistribution in interface BaseCacheStream<Integer,IntStream>
      Returns:
      a stream with parallel distribution disabled.
    • parallelDistribution

      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() and CacheStream.spliterator()

      Specified by:
      parallelDistribution in interface BaseCacheStream<Integer,IntStream>
      Returns:
      a stream with parallel distribution enabled.
    • filterKeySegments

      IntCacheStream filterKeySegments(Set<Integer> segments)
      Filters which entries are returned by what segment they are present in. This method can be substantially more efficient than using a regular CacheStream.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 interface BaseCacheStream<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

      IntCacheStream filterKeys(Set<?> keys)
      Filters which entries are returned by only returning ones that map to the given key. This method will be faster than a regular CacheStream.filter(Predicate) if the filter is holding references to the same keys.
      Specified by:
      filterKeys in interface BaseCacheStream<Integer,IntStream>
      Parameters:
      keys - The keys that this stream will only operate on.
      Returns:
      a stream with the keys filtered.
    • distributedBatchSize

      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. This value is ignored when terminal operators that don't track keys are used. Key tracking terminal operators are CacheStream.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 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
    • segmentCompletionListener

      IntCacheStream segmentCompletionListener(BaseCacheStream.SegmentCompletionListener listener)
      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 see CacheStream.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 interface BaseCacheStream<Integer,IntStream>
      Parameters:
      listener - The listener that will be called back as segments are completed.
      Returns:
      a stream with the listener registered.
    • disableRehashAware

      IntCacheStream 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:
      disableRehashAware in interface BaseCacheStream<Integer,IntStream>
      Returns:
      a stream with rehash awareness disabled.
    • timeout

      IntCacheStream timeout(long timeout, TimeUnit unit)
      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 the Iterator or Spliterator.

      Note that if a rehash occurs this timeout value is reset for the subsequent retry if rehash aware is enabled.

      Specified by:
      timeout in 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

      IntCacheStream filter(IntPredicate predicate)
      Specified by:
      filter in interface IntStream
      Returns:
      the new cache int stream
    • filter

      default IntCacheStream filter(SerializableIntPredicate predicate)
      Same as filter(IntPredicate) except that the IntPredicate must also implement Serializable

      The 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

      Specified by:
      map in interface IntStream
      Returns:
      the new cache int stream
    • map

      Same as map(IntUnaryOperator) except that the IntUnaryOperator must also implement Serializable

      The 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

      <U> CacheStream<U> mapToObj(IntFunction<? extends U> mapper)
      Specified by:
      mapToObj in interface IntStream
      Returns:
      the new cache stream
    • mapToObj

      default <U> CacheStream<U> mapToObj(SerializableIntFunction<? extends U> mapper)
      Same as mapToObj(IntFunction) except that the IntFunction must also implement Serializable

      The 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:
      mapToDouble in interface IntStream
      Returns:
      the new cache double stream
    • mapToDouble

      default DoubleCacheStream mapToDouble(SerializableIntToDoubleFunction mapper)
      Same as mapToDouble(IntToDoubleFunction) except that the IntToIntFunction must also implement Serializable

      The 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

      Specified by:
      mapToLong in interface IntStream
      Returns:
      the new cache long stream
    • mapToLong

      default LongCacheStream mapToLong(SerializableIntToLongFunction mapper)
      Same as mapToLong(IntToLongFunction) except that the IntToLongFunction must also implement Serializable

      The 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

      IntCacheStream flatMap(IntFunction<? extends IntStream> mapper)
      Specified by:
      flatMap in interface IntStream
      Returns:
      the new cache int stream
    • flatMap

      default IntCacheStream flatMap(SerializableIntFunction<? extends IntStream> mapper)
      Same as flatMap(IntFunction) except that the IntFunction must also implement Serializable

      The 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 IntStream of new values
      Returns:
      the new cache int stream
    • distinct

      IntCacheStream distinct()
      Specified by:
      distinct in interface IntStream
      Returns:
      the new cache int stream
    • sorted

      IntCacheStream sorted()
      Specified by:
      sorted in interface IntStream
      Returns:
      the new cache int stream
    • peek

      Specified by:
      peek in interface IntStream
      Returns:
      the new cache int stream
    • peek

      default IntCacheStream peek(SerializableIntConsumer action)
      Same as flatMap(IntFunction) except that the IntFunction must also implement Serializable

      The 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

      IntCacheStream limit(long maxSize)
      Specified by:
      limit in interface IntStream
      Returns:
      the new cache int stream
    • skip

      IntCacheStream skip(long n)
      Specified by:
      skip in interface IntStream
      Returns:
      the new cache int stream
    • forEach

      default void forEach(SerializableIntConsumer action)
      Same as IntStream.forEach(IntConsumer) except that the IntConsumer must also implement Serializable

      The compiler will pick this overload for lambda parameters, making them Serializable

      Parameters:
      action - a non-interfering action to perform on the elements
    • forEach

      <K, V> void forEach(ObjIntConsumer<Cache<K,V>> action)
      Same as IntStream.forEach(IntConsumer) except that it takes an ObjIntConsumer that provides access to the underlying Cache 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.

      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

      default <K, V> void forEach(SerializableObjIntConsumer<Cache<K,V>> action)
      Same as forEach(ObjIntConsumer) except that the BiConsumer must also implement Serializable
      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
    • reduce

      default int reduce(int identity, SerializableIntBinaryOperator op)
      Same as IntStream.reduce(int, IntBinaryOperator) except that the IntBinaryOperator must also implement Serializable

      The 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
    • reduce

      Same as IntStream.reduce(IntBinaryOperator) except that the IntBinaryOperator must also implement Serializable

      The 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
    • collect

      default <R> R collect(SerializableSupplier<R> supplier, SerializableObjIntConsumer<R> accumulator, SerializableBiConsumer<R,R> combiner)
      Same as IntStream.collect(Supplier, ObjIntConsumer, BiConsumer) except that the arguments must also implement Serializable

      The 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
    • anyMatch

      default boolean anyMatch(SerializableIntPredicate predicate)
      Same as IntStream.anyMatch(IntPredicate) except that the IntPredicate must also implement Serializable

      The 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:
      true if any elements of the stream match the provided predicate, otherwise false
    • allMatch

      default boolean allMatch(SerializableIntPredicate predicate)
      Same as IntStream.allMatch(IntPredicate) except that the IntPredicate must also implement Serializable

      The 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:
      true if either all elements of the stream match the provided predicate or the stream is empty, otherwise false
    • noneMatch

      default boolean noneMatch(SerializableIntPredicate predicate)
      Same as IntStream.noneMatch(IntPredicate) except that the IntPredicate must also implement Serializable

      The 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:
      true if either no elements of the stream match the provided predicate or the stream is empty, otherwise false
    • boxed

      Specified by:
      boxed in interface IntStream
      Returns:
      the new cache stream containing integers
    • asDoubleStream

      DoubleCacheStream asDoubleStream()
      Specified by:
      asDoubleStream in interface IntStream
      Returns:
      the cache double stream
    • asLongStream

      LongCacheStream asLongStream()
      Specified by:
      asLongStream in interface IntStream
      Returns:
      the cache long stream
    • sequential

      IntCacheStream sequential()
      Specified by:
      sequential in interface BaseStream<Integer,IntStream>
      Specified by:
      sequential in interface IntStream
      Returns:
      a sequential cache int stream
    • parallel

      IntCacheStream parallel()
      Specified by:
      parallel in interface BaseStream<Integer,IntStream>
      Specified by:
      parallel in interface IntStream
      Returns:
      a parallel cache int stream
    • unordered

      IntCacheStream unordered()
      Specified by:
      unordered in interface BaseStream<Integer,IntStream>
      Returns:
      an unordered cache int stream
    • onClose

      IntCacheStream onClose(Runnable closeHandler)
      Specified by:
      onClose in interface BaseStream<Integer,IntStream>
      Returns:
      a cache int stream with the handler applied