Uses of Interface
org.infinispan.commons.util.IntSet
Packages that use IntSet
Package
Description
This is the core of Infinispan, a distributed, transactional, highly scalable data grid
platform.
Hot Rod client API.
Commands that operate on the cache, either locally or remotely.
Commons package providing various utility classes
Data containers which store cache entries.
Classes relating to the distributed cache mode.
Persistence API.
Simple filesystem-based
NonBlockingStore implementation.This package contains a
NonBlockingStore implementation based on
a JDBC database connection.JDBC CacheStore implementation which maps keys to strings.
Hot Rod-based
NonBlockingStore.RocksDB-based
NonBlockingStore.Soft Index
NonBlockingStore.The Persistence SPI.
This package contains a
NonBlockingStore implementation based on
a JDBC database connection.General utilities that are not specific to Infinispan, including string parsing helpers, reflection tools and
collections and containers designed to supplement the JDK-provided containers.
Infinispan's logging abstractions that delegate to either JDK or Log4J logging engines.
-
Uses of IntSet in org.infinispan
Methods in org.infinispan with parameters of type IntSetModifier and TypeMethodDescriptionBaseCacheStream.filterKeySegments(IntSet segments) Filters which entries are returned by what segment they are present in.CacheStream.filterKeySegments(IntSet segments) Filters which entries are returned by what segment they are present in.LockedStream.filterKeySegments(IntSet segments) Filters which entries are returned by what segment they are present in.default org.reactivestreams.Publisher<E> CacheCollection.localPublisher(IntSet segments) Returns a publisher that will publish all elements that map to the given segment.abstract org.reactivestreams.Publisher<E> InternalCacheSet.localPublisher(IntSet segments) CachePublisher.withSegments(IntSet segments) Configures the publisher to only publish keys or values that map to a given segment in the provided IntSet. -
Uses of IntSet in org.infinispan.cache.impl
Methods in org.infinispan.cache.impl with parameters of type IntSet -
Uses of IntSet in org.infinispan.client.hotrod
Methods in org.infinispan.client.hotrod with parameters of type IntSetModifier and TypeMethodDescriptionThis method is identical toRemoteCache.entrySet()except that it will only return entries that map to the given segments.This method is identical toRemoteCache.keySet()except that it will only return keys that map to the given segments.This method is identical toRemoteCache.values()except that it will only return values that map to the given segments. -
Uses of IntSet in org.infinispan.client.hotrod.impl
Methods in org.infinispan.client.hotrod.impl with parameters of type IntSetModifier and TypeMethodDescriptionDelegatingRemoteCache.entryIterator(IntSet segments) InternalRemoteCache.entryIterator(IntSet segments) RemoteCacheImpl.entryIterator(IntSet segments) DelegatingRemoteCache.keyIterator(IntSet segments) InternalRemoteCache.keyIterator(IntSet segments) RemoteCacheImpl.keyIterator(IntSet segments) -
Uses of IntSet in org.infinispan.commands
Methods in org.infinispan.commands with parameters of type IntSetModifier and TypeMethodDescriptionorg.infinispan.commands.statetransfer.ConflictResolutionStartCommandCommandsFactory.buildConflictResolutionStartCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ConflictResolutionStartCommandCommandsFactoryImpl.buildConflictResolutionStartCommand(int topologyId, IntSet segments) <K,V, R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> CommandsFactory.buildEntryReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <K,V, R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> CommandsFactoryImpl.buildEntryReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <K,I, R> org.infinispan.reactive.publisher.impl.commands.batch.InitialPublisherCommand <K, I, R> CommandsFactory.buildInitialPublisherCommand(String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) <K,I, R> org.infinispan.reactive.publisher.impl.commands.batch.InitialPublisherCommand <K, I, R> CommandsFactoryImpl.buildInitialPublisherCommand(String requestId, DeliveryGuarantee deliveryGuarantee, int batchSize, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, boolean entryStream, boolean trackKeys, Function<? super org.reactivestreams.Publisher<I>, ? extends org.reactivestreams.Publisher<R>> transformer) org.infinispan.commands.irac.IracRequestStateCommandCommandsFactory.buildIracRequestStateCommand(IntSet segments) org.infinispan.commands.irac.IracRequestStateCommandCommandsFactoryImpl.buildIracRequestStateCommand(IntSet segments) <K,R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> CommandsFactory.buildKeyReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <K,R> org.infinispan.reactive.publisher.impl.commands.reduction.ReductionPublisherRequestCommand <K> CommandsFactoryImpl.buildKeyReductionPublisherCommand(boolean parallelStream, DeliveryGuarantee deliveryGuarantee, IntSet segments, Set<K> keys, Set<K> excludedKeys, long explicitFlags, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) org.infinispan.commands.read.SizeCommandCommandsFactory.buildSizeCommand(IntSet segments, long flagsBitSet) Builds a SizeCommandorg.infinispan.commands.read.SizeCommandCommandsFactoryImpl.buildSizeCommand(IntSet segments, long flagsBitSet) org.infinispan.commands.statetransfer.StateTransferCancelCommandCommandsFactory.buildStateTransferCancelCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferCancelCommandCommandsFactoryImpl.buildStateTransferCancelCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommandCommandsFactory.buildStateTransferGetTransactionsCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommandCommandsFactoryImpl.buildStateTransferGetTransactionsCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommandCommandsFactory.buildStateTransferStartCommand(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommandCommandsFactoryImpl.buildStateTransferStartCommand(int topologyId, IntSet segments) -
Uses of IntSet in org.infinispan.commons.util
Classes in org.infinispan.commons.util that implement IntSetModifier and TypeClassDescriptionclassConcurrent implementation of anIntSet.classImmutable empty IntSetclassRead-only set representing all the integers from0tosize - 1(inclusive).classImmutable implementation of IntSet that contains a single valueclassRepresent a set of integers (e.g. segments) as aBitSet.Methods in org.infinispan.commons.util that return IntSetModifier and TypeMethodDescriptionstatic IntSetIntSets.concurrentCopyFrom(IntSet intSet, int maxExclusive) Returns a copy of the given set that supports concurrent operations.static IntSetIntSets.concurrentSet(int maxExclusive) Returns a concurrent mutable IntSet that can store values in the range of0..maxExclusive-1static IntSetIntSets.from(byte[] bytes) static IntSetIntSets.from(PrimitiveIterator.OfInt iterator) Returns an IntSet based on the ints in the iterator.static IntSetReturns an IntSet based on the provided Set.BloomFilter.getIntSet()static IntSetIntSets.immutableEmptySet()Returns an immutable IntSet containing no valuesstatic IntSetIntSets.immutableOffsetIntSet(int start, int exclusiveEnd) Creates an immutableIntSetcontaining all values from to .static IntSetIntSets.immutableRangeSet(int endExclusive) Returns an immutable IntSet containing all values from0toendExclusive - 1.static IntSetIntSets.immutableSet(int value) Returns an immutable IntSet containing a single valuestatic IntSetIntSets.immutableSet(IntSet set) Returns an immutable IntSet that wraps the given IntSet to prevent modifications.static IntSetIntSets.mutableCopyFrom(Set<Integer> mutableSet) Returns an IntSet that contains all ints from the given Set that is mutable.static IntSetIntSets.mutableEmptySet()Returns a mutable IntSet with no values set.static IntSetIntSets.mutableEmptySet(int maxExclusive) Returns an IntSet that contains no values but is initialized to hold ints equal to themaxExclusive -1or smaller.static IntSetIntSets.mutableFrom(Set<Integer> integerSet) Returns an IntSet that is mutable that contains all of the values from the given set.static IntSetIntSets.mutableSet(int value) Returns a mutable set with the initial value set.static IntSetIntSets.mutableSet(int value1, int value2) Returns a mutable IntSet that begins with the initialized valuesMethods in org.infinispan.commons.util with parameters of type IntSetModifier and TypeMethodDescriptionbooleanbooleanAdds all ints from the provided set into this onebooleanbooleanstatic IntSetIntSets.concurrentCopyFrom(IntSet intSet, int maxExclusive) Returns a copy of the given set that supports concurrent operations.booleanConcurrentSmallIntSet.containsAll(IntSet set) booleanEmptyIntSet.containsAll(IntSet set) booleanIntSet.containsAll(IntSet set) Whether this set contains all ints in the given IntSetbooleanRangeSet.containsAll(IntSet set) booleanSingletonIntSet.containsAll(IntSet set) booleanSmallIntSet.containsAll(IntSet set) static IntSetIntSets.immutableSet(IntSet set) Returns an immutable IntSet that wraps the given IntSet to prevent modifications.booleanbooleanRemoves all ints from this IntSet that are in the provided IntSetbooleanbooleanbooleanbooleanModifies this set to remove all ints that are not present in the provided IntSetbooleanbooleanvoidClears all current bits and sets them to the values in the providedIntSet. -
Uses of IntSet in org.infinispan.container.impl
Methods in org.infinispan.container.impl with parameters of type IntSetModifier and TypeMethodDescriptionvoidAbstractDelegatingInternalDataContainer.addSegments(IntSet segments) voidDefaultDataContainer.addSegments(IntSet segments) voidDefaultSegmentedDataContainer.addSegments(IntSet segments) voidInternalDataContainer.addSegments(IntSet segments) Sets what segments this data container should be using.voidvoidvoidvoidvoidRemoves entries from the container whose key maps to one of the provided segmentsvoidRemoves all entries that map to the given segmentsvoidAbstractDelegatingInternalDataContainer.forEach(IntSet segments, Consumer<? super InternalCacheEntry<K, V>> action) voidDefaultSegmentedDataContainer.forEach(IntSet segments, Consumer<? super InternalCacheEntry<K, V>> action) default voidPerforms the given action for each element of the container that maps to the given set of segments until all elements have been processed or the action throws an exception.Same asDataContainer.iterator()except that only entries that map to the provided segments are returned via the iterator.AbstractDelegatingInternalDataContainer.iteratorIncludingExpired(IntSet segments) BoundedSegmentedDataContainer.iteratorIncludingExpired(IntSet segments) DefaultDataContainer.iteratorIncludingExpired(IntSet segments) DefaultSegmentedDataContainer.iteratorIncludingExpired(IntSet segments) InternalDataContainer.iteratorIncludingExpired(IntSet segments) Same asDataContainer.iteratorIncludingExpired()except that only entries that map to the provided segments are returned via the iterator.L1SegmentedDataContainer.iteratorIncludingExpired(IntSet segments) org.reactivestreams.Publisher<InternalCacheEntry<K, V>> org.reactivestreams.Publisher<InternalCacheEntry<K, V>> default org.reactivestreams.Publisher<InternalCacheEntry<K, V>> voidAbstractDelegatingInternalDataContainer.removeSegments(IntSet segments) voidBoundedSegmentedDataContainer.removeSegments(IntSet segments) voidDefaultDataContainer.removeSegments(IntSet segments) voidDefaultSegmentedDataContainer.removeSegments(IntSet segments) voidInternalDataContainer.removeSegments(IntSet segments) Removes and un-associates the given segments.voidL1SegmentedDataContainer.removeSegments(IntSet segments) intdefault intReturns how many entries are present in the data container that map to the given segments without counting entries that are currently expired.intAbstractDelegatingInternalDataContainer.sizeIncludingExpired(IntSet segments) intDefaultSegmentedDataContainer.sizeIncludingExpired(IntSet segment) default intInternalDataContainer.sizeIncludingExpired(IntSet segments) Returns how many entries are present in the data container that map to the given segments including any entries that may be expiredAbstractDelegatingInternalDataContainer.spliterator(IntSet segments) DefaultDataContainer.spliterator(IntSet segments) DefaultSegmentedDataContainer.spliterator(IntSet segments) InternalDataContainer.spliterator(IntSet segments) Same asDataContainer.spliterator()except that only entries that map to the provided segments are returned via this spliterator.AbstractDelegatingInternalDataContainer.spliteratorIncludingExpired(IntSet segments) BoundedSegmentedDataContainer.spliteratorIncludingExpired(IntSet segments) DefaultDataContainer.spliteratorIncludingExpired(IntSet segments) DefaultSegmentedDataContainer.spliteratorIncludingExpired(IntSet segments) InternalDataContainer.spliteratorIncludingExpired(IntSet segments) Same asDataContainer.spliteratorIncludingExpired()except that only entries that map to the provided segments are returned via this spliterator.L1SegmentedDataContainer.spliteratorIncludingExpired(IntSet segments) -
Uses of IntSet in org.infinispan.container.offheap
Methods in org.infinispan.container.offheap with parameters of type IntSetModifier and TypeMethodDescriptionvoidBoundedOffHeapDataContainer.addSegments(IntSet segments) voidOffHeapDataContainer.addSegments(IntSet segments) BoundedOffHeapDataContainer.iteratorIncludingExpired(IntSet segments) OffHeapDataContainer.iteratorIncludingExpired(IntSet segments) voidBoundedOffHeapDataContainer.removeSegments(IntSet segments) voidOffHeapDataContainer.removeSegments(IntSet segments) intintBoundedOffHeapDataContainer.sizeIncludingExpired(IntSet segments) BoundedOffHeapDataContainer.spliterator(IntSet segments) OffHeapDataContainer.spliterator(IntSet segments) BoundedOffHeapDataContainer.spliteratorIncludingExpired(IntSet segments) OffHeapDataContainer.spliteratorIncludingExpired(IntSet segments) -
Uses of IntSet in org.infinispan.container.versioning.irac
Methods in org.infinispan.container.versioning.irac with parameters of type IntSetModifier and TypeMethodDescriptionvoidDefaultIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) voidIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) Sends the tombstone belonging to the segments insegmentto theoriginatorvoidNoOpIracTombstoneManager.sendStateTo(Address requestor, IntSet segments) -
Uses of IntSet in org.infinispan.distribution
Methods in org.infinispan.distribution that return IntSetModifier and TypeMethodDescriptionLocalizedCacheTopology.getLocalPrimarySegments()LocalizedCacheTopology.getLocalReadSegments()LocalizedCacheTopology.getLocalWriteSegments() -
Uses of IntSet in org.infinispan.distribution.util
Fields in org.infinispan.distribution.util declared as IntSetModifier and TypeFieldDescriptionprotected final IntSetReadOnlySegmentAwareCollection.allowedSegmentsprotected final IntSetReadOnlySegmentAwareIterator.allowedSegmentsprotected final IntSetReadOnlySegmentAwareMap.allowedSegmentsConstructors in org.infinispan.distribution.util with parameters of type IntSetModifierConstructorDescriptionReadOnlySegmentAwareCollection(Collection<E> set, LocalizedCacheTopology topology, IntSet allowedSegments) ReadOnlySegmentAwareEntryCollection(Set<Map.Entry<K, V>> set, LocalizedCacheTopology topology, IntSet allowedSegments) ReadOnlySegmentAwareEntryIterator(Iterator<Map.Entry<K, V>> iter, LocalizedCacheTopology topology, IntSet allowedSegments) ReadOnlySegmentAwareIterator(Iterator<E> iter, LocalizedCacheTopology topology, IntSet allowedSegments) ReadOnlySegmentAwareMap(Map<K, V> map, LocalizedCacheTopology topology, IntSet allowedSegments) -
Uses of IntSet in org.infinispan.persistence
Methods in org.infinispan.persistence with parameters of type IntSetModifier and TypeMethodDescriptionstatic <R> org.reactivestreams.Publisher<R> PersistenceUtil.parallelizePublisher(IntSet segments, Executor executor, IntFunction<org.reactivestreams.Publisher<R>> publisherFunction) Will create a publisher that parallelizes each publisher returned from the publisherFunction by executing them on the executor as needed.static <K,V> Set <K> PersistenceUtil.toKeySet(NonBlockingStore<K, V> nonBlockingStore, IntSet segments, Predicate<? super K> filter) -
Uses of IntSet in org.infinispan.persistence.async
Methods in org.infinispan.persistence.async with parameters of type IntSetModifier and TypeMethodDescriptionAsyncNonBlockingStore.addSegments(IntSet segments) AsyncNonBlockingStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> AsyncNonBlockingStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K> AsyncNonBlockingStore.publishKeys(IntSet segments, Predicate<? super K> filter) AsyncNonBlockingStore.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.file
Methods in org.infinispan.persistence.file with parameters of type IntSetModifier and TypeMethodDescriptionSingleFileStore.addSegments(IntSet segments) SingleFileStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> SingleFileStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K> SingleFileStore.publishKeys(IntSet segments, Predicate<? super K> filter) SingleFileStore.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.internal
Methods in org.infinispan.persistence.internal with parameters of type IntSetModifier and TypeMethodDescriptionstatic <K> Predicate<? super K> PersistenceUtil.combinePredicate(IntSet segments, KeyPartitioner keyPartitioner, Predicate<? super K> filter) static <R> io.reactivex.rxjava3.core.Flowable<R> PersistenceUtil.parallelizePublisher(IntSet segments, io.reactivex.rxjava3.core.Scheduler scheduler, IntFunction<org.reactivestreams.Publisher<R>> publisherFunction) -
Uses of IntSet in org.infinispan.persistence.jdbc.common
Methods in org.infinispan.persistence.jdbc.common with parameters of type IntSetModifier and TypeMethodDescriptionio.reactivex.rxjava3.core.Flowable<MarshallableEntry<K, V>> TableOperations.publishEntries(Supplier<Connection> connectionSupplier, Consumer<Connection> connectionCloser, IntSet segments, Predicate<? super K> filter, boolean fetchValue) default io.reactivex.rxjava3.core.Flowable<K> TableOperations.publishKeys(Supplier<Connection> connectionSupplier, Consumer<Connection> connectionCloser, IntSet segments, Predicate<? super K> filter) -
Uses of IntSet in org.infinispan.persistence.jdbc.common.impl
Methods in org.infinispan.persistence.jdbc.common.impl with parameters of type IntSetModifier and TypeMethodDescriptionBaseJdbcStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> BaseJdbcStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K> BaseJdbcStore.publishKeys(IntSet segments, Predicate<? super K> filter) -
Uses of IntSet in org.infinispan.persistence.jdbc.common.sql
Methods in org.infinispan.persistence.jdbc.common.sql with parameters of type IntSetModifier and TypeMethodDescriptionabstract StringBaseTableOperations.getSelectAllSql(IntSet segments) protected voidBaseTableOperations.preparePublishStatement(PreparedStatement ps, IntSet segments) io.reactivex.rxjava3.core.Flowable<MarshallableEntry<K, V>> BaseTableOperations.publishEntries(Supplier<Connection> connectionSupplier, Consumer<Connection> connectionCloser, IntSet segments, Predicate<? super K> filter, boolean fetchValue) -
Uses of IntSet in org.infinispan.persistence.jdbc.stringbased
Methods in org.infinispan.persistence.jdbc.stringbased with parameters of type IntSetModifier and TypeMethodDescriptionJdbcStringBasedStore.addSegments(IntSet segments) JdbcStringBasedStore.approximateSize(IntSet segments) JdbcStringBasedStore.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.remote
Methods in org.infinispan.persistence.remote with parameters of type IntSetModifier and TypeMethodDescriptionRemoteStore.addSegments(IntSet segments) RemoteStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> RemoteStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) io.reactivex.rxjava3.core.Flowable<K> RemoteStore.publishKeys(IntSet segments, Predicate<? super K> filter) RemoteStore.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.rocksdb
Methods in org.infinispan.persistence.rocksdb with parameters of type IntSetModifier and TypeMethodDescriptionRocksDBStore.addSegments(IntSet segments) RocksDBStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> RocksDBStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K> RocksDBStore.publishKeys(IntSet segments, Predicate<? super K> filter) RocksDBStore.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.sifs
Methods in org.infinispan.persistence.sifs with parameters of type IntSetModifier and TypeMethodDescriptionNonBlockingSoftIndexFileStore.addSegments(IntSet segments) voidTemporaryTable.addSegments(IntSet segments) NonBlockingSoftIndexFileStore.approximateSize(IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> NonBlockingSoftIndexFileStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K> NonBlockingSoftIndexFileStore.publishKeys(IntSet segments, Predicate<? super K> filter) NonBlockingSoftIndexFileStore.removeSegments(IntSet segments) voidTemporaryTable.removeSegments(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.spi
Methods in org.infinispan.persistence.spi with parameters of type IntSetModifier and TypeMethodDescriptiondefault CompletionStage<Void> NonBlockingStore.addSegments(IntSet segments) Invoked when a node becomes an owner of the given segments.default CompletionStage<Long> NonBlockingStore.approximateSize(IntSet segments) Returns an estimation of the amount of entries that map to the given segments in the store.default org.reactivestreams.Publisher<MarshallableEntry<K, V>> NonBlockingStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) Publishes entries from this store that are in one of the provided segments and also pass the provided filter.default org.reactivestreams.Publisher<K> NonBlockingStore.publishKeys(IntSet segments, Predicate<? super K> filter) Publishes keys from this store that are in one of the provided segments and also pass the provided filter.default CompletionStage<Void> NonBlockingStore.removeSegments(IntSet segments) Invoked when a node loses ownership of the given segments.default CompletionStage<Long> Returns the amount of entries that map to the given segments in the store. -
Uses of IntSet in org.infinispan.persistence.sql
Methods in org.infinispan.persistence.sql with parameters of type IntSetModifier and TypeMethodDescriptionQueriesJdbcStore.QueryTableOperations.getSelectAllSql(IntSet segments) TableJdbcStore.TableTableOperations.getSelectAllSql(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.support
Methods in org.infinispan.persistence.support with parameters of type IntSetModifier and TypeMethodDescriptionDelegatingNonBlockingStore.addSegments(IntSet segments) DelegatingPersistenceManager.addSegments(IntSet segments) DelegatingNonBlockingStore.approximateSize(IntSet segments) DelegatingPersistenceManager.approximateSize(Predicate<? super StoreConfiguration> predicate, IntSet segments) org.reactivestreams.Publisher<MarshallableEntry<K, V>> DelegatingNonBlockingStore.publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) <K,V> org.reactivestreams.Publisher <MarshallableEntry<K, V>> DelegatingPersistenceManager.publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata, Predicate<? super StoreConfiguration> predicate) org.reactivestreams.Publisher<K> DelegatingNonBlockingStore.publishKeys(IntSet segments, Predicate<? super K> filter) <K> org.reactivestreams.Publisher<K> DelegatingPersistenceManager.publishKeys(IntSet segments, Predicate<? super K> filter, Predicate<? super StoreConfiguration> predicate) DelegatingNonBlockingStore.removeSegments(IntSet segments) DelegatingPersistenceManager.removeSegments(IntSet segments) DelegatingPersistenceManager.size(Predicate<? super StoreConfiguration> predicate, IntSet segments) -
Uses of IntSet in org.infinispan.reactive.publisher.impl
Methods in org.infinispan.reactive.publisher.impl with parameters of type IntSetModifier and TypeMethodDescription<R> SegmentPublisherSupplier<R> ClusterPublisherManager.entryPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) Performs the given transformer on data in the cache, resulting in multiple values.<R> SegmentPublisherSupplier<R> ClusterPublisherManagerImpl.entryPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R> LocalClusterPublisherManagerImpl.entryPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) LocalPublisherManager.entryPublisher(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) Performs the given transformer on data in the cache that is local, resulting in a stream of values of possibly varying size.LocalPublisherManagerImpl.entryPublisher(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R> PartitionAwareClusterPublisherManager.entryPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> CompletionStage<R> ClusterPublisherManager.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Performs the given transformer and finalizer on data in the cache, resulting in a single value.<R> CompletionStage<R> ClusterPublisherManagerImpl.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R> LocalClusterPublisherManagerImpl.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>> LocalPublisherManager.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Performs the given transformer and finalizer on data in the cache that is local, resulting in a single value.<R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>> LocalPublisherManagerImpl.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> collator, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R> PartitionAwareClusterPublisherManager.entryReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<CacheEntry<K, V>>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) protected <I,R> io.reactivex.rxjava3.core.Flowable <R> LocalPublisherManagerImpl.exactlyOnceParallel(CacheSet<I> set, Set<K> keysToExclude, Function<I, K> toKeyFunction, IntSet segments, Function<? super org.reactivestreams.Publisher<I>, ? extends CompletionStage<R>> collator, LocalPublisherManagerImpl<K, V>.org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl.SegmentListener listener, IntSet concurrentSegments) This method iteratively submits a task to operate on the cpu bound thread pool up to the number of cores - 1.protected <I,R> io.reactivex.rxjava3.core.Flowable <R> LocalPublisherManagerImpl.exactlyOnceSequential(CacheSet<I> set, Set<K> keysToExclude, Function<I, K> toKeyFunction, IntSet segments, Function<? super org.reactivestreams.Publisher<I>, ? extends CompletionStage<R>> collator, LocalPublisherManagerImpl<K, V>.org.infinispan.reactive.publisher.impl.LocalPublisherManagerImpl.SegmentListener listener, IntSet concurrentSegments) <R> SegmentPublisherSupplier<R> ClusterPublisherManager.keyPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) Same asClusterPublisherManager.entryPublisher(IntSet, Set, InvocationContext, long, DeliveryGuarantee, int, Function)except that the source publisher provided to the transformer is made up of keys only.<R> SegmentPublisherSupplier<R> ClusterPublisherManagerImpl.keyPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R> LocalClusterPublisherManagerImpl.keyPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) LocalPublisherManager.keyPublisher(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) Same asLocalPublisherManager.entryPublisher(IntSet, Set, Set, long, DeliveryGuarantee, Function)except that the source publisher provided to the transformer is made up of keys only.LocalPublisherManagerImpl.keyPublisher(IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> SegmentPublisherSupplier<R> PartitionAwareClusterPublisherManager.keyPublisher(IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, int batchSize, Function<? super org.reactivestreams.Publisher<K>, ? extends org.reactivestreams.Publisher<R>> transformer) <R> CompletionStage<R> ClusterPublisherManager.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Same asClusterPublisherManager.entryReduction(boolean, IntSet, Set, InvocationContext, long, DeliveryGuarantee, Function, Function)except that the source publisher provided to the transformer is made up of keys only.<R> CompletionStage<R> ClusterPublisherManagerImpl.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R> LocalClusterPublisherManagerImpl.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext invocationContext, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>> LocalPublisherManager.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) Same asLocalPublisherManager.entryReduction(boolean, IntSet, Set, Set, long, DeliveryGuarantee, Function, Function)except that the source publisher provided to the transformer is made up of keys only.<R> CompletionStage<org.infinispan.reactive.publisher.impl.commands.reduction.PublisherResult<R>> LocalPublisherManagerImpl.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> collator, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) <R> CompletionStage<R> PartitionAwareClusterPublisherManager.keyReduction(boolean parallelPublisher, IntSet segments, Set<K> keysToInclude, InvocationContext ctx, long explicitFlags, DeliveryGuarantee deliveryGuarantee, Function<? super org.reactivestreams.Publisher<K>, ? extends CompletionStage<R>> transformer, Function<? super org.reactivestreams.Publisher<R>, ? extends CompletionStage<R>> finalizer) voidLocalPublisherManager.segmentsLost(IntSet lostSegments) Method to invoke when a set of segments are being removed from this node.voidLocalPublisherManagerImpl.segmentsLost(IntSet lostSegments) ClusterPublisherManager.sizePublisher(IntSet segments, InvocationContext ctx, long flags) ClusterPublisherManagerImpl.sizePublisher(IntSet segments, InvocationContext ctx, long flags) LocalClusterPublisherManagerImpl.sizePublisher(IntSet segments, InvocationContext ctx, long flags) LocalPublisherManager.sizePublisher(IntSet segments, long flags) LocalPublisherManagerImpl.sizePublisher(IntSet segments, long flags) Constructor parameters in org.infinispan.reactive.publisher.impl with type arguments of type IntSetModifierConstructorDescriptionInnerPublisherSubscriptionBuilder(ClusterPublisherManagerImpl<K, ?>.org.infinispan.reactive.publisher.impl.ClusterPublisherManagerImpl.SubscriberHandler<I, R> parent, int batchSize, Supplier<Map.Entry<Address, IntSet>> supplier, Map<Address, Set<K>> excludedKeys, int topologyId) -
Uses of IntSet in org.infinispan.server.iteration.list
Methods in org.infinispan.server.iteration.list with parameters of type IntSetModifier and TypeMethodDescriptionListStreamSupplier.buildStream(IntSet ignore, Set valuesToFilter, boolean parallel) -
Uses of IntSet in org.infinispan.server.iteration.map
Methods in org.infinispan.server.iteration.map with parameters of type IntSetModifier and TypeMethodDescriptionMapStreamSupplier.buildStream(IntSet ignore, Set keysToFilter, boolean parallel) -
Uses of IntSet in org.infinispan.server.resp.commands.cluster
Methods in org.infinispan.server.resp.commands.cluster that return IntSet -
Uses of IntSet in org.infinispan.stream.impl
Fields in org.infinispan.stream.impl declared as IntSetMethods in org.infinispan.stream.impl with parameters of type IntSetModifier and TypeMethodDescriptionDistributedCacheStream.filterKeySegments(IntSet segments) DistributedDoubleCacheStream.filterKeySegments(IntSet segments) DistributedIntCacheStream.filterKeySegments(IntSet segments) DistributedLongCacheStream.filterKeySegments(IntSet segments) IntermediateCacheStream.filterKeySegments(IntSet segments) IntermediateDoubleCacheStream.filterKeySegments(IntSet segments) IntermediateIntCacheStream.filterKeySegments(IntSet segments) IntermediateLongCacheStream.filterKeySegments(IntSet segments) LockedStreamImpl.filterKeySegments(IntSet segments) -
Uses of IntSet in org.infinispan.util
Methods in org.infinispan.util with parameters of type IntSetModifier and TypeMethodDescriptionAbstractDelegatingCacheStream.filterKeySegments(IntSet segments) -
Uses of IntSet in org.infinispan.util.logging
Methods in org.infinispan.util.logging with parameters of type IntSetModifier and TypeMethodDescriptionfinal voidLog_$logger.failedToTransferTombstones(Address requestor, IntSet segments, Throwable t) -
Uses of IntSet in org.infinispan.xsite.commands.remote
Subclasses with type arguments of type IntSet in org.infinispan.xsite.commands.remoteModifier and TypeClassDescriptionclassA multi-key cross-site requests.classAXSiteCacheRequestto check tombstones for IRAC algorithm.Methods in org.infinispan.xsite.commands.remote that return types with arguments of type IntSetModifier and TypeMethodDescriptionIracPutManyRequest.executeOperation(org.infinispan.xsite.BackupReceiver receiver) protected CompletionStage<IntSet> IracTombstoneCheckRequest.invokeInLocalCache(String origin, ComponentRegistry registry) -
Uses of IntSet in org.infinispan.xsite.irac
Classes in org.infinispan.xsite.irac that implement interfaces with type arguments of type IntSetModifier and TypeClassDescriptionclassA response collector for an asynchronous cross site requests.Methods in org.infinispan.xsite.irac with parameters of type IntSetModifier and TypeMethodDescriptionvoidvoidDefaultIracManager.requestState(Address requestor, IntSet segments) voidIracManager.requestState(Address requestor, IntSet segments) Requests the state stored in this instance for the givensegments.voidNoOpIracManager.requestState(Address requestor, IntSet segments)