Uses of Interface
org.infinispan.commons.util.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
CacheWriter
implementation.This package contains a
AdvancedLoadWriteStore
implementation based on
a JDBC database connection.JDBC CacheStore implementation which maps keys to strings.
Hot Rod-based
AdvancedLoadWriteStore
.RocksDB-based
AdvancedLoadWriteStore
.Soft Index
AdvancedLoadWriteStore
.The Persistence SPI.
This package contains a
AdvancedLoadWriteStore
implementation based on
a JDBC database connection.SCATTERED CACHE DESIGN
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.
-
Uses of IntSet in org.infinispan
Modifier 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) -
Uses of IntSet in org.infinispan.client.hotrod
Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionorg.infinispan.commands.statetransfer.ConflictResolutionStartCommand
CommandsFactory.buildConflictResolutionStartCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ConflictResolutionStartCommand
CommandsFactoryImpl.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.IracRequestStateCommand
CommandsFactory.buildIracRequestStateCommand
(IntSet segments) org.infinispan.commands.irac.IracRequestStateCommand
CommandsFactoryImpl.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.statetransfer.ScatteredStateConfirmRevokedCommand
CommandsFactory.buildScatteredStateConfirmRevokeCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ScatteredStateConfirmRevokedCommand
CommandsFactoryImpl.buildScatteredStateConfirmRevokeCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ScatteredStateGetKeysCommand
CommandsFactory.buildScatteredStateGetKeysCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.ScatteredStateGetKeysCommand
CommandsFactoryImpl.buildScatteredStateGetKeysCommand
(int topologyId, IntSet segments) org.infinispan.commands.read.SizeCommand
CommandsFactory.buildSizeCommand
(IntSet segments, long flagsBitSet) Builds a SizeCommandorg.infinispan.commands.read.SizeCommand
CommandsFactoryImpl.buildSizeCommand
(IntSet segments, long flagsBitSet) org.infinispan.commands.statetransfer.StateTransferCancelCommand
CommandsFactory.buildStateTransferCancelCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferCancelCommand
CommandsFactoryImpl.buildStateTransferCancelCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand
CommandsFactory.buildStateTransferGetTransactionsCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferGetTransactionsCommand
CommandsFactoryImpl.buildStateTransferGetTransactionsCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommand
CommandsFactory.buildStateTransferStartCommand
(int topologyId, IntSet segments) org.infinispan.commands.statetransfer.StateTransferStartCommand
CommandsFactoryImpl.buildStateTransferStartCommand
(int topologyId, IntSet segments) -
Uses of IntSet in org.infinispan.commons.util
Modifier and TypeClassDescriptionclass
Deprecated, for removal: This API element is subject to removal in a future version.class
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3 This class will no longer be public.class
Deprecated, for removal: This API element is subject to removal in a future version.since 9.3 This class will no longer be public.Modifier and TypeMethodDescriptionstatic IntSet
IntSets.concurrentCopyFrom
(IntSet intSet, int maxExclusive) Returns a copy of the given set that supports concurrent operations.static IntSet
IntSets.concurrentSet
(int maxExclusive) Returns a concurrent mutable IntSet that can store values in the range of0..maxExclusive-1
static IntSet
IntSets.from
(byte[] bytes) static IntSet
IntSets.from
(PrimitiveIterator.OfInt iterator) Returns an IntSet based on the ints in the iterator.static IntSet
Returns an IntSet based on the provided Set.BloomFilter.getIntSet()
static IntSet
IntSets.immutableEmptySet()
Returns an immutable IntSet containing no valuesstatic IntSet
IntSets.immutableRangeSet
(int endExclusive) Returns an immutable IntSet containing all values from0
toendExclusive - 1
.static IntSet
IntSets.immutableSet
(int value) Returns an immutable IntSet containing a single valuestatic IntSet
IntSets.immutableSet
(IntSet set) Returns an immutable IntSet that wraps the given IntSet to prevent modifications.static IntSet
IntSets.mutableCopyFrom
(Set<Integer> mutableSet) Returns an IntSet that contains all ints from the given Set that is mutable.static IntSet
IntSets.mutableEmptySet()
Returns a mutable IntSet with no values set.static IntSet
IntSets.mutableEmptySet
(int maxExclusive) Returns an IntSet that contains no values but is initialized to hold ints equal to themaxExclusive -1
or smaller.static IntSet
IntSets.mutableFrom
(Set<Integer> integerSet) Returns an IntSet that is mutable that contains all of the values from the given set.static IntSet
IntSets.mutableSet
(int value) Returns a mutable set with the initial value set.static IntSet
IntSets.mutableSet
(int value1, int value2) Returns a mutable IntSet that begins with the initialized valuesstatic IntSet
IntSetsExternalization.readFrom
(ObjectInput input) Modifier and TypeMethodDescriptionboolean
Deprecated, for removal: This API element is subject to removal in a future version.boolean
Adds all ints from the provided set into this oneboolean
Deprecated, for removal: This API element is subject to removal in a future version.boolean
Deprecated, for removal: This API element is subject to removal in a future version.static IntSet
IntSets.concurrentCopyFrom
(IntSet intSet, int maxExclusive) Returns a copy of the given set that supports concurrent operations.boolean
ImmutableIntSet.containsAll
(IntSet set) Deprecated, for removal: This API element is subject to removal in a future version.boolean
IntSet.containsAll
(IntSet set) Whether this set contains all ints in the given IntSetboolean
RangeSet.containsAll
(IntSet set) Deprecated, for removal: This API element is subject to removal in a future version.boolean
SmallIntSet.containsAll
(IntSet set) Deprecated, for removal: This API element is subject to removal in a future version.static IntSet
IntSets.immutableSet
(IntSet set) Returns an immutable IntSet that wraps the given IntSet to prevent modifications.boolean
Removes all ints from this IntSet that are in the provided IntSetboolean
Deprecated, for removal: This API element is subject to removal in a future version.boolean
Deprecated, for removal: This API element is subject to removal in a future version.boolean
Modifies this set to remove all ints that are not present in the provided IntSetboolean
Deprecated, for removal: This API element is subject to removal in a future version.boolean
Deprecated, for removal: This API element is subject to removal in a future version.void
Clears all current bits and sets them to the values in the providedIntSet
.static void
IntSetsExternalization.writeTo
(ObjectOutput output, IntSet intSet) ModifierConstructorDescriptionImmutableIntSet
(IntSet set) Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of IntSet in org.infinispan.container.impl
Modifier and TypeMethodDescriptionvoid
AbstractDelegatingInternalDataContainer.addSegments
(IntSet segments) void
DefaultDataContainer.addSegments
(IntSet segments) void
DefaultSegmentedDataContainer.addSegments
(IntSet segments) void
InternalDataContainer.addSegments
(IntSet segments) Sets what segments this data container should be using.void
void
void
void
void
Removes entries from the container whose key maps to one of the provided segmentsvoid
Removes all entries that map to the given segmentsvoid
AbstractDelegatingInternalDataContainer.forEach
(IntSet segments, Consumer<? super InternalCacheEntry<K, V>> action) void
DefaultSegmentedDataContainer.forEach
(IntSet segments, Consumer<? super InternalCacheEntry<K, V>> action) default void
Performs 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>> void
AbstractDelegatingInternalDataContainer.removeSegments
(IntSet segments) void
BoundedSegmentedDataContainer.removeSegments
(IntSet segments) void
DefaultDataContainer.removeSegments
(IntSet segments) void
DefaultSegmentedDataContainer.removeSegments
(IntSet segments) void
InternalDataContainer.removeSegments
(IntSet segments) Removes and un-associates the given segments.void
L1SegmentedDataContainer.removeSegments
(IntSet segments) int
default int
Returns how many entries are present in the data container that map to the given segments without counting entries that are currently expired.int
AbstractDelegatingInternalDataContainer.sizeIncludingExpired
(IntSet segments) int
DefaultSegmentedDataContainer.sizeIncludingExpired
(IntSet segment) default int
InternalDataContainer.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
Modifier and TypeMethodDescriptionvoid
BoundedOffHeapDataContainer.addSegments
(IntSet segments) void
OffHeapDataContainer.addSegments
(IntSet segments) BoundedOffHeapDataContainer.iteratorIncludingExpired
(IntSet segments) OffHeapDataContainer.iteratorIncludingExpired
(IntSet segments) void
BoundedOffHeapDataContainer.removeSegments
(IntSet segments) void
OffHeapDataContainer.removeSegments
(IntSet segments) int
int
BoundedOffHeapDataContainer.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
Modifier and TypeMethodDescriptionvoid
DefaultIracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) void
IracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) Sends the tombstone belonging to the segments insegment
to theoriginator
void
NoOpIracTombstoneManager.sendStateTo
(Address requestor, IntSet segments) -
Uses of IntSet in org.infinispan.distribution
Modifier and TypeMethodDescriptionLocalizedCacheTopology.getLocalPrimarySegments()
LocalizedCacheTopology.getLocalReadSegments()
LocalizedCacheTopology.getLocalWriteSegments()
-
Uses of IntSet in org.infinispan.distribution.util
Modifier and TypeFieldDescriptionprotected final IntSet
ReadOnlySegmentAwareCollection.allowedSegments
protected final IntSet
ReadOnlySegmentAwareIterator.allowedSegments
protected final IntSet
ReadOnlySegmentAwareMap.allowedSegments
ModifierConstructorDescriptionReadOnlySegmentAwareCollection
(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
Modifier and TypeMethodDescriptionstatic int
PersistenceUtil.count
(SegmentedAdvancedLoadWriteStore<?, ?> salws, IntSet segments) Counts how many entries are present in the segmented store.static <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
Modifier 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
Modifier 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
Modifier 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
Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionabstract String
BaseTableOperations.getSelectAllSql
(IntSet segments) protected void
BaseTableOperations.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
Modifier and TypeMethodDescriptionJdbcStringBasedStore.addSegments
(IntSet segments) JdbcStringBasedStore.approximateSize
(IntSet segments) JdbcStringBasedStore.removeSegments
(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.remote
Modifier 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
Modifier 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
Modifier and TypeMethodDescriptionNonBlockingSoftIndexFileStore.addSegments
(IntSet segments) void
TemporaryTable.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) void
TemporaryTable.removeSegments
(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.spi
Modifier and TypeMethodDescriptiondefault CompletionStage<Void>
NonBlockingStore.addSegments
(IntSet segments) Invoked when a node becomes an owner of the given segments.default void
SegmentedAdvancedLoadWriteStore.addSegments
(IntSet segments) Deprecated, for removal: This API element is subject to removal in a future version.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.void
Deprecated, for removal: This API element is subject to removal in a future version.Removes all the data that maps to the given segments from the storage.org.reactivestreams.Publisher<MarshallableEntry<K,
V>> SegmentedAdvancedLoadWriteStore.entryPublisher
(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata) Deprecated, for removal: This API element is subject to removal in a future version.Publishes all entries from this 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.org.reactivestreams.Publisher<K>
SegmentedAdvancedLoadWriteStore.publishKeys
(IntSet segments, Predicate<? super K> filter) Deprecated, for removal: This API element is subject to removal in a future version.Publishes all the keys that map to the given segments from this store.default CompletionStage<Void>
NonBlockingStore.removeSegments
(IntSet segments) Invoked when a node loses ownership of the given segments.default void
SegmentedAdvancedLoadWriteStore.removeSegments
(IntSet segments) Deprecated, for removal: This API element is subject to removal in a future version.Invoked when a node loses ownership of a segment.default CompletionStage<Long>
Returns the amount of entries that map to the given segments in the store.int
Deprecated, for removal: This API element is subject to removal in a future version.Returns the number of elements in the store that map to the given segments that aren't expired. -
Uses of IntSet in org.infinispan.persistence.sql
Modifier and TypeMethodDescriptionQueriesJdbcStore.QueryTableOperations.getSelectAllSql
(IntSet segments) TableJdbcStore.TableTableOperations.getSelectAllSql
(IntSet segments) -
Uses of IntSet in org.infinispan.persistence.support
Modifier and TypeMethodDescriptionvoid
ComposedSegmentedLoadWriteStore.addSegments
(IntSet segments) DelegatingNonBlockingStore.addSegments
(IntSet segments) DelegatingPersistenceManager.addSegments
(IntSet segments) NonBlockingStoreAdapter.addSegments
(IntSet segments) DelegatingNonBlockingStore.approximateSize
(IntSet segments) DelegatingPersistenceManager.approximateSize
(Predicate<? super StoreConfiguration> predicate, IntSet segments) NonBlockingStoreAdapter.approximateSize
(IntSet segments) void
org.reactivestreams.Publisher<MarshallableEntry<K,
V>> ComposedSegmentedLoadWriteStore.entryPublisher
(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata) 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<MarshallableEntry<K,
V>> NonBlockingStoreAdapter.publishEntries
(IntSet segments, Predicate<? super K> filter, boolean includeValues) org.reactivestreams.Publisher<K>
ComposedSegmentedLoadWriteStore.publishKeys
(IntSet segments, Predicate<? super K> filter) 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) org.reactivestreams.Publisher<K>
NonBlockingStoreAdapter.publishKeys
(IntSet segments, Predicate<? super K> filter) void
ComposedSegmentedLoadWriteStore.removeSegments
(IntSet segments) DelegatingNonBlockingStore.removeSegments
(IntSet segments) DelegatingPersistenceManager.removeSegments
(IntSet segments) NonBlockingStoreAdapter.removeSegments
(IntSet segments) int
DelegatingPersistenceManager.size
(Predicate<? super StoreConfiguration> predicate, IntSet segments) -
Uses of IntSet in org.infinispan.reactive.publisher.impl
Modifier 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) void
LocalPublisherManager.segmentsLost
(IntSet lostSegments) Method to invoke when a set of segments are being removed from this node.void
LocalPublisherManagerImpl.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) ModifierConstructorDescriptionInnerPublisherSubscriptionBuilder
(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.scattered
Modifier and TypeMethodDescriptionvoid
BiasManager.revokeLocalBiasForSegments
(IntSet segments) Stop reading local data from this segment.void
ScatteredVersionManager.setOwnedSegments
(IntSet segments) Move the segment fromScatteredVersionManager.SegmentState.NOT_OWNED
toScatteredVersionManager.SegmentState.OWNED
without transferring data.void
ScatteredStateProvider.startKeysTransfer
(IntSet segments, Address origin) Start transferring keys and remote metadata for the given segments to the origin.void
ScatteredVersionManager.startKeyTransfer
(IntSet segments) Move the segments fromScatteredVersionManager.SegmentState.BLOCKED
toScatteredVersionManager.SegmentState.KEY_TRANSFER
state. -
Uses of IntSet in org.infinispan.scattered.impl
Modifier and TypeMethodDescriptionprotected CompletionStage<Void>
ScatteredStateConsumerImpl.handleSegments
(boolean isRebalance, IntSet addedSegments, IntSet transactionOnlySegments) protected CompletionStage<Void>
ScatteredStateConsumerImpl.removeStaleData
(IntSet removedSegments) void
BiasManagerImpl.revokeLocalBiasForSegments
(IntSet segments) void
ScatteredVersionManagerImpl.setOwnedSegments
(IntSet segments) void
ScatteredStateProviderImpl.startKeysTransfer
(IntSet segments, Address origin) void
ScatteredVersionManagerImpl.startKeyTransfer
(IntSet segments) -
Uses of IntSet in org.infinispan.stats.impl
-
Uses of IntSet in org.infinispan.stream.impl
Modifier 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
Modifier and TypeMethodDescriptionAbstractDelegatingCacheStream.filterKeySegments
(IntSet segments) void
IntSetExternalizer.writeObject
(ObjectOutput output, IntSet intSet) -
Uses of IntSet in org.infinispan.xsite.commands.remote
Modifier and TypeMethodDescriptionIracPutManyRequest.executeOperation
(org.infinispan.xsite.BackupReceiver receiver) protected CompletionStage<IntSet>
IracTombstoneCheckRequest.invokeInLocalCache
(String origin, ComponentRegistry registry) IracPutManyRequest.readFrom
(ObjectInput input) IracTombstoneCheckRequest.readFrom
(ObjectInput input) -
Uses of IntSet in org.infinispan.xsite.irac
Modifier and TypeMethodDescriptionvoid
DefaultIracManager.requestState
(Address requestor, IntSet segments) void
IracManager.requestState
(Address requestor, IntSet segments) Requests the state stored in this instance for the givensegments
.void
NoOpIracManager.requestState
(Address requestor, IntSet segments) Modifier and TypeMethodDescriptionvoid
IracResponseCollector.dependsOn
(IracXSiteBackup backup, CompletionStage<? extends IntSet> request)
IntSets.immutableSet(IntSet)