- ABORT_POLICY - Static variable in class org.aredis.util.concurrent.LimitingTaskExecutor
-
RejectedTaskHandler which Aborts the rejected task by throwing a RejectedExecutionException.
- AbstractAsyncRedisClient - Class in org.aredis.cache
-
A basic implementation of AsyncRedisClient based on 2 abstract methods.
- AbstractAsyncRedisClient() - Constructor for class org.aredis.cache.AbstractAsyncRedisClient
-
- AbstractAsyncSocketTransport - Class in org.aredis.net
-
Provides a base implementation of AsyncSocketTransport which provides connection status handling and a retry mechanism.
- AbstractAsyncSocketTransport(String, int) - Constructor for class org.aredis.net.AbstractAsyncSocketTransport
-
- acquireIdle() - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Acquires an idle Q and marks it as active.
- add(E, boolean) - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Adds an item to the head of the Q.
- ADD_SCRIPT - Static variable in class org.aredis.cache.Script
-
Deprecated.
Since version 2.6.12 Redis has an enhanced SET command which has an NX and expiry option. So this script is not required.
- addDebug(String) - Method in class org.aredis.cache.RedisCommandInfo
-
Utility to add a Debug message to the Command.
- addDebug(StringBuffer, String) - Static method in class org.aredis.util.GenUtil
-
Add a debug message to a StringBuffer with a new line.
- addTask(PeriodicTask) - Method in class org.aredis.util.PeriodicTaskPoller
-
Adds a task to be run at the specified interval of 15 seconds.
- afterAcquireIdle(SingleConsumerQueue<E>) - Method in interface org.aredis.util.concurrent.SingleConsumerQueue.IdleListener
-
Gets called after the Q is marked active when acquiring an idle Q.
- ArrayWrappingList<E> - Class in org.aredis.util
-
A simple unmodifiable list wrapping an array.
- ArrayWrappingList(E[]) - Constructor for class org.aredis.util.ArrayWrappingList
-
- asyncBorrow(AvailabeCallback<E>) - Method in class org.aredis.util.pool.AsyncObjectPool
-
Asynchronous borrow.
- AsyncHandler<V> - Interface in org.aredis.cache
-
Callback interface used in aredis to indicate completion of an Asynchronous task submitted.
- AsyncJavaSocketTransport - Class in org.aredis.net
-
- AsyncJavaSocketTransport(String, int, AsyncSocketTransportFactory) - Constructor for class org.aredis.net.AsyncJavaSocketTransport
-
Creates an AsyncJavaSocketTransport.
- AsyncObjectPool<E> - Class in org.aredis.util.pool
-
An fixed size Object pool with the feature of Async borrow used as connection pool by aredis for MULTI-EXEC transactions with WATCH commands.
- AsyncObjectPool(AsyncPoolMemberManager<E>, int, Executor) - Constructor for class org.aredis.util.pool.AsyncObjectPool
-
Creates an AsyncObject Pool.
- AsyncObjectPool.PoolMemberHolder<T> - Class in org.aredis.util.pool
-
Class Holding pool members.
- AsyncObjectPool.PoolMemberHolder() - Constructor for class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
- AsyncPoolMemberManager<E> - Interface in org.aredis.util.pool
-
- AsyncRedisClient - Interface in org.aredis.cache
-
Specifies the different methods to run Redis Commands.
- AsyncRedisConnection - Class in org.aredis.cache
-
This is the pipelined asynchronous implementation of AsyncRedisClient that is the basis of aredis.
- AsyncRedisConnection(AsyncSocketTransport, int, Executor, ConnectionType) - Constructor for class org.aredis.cache.AsyncRedisConnection
-
Constructor to create an AsyncRedisConnection of the given connection type.
- AsyncRedisConnection(AsyncSocketTransport, int, Executor) - Constructor for class org.aredis.cache.AsyncRedisConnection
-
Constructor to create a SHARED AsyncRedisConnection.
- AsyncRedisConnectionPoolManager - Class in org.aredis.cache
-
A Pool Member Manager for AsyncRedisConnection so that
AsyncObjectPool
can be used to create a pool of
AsyncRedisConnection.
- AsyncRedisConnectionPoolManager(AsyncSocketTransportFactory, RedisServerInfo, Executor, int) - Constructor for class org.aredis.cache.AsyncRedisConnectionPoolManager
-
- AsyncRedisConnectionPoolManager(RedisServerInfo, Executor) - Constructor for class org.aredis.cache.AsyncRedisConnectionPoolManager
-
- AsyncRedisFactory - Class in org.aredis.cache
-
- AsyncRedisFactory(AsyncSocketTransportFactory, Executor, int, int) - Constructor for class org.aredis.cache.AsyncRedisFactory
-
Creates an AsyncRedisFactory Object.
- AsyncRedisFactory(AsyncSocketTransportFactory, Executor) - Constructor for class org.aredis.cache.AsyncRedisFactory
-
Creates an AsyncRedisFactory Object with a default pool size of 10 and Shutdown delay of 10 seconds.
- AsyncRedisFactory(Executor) - Constructor for class org.aredis.cache.AsyncRedisFactory
-
Creates an AsyncRedisFactory Object with the default Transport Factory, a default pool size of 10 and Shutdown delay of 10 seconds.
- AsyncSocketTransport - Interface in org.aredis.net
-
Specifies an Async Socket Transport interface that can be used by
AsyncRedisConnection
to connect to a Redis Server.
- AsyncSocketTransportConfig - Class in org.aredis.net
-
Specifies the Configuration of AsyncSocketTransport.
- AsyncSocketTransportConfig(int, int, long, long, long) - Constructor for class org.aredis.net.AsyncSocketTransportConfig
-
Creates a Config with custom parameters.
- AsyncSocketTransportConfig() - Constructor for class org.aredis.net.AsyncSocketTransportConfig
-
Creates a config with default parameters.
- AsyncSocketTransportFactory - Class in org.aredis.net
-
Factory class to create an
AsyncSocketTransport
connection to a Redis Server via the getTransport method.
- AsyncSocketTransportFactory(AsyncSocketTransportConfig) - Constructor for class org.aredis.net.AsyncSocketTransportFactory
-
Create an AsyncSocketTransportFactory.
- AsyncSocketTransportFactory() - Constructor for class org.aredis.net.AsyncSocketTransportFactory
-
Create an AsyncSocketTransportFactory with default config.
- AvailabeCallback<E> - Interface in org.aredis.util.pool
-
Callback interface to be passed when making an asyncBorrow call on an Object pool
- awaitTermination(long, TimeUnit) - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Calls awaitTermination on the underlying Executor Service.
- call() - Method in class org.aredis.util.concurrent.CallableResult
-
- CallableResult<V> - Class in org.aredis.util.concurrent
-
Utility Callable class where the result can be set before the call method is called.
- CallableResult() - Constructor for class org.aredis.util.concurrent.CallableResult
-
- channelGroup - Static variable in class org.aredis.net.AsyncJavaSocketTransport
-
Channel group used by the AsyncSocketChannels.
- checkRetry(AsyncHandler<ConnectionStatus>) - Method in class org.aredis.net.ConnectionState
-
This method is to be called when the getStatus method returns RETRY.
- ClassDescriptors - Class in org.aredis.io
-
Holds Class Descriptors in an internal array.
- ClassDescriptors() - Constructor for class org.aredis.io.ClassDescriptors
-
Creates a read only ClassDescriptors.
- ClassDescriptorsInfo - Class in org.aredis.io
-
Parent class of ClassDescriptors holding just the specVersion (Currently 1) and the versionNo.
- ClassDescriptorsInfo(int) - Constructor for class org.aredis.io.ClassDescriptorsInfo
-
- ClassDescriptorsInfo() - Constructor for class org.aredis.io.ClassDescriptorsInfo
-
- ClassDescriptorStorage - Class in org.aredis.io
-
- ClassDescriptorStorage() - Constructor for class org.aredis.io.ClassDescriptorStorage
-
Creates a Class Descriptor Storage.
- ClassDescriptorStorageFactory - Interface in org.aredis.cache
-
- classDescriptorStorageFactory - Variable in class org.aredis.cache.JavaHandler
-
- clearCompressionInfo() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
- clone(boolean) - Method in class org.aredis.io.ClassDescriptors
-
Clones the current descriptor.
- clone() - Method in class org.aredis.io.ClassDescriptors
-
Clones the current descriptor.
- clone() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
Creates a copy of this config in case a local change is to be done without affecting other connections.
- close() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
- close() - Method in class org.aredis.net.AsyncJavaSocketTransport
-
- close() - Method in interface org.aredis.net.AsyncSocketTransport
-
Closes the Socket connection.
- closeStaleConnection() - Method in class org.aredis.cache.AsyncRedisConnection
-
Closes the connection if it has been idle beyond the configured idle timeout or the Redis Server timeout.
- closeStaleConnection() - Method in class org.aredis.cache.RedisSubscriptionConnection
-
Closes the connection if it has been idle beyond the configured idle timeout or the Redis Server timeout.
- compare(ServerInfo, ServerInfo) - Method in class org.aredis.net.ServerInfoComparator
-
- compareTo(RedisServerInfo) - Method in class org.aredis.cache.RedisServerInfo
-
- compareTo(RedisServerListInfo) - Method in class org.aredis.cache.RedisServerListInfo
-
- compareTo(Script) - Method in class org.aredis.cache.Script
-
- compareTo(AsyncObjectPool.PoolMemberHolder<T>) - Method in class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
Identity System.identityHashCode base comparator on members so that Binary Search can be used to locate a member.
- completed(V, Throwable) - Method in interface org.aredis.cache.AsyncHandler
-
Called upon completion of an Asynchronous task
- completed(Integer, Throwable) - Method in class org.aredis.cache.RedisResponseReader
-
This method is an internal method made public as a consequence of implementing AsyncHandler.
- CompressibleByteArrayOutputStream - Class in org.aredis.io
-
An OutputStream that compresses the data once the size crosses a certain threshold.
- CompressibleByteArrayOutputStream(int) - Constructor for class org.aredis.io.CompressibleByteArrayOutputStream
-
Creates a new CompressibleByteArrayOutputStream.
- CompressibleByteArrayOutputStream(int, int) - Constructor for class org.aredis.io.CompressibleByteArrayOutputStream
-
Creates a new CompressibleByteArrayOutputStream.
- CompressibleByteArrayOutputStream() - Constructor for class org.aredis.io.CompressibleByteArrayOutputStream
-
Creates a new CompressibleByteArrayOutputStream with the default compression threshold of 1024 bytes.
- CompressibleByteArrayOutputStreamPool - Class in org.aredis.io
-
This is a class to reuse CompressibleByteArrayOutputStream to avoid creating a new one every time.
- CompressibleByteArrayOutputStreamPool() - Constructor for class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- computeMd5(String) - Static method in enum org.aredis.cache.DefaultHashAlgorithm
-
Get the md5 of the given key.
- config - Variable in class org.aredis.net.AbstractAsyncSocketTransport
-
- connect(AsyncHandler<Boolean>) - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- connect(AsyncHandler<Boolean>) - Method in interface org.aredis.net.AsyncSocketTransport
-
Connects to Socket and calls handler with true on success and false with
Exception on failure.
- connectInternal(AsyncHandler<Boolean>) - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
Connect Method to be implemented by sub-class.
- connectInternal(AsyncHandler<Boolean>) - Method in class org.aredis.net.AsyncJavaSocketTransport
-
- ConnectionState - Class in org.aredis.net
-
Captures the Connection State for all AsyncSocketTransports connected to a given host and port.
- ConnectionState() - Constructor for class org.aredis.net.ConnectionState
-
Creates a new ConnectionState.
- connectionStatus - Variable in class org.aredis.net.AbstractAsyncSocketTransport
-
ConnectionStatus of this connection.
- ConnectionStatus - Enum in org.aredis.net
-
Connection Status.
- connectionString - Variable in class org.aredis.net.AbstractAsyncSocketTransport
-
- ConnectionType - Enum in org.aredis.cache
-
Defines the types of a Redis Connection.
- ConsistentKeyHasher - Class in org.aredis.cache
-
Consistent Hashing Algorithm derived from the one in SpyMemcached memcached client.
- ConsistentKeyHasher(AsyncRedisConnection[], int, HashAlgorithm) - Constructor for class org.aredis.cache.ConsistentKeyHasher
-
Creates a Consistent Key Hasher.
- ConsistentKeyHasher(AsyncRedisConnection[]) - Constructor for class org.aredis.cache.ConsistentKeyHasher
-
Creates a Consistent Key Hasher with 180 hashes per connection and CRC_HASH as the Hash Algorithm.
- copyMetaInfoTo(ClassDescriptors) - Method in class org.aredis.io.ClassDescriptors
-
Copies meta info like written class descriptors and lastUseTime to another ClassDescriptors.
- createInfo() - Method in class org.aredis.io.ClassDescriptors
-
Creates an info Object containing the versionNo.
- createObject() - Method in class org.aredis.cache.AsyncRedisConnectionPoolManager
-
Creates an AsyncRedisConnection.
- createObject() - Method in interface org.aredis.util.pool.AsyncPoolMemberManager
-
Create a new Object for using in pool.
- CUSTOM_CLASS_NAME - Static variable in class org.aredis.net.AsyncSocketTransportFactory
-
Used this as the class name you are extending AsyncSocketTransportFactory and overriding getTransport.
- GenUtil - Class in org.aredis.util
-
Generic util class containing static methods.
- GenUtil() - Constructor for class org.aredis.util.GenUtil
-
- get(int) - Method in class org.aredis.util.ArrayWrappingList
- getAbandonCompressionRatio() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Gets the abandon compression ratio.
- getArgTypes() - Method in enum org.aredis.cache.RedisCommand
-
Gets the command argument types as a character array.
- getAuth(ServerInfo) - Static method in class org.aredis.cache.AsyncRedisFactory
-
Gets the Configured Authentication for the given serverInfo.
- getAuth(String) - Static method in class org.aredis.cache.AsyncRedisFactory
-
Gets the Configured Authentication for the Redis Server with the given connectionString.
- getBuf() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Gets the underlying buffer.
- getBuf() - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Gets the underlying buffer.
- getByteResult(Object, byte) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to a byte
- getByteResult(byte) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to a byte
- getCapacity() - Method in class org.aredis.util.concurrent.SynchronizedStack
-
Gets max capacity of this stack was created with which is the length of the underlying array.
- getChannelGroup() - Static method in class org.aredis.net.AsyncJavaSocketTransport
-
- getChannelName() - Method in class org.aredis.cache.SubscriptionInfo
-
Gets the channel name.
- getCharEncoding() - Method in class org.aredis.cache.JavaHandler
-
Gets the character encoding used for Serializing Strings.
- getCharEncoding() - Method in class org.aredis.cache.StringHandler
-
- getCleanupAgeDays() - Method in class org.aredis.io.ClassDescriptorStorage
-
Getter for cleanupAgeDays.
- getClient(String, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsyncRedisClient from a connection string containing one or more redis servers.
- getClient(String) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsyncRedisClient from a connection string containing one or more redis servers.
- getCommand() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the command
- getCommandRun() - Method in class org.aredis.cache.RedisCommandInfo
-
Returns the actual command that was attempted to run.
- getCompressionInfo() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Returns the current compression info as a String.
- getCompressionThreshold() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Gets the compression threshold.
- getCompressionThreshold() - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- getConfig() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getConfig() - Method in interface org.aredis.net.AsyncSocketTransport
-
Gets the AsyncSocketTransport config in use.
- getConfig() - Method in class org.aredis.net.AsyncSocketTransportFactory
-
Gets Config in use.
- getConnection() - Method in class org.aredis.cache.AsyncRedisConnection
-
Returns the Async Socket Transport used
- getConnection(RedisServerInfo, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsycRedisConnection.
- getConnection(RedisServerInfo) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsycRedisConnection.
- getConnection() - Method in class org.aredis.cache.RedisSubscriptionConnection
-
Returns the Async Socket Transport used
- getConnectionIndex(String, AsyncRedisConnection[], boolean) - Method in class org.aredis.cache.ConsistentKeyHasher
-
- getConnectionIndex(String, AsyncRedisConnection[], boolean) - Method in class org.aredis.cache.JavaKeyHasher
-
- getConnectionIndex(String, AsyncRedisConnection[], boolean) - Method in interface org.aredis.cache.KeyHasher
-
Returns the connection index for a key
- getConnectionPool(RedisServerInfo, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a connection pool for use in Redis Transactions with WATCH-MULTI-EXEC commands.
- getConnectionPool(RedisServerInfo) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a connection pool for use in Redis Transactions with WATCH-MULTI-EXEC commands.
- getConnectionPool(String, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsyncObjectPool holding AsyncRedisConnection objects for WATCH-MULTI-EXEC redis transactions.
- getConnectionPool(String) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns an AsyncObjectPool holding AsyncRedisConnection objects for WATCH-MULTI-EXEC redis transactions.
- getConnections() - Method in class org.aredis.cache.ShardedAsyncRedisClient
-
Gets List of connections
- getConnectionString() - Method in class org.aredis.cache.RedisServerInfo
-
- getConnectionString() - Method in class org.aredis.cache.RedisServerListInfo
-
- getConnectionString() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getConnectionString() - Method in interface org.aredis.net.ServerInfo
-
Gets the Connection String in the form of host:port so that it does not have to be constructed
each time.
- getCount() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Low level method to get the count of the data in the buffer.
- getCount() - Method in class org.aredis.io.ReusableByteArrayInputStream
-
Gets the current last position of the Stream till which there is data
- getCount() - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Current count of the bytes in the buffer.
- getCountAtSessionStart() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Low level method to get the count at the start of the current compression session.
- getDataHandler() - Method in class org.aredis.cache.AsyncRedisConnection
-
- getDataHandler() - Method in class org.aredis.cache.AsyncRedisFactory
-
Gets the Data Handler used by the factory.
- getDataHandler() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the data handler
- getDataHandler() - Method in class org.aredis.cache.SubscriptionInfo
-
Gets the Data Handler.
- getDbIndex() - Method in class org.aredis.cache.AsyncRedisConnection
-
Returns the DB Index of the connection
- getDbIndex() - Method in class org.aredis.cache.RedisServerInfo
-
- getDebugBuf() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the debug buf in use
- getDefault() - Static method in class org.aredis.net.AsyncSocketTransportFactory
-
Singleton method to return defaultFactory.
- getDescriptor(int) - Method in class org.aredis.io.ClassDescriptors
-
Gets the ObjectStreamClass at the given index.
- getDescriptorsKey() - Method in class org.aredis.cache.PerConnectionRedisClassDescriptorStorageFactory
-
Gets the key in which the Descriptors are stored.
- getDoubleResult(Object, double) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to a double value
- getDoubleResult(double) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to a double value
- getDownSince() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getDownSince() - Method in interface org.aredis.net.AsyncSocketTransport
-
Returns the millisecond time since this connection was down.
- getDownSince() - Method in class org.aredis.net.ConnectionState
-
Milliseconds time when the connection was found to be down.
- getError() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the exception that was encountered
- getExecutor() - Method in class org.aredis.cache.AsyncRedisFactory
-
Gets the configured Executor for this factory or null if none is configured.
- getExecutor() - Method in class org.aredis.cache.SubscriptionInfo
-
Gets the executor.
- getFloatResult(Object, float) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to a float
- getFloatResult(float) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to a float
- getHost() - Method in class org.aredis.cache.RedisServerInfo
-
- getHost() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getHost() - Method in interface org.aredis.net.ServerInfo
-
Gets the host.
- getIdleListener() - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Gets the idle listener in use.
- getIndex() - Method in class org.aredis.cache.Script
-
Gets the identifying index of the script.
- getInitBufSize() - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- getInputStream() - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Gets an Input Stream from which one can read the contents of the data written to the stream.
- getInstance(String) - Static method in class org.aredis.cache.Script
-
This static method must be used to create a Script Object.
- getInstance() - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- getInstance(String) - Static method in class org.aredis.net.ConnectionState
-
Gets the connection state for the given server.
- getInstance() - Static method in class org.aredis.util.PeriodicTaskPoller
-
Gets the single instance of the poller.
- getIntResult(Object, int) - Static method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to an int
- getIntResult(int) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to an int
- getKeyHasher() - Method in class org.aredis.cache.ShardedAsyncRedisClient
-
Gets the Keyhasher being used
- getLastBorrowTime() - Method in class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
Gets the last borrow time irrespective of whether it is currently in use or not
- getLastDownTime() - Method in class org.aredis.net.ConnectionState
-
Milliseconds time when the connection was found to be down.
- getLastException() - Method in class org.aredis.net.ConnectionState
-
The last exception for which updateStatus call.
- getLeakLogIntervalMillis() - Method in class org.aredis.util.pool.LeakCheckingAsyncObjectPool
-
Gets the leak log interval.
- getListener() - Method in class org.aredis.cache.SubscriptionInfo
-
Gets the listener.
- getLongResult(Object, long) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to a long
- getLongResult(long) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to a long
- getMasterClassDescriptors(boolean) - Method in class org.aredis.cache.RedisClassDescriptorStorage
-
- getMasterClassDescriptors(boolean) - Method in class org.aredis.io.ClassDescriptorStorage
-
Gets the class descriptors from the store.
- getMaxHoldTimeMillis() - Method in class org.aredis.util.pool.LeakCheckingAsyncObjectPool
-
Gets max hold time.
- getMaxIdleTimeMillis() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- getMaxMemoryLimitKb() - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- getMaxPipelineSize() - Method in class org.aredis.cache.AsyncRedisConnection
-
Max Pipeline Size
- getMbResultTypes() - Method in class org.aredis.cache.RedisCommandInfo
-
In case the ResultType returned by getResultType is MULTIBULK this method returns the ResultTypes in
the response.
- getMbResultTypes() - Method in class org.aredis.cache.ResultTypeInfo
-
Gets Individual Result Types in case Result Type is MULTIBULK.
- getMember() - Method in class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
Gets the member.
- getMetaData() - Method in class org.aredis.cache.SubscriptionInfo
-
Gets the meta data.
- getNumCompetedTasks() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Returns the number of tasks that have been completed so far by this LimitingTaskExecutor
which is a continously increasing value.
- getNumRunningTasks() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Returns the number of outstanding tasks submitted to the underlying executorService.
- getObjectCompressionThreshold() - Method in class org.aredis.cache.JavaHandler
-
Gets the Object Compression Threshold.
- getParams() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the command parameters
- getPool() - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- getPoolSize() - Method in class org.aredis.cache.AsyncRedisFactory
-
Gets the pool size used when creating a connection pool
- getPoolSize() - Method in class org.aredis.util.pool.AsyncObjectPool
-
Get the current pool size.
- getPort() - Method in class org.aredis.cache.RedisServerInfo
-
- getPort() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getPort() - Method in interface org.aredis.net.ServerInfo
-
Gets the port.
- getPos() - Method in class org.aredis.io.ReusableByteArrayInputStream
-
Gets the current position (offset) of the Stream.
- getPrintStream(String) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Gets a printStream that writes to this Stream corresponding to a given Charset.
- getReadBufSize() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- getReadTimeoutMillis() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- getRedisConnectionString() - Method in class org.aredis.cache.RedisServerInfo
-
- getRemovalStatus() - Method in class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
Returns the removal status in case the pool size is reduced using setPoolSize.
- getRepeatableFromIndex() - Method in enum org.aredis.cache.RedisCommand
-
Gets the repeatable from index int argTypes from which the argTypes are repeated or -1 if there is a fixed list of arguments.
- getResponse() - Method in class org.aredis.cache.RedisResponseReader
-
Gets the response which is saved after it is read and parsed.
- getResult() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the result.
- getResult() - Method in class org.aredis.cache.RedisRawResponse
-
Gets the result.
- getResult() - Method in class org.aredis.util.concurrent.CallableResult
-
- getResultType() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the Type of the Result.
- getResultType() - Method in class org.aredis.cache.RedisRawResponse
-
Gets the Result Type.
- getResultType() - Method in class org.aredis.cache.ResultTypeInfo
-
Gets Result Type.
- getRetryInterval() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getRetryInterval() - Method in interface org.aredis.net.AsyncSocketTransport
-
The current retry interval as per the exponential fall back calculation.
- getRetryInterval() - Method in class org.aredis.net.ConnectionState
-
Current Retry Interval when retrying broken connections.
- getRunStatus() - Method in class org.aredis.cache.RedisCommandInfo
-
Gets the Run Status to indicate whether the command ran successfully or if there was an error.
- getScript() - Method in class org.aredis.cache.Script
-
Gets the script.
- getServerIndex() - Method in class org.aredis.cache.RedisServerInfo
-
- getServerIndex() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getServerIndex() - Method in interface org.aredis.net.ServerInfo
-
Gets an index identifying the server.
- getServerList() - Method in class org.aredis.cache.RedisServerListInfo
-
- getSha1sum() - Method in class org.aredis.cache.Script
-
Gets the SHA-1 digest of the script.
- getShortResult(Object, short) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts any result Object to a short value
- getShortResult(short) - Method in class org.aredis.cache.RedisCommandInfo
-
Converts the result to a short value
- getSpecVersion() - Method in class org.aredis.io.ClassDescriptorsInfo
-
Gets the Spec Version Number.
- getStatus() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- getStatus() - Method in interface org.aredis.net.AsyncSocketTransport
-
Returns the Connection Status
- getStorage(ServerInfo) - Method in interface org.aredis.cache.ClassDescriptorStorageFactory
-
Gets the store to use.
- getStorage(ServerInfo) - Method in class org.aredis.cache.PerConnectionRedisClassDescriptorStorageFactory
-
Gets the storage to use for the passed server.
- getStorage(ServerInfo) - Method in class org.aredis.cache.RedisClassDescriptorStorageFactory
-
Returns the storage.
- getStringCompressionThreshold() - Method in class org.aredis.cache.JavaHandler
-
Gets the String Compression Threshold, -2 indicates that the AsyncRedisConnection's
compressionThreshold is to be used.
- getSubscription(RedisServerInfo, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a RedisSubscription object for subscribing to messages and message patterns on the given Redis Server.
- getSubscription(RedisServerInfo) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a RedisSubscription object for subscribing to messages and message patterns on the given Redis Server.
- getSubscription(String, Executor) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a RedisSubscription object for subscribing to messages and message patterns on the given Redis Server.
- getSubscription(String) - Method in class org.aredis.cache.AsyncRedisFactory
-
Returns a RedisSubscription object for subscribing to messages and message patterns on the given Redis Server.
- getSubscriptionTransportFactory() - Method in class org.aredis.cache.AsyncRedisFactory
-
Gets the Transport Factory used for RedisSuubscription service or null if none is set.
- getTaskLimit() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Returns the Task Limit which specifies the max no.
- getTimer() - Static method in class org.aredis.cache.AsyncRedisFactory
-
Gets the static instance of RedisTimer in use for periodic tasks re-connects, Leak Checks etc.
- getTransport(String, int) - Method in class org.aredis.net.AsyncSocketTransportFactory
-
Creates an AsyncSocketTransport to a redis server by using resolved transportConstructor.
- getTransportFactory() - Method in class org.aredis.cache.AsyncRedisFactory
-
Gets the default Transport Factory which is also used for AsyncRedisConnections.
- getTransportFactory() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
Returns the transportFactory for this connection.
- getUpdatedDescriptors() - Method in class org.aredis.io.OptiObjectOutputStream
-
Gets the updated descriptors.
- getUseableConnections(AsyncRedisConnection[], boolean[]) - Static method in class org.aredis.cache.ShardedAsyncRedisClient
-
Untility Method for use by KeyHashers to return the useable connections.
- getUseTimeUpdateInterval() - Method in class org.aredis.io.ClassDescriptorStorage
-
Getter for useTimeUpdateInterval.
- getVersionNo() - Method in class org.aredis.io.ClassDescriptorsInfo
-
Gets current version no.
- getWaitingTaskQueue() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Returns the queue used to enqueue tasks for later processing.
- getWriteBufSize() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- getWriteTimeoutMillis() - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- GZIP_HEADER - Static variable in class org.aredis.cache.JavaHandler
-
- INIT_RETRY_INTERVAL - Static variable in class org.aredis.net.ConnectionState
-
The starting Retry interval in milliseconds
- INSTANCE - Static variable in class org.aredis.net.ServerInfoComparator
-
Single instance of the ServerInfoComparator.
- instance - Static variable in class org.aredis.util.concurrent.EmptyRunnable
-
The instance of EmptyRunnable to use
- isAbandonCompressionEnabled() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Checks if abandon compression is enabled.
- isBlocking() - Method in enum org.aredis.cache.RedisCommand
-
Identifies blocking commands like BLPOP
- isCompressed() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Checks if compression is currently in effect.
- isCompressionEnabled() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Checks if compression is enabled.
- isError() - Method in class org.aredis.cache.RedisRawResponse
-
Returns if there was an error when reading the response.
- isInUse() - Method in class org.aredis.util.pool.AsyncObjectPool.PoolMemberHolder
-
Checks if pool member is currently in used (Borrowed)
- isOptimizeObjectStorage() - Method in class org.aredis.cache.JavaHandler
-
Checks if ptimizeObjectStorage (OPTI_JAVA_HANDLER) is enabled
- isPatternSubscription() - Method in class org.aredis.cache.SubscriptionInfo
-
Checks if this is a pattern subscription.
- isScriptCommand() - Method in enum org.aredis.cache.RedisCommand
-
Identifies if the command is one of the SCRIPT commands, EVAL, EVALSHA, EVALCHECK or SCRIPT.
- isSerializeNumbers() - Method in class org.aredis.cache.JavaHandler
-
Checks if
Number
s are to be Serialized as Java Objects.
- isShutdown() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Return true if shutdown has been called on this LimitingTaskExecutor or the underlying
executorService is shutdown.
- isStale() - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- isStale() - Method in interface org.aredis.net.AsyncSocketTransport
-
Checks if the connection is stale as per configured idle timeout.
- isStateful() - Method in enum org.aredis.cache.RedisCommand
-
Identifies if the command is stateful i.e the command has an effect on subsequent commands run on the same connections.
- isSyncToStorage() - Method in class org.aredis.io.OptiObjectOutputStream
-
Checks whether syncToStorage is enabled.
- isTerminated() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Checks if this LimitingTaskExecutor is terminated after a shutdown call or a shutdown
of the underlying executorService.
- isUseKeyHandlerAsDefaultDataHandler() - Method in enum org.aredis.cache.RedisCommand
-
Gets if Key Handler is to be used as the default data handler for this command.
- isWritable() - Method in class org.aredis.io.ClassDescriptors
-
Returns if this ClassDescriptors is writable.
- read(OutputStream, int, AsyncHandler<Integer>) - Method in class org.aredis.net.AsyncJavaSocketTransport
-
- read(OutputStream, int, AsyncHandler<Integer>) - Method in interface org.aredis.net.AsyncSocketTransport
-
Reads atleast 1 byte and a max of upto maxBytes writing bytes read to specified
Stream.
- readBufSize - Variable in class org.aredis.net.AsyncSocketTransportConfig
-
Read Buffer Size.
- readClassDescriptor() - Method in class org.aredis.io.OptiObjectInputStream
-
- readResponse(AsyncHandler<RedisRawResponse>) - Method in class org.aredis.cache.RedisResponseReader
-
Reads the response from the Redis Server.
- readTimeoutMillis - Variable in class org.aredis.net.AsyncSocketTransportConfig
-
Read Timeout in milliseconds.
- receive(SubscriptionInfo, String, Object) - Method in interface org.aredis.cache.RedisMessageListener
-
Called when a message is received.
- reconcileCount - Variable in class org.aredis.util.pool.AsyncObjectPool
-
This is only intended for debugging purposes to measure how many times the
relatively expensive call to ensureEmptyWaitersOrMembers is made.
- RedisClassDescriptorStorage - Class in org.aredis.cache
-
Implementation of ClassDescriptorStorage used by aredis that stores the ClassDescriptors on a redis server.
- RedisClassDescriptorStorage(AsyncRedisConnection, String, int) - Constructor for class org.aredis.cache.RedisClassDescriptorStorage
-
Creates a storage for the given Redis Connection and descriptors key.
- RedisClassDescriptorStorage(AsyncRedisConnection) - Constructor for class org.aredis.cache.RedisClassDescriptorStorage
-
Creates a storage for the given Redis Connection with the defalt key "JAVA_CL_DESCRIPTORS".
- RedisClassDescriptorStorageFactory - Class in org.aredis.cache
-
- RedisClassDescriptorStorageFactory(RedisServerInfo, String, AsyncSocketTransportFactory) - Constructor for class org.aredis.cache.RedisClassDescriptorStorageFactory
-
- RedisClassDescriptorStorageFactory(RedisServerInfo) - Constructor for class org.aredis.cache.RedisClassDescriptorStorageFactory
-
- RedisCommand - Enum in org.aredis.cache
-
Enumerates the Redis Commands and also contains information about the command argument types using which the AsyncRedisConnection
determines the arguments to which to used the Data Handler.
- RedisCommandInfo - Class in org.aredis.cache
-
This is a class to Hold a Redis Command with its arguments and also the result once the command is completed.
- RedisCommandInfo(DataHandler, Object, RedisCommand, Object...) - Constructor for class org.aredis.cache.RedisCommandInfo
-
Creates a Redis CommandInfo Object
- RedisCommandInfo(DataHandler, RedisCommand, Object...) - Constructor for class org.aredis.cache.RedisCommandInfo
-
Creates a Redis CommandInfo Object
- RedisCommandInfo(Object, RedisCommand, Object...) - Constructor for class org.aredis.cache.RedisCommandInfo
-
- RedisCommandInfo(RedisCommand, Object...) - Constructor for class org.aredis.cache.RedisCommandInfo
-
- RedisCommandInfo.CommandStatus - Enum in org.aredis.cache
-
Enumerates the CommandStatus which is expected to be SUCCESS on normal execution.
- RedisCommandInfo.ResultType - Enum in org.aredis.cache
-
Enumerates the Result Types of Redis
- RedisConstants - Interface in org.aredis.io
-
Constants related to this package.
- RedisMessageListener - Interface in org.aredis.cache
-
- RedisRawResponse - Class in org.aredis.cache
-
- RedisRawResponse() - Constructor for class org.aredis.cache.RedisRawResponse
-
- RedisResponseReader - Class in org.aredis.cache
-
This is a low level redis response parser that is used by aredis.
- RedisResponseReader(AsyncSocketTransport) - Constructor for class org.aredis.cache.RedisResponseReader
-
Creates a RedisResponseReader.
- RedisServerInfo - Class in org.aredis.cache
-
Identifies a Redis server with its host, port and dbIndex.
- RedisServerInfo(String, int, int) - Constructor for class org.aredis.cache.RedisServerInfo
-
Creates a RedisServerInfo Object.
- RedisServerInfo(String, int) - Constructor for class org.aredis.cache.RedisServerInfo
-
Creates a RedisServerInfo Object with 0 as the DB Index.
- RedisServerInfo(String) - Constructor for class org.aredis.cache.RedisServerInfo
-
Creates a RedisServerInfo Object from a Connection String.
- RedisServerListInfo - Class in org.aredis.cache
-
Identifies a list of Redis servers.
- RedisServerListInfo(RedisServerInfo[]) - Constructor for class org.aredis.cache.RedisServerListInfo
-
Creates a RedisServerListInfo from Individual RedisServerInfo's
- RedisServerListInfo(String) - Constructor for class org.aredis.cache.RedisServerListInfo
-
Creates a RedisServerListInfo from a Connection String containing a comma separated list of RedisServerInfos.
- RedisSubscription - Class in org.aredis.messaging
-
Used to create a subscription connection to a Redis Server after which you can subscribe to channels.
- RedisSubscription(AsyncSocketTransport, int, Executor) - Constructor for class org.aredis.messaging.RedisSubscription
-
Creates a RedisSubscription.
- RedisSubscriptionConnection - Class in org.aredis.cache
-
- RedisSubscriptionConnection(AsyncSocketTransport, int, Executor) - Constructor for class org.aredis.cache.RedisSubscriptionConnection
-
Creates a RedisSubscriptionConnection.
- RedisSubscriptionConnection.CommandType - Enum in org.aredis.cache
-
Different Subscribe Unsubscribe Command Types.
- RedisTimer - Interface in org.aredis.util
-
Timer interface used by redis.
- rejectedExecution(Runnable, LimitingTaskExecutor) - Method in interface org.aredis.util.concurrent.RejectedTaskHandler
-
- RejectedTaskHandler - Interface in org.aredis.util.concurrent
-
- rejectExecution() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor.TaskWrapper
-
Marks the submitted task as rejected so that the LimitingTask executor can take
an appropriate action to queue the task or reject it if the queue is full.
- remove(long, boolean) - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Remove from the tail of the Q.
- removeOldDescriptors(long) - Method in class org.aredis.io.ClassDescriptors
-
Removes old descriptors not used since the passed lastUseTime.
- removeTask(PeriodicTask) - Method in class org.aredis.util.PeriodicTaskPoller
-
Remove a task.
- requiresFlush() - Method in class org.aredis.net.AsyncJavaSocketTransport
-
- requiresFlush() - Method in interface org.aredis.net.AsyncSocketTransport
-
Whether the Socket Output requires a flush to transfer bytes in buffer.
- requiresTimingUpdate(long) - Method in class org.aredis.io.ClassDescriptors
-
Checks whether the use time fetched from store and current use time differs by more than the given
updateInterval for any of the descriptors.
- reset() - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Resets the stream by clearing any existing data.
- reset(int) - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Resets the stream and in addition limits the internal buffer's size to maxBufSize.
- RESOLVED_CLASS_NAME - Static variable in class org.aredis.net.AsyncSocketTransportFactory
-
The resolved Class name created in the static block.
- RESOLVED_TRANSPORT_CONSTRUCTOR - Static variable in class org.aredis.net.AsyncSocketTransportFactory
-
The Resolved Consctructor that is used by getTransport.
- ResultTypeInfo - Class in org.aredis.cache
-
A Holder for Result Type that is used to specify Individual Result Types recursively in case the
Result is of Type MULTIBULK.
- ResultTypeInfo(RedisCommandInfo.ResultType, ResultTypeInfo[]) - Constructor for class org.aredis.cache.ResultTypeInfo
-
Constructor.
- returnStream(CompressibleByteArrayOutputStream) - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- returnToPool(E) - Method in class org.aredis.util.pool.AsyncObjectPool
-
Return a member Object back to the pool
- ReusableByteArrayInputStream - Class in org.aredis.io
-
A ByteArrayInputStream which gives access to the current positions to provide more flexibility.
- ReusableByteArrayInputStream(byte[]) - Constructor for class org.aredis.io.ReusableByteArrayInputStream
-
Creates a ByteArrayInputStream by calling the super class's constructor.
- ReusableByteArrayInputStream(byte[], int, int) - Constructor for class org.aredis.io.ReusableByteArrayInputStream
-
Creates a ByteArrayInputStream by calling the super class's constructor.
- ReusableByteArrayOutputStream - Class in org.aredis.io
-
A GC friendly ByteArrayOutputStream which has a getInputStream method to read the
internal byte array without having to copy the contents.
- ReusableByteArrayOutputStream() - Constructor for class org.aredis.io.ReusableByteArrayOutputStream
-
Creates a ByteArrayOutputStream by calling the super class's constructor.
- ReusableByteArrayOutputStream(int) - Constructor for class org.aredis.io.ReusableByteArrayOutputStream
-
Creates a ByteArrayOutputStream by calling the super class's constructor.
- run() - Method in class org.aredis.util.concurrent.EmptyRunnable
-
- run() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor.TaskWrapper
-
- run() - Method in class org.aredis.util.PeriodicTaskPoller
-
This method is public because it implements runnable.
- RUN_IN_PLACE_POLICY - Static variable in class org.aredis.util.concurrent.LimitingTaskExecutor
-
RejectedTaskHandler which runs the rejected task in place by calling the run method
of the submitted task so that the task runs in the same thread as the caller effectively
slowing down the caller thread.
- schedule(Runnable, long) - Method in class org.aredis.util.DefaultRedisTimer
-
- schedule(Runnable, long) - Method in interface org.aredis.util.RedisTimer
-
Schedule a command to run once after the given delay.
- scheduleWithFixedDelay(Runnable, long, long) - Method in class org.aredis.util.DefaultRedisTimer
-
- scheduleWithFixedDelay(Runnable, long, long) - Method in interface org.aredis.util.RedisTimer
-
Schedule a command to run with a fixed delay.
- Script - Class in org.aredis.cache
-
A simple immutable holder class to hold a Redis Lua Script and its sha1 digest.
- sendCommand(RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- sendCommand(Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- sendCommand(DataHandler, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- sendCommand(DataHandler, Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- sendCommand(RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Send a command without looking for a return value.
- sendCommand(Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Send a command without looking for a return value.
- sendCommand(DataHandler, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Send a command without looking for a return value.
- sendCommand(DataHandler, Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Send a command without looking for a return value.
- serialize(Object, Object, CompressibleByteArrayOutputStream, ServerInfo) - Method in class org.aredis.cache.BinaryHandler
-
The data to serialize must be a byte array.
- serialize(Object, Object, CompressibleByteArrayOutputStream, ServerInfo) - Method in interface org.aredis.cache.DataHandler
-
Serialze value
- serialize(Object, Object, CompressibleByteArrayOutputStream, ServerInfo) - Method in class org.aredis.cache.JavaHandler
-
- serialize(Object, Object, CompressibleByteArrayOutputStream, ServerInfo) - Method in class org.aredis.cache.StringHandler
-
The data to serialize must be a String.
- serializeNumbers - Variable in class org.aredis.cache.JavaHandler
-
Indicates whether to serialize numbers.
- serverIndex - Variable in class org.aredis.net.AbstractAsyncSocketTransport
-
- ServerInfo - Interface in org.aredis.net
-
Identifies a Server.
- ServerInfoComparator - Class in org.aredis.net
-
Compares two ServerInfo Objects by comparing their hosts followed by ports.
- setAbandonCompressionEnabled(boolean) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Sets if abandon compression should be enabled.
- setAbandonCompressionRatio(double) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Sets the abandon compression ratio.
- setAuth(ServerInfo, String) - Static method in class org.aredis.cache.AsyncRedisFactory
-
Sets Password for authentication if the redis server is configured with a password via requirepass
directive in redis.conf.
- setAuth(String, String) - Static method in class org.aredis.cache.AsyncRedisFactory
-
Sets Password for authentication if the redis server is configured with a password via requirepass
directive in redis.conf.
- setBootstrapExecutorPoolSize(int) - Static method in class org.aredis.cache.AsyncRedisConnection
-
Method to change the size of the bootstrapExecutor
- setBuf(byte[], int, int) - Method in class org.aredis.io.ReusableByteArrayInputStream
-
Sets the buffer to use.
- setBuf(byte[]) - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Sets a new buffer and resets the stream.
- setCapacity(int) - Method in class org.aredis.util.concurrent.SynchronizedStack
-
Sets the capacity of the stack to the new value if the current count is not greater than the new capacity.
- setChannelGroup(AsynchronousChannelGroup) - Static method in class org.aredis.net.AsyncJavaSocketTransport
-
Sets a custom channel group.
- setCharEncoding(String) - Method in class org.aredis.cache.JavaHandler
-
Sets the character encoding to use for Serializing Strings.
- setCharEncoding(String) - Method in class org.aredis.cache.StringHandler
-
- setCleanupAgeDays(int) - Method in class org.aredis.io.ClassDescriptorStorage
-
Setter for cleanupAgeDays.
- setCompressionEnabled(boolean) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Sets if compression is enabled.
- setCompressionThreshold(int) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Sets the compression threshold.
- setCompressionThreshold(int) - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- setConfig(AsyncSocketTransportConfig) - Method in class org.aredis.net.AbstractAsyncSocketTransport
-
- setConfig(AsyncSocketTransportConfig) - Method in interface org.aredis.net.AsyncSocketTransport
-
Sets the AsyncSocketTransport config to use.
- setCount(int) - Method in class org.aredis.io.CompressibleByteArrayOutputStream
-
Low level method to set the count in the buffer.
- setCount(int) - Method in class org.aredis.io.ReusableByteArrayOutputStream
-
Sets the count value.
- setDataHandler(DataHandler) - Method in class org.aredis.cache.AsyncRedisConnection
-
- setDataHandler(DataHandler) - Method in class org.aredis.cache.AsyncRedisFactory
-
Sets the Data Handler used by the factory
- setDebugBuf(StringBuffer) - Method in class org.aredis.cache.RedisCommandInfo
-
Sets a StringBuffer for debuging purposes.
- setDescriptorsKey(String) - Method in class org.aredis.cache.PerConnectionRedisClassDescriptorStorageFactory
-
Sets the descriptors key to use.
- setError(boolean) - Method in class org.aredis.cache.RedisRawResponse
-
Sets the error flag to indicate an error while reading the response.
- setIdleListener(SingleConsumerQueue.IdleListener<E>) - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Sets an idle listener which is called whenever the Q status changes from IDLE to ACTIVE or vice-versa.
- setInitBufSize(int) - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- setKeyHasher(KeyHasher) - Method in class org.aredis.cache.ShardedAsyncRedisClient
-
Sets the Keyhasher
- setLeakLogIntervalMillis(long) - Method in class org.aredis.util.pool.LeakCheckingAsyncObjectPool
-
Sets the leak log interval.
- setMaxHoldTimeMillis(long) - Method in class org.aredis.util.pool.LeakCheckingAsyncObjectPool
-
Sets the max hold time.
- setMaxIdleTimeMillis(long) - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- setMaxPipelineSize(int) - Method in class org.aredis.cache.AsyncRedisConnection
-
Sets the max number of commands pending for response in the Redis Server.
- setMemoryLimitKb(int) - Method in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- setObjectCompressionThreshold(int) - Method in class org.aredis.cache.JavaHandler
-
Sets the Object Compression Threshold.
- setPoolSize(int) - Method in class org.aredis.cache.AsyncRedisFactory
-
Sets the pool size to use when creating a connection pool
- setPoolSize(int) - Method in class org.aredis.util.pool.AsyncObjectPool
-
Change the pool size
- setPoolTransportFactory(AsyncSocketTransportFactory) - Method in class org.aredis.cache.AsyncRedisFactory
-
Sets the Transport Factory to use when creating a connection pool.
- setReadBufSize(int) - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- setReadTimeoutMillis(long) - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- setResult(Object) - Method in class org.aredis.cache.RedisRawResponse
-
Sets the result
- setResult(V) - Method in class org.aredis.util.concurrent.CallableResult
-
- setResultType(RedisCommandInfo.ResultType) - Method in class org.aredis.cache.RedisRawResponse
-
Sets the result type.
- setSerializeNumbers(boolean) - Method in class org.aredis.cache.JavaHandler
-
Sets Serialization option for java Numbers.
- setStringCompressionThreshold(int) - Method in class org.aredis.cache.JavaHandler
-
Sets the String Compression Threshold.
- setSubscriptionTransportFactory(AsyncSocketTransportFactory) - Method in class org.aredis.cache.AsyncRedisFactory
-
Sets the Transport Factory to Use for RedisSuubscription service.
- setTaskLimit(int) - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Sets a new value of the task limit which should be between 1 and 1000.
- setTimer(RedisTimer) - Static method in class org.aredis.cache.AsyncRedisFactory
-
Sets the RedisTimer to use.
- setUseTimeUpdateInterval(long) - Method in class org.aredis.io.ClassDescriptorStorage
-
Setter for useTimeUpdateInterval.
- setWriteBufSize(int) - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- setWriteTimeoutMillis(long) - Method in class org.aredis.net.AsyncSocketTransportConfig
-
- ShardedAsyncRedisClient - Class in org.aredis.cache
-
ShardedAsyncRedisClient is an implementation of AsynRedisClient which holds 2 or more
AsyncRedisConnection
Objects and forwards the commands to one of them based on the hash of the key in the command.
- ShardedAsyncRedisClient(List<AsyncRedisConnection>, Executor, KeyHasher) - Constructor for class org.aredis.cache.ShardedAsyncRedisClient
-
- ShardedAsyncRedisClient(List<AsyncRedisConnection>, Executor) - Constructor for class org.aredis.cache.ShardedAsyncRedisClient
-
Constructor which uses ConsistentKeyHasher as default.
- ShardedAsyncRedisClient(List<AsyncRedisConnection>) - Constructor for class org.aredis.cache.ShardedAsyncRedisClient
-
Basic Constructor.
- shutdown(long) - Method in class org.aredis.cache.AsyncRedisConnection
-
Shutdown the connection.
- shutdown() - Method in class org.aredis.cache.RedisSubscriptionConnection
-
Shutdown the connection.
- shutdown() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
Shuts down this LimitingTaskExecutor.
- shutDownHook - Static variable in class org.aredis.cache.AsyncRedisConnection
-
- shutdownNow() - Method in class org.aredis.util.concurrent.LimitingTaskExecutor
-
In addition to shut down the task queue is emptied and returned.
- SimpleThreadFactory - Class in org.aredis.util.concurrent
-
A utility class which cannot be instantiated but which provides two final instances of ThreadFactorys one for
creating daemon threads and one for creating user threads.
- SINGLE_INSTANCE - Static variable in class org.aredis.io.CompressibleByteArrayOutputStreamPool
-
- SingleConsumerQueue<E> - Class in org.aredis.util.concurrent
-
- SingleConsumerQueue(int, long) - Constructor for class org.aredis.util.concurrent.SingleConsumerQueue
-
Creates a Q with the given capacity and maxEnqueTimeMillis to wait for when adding to the Q in case the Q is
full.
- SingleConsumerQueue(int) - Constructor for class org.aredis.util.concurrent.SingleConsumerQueue
-
Creates a Q with the given capacity and default maxEnqueTimeMillis of 5 seconds
- SingleConsumerQueue() - Constructor for class org.aredis.util.concurrent.SingleConsumerQueue
-
Creates a Q with unbounded capacity.
- SingleConsumerQueue.IdleListener<E> - Interface in org.aredis.util.concurrent
-
Callback Interface to get called back when the IDLE status of the Q changes.
- SingleConsumerQueue.QueueStatus - Enum in org.aredis.util.concurrent
-
- size() - Method in class org.aredis.util.ArrayWrappingList
- size() - Method in class org.aredis.util.concurrent.SingleConsumerQueue
-
Gets the size of the Q.
- size() - Method in class org.aredis.util.concurrent.SynchronizedStack
-
- SortedArray<T> - Class in org.aredis.util
-
A utility class to hold a unique instance of comparable objects like ServerInfo or Script in an array.
- SortedArray() - Constructor for class org.aredis.util.SortedArray
-
- SortedArray.IndexUpdater - Interface in org.aredis.util
-
- specVersion - Variable in class org.aredis.io.ClassDescriptorsInfo
-
Spec version.
- StringHandler - Class in org.aredis.cache
-
A Data Handler which stores a String optionally compressing it.
- StringHandler(boolean) - Constructor for class org.aredis.cache.StringHandler
-
- StringHandler() - Constructor for class org.aredis.cache.StringHandler
-
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>, boolean, boolean) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(RedisCommandInfo) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(DataHandler, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(DataHandler, Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(AsyncHandler<RedisCommandInfo>, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(AsyncHandler<RedisCommandInfo>, Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(AsyncHandler<RedisCommandInfo>, DataHandler, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(AsyncHandler<RedisCommandInfo>, DataHandler, Object, RedisCommand, Object...) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>, boolean, boolean) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(RedisCommandInfo) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(DataHandler, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(DataHandler, Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(AsyncHandler<RedisCommandInfo>, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(AsyncHandler<RedisCommandInfo>, Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(AsyncHandler<RedisCommandInfo>, DataHandler, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(AsyncHandler<RedisCommandInfo>, DataHandler, Object, RedisCommand, Object...) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit a Redis Command.
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>, boolean, boolean) - Method in class org.aredis.cache.AsyncRedisConnection
-
- submitCommand(RedisCommandInfo, SubscriptionInfo) - Method in class org.aredis.cache.RedisSubscriptionConnection
-
Submit a Redis Subscribe or Unsubscribe Command.
- submitCommand(RedisCommandInfo, AsyncHandler<RedisCommandInfo>, boolean, boolean) - Method in class org.aredis.cache.ShardedAsyncRedisClient
-
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>, boolean, boolean) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommands(RedisCommandInfo[]) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>) - Method in class org.aredis.cache.AbstractAsyncRedisClient
-
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>, boolean, boolean) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit multiple Redis Commands.
- submitCommands(RedisCommandInfo[]) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit multiple Redis Commands.
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>) - Method in interface org.aredis.cache.AsyncRedisClient
-
Submit multiple Redis Commands.
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>, boolean, boolean) - Method in class org.aredis.cache.AsyncRedisConnection
-
- submitCommands(RedisCommandInfo[], AsyncHandler<RedisCommandInfo[]>, boolean, boolean) - Method in class org.aredis.cache.ShardedAsyncRedisClient
-
- subscribe(SubscriptionInfo) - Method in class org.aredis.messaging.RedisSubscription
-
Subscribe to a channel or to a channel pattern.
- SubscriptionInfo - Class in org.aredis.cache
-
Subscription Info for a Redis Subscription including the Listener.
- SubscriptionInfo(String, RedisMessageListener, boolean, DataHandler, Object, Executor) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- SubscriptionInfo(String, RedisMessageListener, boolean, DataHandler, Executor) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- SubscriptionInfo(String, RedisMessageListener, boolean, DataHandler, Object) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- SubscriptionInfo(String, RedisMessageListener, boolean, DataHandler) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- SubscriptionInfo(String, RedisMessageListener, boolean) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- SubscriptionInfo(String, RedisMessageListener) - Constructor for class org.aredis.cache.SubscriptionInfo
-
Creates a SubscriptionInfo.
- syncBorrow(long) - Method in class org.aredis.util.pool.AsyncObjectPool
-
Synchronously borrow from the pool.
- SynchronizedStack<E> - Class in org.aredis.util.concurrent
-
A simple array based synchronized stack implementing a subset of methods in
BlockingDeque
.
- SynchronizedStack(int) - Constructor for class org.aredis.util.concurrent.SynchronizedStack
-
Creates a Synchronized Stack.
- valueOf(String) - Static method in enum org.aredis.cache.ConnectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.cache.DefaultHashAlgorithm
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.cache.RedisCommand
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.cache.RedisCommandInfo.CommandStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.cache.RedisCommandInfo.ResultType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.cache.RedisSubscriptionConnection.CommandType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.net.ConnectionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.aredis.util.concurrent.SingleConsumerQueue.QueueStatus
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.aredis.cache.ConnectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.cache.DefaultHashAlgorithm
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.cache.RedisCommand
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.cache.RedisCommandInfo.CommandStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.cache.RedisCommandInfo.ResultType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.cache.RedisSubscriptionConnection.CommandType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.net.ConnectionStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.aredis.util.concurrent.SingleConsumerQueue.QueueStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- versionNo - Variable in class org.aredis.io.ClassDescriptorsInfo
-
Current Version Number.