Uses of Class
org.infinispan.loaders.CacheLoaderException

Packages that use CacheLoaderException
org.infinispan.commands.control Commands that control and coordinate certain cache operations, such as rehashing, state transfer and locking. 
org.infinispan.eviction Classes related to eviction. 
org.infinispan.loaders This package contains loaders and stores, which are used for overflow or persistence. 
org.infinispan.loaders.bdbje This package contains a CacheStore implementation based on Oracle's BDBJE storage engine. 
org.infinispan.loaders.bucket Abstract classes that use hashed buckets to store entries. 
org.infinispan.loaders.cloud This package contains a CacheStore implementation based on JClouds, which in turn is an abstraction layer to store data on cloud infrastructure providers such as Amazon's S3, RackspaceCloud's CloudFiles, Microsoft's Windows Azure Blob Storage API, and others. 
org.infinispan.loaders.cluster A CacheLoader (not CacheStore) that polls other nodes in the cluster for state. 
org.infinispan.loaders.decorators This package contains loaders and stores, which are used for overflow or persistence. 
org.infinispan.loaders.file Simple filesystem-based CacheStore implementation. 
org.infinispan.loaders.jdbc This package contains a CacheStore implementation based on a JDBC database connection. 
org.infinispan.loaders.jdbc.binary This JDBC CacheStore implementation is optimized for storing binary (non-String) keys in the cache. 
org.infinispan.loaders.jdbc.connectionfactory Connection factories for use with the JDBC Cache Store. 
org.infinispan.loaders.jdbc.mixed This is a delegating CacheStore implementation that delegates either to a binary or String based JDBC cache store depending on the key used. 
org.infinispan.loaders.jdbc.stringbased This JDBC CacheStore implementation is optimized for storing String keys in the cache. 
org.infinispan.loaders.jdbm This package contains a CacheStore implementation based on persisting to JDBM. 
org.infinispan.loaders.remote   
 

Uses of CacheLoaderException in org.infinispan.commands.control
 

Methods in org.infinispan.commands.control that throw CacheLoaderException
 Map<Object,InternalCacheValue> RehashControlCommand.pullStateForJoin()
           
 Map<Object,InternalCacheValue> RehashControlCommand.pullStateForLeave()
           
 

Uses of CacheLoaderException in org.infinispan.eviction
 

Methods in org.infinispan.eviction that throw CacheLoaderException
 void PassivationManagerImpl.passivate(Object key, InternalCacheEntry entry, InvocationContext ctx)
           
 void PassivationManager.passivate(Object key, InternalCacheEntry entry, InvocationContext ctx)
           
 

Uses of CacheLoaderException in org.infinispan.loaders
 

Methods in org.infinispan.loaders that throw CacheLoaderException
protected  void LockSupportCacheStore.acquireGlobalLock(boolean exclusive)
          Based on the supplied param, acquires a global read(false) or write (true) lock.
protected  void AbstractCacheStore.applyModifications(List<? extends Modification> mods)
           
 void LockSupportCacheStore.clear()
           
 void CacheStore.clear()
          Clears all entries in the store
protected abstract  void LockSupportCacheStore.clearLockSafe()
           
 void AbstractCacheStore.commit(GlobalTransaction tx)
           
 void CacheStore.commit(GlobalTransaction tx)
          Commits a transaction that has been previously prepared.
 boolean AbstractCacheLoader.containsKey(Object key)
           This implementation delegates to CacheLoader.load(Object), to ensure that a response is returned only if the entry is not expired.
 boolean CacheLoader.containsKey(Object key)
           
 void LockSupportCacheStore.fromStream(ObjectInput objectInput)
           
 void CacheStore.fromStream(ObjectInput inputStream)
          Writes contents of the stream to the store.
protected abstract  void LockSupportCacheStore.fromStreamLockSafe(ObjectInput ois)
           
protected abstract  String LockSupportCacheStore.getLockFromKey(Object key)
           
protected  boolean LockSupportCacheStore.immediateLockForWriting(String key)
          Same as LockSupportCacheStore.lockForWriting(String), but with 0 timeout.
 void LockSupportCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AbstractCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AbstractCacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void CacheLoader.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
          Used to initialize a cache loader.
 Set<InternalCacheEntry> LockSupportCacheStore.load(int maxEntries)
           
 Set<InternalCacheEntry> CacheLoader.load(int numEntries)
          Loads up to a specific number of entries.
 InternalCacheEntry LockSupportCacheStore.load(Object key)
           
 InternalCacheEntry CacheLoader.load(Object key)
          Loads an entry mapped to by a given key.
 Set<InternalCacheEntry> LockSupportCacheStore.loadAll()
           
 Set<InternalCacheEntry> CacheLoader.loadAll()
          Loads all entries in the loader.
 Set<Object> LockSupportCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
 Set<Object> CacheLoader.loadAllKeys(Set<Object> keysToExclude)
          Loads a set of all keys, excluding a filter set.
protected abstract  Set<Object> LockSupportCacheStore.loadAllKeysLockSafe(Set<Object> keysToExclude)
           
protected abstract  Set<InternalCacheEntry> LockSupportCacheStore.loadAllLockSafe()
           
protected abstract  Set<InternalCacheEntry> LockSupportCacheStore.loadLockSafe(int maxEntries)
           
protected abstract  InternalCacheEntry LockSupportCacheStore.loadLockSafe(Object key, String lockingKey)
           
protected  void LockSupportCacheStore.lockForReading(String key)
          Acquires read lock on the given key.
protected  void LockSupportCacheStore.lockForWriting(String key)
          Acquires write lock on the given key.
 void AbstractCacheStore.prepare(List<? extends Modification> mods, GlobalTransaction tx, boolean isOnePhase)
           
 void CacheStore.prepare(List<? extends Modification> modifications, GlobalTransaction tx, boolean isOnePhase)
          Issues a prepare call with a set of modifications to be applied to the cache store
 void AbstractCacheStore.purgeExpired()
           
 void CacheStore.purgeExpired()
          Purges expired entries from the store.
protected abstract  void AbstractCacheStore.purgeInternal()
           
 boolean LockSupportCacheStore.remove(Object key)
           
 boolean CacheStore.remove(Object key)
          Removes an entry in the store.
 void AbstractCacheStore.removeAll(Set<Object> keys)
           
 void CacheStore.removeAll(Set<Object> keys)
          Bulk remove operation
protected abstract  boolean LockSupportCacheStore.removeLockSafe(Object key, String lockingKey)
           
protected  void AbstractCacheStore.safeClose(InputStream stream)
           
protected  void AbstractCacheStore.safeClose(OutputStream stream)
           
 void LockSupportCacheStore.start()
           
 void AbstractCacheStore.start()
           
 void CacheLoader.start()
           
 void AbstractCacheStore.stop()
           
 void CacheLoader.stop()
           
 void LockSupportCacheStore.store(InternalCacheEntry ed)
           
 void CacheStore.store(InternalCacheEntry entry)
          Stores an entry
protected abstract  void LockSupportCacheStore.storeLockSafe(InternalCacheEntry ed, String lockingKey)
           
 void LockSupportCacheStore.toStream(ObjectOutput objectOutput)
           
 void CacheStore.toStream(ObjectOutput outputStream)
          Loads the entire state into a stream, using whichever format is most efficient for the cache loader implementation.
protected abstract  void LockSupportCacheStore.toStreamLockSafe(ObjectOutput oos)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.bdbje
 

Methods in org.infinispan.loaders.bdbje that throw CacheLoaderException
protected  void BdbjeCacheStore.applyModifications(List<? extends Modification> mods)
          Perform the mods atomically by creating a worker and invoking them in TransactionRunner.run(com.sleepycat.collections.TransactionWorker).
 void BdbjeCacheStore.clear()
          Clears all entries in the store
 void BdbjeCacheStore.commit(GlobalTransaction tx)
          Commits a transaction that has been previously prepared.
protected  void BdbjeCacheStore.completeTransaction(GlobalTransaction tx, boolean commit)
          Looks up the SleepyCat transaction associated with the parameter tx.
 void BdbjeCacheStore.fromStream(ObjectInput ois)
          Writes contents of the stream to the store.
 void BdbjeCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
          Used to initialize a cache loader.
 Set<InternalCacheEntry> BdbjeCacheStore.load(int numEntries)
           
 InternalCacheEntry BdbjeCacheStore.load(Object key)
          Loads an entry mapped to by a given key.
 Set<InternalCacheEntry> BdbjeCacheStore.loadAll()
          Loads all entries in the loader.
 Set<Object> BdbjeCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
protected  void BdbjeCacheStore.prepare(List<? extends Modification> mods, GlobalTransaction tx)
          Looks up the SleepyCat transaction associated with tx.
 void BdbjeCacheStore.prepare(List<? extends Modification> mods, GlobalTransaction tx, boolean isOnePhase)
          Issues a prepare call with a set of modifications to be applied to the cache store
protected  void BdbjeCacheStore.purgeInternal()
          Iterate through StoredMap.entrySet() and remove, if expired.
 boolean BdbjeCacheStore.remove(Object key)
          Removes an entry in the store.
 void BdbjeCacheStore.start()
           Validates configuration, configures and opens the Environment, then opens the databases.
 void BdbjeCacheStore.stop()
          Stops transaction and purge processing and closes the SleepyCat environment.
 void BdbjeCacheStore.store(InternalCacheEntry ed)
          Stores an entry
 void BdbjeCacheStore.toStream(ObjectOutput oos)
          Writes the current count of cachestore entries followed by a pair of byte[]s corresponding to the SleepyCat binary representation of key value.
 

Uses of CacheLoaderException in org.infinispan.loaders.bucket
 

Methods in org.infinispan.loaders.bucket that throw CacheLoaderException
 boolean BucketBasedCacheStore.BucketHandler.handle(Bucket bucket)
          Handles a bucket that is passed in.
 boolean BucketBasedCacheStore.CollectionGeneratingBucketHandler.handle(Bucket bucket)
           
protected  void BucketBasedCacheStore.insertBucket(Bucket bucket)
          Inserts a new Bucket in the storage system.
protected  Set<Object> BucketBasedCacheStore.loadAllKeysLockSafe(Set<Object> keysToExclude)
           
protected  Set<InternalCacheEntry> BucketBasedCacheStore.loadAllLockSafe()
           
protected abstract  Bucket BucketBasedCacheStore.loadBucket(String hash)
          Loads a Bucket from the store, based on the hash code of the bucket.
protected  Set<InternalCacheEntry> BucketBasedCacheStore.loadLockSafe(int max)
           
protected  InternalCacheEntry BucketBasedCacheStore.loadLockSafe(Object key, String lockingKey)
          Loads an entry from a Bucket, locating the relevant Bucket using the key's hash code.
protected abstract  void BucketBasedCacheStore.loopOverBuckets(BucketBasedCacheStore.BucketHandler handler)
          A mechanism to loop over all buckets in the cache store.
protected  boolean BucketBasedCacheStore.removeLockSafe(Object key, String lockingKey)
          Removes an entry from a Bucket, locating the relevant Bucket using the key's hash code.
protected  void BucketBasedCacheStore.storeLockSafe(InternalCacheEntry entry, String lockingKey)
          Stores an entry in an appropriate Bucket, based on the key's hash code.
protected abstract  void BucketBasedCacheStore.updateBucket(Bucket bucket)
          Updates a bucket in the store with the Bucket passed in to the method.
 

Uses of CacheLoaderException in org.infinispan.loaders.cloud
 

Methods in org.infinispan.loaders.cloud that throw CacheLoaderException
 void CloudCacheStore.applyModifications(List<? extends Modification> modifications)
           
protected  void CloudCacheStore.fromStreamLockSafe(ObjectInput objectInput)
           
 void CloudCacheStore.init(CacheLoaderConfig cfg, Cache<?,?> cache, StreamingMarshaller m)
           
 void CloudCacheStore.init(CacheLoaderConfig cfg, Cache<?,?> cache, StreamingMarshaller m, org.jclouds.blobstore.BlobStoreContext ctx, org.jclouds.blobstore.BlobStore blobStore, org.jclouds.blobstore.AsyncBlobStore asyncBlobStore, boolean constructInternalBlobstores)
           
protected  Bucket CloudCacheStore.loadBucket(String hash)
           
protected  void CloudCacheStore.loopOverBuckets(BucketBasedCacheStore.BucketHandler handler)
           
protected  void CloudCacheStore.purgeInternal()
           
 void CloudCacheStore.start()
           
protected  void CloudCacheStore.toStreamLockSafe(ObjectOutput objectOutput)
           
protected  void CloudCacheStore.updateBucket(Bucket bucket)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.cluster
 

Methods in org.infinispan.loaders.cluster that throw CacheLoaderException
 Set<InternalCacheEntry> ClusterCacheLoader.load(int maxElems)
           
 InternalCacheEntry ClusterCacheLoader.load(Object key)
           
 Set<InternalCacheEntry> ClusterCacheLoader.loadAll()
           
 Set<Object> ClusterCacheLoader.loadAllKeys(Set<Object> keysToExclude)
           
 void ClusterCacheLoader.start()
           
 void ClusterCacheLoader.stop()
           
 

Uses of CacheLoaderException in org.infinispan.loaders.decorators
 

Methods in org.infinispan.loaders.decorators that throw CacheLoaderException
protected  void AsyncStore.applyModificationsSync(ConcurrentMap<Object,Modification> mods)
           
 void SingletonStore.clear()
           
 void ChainingCacheStore.clear()
           
 void AbstractDelegatingStore.clear()
           
 void AsyncStore.commit(GlobalTransaction tx)
           
 void SingletonStore.commit(GlobalTransaction tx)
           
 void ChainingCacheStore.commit(GlobalTransaction tx)
           
 void AbstractDelegatingStore.commit(GlobalTransaction tx)
           
 boolean ChainingCacheStore.containsKey(Object key)
           
 boolean AbstractDelegatingStore.containsKey(Object key)
           
protected  void AsyncStore.enqueueModificationsList(List<? extends Modification> mods)
           
 void SingletonStore.fromStream(ObjectInput inputStream)
           
 void ChainingCacheStore.fromStream(ObjectInput inputStream)
           
 void AbstractDelegatingStore.fromStream(ObjectInput inputStream)
           
 void AsyncStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void AbstractDelegatingStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 void ChainingCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
           
 Set<InternalCacheEntry> ChainingCacheStore.load(int numEntries)
           
 Set<InternalCacheEntry> AbstractDelegatingStore.load(int numEntries)
           
 InternalCacheEntry ChainingCacheStore.load(Object key)
           
 InternalCacheEntry AbstractDelegatingStore.load(Object key)
           
 Set<InternalCacheEntry> ChainingCacheStore.loadAll()
           
 Set<InternalCacheEntry> AbstractDelegatingStore.loadAll()
           
 Set<Object> ChainingCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
 Set<Object> AbstractDelegatingStore.loadAllKeys(Set<Object> keysToExclude)
           
 void AsyncStore.prepare(List<? extends Modification> mods, GlobalTransaction tx, boolean isOnePhase)
           
 void SingletonStore.prepare(List<? extends Modification> list, GlobalTransaction tx, boolean isOnePhase)
           
 void ChainingCacheStore.prepare(List<? extends Modification> list, GlobalTransaction tx, boolean isOnePhase)
           
 void AbstractDelegatingStore.prepare(List<? extends Modification> list, GlobalTransaction tx, boolean isOnePhase)
           
 void SingletonStore.purgeExpired()
           
 void ChainingCacheStore.purgeExpired()
           
 void AbstractDelegatingStore.purgeExpired()
           
 void ChainingCacheStore.purgeIfNecessary()
           
 boolean SingletonStore.remove(Object key)
           
 boolean ChainingCacheStore.remove(Object key)
           
 boolean AbstractDelegatingStore.remove(Object key)
           
 void ChainingCacheStore.removeAll(Set<Object> keys)
           
 void AbstractDelegatingStore.removeAll(Set<Object> keys)
           
 void AsyncStore.start()
           
 void SingletonStore.start()
           
 void ChainingCacheStore.start()
           
 void AbstractDelegatingStore.start()
           
 void AsyncStore.stop()
           
 void SingletonStore.stop()
           
 void ChainingCacheStore.stop()
           
 void AbstractDelegatingStore.stop()
           
 void SingletonStore.store(InternalCacheEntry ed)
           
 void ChainingCacheStore.store(InternalCacheEntry ed)
           
 void AbstractDelegatingStore.store(InternalCacheEntry ed)
           
 void ChainingCacheStore.toStream(ObjectOutput outputStream)
           
 void AbstractDelegatingStore.toStream(ObjectOutput outputStream)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.file
 

Methods in org.infinispan.loaders.file that throw CacheLoaderException
protected  void FileCacheStore.clearLockSafe()
           
protected  void FileCacheStore.fromStreamLockSafe(ObjectInput objectInput)
           
 void FileCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
           
protected  Bucket FileCacheStore.loadBucket(File bucketFile)
           
protected  Bucket FileCacheStore.loadBucket(String bucketName)
           
 Bucket FileCacheStore.loadBucketContainingKey(String key)
           
protected  void FileCacheStore.loopOverBuckets(BucketBasedCacheStore.BucketHandler handler)
           
protected  void FileCacheStore.purgeInternal()
           
 void FileCacheStore.start()
           
protected  void FileCacheStore.toStreamLockSafe(ObjectOutput objectOutput)
           
 void FileCacheStore.updateBucket(Bucket b)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbc
 

Methods in org.infinispan.loaders.jdbc that throw CacheLoaderException
 void DataManipulationHelper.clear()
           
 void TableManipulation.createTable(Connection conn)
           
 void TableManipulation.dropTable(Connection conn)
           
protected abstract  boolean DataManipulationHelper.fromStreamProcess(Object objFromStream, PreparedStatement ps, ObjectInput objectInput)
           
 void DataManipulationHelper.fromStreamSupport(ObjectInput objectInput)
           
protected abstract  void DataManipulationHelper.loadAllKeysProcess(ResultSet rs, Set<Object> keys, Set<Object> keysToExclude)
           
 Set<Object> DataManipulationHelper.loadAllKeysSupport(Set<Object> keysToExclude)
           
protected abstract  void DataManipulationHelper.loadAllProcess(ResultSet rs, Set<InternalCacheEntry> result)
           
 Set<InternalCacheEntry> DataManipulationHelper.loadAllSupport(boolean filterExpired)
           
 Set<InternalCacheEntry> DataManipulationHelper.loadSome(int maxEntries)
           
static void DataManipulationHelper.logAndThrow(Exception e, String message)
           
static ByteBuffer JdbcUtil.marshall(StreamingMarshaller marshaller, Object bucket)
           
 void TableManipulation.start(ConnectionFactory connectionFactory)
           
 void TableManipulation.stop()
           
 boolean TableManipulation.tableExists(Connection connection)
           
 boolean TableManipulation.tableExists(Connection connection, String tableName)
           
protected abstract  void DataManipulationHelper.toStreamProcess(ResultSet rs, InputStream is, ObjectOutput objectOutput)
           
 void DataManipulationHelper.toStreamSupport(ObjectOutput objectOutput, byte streamDelimiter, boolean filterExpired)
           
static Object JdbcUtil.unmarshall(StreamingMarshaller marshaller, InputStream inputStream)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbc.binary
 

Methods in org.infinispan.loaders.jdbc.binary that throw CacheLoaderException
protected  void JdbcBinaryCacheStore.clearLockSafe()
           
 void JdbcBinaryCacheStore.doConnectionFactoryInitialization(ConnectionFactory connectionFactory)
          Keeps a reference to the connection factory for further use.
protected  void JdbcBinaryCacheStore.fromStreamLockSafe(ObjectInput objectInput)
           
 void JdbcBinaryCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
           
protected  void JdbcBinaryCacheStore.insertBucket(Bucket bucket)
           
 Set<Object> JdbcBinaryCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
 Set<InternalCacheEntry> JdbcBinaryCacheStore.loadAllLockSafe()
           
protected  Bucket JdbcBinaryCacheStore.loadBucket(String keyHashCode)
           
protected  Set<InternalCacheEntry> JdbcBinaryCacheStore.loadLockSafe(int maxEntries)
           
protected  void JdbcBinaryCacheStore.loopOverBuckets(BucketBasedCacheStore.BucketHandler handler)
           
 void JdbcBinaryCacheStore.purgeInternal()
           
 void JdbcBinaryCacheStore.start()
           
 void JdbcBinaryCacheStore.stop()
           
protected  void JdbcBinaryCacheStore.toStreamLockSafe(ObjectOutput objectOutput)
           
protected  void JdbcBinaryCacheStore.updateBucket(Bucket bucket)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbc.connectionfactory
 

Methods in org.infinispan.loaders.jdbc.connectionfactory that throw CacheLoaderException
 Connection ManagedConnectionFactory.getConnection()
           
 Connection PooledConnectionFactory.getConnection()
           
 Connection SimpleConnectionFactory.getConnection()
           
abstract  Connection ConnectionFactory.getConnection()
          Fetches a connection from the factory.
static ConnectionFactory ConnectionFactory.getConnectionFactory(String connectionFactoryClass)
          Constructs a ConnectionFactory based on the supplied class name.
 void ManagedConnectionFactory.start(ConnectionFactoryConfig config)
           
 void PooledConnectionFactory.start(ConnectionFactoryConfig config)
           
 void SimpleConnectionFactory.start(ConnectionFactoryConfig config)
           
abstract  void ConnectionFactory.start(ConnectionFactoryConfig config)
          Starts the connection factory.
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbc.mixed
 

Methods in org.infinispan.loaders.jdbc.mixed that throw CacheLoaderException
 void JdbcMixedCacheStore.clear()
           
 void JdbcMixedCacheStore.fromStream(ObjectInput inputStream)
           
 void JdbcMixedCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
           
 Set<InternalCacheEntry> JdbcMixedCacheStore.load(int numEntries)
           
 InternalCacheEntry JdbcMixedCacheStore.load(Object key)
           
 Set<InternalCacheEntry> JdbcMixedCacheStore.loadAll()
           
 Set<Object> JdbcMixedCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
protected  void JdbcMixedCacheStore.purgeInternal()
           
 boolean JdbcMixedCacheStore.remove(Object key)
           
 void JdbcMixedCacheStore.start()
           
 void JdbcMixedCacheStore.stop()
           
 void JdbcMixedCacheStore.store(InternalCacheEntry ed)
           
 void JdbcMixedCacheStore.toStream(ObjectOutput outputStream)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbc.stringbased
 

Subclasses of CacheLoaderException in org.infinispan.loaders.jdbc.stringbased
 class UnsupportedKeyTypeException
          Exception thrown by JdbcStringBasedCacheStore when one tries to persist a StoredEntry with an unsupported key type.
 

Methods in org.infinispan.loaders.jdbc.stringbased that throw CacheLoaderException
protected  void JdbcStringBasedCacheStore.clearLockSafe()
           
 void JdbcStringBasedCacheStore.doConnectionFactoryInitialization(ConnectionFactory connectionFactory)
          Keeps a reference to the connection factory for further use.
 void JdbcStringBasedCacheStore.fromStreamLockSafe(ObjectInput objectInput)
           
protected  String JdbcStringBasedCacheStore.getLockFromKey(Object key)
           
 void JdbcStringBasedCacheStore.init(CacheLoaderConfig config, Cache cache, StreamingMarshaller m)
           
protected  Set<Object> JdbcStringBasedCacheStore.loadAllKeysLockSafe(Set<Object> keysToExclude)
           
protected  Set<InternalCacheEntry> JdbcStringBasedCacheStore.loadAllLockSafe()
           
protected  Set<InternalCacheEntry> JdbcStringBasedCacheStore.loadLockSafe(int maxEntries)
           
protected  InternalCacheEntry JdbcStringBasedCacheStore.loadLockSafe(Object key, String lockingKey)
           
protected  void JdbcStringBasedCacheStore.logAndThrow(Exception e, String message)
           
 void JdbcStringBasedCacheStore.purgeInternal()
           
 boolean JdbcStringBasedCacheStore.removeLockSafe(Object key, String keyStr)
           
 void JdbcStringBasedCacheStore.start()
           
 void JdbcStringBasedCacheStore.stop()
           
 void JdbcStringBasedCacheStore.storeLockSafe(InternalCacheEntry ed, String lockingKey)
           
protected  void JdbcStringBasedCacheStore.toStreamLockSafe(ObjectOutput objectOutput)
           
 

Uses of CacheLoaderException in org.infinispan.loaders.jdbm
 

Methods in org.infinispan.loaders.jdbm that throw CacheLoaderException
protected  void JdbmCacheStore.applyModifications(List<? extends Modification> mods)
           
 void JdbmCacheStore.clear()
           
 void JdbmCacheStore.fromStream(ObjectInput in)
          Reads from a stream the number of entries (long) then the entries themselves.
 void JdbmCacheStore.init(CacheLoaderConfig clc, Cache cache, StreamingMarshaller m)
           
 Set<InternalCacheEntry> JdbmCacheStore.load(int numEntries)
           
 InternalCacheEntry JdbmCacheStore.load(Object key)
           
 Set<InternalCacheEntry> JdbmCacheStore.loadAll()
           
 Set<Object> JdbmCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
protected  void JdbmCacheStore.purgeInternal()
          Purge expired entries.
 boolean JdbmCacheStore.remove(Object key)
           
 boolean JdbmCacheStore.remove0(Object key)
           
 void JdbmCacheStore.start()
           
 void JdbmCacheStore.store(InternalCacheEntry entry)
           
 void JdbmCacheStore.toStream(ObjectOutput out)
          Writes to a stream the number of entries (long) then the entries themselves.
 

Uses of CacheLoaderException in org.infinispan.loaders.remote
 

Methods in org.infinispan.loaders.remote that throw CacheLoaderException
 void RemoteCacheStore.clear()
           
 boolean RemoteCacheStore.containsKey(Object key)
           
 void RemoteCacheStore.fromStream(ObjectInput inputStream)
           
 void RemoteCacheStore.init(CacheLoaderConfig config, Cache<?,?> cache, StreamingMarshaller m)
           
 Set<InternalCacheEntry> RemoteCacheStore.load(int numEntries)
           
 InternalCacheEntry RemoteCacheStore.load(Object key)
           
 Set<InternalCacheEntry> RemoteCacheStore.loadAll()
           
 Set<Object> RemoteCacheStore.loadAllKeys(Set<Object> keysToExclude)
           
protected  void RemoteCacheStore.purgeInternal()
           
 boolean RemoteCacheStore.remove(Object key)
           
 void RemoteCacheStore.start()
           
 void RemoteCacheStore.stop()
           
 void RemoteCacheStore.store(InternalCacheEntry entry)
           
 void RemoteCacheStore.toStream(ObjectOutput outputStream)
           
 


Google Analytics

Copyright © 2010 JBoss, a division of Red Hat. All Rights Reserved.