Uses of Interface
org.infinispan.commons.util.IntSet
-
Packages that use IntSet Package Description org.infinispan This is the core of Infinispan, a distributed, transactional, highly scalable data grid platform.org.infinispan.client.hotrod Hot Rod client API.org.infinispan.client.hotrod.impl org.infinispan.commands Commands that operate on the cache, either locally or remotely.org.infinispan.commons.util Commons package providing various utility classesorg.infinispan.container.impl Data containers which store cache entries.org.infinispan.container.offheap org.infinispan.distribution Classes relating to the distributed cache mode.org.infinispan.distribution.util org.infinispan.persistence Persistence API.org.infinispan.persistence.internal org.infinispan.persistence.jdbc.stringbased JDBC CacheStore implementation which maps keys to strings.org.infinispan.persistence.manager Implementations of thePersistenceManager
interface, which define the logic of how infinispan interacts with external stores.org.infinispan.persistence.remote Hot Rod-basedAdvancedLoadWriteStore
.org.infinispan.persistence.rocksdb RocksDB-basedAdvancedLoadWriteStore
.org.infinispan.persistence.spi The Persistence SPI.org.infinispan.persistence.support org.infinispan.scattered SCATTERED CACHE DESIGNorg.infinispan.scattered.impl org.infinispan.statetransfer Transfer of state to new caches in a cluster.org.infinispan.stream.impl org.infinispan.transaction.xa.recovery org.infinispan.util 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.org.infinispan.util.rxjava -
-
Uses of IntSet in org.infinispan
Methods in org.infinispan with parameters of type IntSet Modifier and Type Method Description BaseCacheStream
BaseCacheStream. filterKeySegments(IntSet segments)
Filters which entries are returned by what segment they are present in.CacheStream<R>
CacheStream. filterKeySegments(IntSet segments)
Filters which entries are returned by what segment they are present in.LockedStream<K,V>
LockedStream. filterKeySegments(IntSet segments)
Filters which entries are returned by what segment they are present in. -
Uses of IntSet in org.infinispan.client.hotrod
Methods in org.infinispan.client.hotrod with parameters of type IntSet Modifier and Type Method Description CloseableIteratorSet<Map.Entry<K,V>>
RemoteCache. entrySet(IntSet segments)
This method is identical toRemoteCache.entrySet()
except that it will only return entries that map to the given segments.CloseableIteratorSet<K>
RemoteCache. keySet(IntSet segments)
This method is identical toRemoteCache.keySet()
except that it will only return keys that map to the given segments.CloseableIteratorCollection<V>
RemoteCache. values(IntSet 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 IntSet Modifier and Type Method Description CloseableIteratorSet<Map.Entry<K,V>>
RemoteCacheImpl. entrySet(IntSet segments)
CloseableIteratorSet<K>
RemoteCacheImpl. keySet(IntSet segments)
CloseableIteratorCollection<V>
RemoteCacheImpl. values(IntSet segments)
-
Uses of IntSet in org.infinispan.commands
Methods in org.infinispan.commands with parameters of type IntSet Modifier and Type Method Description StateRequestCommand
CommandsFactory. buildStateRequestCommand(StateRequestCommand.Type subtype, Address sender, int topologyId, IntSet segments)
Builds a StateRequestCommand used for requesting transactions and locks and for starting or canceling transfer of cache entries.StateRequestCommand
CommandsFactoryImpl. buildStateRequestCommand(StateRequestCommand.Type subtype, Address sender, int topologyId, IntSet segments)
<K> StreamIteratorRequestCommand<K>
CommandsFactory. buildStreamIteratorRequestCommand(Object id, boolean parallelStream, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intOps, long batchSize)
<K> StreamIteratorRequestCommand<K>
CommandsFactoryImpl. buildStreamIteratorRequestCommand(Object id, boolean parallelStream, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intOps, long batchSize)
<K> StreamRequestCommand<K>
CommandsFactory. buildStreamRequestCommand(Object id, boolean parallelStream, StreamRequestCommand.Type type, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Object terminalOperation)
<K> StreamRequestCommand<K>
CommandsFactoryImpl. buildStreamRequestCommand(Object id, boolean parallelStream, StreamRequestCommand.Type type, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Object terminalOperation)
<R> StreamResponseCommand<R>
CommandsFactory. buildStreamResponseCommand(Object identifier, boolean complete, IntSet lostSegments, R response)
BuildsStreamResponseCommand
used to send back a response either intermediate or complete to the originating node with the information for the stream request.<R> StreamResponseCommand<R>
CommandsFactoryImpl. buildStreamResponseCommand(Object identifier, boolean complete, IntSet lostSegments, R response)
-
Uses of IntSet in org.infinispan.commons.util
Classes in org.infinispan.commons.util that implement IntSet Modifier and Type Class Description class
ImmutableIntSet
Deprecated.since 9.3 This class will no longer be public, please useIntSets.immutableSet(IntSet)
class
RangeSet
Deprecated.since 9.3 This class will no longer be public.class
SmallIntSet
Deprecated.since 9.3 This class will no longer be public.Methods in org.infinispan.commons.util that return IntSet Modifier and Type Method Description static 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(PrimitiveIterator.OfInt iterator)
Returns an IntSet based on the ints in the iterator.static IntSet
IntSets. from(Set<Integer> integerSet)
Returns an IntSet based on the provided Set.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)
Methods in org.infinispan.commons.util that return types with arguments of type IntSet Modifier and Type Method Description static Set<Class<? extends IntSet>>
IntSetsExternalization. getTypeClasses()
Methods in org.infinispan.commons.util with parameters of type IntSet Modifier and Type Method Description boolean
ImmutableIntSet. addAll(IntSet set)
Deprecated.boolean
IntSet. addAll(IntSet set)
Adds all ints from the provided set into this oneboolean
RangeSet. addAll(IntSet set)
Deprecated.boolean
SmallIntSet. addAll(IntSet set)
Deprecated.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.boolean
IntSet. containsAll(IntSet set)
Whether this set contains all ints in the given IntSetboolean
RangeSet. containsAll(IntSet set)
Deprecated.boolean
SmallIntSet. containsAll(IntSet set)
Deprecated.static IntSet
IntSets. immutableSet(IntSet set)
Returns an immutable IntSet that wraps the given IntSet to prevent modifications.boolean
IntSet. removeAll(IntSet set)
Removes all ints from this IntSet that are in the provided IntSetboolean
RangeSet. removeAll(IntSet set)
Deprecated.boolean
SmallIntSet. removeAll(IntSet set)
Deprecated.boolean
IntSet. retainAll(IntSet c)
Modifies this set to remove all ints that are not present in the provided IntSetboolean
RangeSet. retainAll(IntSet c)
Deprecated.boolean
SmallIntSet. retainAll(IntSet c)
Deprecated.static void
IntSetsExternalization. writeTo(ObjectOutput output, IntSet intSet)
Constructors in org.infinispan.commons.util with parameters of type IntSet Constructor Description ImmutableIntSet(IntSet set)
Deprecated. -
Uses of IntSet in org.infinispan.container.impl
Methods in org.infinispan.container.impl with parameters of type IntSet Modifier and Type Method Description void
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
InternalDataContainerAdapter. addSegments(IntSet segments)
void
AbstractDelegatingInternalDataContainer. clear(IntSet segments)
void
AbstractInternalDataContainer. clear(IntSet segments)
void
BoundedSegmentedDataContainer. clear(IntSet segments)
void
DefaultDataContainer. clear(IntSet segments)
void
InternalDataContainer. clear(IntSet segments)
Removes entries from the container whose key maps to one of the provided segmentsvoid
InternalDataContainerAdapter. clear(IntSet segments)
void
L1SegmentedDataContainer. clear(IntSet segments)
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
InternalDataContainer. forEach(IntSet segments, Consumer<? super InternalCacheEntry<K,V>> action)
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.Iterator<InternalCacheEntry<K,V>>
AbstractDelegatingInternalDataContainer. iterator(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
DefaultDataContainer. iterator(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
DefaultSegmentedDataContainer. iterator(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
InternalDataContainer. iterator(IntSet segments)
Same asDataContainer.iterator()
except that only entries that map to the provided segments are returned via the iterator.Iterator<InternalCacheEntry<K,V>>
InternalDataContainerAdapter. iterator(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
AbstractDelegatingInternalDataContainer. iteratorIncludingExpired(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
BoundedSegmentedDataContainer. iteratorIncludingExpired(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
DefaultDataContainer. iteratorIncludingExpired(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
DefaultSegmentedDataContainer. iteratorIncludingExpired(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
InternalDataContainer. iteratorIncludingExpired(IntSet segments)
Same asDataContainer.iteratorIncludingExpired()
except that only entries that map to the provided segments are returned via the iterator.Iterator<InternalCacheEntry<K,V>>
InternalDataContainerAdapter. iteratorIncludingExpired(IntSet segments)
Iterator<InternalCacheEntry<K,V>>
L1SegmentedDataContainer. iteratorIncludingExpired(IntSet segments)
static <K,V>
voidInternalDataContainerAdapter. removeSegmentEntries(DataContainer<K,V> dataContainer, IntSet segments, List<Consumer<Iterable<InternalCacheEntry<K,V>>>> listeners, KeyPartitioner keyPartitioner)
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
InternalDataContainerAdapter. removeSegments(IntSet segments)
void
L1SegmentedDataContainer. removeSegments(IntSet segments)
int
AbstractDelegatingInternalDataContainer. size(IntSet segments)
default int
InternalDataContainer. size(IntSet segments)
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 expiredSpliterator<InternalCacheEntry<K,V>>
AbstractDelegatingInternalDataContainer. spliterator(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
DefaultDataContainer. spliterator(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
DefaultSegmentedDataContainer. spliterator(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
InternalDataContainer. spliterator(IntSet segments)
Same asDataContainer.spliterator()
except that only entries that map to the provided segments are returned via this spliterator.Spliterator<InternalCacheEntry<K,V>>
InternalDataContainerAdapter. spliterator(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
AbstractDelegatingInternalDataContainer. spliteratorIncludingExpired(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
BoundedSegmentedDataContainer. spliteratorIncludingExpired(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
DefaultDataContainer. spliteratorIncludingExpired(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
DefaultSegmentedDataContainer. spliteratorIncludingExpired(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
InternalDataContainer. spliteratorIncludingExpired(IntSet segments)
Same asDataContainer.spliteratorIncludingExpired()
except that only entries that map to the provided segments are returned via this spliterator.Spliterator<InternalCacheEntry<K,V>>
InternalDataContainerAdapter. spliteratorIncludingExpired(IntSet segments)
Spliterator<InternalCacheEntry<K,V>>
L1SegmentedDataContainer. spliteratorIncludingExpired(IntSet segments)
-
Uses of IntSet in org.infinispan.container.offheap
-
Uses of IntSet in org.infinispan.distribution
Methods in org.infinispan.distribution that return IntSet Modifier and Type Method Description IntSet
LocalizedCacheTopology. getLocalReadSegments()
-
Uses of IntSet in org.infinispan.distribution.util
Fields in org.infinispan.distribution.util declared as IntSet Modifier and Type Field Description protected IntSet
ReadOnlySegmentAwareCollection. allowedSegments
protected IntSet
ReadOnlySegmentAwareIterator. allowedSegments
protected IntSet
ReadOnlySegmentAwareMap. allowedSegments
Constructors in org.infinispan.distribution.util with parameters of type IntSet Constructor Description ReadOnlySegmentAwareCollection(Collection<E> set, ConsistentHash ch, IntSet allowedSegments)
ReadOnlySegmentAwareEntryCollection(Set<Map.Entry<K,V>> set, ConsistentHash ch, IntSet allowedSegments)
ReadOnlySegmentAwareEntryIterator(Iterator<Map.Entry<K,V>> iter, ConsistentHash ch, IntSet allowedSegments)
ReadOnlySegmentAwareIterator(Iterator<E> iter, ConsistentHash ch, IntSet allowedSegments)
ReadOnlySegmentAwareMap(Map<K,V> map, ConsistentHash ch, IntSet allowedSegments)
-
Uses of IntSet in org.infinispan.persistence
Methods in org.infinispan.persistence with parameters of type IntSet Modifier and Type Method Description static 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. -
Uses of IntSet in org.infinispan.persistence.internal
Methods in org.infinispan.persistence.internal with parameters of type IntSet Modifier and Type Method Description static <K> Predicate<? super K>
PersistenceUtil. combinePredicate(IntSet segments, KeyPartitioner keyPartitioner, Predicate<? super K> filter)
static <R> io.reactivex.Flowable<R>
PersistenceUtil. parallelizePublisher(IntSet segments, io.reactivex.Scheduler scheduler, IntFunction<org.reactivestreams.Publisher<R>> publisherFunction)
-
Uses of IntSet in org.infinispan.persistence.jdbc.stringbased
Methods in org.infinispan.persistence.jdbc.stringbased with parameters of type IntSet Modifier and Type Method Description void
JdbcStringBasedStore. clear(IntSet segments)
org.reactivestreams.Publisher<MarshalledEntry<K,V>>
JdbcStringBasedStore. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata)
org.reactivestreams.Publisher<K>
JdbcStringBasedStore. publishKeys(IntSet segments, Predicate<? super K> filter)
int
JdbcStringBasedStore. size(IntSet segments)
-
Uses of IntSet in org.infinispan.persistence.manager
Methods in org.infinispan.persistence.manager with parameters of type IntSet Modifier and Type Method Description default boolean
PersistenceManager. addSegments(IntSet segments)
Notifies any underlying segmented stores that the segments provided are owned by this cache and to start/configure any underlying resources required to handle requests for entries on the given segments.boolean
PersistenceManagerImpl. addSegments(IntSet segments)
<K,V>
org.reactivestreams.Publisher<MarshalledEntry<K,V>>PersistenceManager. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata, Predicate<? super StoreConfiguration> predicate)
Returns a publisher that will publish entries that map to the provided segments.<K,V>
org.reactivestreams.Publisher<MarshalledEntry<K,V>>PersistenceManagerImpl. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata, Predicate<? super StoreConfiguration> predicate)
<K,V>
org.reactivestreams.Publisher<MarshalledEntry<K,V>>PersistenceManagerStub. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata, Predicate<? super StoreConfiguration> predicate)
<K> org.reactivestreams.Publisher<K>
PersistenceManager. publishKeys(IntSet segments, Predicate<? super K> filter, Predicate<? super StoreConfiguration> predicate)
Returns a publisher that will publish keys that map to the provided segments.<K> org.reactivestreams.Publisher<K>
PersistenceManagerImpl. publishKeys(IntSet segments, Predicate<? super K> filter, Predicate<? super StoreConfiguration> predicate)
<K> org.reactivestreams.Publisher<K>
PersistenceManagerStub. publishKeys(IntSet segments, Predicate<? super K> filter, Predicate<? super StoreConfiguration> predicate)
default boolean
PersistenceManager. removeSegments(IntSet segments)
Notifies any underlying segmented stores that a given segment is no longer owned by this cache and allowing it to remove the given segments and release resources related to it.boolean
PersistenceManagerImpl. removeSegments(IntSet segments)
int
PersistenceManager. size(IntSet segments)
Returns the count of how many entries are persisted within the given segments.int
PersistenceManagerImpl. size(IntSet segments)
int
PersistenceManagerStub. size(IntSet segments)
-
Uses of IntSet in org.infinispan.persistence.remote
Methods in org.infinispan.persistence.remote with parameters of type IntSet Modifier and Type Method Description void
RemoteStore. clear(IntSet segments)
org.reactivestreams.Publisher<MarshalledEntry<K,V>>
RemoteStore. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata)
io.reactivex.Flowable<K>
RemoteStore. publishKeys(IntSet segments, Predicate<? super K> filter)
int
RemoteStore. size(IntSet segments)
-
Uses of IntSet in org.infinispan.persistence.rocksdb
Methods in org.infinispan.persistence.rocksdb with parameters of type IntSet Modifier and Type Method Description void
RocksDBStore. addSegments(IntSet segments)
void
RocksDBStore. clear(IntSet segments)
org.reactivestreams.Publisher<MarshalledEntry<K,V>>
RocksDBStore. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata)
org.reactivestreams.Publisher<K>
RocksDBStore. publishKeys(IntSet segments, Predicate<? super K> filter)
void
RocksDBStore. removeSegments(IntSet segments)
int
RocksDBStore. size(IntSet segments)
-
Uses of IntSet in org.infinispan.persistence.spi
Methods in org.infinispan.persistence.spi with parameters of type IntSet Modifier and Type Method Description default void
SegmentedAdvancedLoadWriteStore. addSegments(IntSet segments)
Invoked when a node becomes an owner of the given segments.void
SegmentedAdvancedLoadWriteStore. clear(IntSet segments)
Removes all the data that maps to the given segments from the storage.org.reactivestreams.Publisher<MarshalledEntry<K,V>>
SegmentedAdvancedLoadWriteStore. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata)
Publishes all entries from this store.org.reactivestreams.Publisher<K>
SegmentedAdvancedLoadWriteStore. publishKeys(IntSet segments, Predicate<? super K> filter)
Publishes all the keys that map to the given segments from this store.default void
SegmentedAdvancedLoadWriteStore. removeSegments(IntSet segments)
Invoked when a node loses ownership of a segment.int
SegmentedAdvancedLoadWriteStore. size(IntSet segments)
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.support
Methods in org.infinispan.persistence.support with parameters of type IntSet Modifier and Type Method Description void
ComposedSegmentedLoadWriteStore. addSegments(IntSet segments)
void
ComposedSegmentedLoadWriteStore. clear(IntSet segments)
org.reactivestreams.Publisher<MarshalledEntry<K,V>>
ComposedSegmentedLoadWriteStore. publishEntries(IntSet segments, Predicate<? super K> filter, boolean fetchValue, boolean fetchMetadata)
io.reactivex.Flowable<K>
ComposedSegmentedLoadWriteStore. publishKeys(IntSet segments, Predicate<? super K> filter)
void
ComposedSegmentedLoadWriteStore. removeSegments(IntSet segments)
int
ComposedSegmentedLoadWriteStore. size(IntSet segments)
-
Uses of IntSet in org.infinispan.scattered
Methods in org.infinispan.scattered with parameters of type IntSet Modifier and Type Method Description void
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)
void
ScatteredVersionManager. startKeyTransfer(IntSet segments)
Move the segments fromScatteredVersionManager.SegmentState.BLOCKED
toScatteredVersionManager.SegmentState.KEY_TRANSFER
state. -
Uses of IntSet in org.infinispan.scattered.impl
Fields in org.infinispan.scattered.impl declared as IntSet Modifier and Type Field Description protected IntSet
ScatteredStateConsumerImpl. inboundSegments
Methods in org.infinispan.scattered.impl with parameters of type IntSet Modifier and Type Method Description protected void
ScatteredStateConsumerImpl. handleSegments(boolean startRebalance, IntSet addedSegments, IntSet removedSegments)
protected 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.statetransfer
Methods in org.infinispan.statetransfer that return IntSet Modifier and Type Method Description protected IntSet
StateConsumerImpl. getOwnedSegments(ConsistentHash consistentHash)
IntSet
InboundTransferTask. getSegments()
Returns a copy of segments currently tied to this taskIntSet
OutboundTransferTask. getSegments()
IntSet
StateRequestCommand. getSegments()
IntSet
InboundTransferTask. getUnfinishedSegments()
Returns a copy of the unfinished segmentsMethods in org.infinispan.statetransfer with parameters of type IntSet Modifier and Type Method Description protected void
StateConsumerImpl. addTransfer(InboundTransferTask inboundTransfer, IntSet segments)
void
StateConsumerImpl.KeyInvalidationListener. beforeInvalidation(IntSet removedSegments, IntSet staleL1Segments)
void
StateProvider. cancelOutboundTransfer(Address destination, int topologyId, IntSet segments)
Cancel sending of cache entries that belong to the given set of segments.void
StateProviderImpl. cancelOutboundTransfer(Address destination, int topologyId, IntSet segments)
void
InboundTransferTask. cancelSegments(IntSet cancelledSegments)
Cancels a set of segments and marks them as finished.void
OutboundTransferTask. cancelSegments(IntSet cancelledSegments)
Cancel some of the segments.protected void
StateConsumerImpl. cancelTransfers(IntSet removedSegments)
Cancel transfers for segments we no longer own.List<TransactionInfo>
StateProvider. getTransactionsForSegments(Address destination, int topologyId, IntSet segments)
Gets the list of transactions that affect keys from the given segments.List<TransactionInfo>
StateProviderImpl. getTransactionsForSegments(Address destination, int requestTopologyId, IntSet segments)
protected void
StateConsumerImpl. handleSegments(boolean startRebalance, IntSet addedSegments, IntSet removedSegments)
protected void
StateConsumerImpl. removeStaleData(IntSet removedSegments)
void
StateProvider. startOutboundTransfer(Address destination, int topologyId, IntSet segments, boolean applyState)
Start to send cache entries that belong to the given set of segments.void
StateProviderImpl. startOutboundTransfer(Address destination, int requestTopologyId, IntSet segments, boolean applyState)
Constructors in org.infinispan.statetransfer with parameters of type IntSet Constructor Description InboundTransferTask(IntSet segments, Address source, int topologyId, RpcManager rpcManager, CommandsFactory commandsFactory, long timeout, String cacheName, boolean applyState)
OutboundTransferTask(Address destination, IntSet segments, int segmentCount, int chunkSize, int topologyId, KeyPartitioner keyPartitioner, Consumer<OutboundTransferTask> onCompletion, Consumer<List<StateChunk>> onChunkReplicated, BiFunction<InternalCacheEntry,InternalEntryFactory,InternalCacheEntry> mapEntryFromDataContainer, BiFunction<MarshalledEntry,InternalEntryFactory,InternalCacheEntry> mapEntryFromStore, InternalDataContainer dataContainer, PersistenceManager persistenceManager, RpcManager rpcManager, CommandsFactory commandsFactory, InternalEntryFactory ef, long timeout, String cacheName, boolean applyState, boolean pushTransfer)
StateRequestCommand(ByteString cacheName, StateRequestCommand.Type type, Address origin, int topologyId, IntSet segments)
-
Uses of IntSet in org.infinispan.stream.impl
Fields in org.infinispan.stream.impl declared as IntSet Modifier and Type Field Description protected IntSet
StreamResponseCommand. missedSegments
protected IntSet
AbstractCacheStream. segmentsToFilter
Methods in org.infinispan.stream.impl that return IntSet Modifier and Type Method Description IntSet
IteratorResponse. getSuspectedSegments()
The segments that were lost during the iteration processMethods in org.infinispan.stream.impl with parameters of type IntSet Modifier and Type Method Description org.reactivestreams.Publisher<S>
CompletionRehashPublisherDecorator. decorateLocal(ConsistentHash beginningCh, boolean onlyLocal, IntSet segmentsToFilter, org.reactivestreams.Publisher<S> localPublisher)
CacheStream<R>
DistributedCacheStream. filterKeySegments(IntSet segments)
DoubleCacheStream
DistributedDoubleCacheStream. filterKeySegments(IntSet segments)
IntCacheStream
DistributedIntCacheStream. filterKeySegments(IntSet segments)
LongCacheStream
DistributedLongCacheStream. filterKeySegments(IntSet segments)
CacheStream<R>
IntermediateCacheStream. filterKeySegments(IntSet segments)
DoubleCacheStream
IntermediateDoubleCacheStream. filterKeySegments(IntSet segments)
IntCacheStream
IntermediateIntCacheStream. filterKeySegments(IntSet segments)
LongCacheStream
IntermediateLongCacheStream. filterKeySegments(IntSet segments)
LockedStream<K,V>
LockedStreamImpl. filterKeySegments(IntSet segments)
void
ClusterStreamManager.ResultsCallback. onCompletion(Address address, IntSet completedSegments, R results)
Essentially the same asClusterStreamManager.ResultsCallback.onIntermediateResult(Address address, Object)
except that this is the last time this callback will be invoked and it tells which segments were completedvoid
ClusterStreamManager.ResultsCallback. onSegmentsLost(IntSet segments)
Called back when a segment is found to have been lost that is no longer remote This method should return as soon as possible and not block in any fashion.<R1> boolean
ClusterStreamManager. receiveResponse(Object id, Address origin, boolean complete, IntSet segments, R1 response)
Receives a response for a given request<R1> boolean
ClusterStreamManagerImpl. receiveResponse(Object id, Address origin, boolean complete, IntSet missingSegments, R1 response)
<R> Object
ClusterStreamManager. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,R> operation, ClusterStreamManager.ResultsCallback<Collection<R>> callback)
Key tracking remote operation that doesn't have rehash enabled.<R> Object
ClusterStreamManager. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
Performs the remote stream operation without rehash awareness.<R> Object
ClusterStreamManagerImpl. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,R> operation, ClusterStreamManager.ResultsCallback<Collection<R>> callback)
<R> Object
ClusterStreamManagerImpl. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
<R> Object
PartitionAwareClusterStreamManager. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,R> operation, ClusterStreamManager.ResultsCallback<Collection<R>> callback)
<R> Object
PartitionAwareClusterStreamManager. remoteStreamOperation(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
Object
ClusterStreamManager. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,?> operation, ClusterStreamManager.ResultsCallback<Collection<K>> callback)
Key tracking remote operation that has rehash enabled<R> Object
ClusterStreamManager. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
Performs the remote stream operation with rehash awareness.Object
ClusterStreamManagerImpl. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,?> operation, ClusterStreamManager.ResultsCallback<Collection<K>> callback)
<R> Object
ClusterStreamManagerImpl. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
Object
PartitionAwareClusterStreamManager. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,?> operation, ClusterStreamManager.ResultsCallback<Collection<K>> callback)
<R> Object
PartitionAwareClusterStreamManager. remoteStreamOperationRehashAware(boolean parallelDistribution, boolean parallelStream, ConsistentHash ch, IntSet segments, Set<K> keysToInclude, Map<Integer,Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation, ClusterStreamManager.ResultsCallback<R> callback, Predicate<? super R> earlyTerminatePredicate)
IteratorResponse
LocalStreamManager. startIterator(Object requestId, Address origin, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intermediateOperations, long batchSize)
Signals that a new iterator is created using the given arguments.IteratorResponse
LocalStreamManagerImpl. startIterator(Object requestId, Address origin, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intermediateOperations, long batchSize)
<R> void
LocalStreamManager. streamOperation(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,R> operation)
Stream operation for a key aware operation without rehash enabled<R> void
LocalStreamManager. streamOperation(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation)
Stream operation for a non key aware operation without rehash enabled.<R> void
LocalStreamManagerImpl. streamOperation(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,R> operation)
<R> void
LocalStreamManagerImpl. streamOperation(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation)
void
LocalStreamManager. streamOperationRehashAware(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,?> operation)
Stream operation for a key aware operation with rehash enabled<R> void
LocalStreamManager. streamOperationRehashAware(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation)
Stream operation for a non key aware operation with rehash enabled.void
LocalStreamManagerImpl. streamOperationRehashAware(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, KeyTrackingTerminalOperation<Original,K,?> operation)
<R> void
LocalStreamManagerImpl. streamOperationRehashAware(Object requestId, Address origin, boolean parallelStream, IntSet segments, Set<K> keysToInclude, Set<K> keysToExclude, boolean includeLoader, boolean entryStream, TerminalOperation<Original,R> operation)
protected Supplier<Stream<Original>>
AbstractCacheStream. supplierForSegments(ConsistentHash ch, IntSet targetSegments, Set<Object> excludedKeys)
protected Supplier<Stream<Original>>
AbstractCacheStream. supplierForSegments(ConsistentHash ch, IntSet targetSegments, Set<Object> excludedKeys, boolean usePrimary)
IfusePrimary
is true the segments are the primary segments but only those that exist in targetSegments.Method parameters in org.infinispan.stream.impl with type arguments of type IntSet Modifier and Type Method Description <E> ClusterStreamManager.RemoteIteratorPublisher<E>
ClusterStreamManager. remoteIterationPublisher(boolean parallelStream, Supplier<Map.Entry<Address,IntSet>> segments, Set<K> keysToInclude, IntFunction<Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intermediateOperations)
<E> ClusterStreamManager.RemoteIteratorPublisher<E>
ClusterStreamManagerImpl. remoteIterationPublisher(boolean parallelStream, Supplier<Map.Entry<Address,IntSet>> targets, Set<K> keysToInclude, IntFunction<Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intermediateOperations)
<E> ClusterStreamManager.RemoteIteratorPublisher<E>
PartitionAwareClusterStreamManager. remoteIterationPublisher(boolean parallelStream, Supplier<Map.Entry<Address,IntSet>> targets, Set<K> keysToInclude, IntFunction<Set<K>> keysToExclude, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intermediateOperations)
Constructors in org.infinispan.stream.impl with parameters of type IntSet Constructor Description StreamIteratorRequestCommand(ByteString cacheName, Address origin, Object id, boolean parallelStream, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Iterable<org.infinispan.stream.impl.intops.IntermediateOperation> intOps, long batchSize)
StreamRequestCommand(ByteString cacheName, Address origin, Object id, boolean parallelStream, StreamRequestCommand.Type type, IntSet segments, Set<K> keys, Set<K> excludedKeys, boolean includeLoader, boolean entryStream, Object terminalOperation)
StreamResponseCommand(ByteString cacheName, Address origin, Object id, boolean complete, IntSet missedSegments, R response)
-
Uses of IntSet in org.infinispan.transaction.xa.recovery
Constructors in org.infinispan.transaction.xa.recovery with parameters of type IntSet Constructor Description InDoubtTxInfoImpl(Xid xid, long internalId, IntSet status)
-
Uses of IntSet in org.infinispan.util
Classes in org.infinispan.util that implement IntSet Modifier and Type Class Description class
RangeSet
Deprecated.UseRangeSet
insteadMethods in org.infinispan.util that return IntSet Modifier and Type Method Description IntSet
IntSetExternalizer. readObject(ObjectInput input)
Methods in org.infinispan.util that return types with arguments of type IntSet Modifier and Type Method Description Set<Class<? extends IntSet>>
IntSetExternalizer. getTypeClasses()
Methods in org.infinispan.util with parameters of type IntSet Modifier and Type Method Description AbstractDelegatingCacheStream<R>
AbstractDelegatingCacheStream. filterKeySegments(IntSet segments)
void
IntSetExternalizer. writeObject(ObjectOutput output, IntSet intSet)
-
Uses of IntSet in org.infinispan.util.rxjava
Constructors in org.infinispan.util.rxjava with parameters of type IntSet Constructor Description FlowableFromIntSetFunction(IntSet intSet, IntFunction<T> intFunction)
-