Class DelegatingNonBlockingStore<K,V> 
- All Implemented Interfaces:
- NonBlockingStore<K,- V> 
- Direct Known Subclasses:
- AsyncNonBlockingStore,- SFSToSIFSStore
- 
Nested Class SummaryNested classes/interfaces inherited from interface org.infinispan.persistence.spi.NonBlockingStoreNonBlockingStore.Characteristic, NonBlockingStore.SegmentedPublisher<Type>
- 
Field SummaryFields inherited from interface org.infinispan.persistence.spi.NonBlockingStoreSIZE_UNAVAILABLE_FUTURE
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionaddSegments(IntSet segments) Invoked when a node becomes an owner of the given segments.approximateSize(IntSet segments) Returns an estimation of the amount of entries that map to the given segments in the store.batch(int publisherCount, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<Object>> removePublisher, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>> writePublisher) Writes and removes the entries provided by the Publishers into the store.Returns a set of characteristics for this store and its elements.clear()Clears all entries from the store.commit(javax.transaction.Transaction transaction) Commit changes in the provided transaction to the underlying store.containsKey(int segment, Object key) Returns a stage that will contain whether the value can be found in the store.abstract NonBlockingStore<K,V> delegate()Removes the entry for given key and segment from the store and optionally report if the entry was actually removed or not.booleanignoreCommandWithFlags(long commandFlags) Some stores may not want to perform operations based on if a command has certain flags.Returns a stage that, when complete, returns a boolean indicating whether the current store can be accessed for requests.Returns a stage that will contain the value loaded from the store.prepareWithModifications(javax.transaction.Transaction transaction, int publisherCount, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<Object>> removePublisher, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>> writePublisher) Write remove and put modifications to the store in the prepare phase, which should not yet persisted until the same transaction is committed viaNonBlockingStore.commit(Transaction)or they are discarded if the transaction is rolled back viaNonBlockingStore.rollback(Transaction).org.reactivestreams.Publisher<MarshallableEntry<K,V>> 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.org.reactivestreams.Publisher<K>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<MarshallableEntry<K,V>> Returns a Publisher that, after it is subscribed to, removes any expired entries from the store and publishes them to the returned Publisher.removeSegments(IntSet segments) Invoked when a node loses ownership of the given segments.rollback(javax.transaction.Transaction transaction) Roll back the changes from the provided transaction to the underlying store.Returns the amount of entries that map to the given segments in the store.The first method to invoke so that the store can be configured and additional steps, such as connecting through a socket or opening file descriptors, are performed.stop()This method is invoked when the cache is being shutdown.write(int segment, MarshallableEntry<? extends K, ? extends V> entry) Writes the entry to the store for the given segment returning a stage that completes normally when it is finished.Methods inherited from class java.lang.Objectclone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface org.infinispan.persistence.spi.NonBlockingStoredestroy
- 
Constructor Details- 
DelegatingNonBlockingStorepublic DelegatingNonBlockingStore()
 
- 
- 
Method Details- 
delegate
- 
startDescription copied from interface:NonBlockingStoreThe first method to invoke so that the store can be configured and additional steps, such as connecting through a socket or opening file descriptors, are performed.The provided InitializationContextcontains many helpful objects, including the configuration of the cache and store, concurrency utilities such asBlockingManageror an executor reserved for non-blocking operations onlyInitializationContext.getNonBlockingExecutor().This method is guaranteed not to be invoked concurrently with other operations. This means other methods are not invoked on this store until after the returned Stage completes. It is expected that an implementation should be able to "restart" by invoking starta second time ifNonBlockingStore.stop()has been invoked and allowed for its stage to complete.- Specified by:
- startin interface- NonBlockingStore<K,- V> 
- Parameters:
- ctx- initialization context used to initialize this store.
- Returns:
- a stage that, when complete, indicates that this store has started successfully.
 
- 
stopDescription copied from interface:NonBlockingStoreThis method is invoked when the cache is being shutdown. It is expected that all resources related to the store are freed when the returned stage is complete.This method is guaranteed not to be invoked concurrently with other operations. This means other methods are not invoked on this store until after the returned Stage completes. It is expected that an implementation should be able to "restart" by invoking NonBlockingStore.start(InitializationContext)a second time ifstophas been invoked and allowed for its stage to complete.- Specified by:
- stopin interface- NonBlockingStore<K,- V> 
- Returns:
- a stage that, when complete, indicates that this store has stopped.
 
- 
characteristicsDescription copied from interface:NonBlockingStoreReturns a set of characteristics for this store and its elements. This method may be invoked multiple times to determine which methods of the store can be used and how the data in the store can be handled.Refer to NonBlockingStore.Characteristicand its values for descriptions of each characteristic for stores.- Specified by:
- characteristicsin interface- NonBlockingStore<K,- V> 
- Returns:
- the set of characteristics that this store supports.
 
- 
isAvailableDescription copied from interface:NonBlockingStoreReturns a stage that, when complete, returns a boolean indicating whether the current store can be accessed for requests. This can be useful for store implementations that rely on an external source, such as a remote database, that may become unreachable. This can reduce sending requests to a store that is not available, as subsequent cache requests will result in aStoreUnavailableExceptionbeing thrown until the store becomes available again.Store availability is polled periodically to update the status of stores if their availability changes. This method is not invoked concurrently with itself. In other words, this method is not invoked until after the previous stage has completed. However, this method is invoked concurrently with other operations, except for NonBlockingStore.start(InitializationContext)andNonBlockingStore.stop().If a store is configured to be StoreConfiguration.async()and the store becomes unavailable, then it is possible for the cache operations to be accepted in the interim period between the loss of availability and the modification-queue becoming full. This allows for this store to be unavailable for short periods of time without aStoreUnavailableExceptionbeing thrown; however if the store does not become available before the queue fills, then aStoreUnavailableExceptionis thrown.- Specified by:
- isAvailablein interface- NonBlockingStore<K,- V> 
- Returns:
- stage that, when complete, indicates if the store is available.
 
- 
loadDescription copied from interface:NonBlockingStoreReturns a stage that will contain the value loaded from the store. If aMarshallableEntryneeds to be created here,InitializationContext.getMarshallableEntryFactory()andInitializationContext.getByteBufferFactory()should be used.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.WRITE_ONLYThis method will never be invoked. NonBlockingStore.Characteristic.EXPIRATIONWhen set this method must not return expired entries. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentparameter may be ignored.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- loadin interface- NonBlockingStore<K,- V> 
- Parameters:
- segment- the segment for the given key if segmentation is enabled, otherwise 0.
- key- key of the entry to load.
- Returns:
- a stage that, when complete, contains the store value or null if not present.
 
- 
containsKeyDescription copied from interface:NonBlockingStoreReturns a stage that will contain whether the value can be found in the store.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.WRITE_ONLYThis method will never be invoked. NonBlockingStore.Characteristic.EXPIRATIONWhen set this method must not return true if the entry was expired. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentparameter may be ignored.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- containsKeyin interface- NonBlockingStore<K,- V> 
- Parameters:
- segment- the segment for the given key if segmentation is enabled, otherwise 0.
- key- key of the entry to check.
- Returns:
- a stage that, when complete, contains a boolean stating if the value is contained in the store.
 
- 
writeDescription copied from interface:NonBlockingStoreWrites the entry to the store for the given segment returning a stage that completes normally when it is finished.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.READ_ONLYThis method will never be invoked. NonBlockingStore.Characteristic.EXPIRATIONWhen set, this method must store the expiration metadata. NonBlockingStore.Characteristic.SEGMENTABLEWhen set and segmentation is not disabled in the configuration, this method must ensure the segment is stored with the entry.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- writein interface- NonBlockingStore<K,- V> 
- Parameters:
- segment- the segment for the given key if segmentation is enabled, otherwise 0.
- entry- the entry to persist to the store.
- Returns:
- a stage that when complete indicates that the store has written the value.
 
- 
deleteDescription copied from interface:NonBlockingStoreRemoves the entry for given key and segment from the store and optionally report if the entry was actually removed or not.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.READ_ONLYThis method will never be invoked. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentparameter may be ignored.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- deletein interface- NonBlockingStore<K,- V> 
- Parameters:
- segment- the segment for the given key if segmentation is enabled, otherwise 0.
- key- key of the entry to delete from the store.
- Returns:
- a stage that completes with TRUEif the key existed in the store,FALSEif the key did not exist in the store, ornullif the store does not report this information.
 
- 
addSegmentsDescription copied from interface:NonBlockingStoreInvoked when a node becomes an owner of the given segments. Some store implementations may require initializing additional resources when a new segment is required. For example a store could store entries in a different file per segment.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.SHAREABLEIf the store has this characteristic and is configured to be StoreConfiguration.shared(), this method will never be invoked.NonBlockingStore.Characteristic.SEGMENTABLEThis method is invoked only if the store has this characteristic and is configured to be segmented.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- addSegmentsin interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- the segments to add.
- Returns:
- a stage that, when complete, indicates that the segments have been added.
 
- 
removeSegmentsDescription copied from interface:NonBlockingStoreInvoked when a node loses ownership of the given segments. A store must then remove any entries that map to the given segments and can remove any resources related to the given segments. For example, a database store can delete rows of the given segment or a file-based store can delete files related to the given segments.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.SHAREABLEIf the store has this characteristic and is configured to be shared, this method will never be invoked.NonBlockingStore.Characteristic.SEGMENTABLEThis method is invoked only if the store has this characteristic and is configured to be segmented.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- removeSegmentsin interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- the segments to remove.
- Returns:
- a stage that, when complete, indicates that the segments have been removed.
 
- 
clearDescription copied from interface:NonBlockingStoreClears all entries from the store.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.READ_ONLYThis method will never be invoked. If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- clearin interface- NonBlockingStore<K,- V> 
- Returns:
- a stage that, when complete, indicates that the store has been cleared.
 
- 
batchpublic CompletionStage<Void> batch(int publisherCount, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<Object>> removePublisher, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>> writePublisher) Description copied from interface:NonBlockingStoreWrites and removes the entries provided by the Publishers into the store. Both are provided in the same method so that a batch may be performed as a single atomic operation if desired, although it is up to the store to manage its batching. If needed a store may generate batches of a configured size by using theStoreConfiguration.maxBatchSize()setting.Each of the Publishers may publish up topublisherCountpublishers where each publisher is separated by the segment each entry maps to. Failure to request at leastpublisherCountpublishers from the Publisher may cause a deadlock. Many reactive tools have methods such asflatMapthat take an argument of how many concurrent subscriptions it manages, which is perfectly matched with this argument.WARNING: For performance reasons neither Publisher will emit any NonBlockingStore.SegmentedPublishers until both write and remove Publishers are subscribed to. These Publishers should also be only subscribed once.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.READ_ONLYThis method will never be invoked. NonBlockingStore.Characteristic.SEGMENTABLEIf not set or segmentation is disabled in the configuration, thepublisherCountparameter has a value of 1, which means there is only be oneSegmentedPublisherto subscribe to.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- batchin interface- NonBlockingStore<K,- V> 
- Parameters:
- publisherCount- the maximum number of- SegmentPublishers either publisher will publish
- removePublisher- publishes what keys should be removed from the store
- writePublisher- publishes the entries to write to the store
- Returns:
- a stage that when complete signals that the store has written the values
 
- 
sizeDescription copied from interface:NonBlockingStoreReturns the amount of entries that map to the given segments in the store.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.BULK_READThis method is only invoked if the store has this characteristic. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentsparameter may be ignored.If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- sizein interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- the segments for which the entries are counted.
- Returns:
- a stage that, when complete, contains the count of how many entries are present for the given segments.
 
- 
approximateSizeDescription copied from interface:NonBlockingStoreReturns an estimation of the amount of entries that map to the given segments in the store. This is similar toNonBlockingStore.size(IntSet)except that it is not strict about the returned size. For instance, this method might ignore if an entry is expired or if the store has some underlying optimizations to eventually have a consistent size.The implementations should be O(1). If a size approximation cannot be returned without iterating over all the entries in the store, the implementation should return -1L.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.BULK_READThis method is only invoked if the store has this characteristic. NonBlockingStore.Characteristic.SEGMENTABLEWhen the store does not have this characteristic or segmentation is disabled in the configuration, thesegmentparameter is alwaysIntSets.immutableRangeSet(numSegments).If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- approximateSizein interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- the segments for which the entries are counted.
- Returns:
- a stage that, when complete, contains the approximate count of the entries in the given segments,
 or -1Lif an approximate count cannot be provided.
 
- 
publishEntriespublic org.reactivestreams.Publisher<MarshallableEntry<K,V>> publishEntries(IntSet segments, Predicate<? super K> filter, boolean includeValues) Description copied from interface:NonBlockingStorePublishes entries from this store that are in one of the provided segments and also pass the provided filter. The returned publisher must support being subscribed to any number of times. That is subsequent invocations ofPublisher.subscribe(Subscriber)should provide independent views of the underlying entries to the Subscribers. Entries should not be retrieved until a given Subscriber requests them via theSubscription.request(long)method.Subscribing to the returned Publishershould not block the invoking thread. It is the responsibility of the store implementation to ensure this occurs. If however the store must block to perform an operation it is recommended to wrap your Publisher before returning with theBlockingManager.blockingPublisher(Publisher)method and it will handle subscription and observation on the blocking and non-blocking executors respectively.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.BULK_READThis method is only invoked if the store has this characteristic. NonBlockingStore.Characteristic.EXPIRATIONWhen set the returned publisher must not return expired entries. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentparameter may be ignored.- Specified by:
- publishEntriesin interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- a set of segments to filter entries by. This will always be non-null.
- filter- a filter to filter the keys by. If this is null then no additional filtering should be done after segments.
- Returns:
- a publisher that provides the keys from the store.
 
- 
publishKeysDescription copied from interface:NonBlockingStorePublishes keys from this store that are in one of the provided segments and also pass the provided filter. The returned publisher must support being subscribed to any number of times. That is subsequent invocations ofPublisher.subscribe(Subscriber)should provide independent views of the underlying keys to the Subscribers. Keys should not be retrieved until a given Subscriber requests them via theSubscription.request(long)method.Subscribing to the returned Publishershould not block the invoking thread. It is the responsibility of the store implementation to ensure this occurs. If however the store must block to perform an operation it is recommended to wrap your Publisher before returning with theBlockingManager.blockingPublisher(Publisher)method and it will handle subscription and observation on the blocking and non-blocking executors respectively.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.BULK_READThis method is only invoked if the store has this characteristic. NonBlockingStore.Characteristic.EXPIRATIONWhen set the returned publisher must not return expired keys. NonBlockingStore.Characteristic.SEGMENTABLEWhen this is not set or segmentation is disabled in the configuration, thesegmentparameter may be ignored.- Specified by:
- publishKeysin interface- NonBlockingStore<K,- V> 
- Parameters:
- segments- a set of segments to filter keys by. This will always be non-null.
- filter- a filter to filter the keys by. If this is null then no additional filtering should be done after segments.
- Returns:
- a publisher that provides the keys from the store.
 
- 
purgeExpiredDescription copied from interface:NonBlockingStoreReturns a Publisher that, after it is subscribed to, removes any expired entries from the store and publishes them to the returned Publisher.When the Publisher is subscribed to, it is expected to do point-in-time expiration and should not return a Publisher that has infinite entries or never completes. Subscribing to the returned Publishershould not block the invoking thread. It is the responsibility of the store implementation to ensure this occurs. If however the store must block to perform an operation it is recommended to wrap your Publisher before returning with theBlockingManager.blockingPublisher(Publisher)method and it will handle subscription and observation on the blocking and non-blocking executors respectively.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.EXPIRATIONThis method is only invoked if the store has this characteristic. If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- purgeExpiredin interface- NonBlockingStore<K,- V> 
- Returns:
- a Publisher that publishes the entries that are expired at the time of subscription.
 
- 
prepareWithModificationspublic CompletionStage<Void> prepareWithModifications(javax.transaction.Transaction transaction, int publisherCount, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<Object>> removePublisher, org.reactivestreams.Publisher<NonBlockingStore.SegmentedPublisher<MarshallableEntry<K, V>>> writePublisher) Description copied from interface:NonBlockingStoreWrite remove and put modifications to the store in the prepare phase, which should not yet persisted until the same transaction is committed viaNonBlockingStore.commit(Transaction)or they are discarded if the transaction is rolled back viaNonBlockingStore.rollback(Transaction).Each of the Publishers may publish up topublisherCountpublishers where each publisher is separated by the segment each entry maps to. Failure to request at leastpublisherCountpublishers from the Publisher may cause a deadlock. Many reactive tools have methods such asflatMapthat take an argument of how many concurrent subscriptions it manages, which is perfectly matched with this argument.WARNING: For performance reasons neither Publisher will emit any NonBlockingStore.SegmentedPublishers until both write and remove Publishers are subscribed to. These Publishers should also be only subscribed once.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.TRANSACTIONALThis method is invoked only if the store has this characteristic. If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- prepareWithModificationsin interface- NonBlockingStore<K,- V> 
- Parameters:
- transaction- the current transactional context.
- publisherCount- the maximum number of- SegmentPublishers either publisher will publish
- removePublisher- publishes what keys should be removed from the store
- writePublisher- publishes the entries to write to the store
- Returns:
- a stage that when complete signals that the store has written the values
 
- 
commitDescription copied from interface:NonBlockingStoreCommit changes in the provided transaction to the underlying store.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.TRANSACTIONALThis method is invoked only if the store has this characteristic. If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- commitin interface- NonBlockingStore<K,- V> 
- Parameters:
- transaction- the current transactional context.
- Returns:
- a stage that, when completed, indicates that the transaction was committed.
 
- 
rollbackDescription copied from interface:NonBlockingStoreRoll back the changes from the provided transaction to the underlying store.Summary of Characteristics EffectsCharacteristic Effect NonBlockingStore.Characteristic.TRANSACTIONALThis method is invoked only if the store has this characteristic. If a problem is encountered, it is recommended to wrap any created/caught Throwable in a PersistenceExceptionand the stage be completed exceptionally.- Specified by:
- rollbackin interface- NonBlockingStore<K,- V> 
- Parameters:
- transaction- the current transactional context.
- Returns:
- a stage that, when completed, indicates that the transaction was rolled back.
 
- 
ignoreCommandWithFlagspublic boolean ignoreCommandWithFlags(long commandFlags) Description copied from interface:NonBlockingStoreSome stores may not want to perform operations based on if a command has certain flags. This method is currently only used for testing single write operations. This method may be removed at any time as it is experimental, it is not recommended for end users to implement it.- Specified by:
- ignoreCommandWithFlagsin interface- NonBlockingStore<K,- V> 
- Parameters:
- commandFlags- the flags attributed to the command when performing the operation.
- Returns:
- whether the operation should occur.
 
 
-