| AbstractColumnList<C> | |
| AbstractColumnListMutation<C> | Abstract implementation of a row mutation |
| AbstractComposite | Parent class of Composite and DynamicComposite. |
| AbstractComposite.Component<T> | |
| AbstractComposite.ComponentEquality | |
| AbstractExecuteWithFailoverImpl<CL, R> | |
| AbstractExecutionImpl<R> | |
| AbstractHostPartitionConnectionPool<CL> | Base for all connection pools that keep a separate pool of connections for each host. |
| AbstractIndexQueryImpl<K, C> | |
| AbstractKeyspaceOperationImpl<R> | |
| AbstractOperationImpl<R> | |
| AbstractRowQueryImpl<K, C> | |
| AbstractRowSliceQueryImpl<K, C> | |
| AbstractSerializer<T> | A base class for serializer implementations. |
| AbstractThriftAllRowsQueryImpl<K, C> | |
| AbstractThriftColumnMutationImpl | |
| AbstractThriftMutationBatchImpl | Basic implementation of a mutation batch using the thrift data structures. |
| AckingQueue | Abstraction for a durable queue requiring an ack to do the final remove |
| AllRowsQuery<K, C> | Specialized query to iterate the contents of a column family. |
| AnnotatedCompositeSerializer<T> | Serializer for a Pojo annotated with Component field annotations Serialized data is formatted as a list of components with each component having the format: <2 byte length><0> |
| AnnotatedCompositeSerializer.ComponentSerializer<P> | Serializer for a single component within the Pojo |
| AnnotationSet<ID extends Annotation, COLUMN extends Annotation> | Allows for any annotations to be used to mark columns in a bean |
| AsciiSerializer | Almost identical to StringSerializer except we use the US-ASCII character set code |
| AstyanaxConfiguration | Interface defining all astyanax API configuration parameters. |
| AstyanaxConfigurationImpl | |
| AstyanaxContext<Entity> | This object tracks the context of an astyanax instance of either a Cluster or Keyspace |
| AstyanaxContext.Builder | |
| AstyanaxTypeFactory<T> | Factory that groups a family of Keyspace, Client and ConnectionFactory for a specific RPC to cassandra (i.e. |
| AuthenticationCredentials | Representation for a user/password used to log into a keyspace. |
| AuthenticationException | |
| AutoAllocatingLinkedBlockingQueue<T> |
| BadConfigurationException | |
| BadHostDetector | Interface for algorithm to detect when a host is considered down. |
| BadHostDetector.Instance | |
| BadHostDetectorImpl | BadHostDetector which marks the host as failed if there is a transport exception or if it timed out too many times within a certain time window |
| BadRequestException | |
| BagConnectionPoolImplTest | |
| BagOfConnectionsConnectionPoolImpl<CL> | Connection pool which puts all connections in a single queue. |
| BaseConnectionPoolTest | |
| BigIntegerSerializer | Serializer implementation for BigInteger |
| BlockingAckingQueue | |
| BlockingConcurrentWindowCounter | |
| BooleanSerializer | Converts bytes to Boolean and vice versa |
| BoundedExponentialBackoff | Bounded exponential backoff that will wait for no more than a provided max amount of time. |
| BusyLockException | |
| ByteBufferOutputStream | Utility to collect data written to an OutputStream in ByteBuffers. |
| ByteBufferRange | Interface to get a raw byte buffer range. |
| ByteBufferRangeImpl | |
| ByteBufferSerializer | The BytesExtractor is a simple identity function. |
| BytesArraySerializer | A BytesArraySerializer translates the byte[] to and from ByteBuffer. |
| Callback<T> | |
| CassandraChunkedStorageProvider | ChunkProvider responsible for reading and writing chunks to cassandra. |
| CassandraChunkedStorageProvider.Columns | |
| CassandraOperationTracer | Notification interface of success or failures executing keyspace operations. |
| CassandraOperationType | |
| CharSerializer | Uses Char Serializer |
| ChunkedStorage | |
| ChunkedStorageProvider | |
| Clock | Interface for a clock used for setting the column timestamp |
| ClockType | |
| Cluster | Interface for cluster operations. |
| Column | |
| Column<C> | Common interface for extracting column values after a query. |
| ColumnarRecordWriter | Writer rows where the first pair is the key and subsequent pairs are columns. |
| ColumnCountQuery | |
| ColumnDefinition | Interface to get/set a single column definition. |
| ColumnFamily<K, C> | Basic column family definition. |
| ColumnFamilyDefinition | |
| ColumnFamilyQuery<K, C> | Top level column family query lets you choose the type of query being performed at the key level. |
| ColumnList<C> | Interface to a list of columns. |
| ColumnListMutation<C> | Abstraction for batching column operations on a single row. |
| ColumnMap<C> | |
| ColumnMutation | |
| ColumnPath<C> | This class is deprecated. Super columns should be replaced with composite columns |
| ColumnPrefixDistributedRowLock<K> | Takes a distributed row lock for a single row. |
| ColumnPrefixUniquenessConstraint<K> | Perform a uniqueness constraint using the locking recipe. |
| ColumnQuery<C> | Interface to execute a column query on a single row. |
| ColumnSlice<C> | Definition for a sub set of slices. |
| ColumnType | This enum is deprecated. Super columns should be replaced with composite columns |
| ComparatorType | |
| Component | Annotation for components of a composite type. |
| Composite | |
| CompositeBuilder | |
| CompositeBuilderImpl | |
| CompositeParser | |
| CompositeParserImpl | |
| CompositeRangeBuilder | |
| Composites | |
| CompositeSerializer | |
| Connection<CL> | Interface to an instance of a connection on a host. |
| Connection.AsyncOpenCallback<CL> | |
| ConnectionAbortedException | |
| ConnectionException | Connection exception caused by an error in the connection pool or a transport error related to the connection itself. |
| ConnectionFactory<CL> | Factory used to create and open new connections on a host. |
| ConnectionPool<CL> | Base interface for a pool of connections. |
| ConnectionPoolConfiguration | |
| ConnectionPoolConfigurationImpl | |
| ConnectionPoolMBeanManager | |
| ConnectionPoolMonitor | Monitoring interface to receive notification of pool events. |
| ConnectionPoolType | |
| ConsistencyLevel | Consistency Level thin abstraction |
| ConstantBackoff | |
| ConstantClock | |
| ConstantSupplier<T> | |
| CountingConnectionPoolMonitor | |
| CqlQuery<K, C> | Interface for executing a CQL query. |
| CqlResult<K, C> | Interface for a CQL query result. |
| CsvColumnReader | Read a CSV where each row represents a single column rowkey, columname, columnvalue |
| CsvRecordReader | |
| CsvRowsWriter |
| DateSerializer | Converts bytes to Date and vice versa, by first converting the Date to or from a long which represents the specified number of milliseconds since the standard base time known as "the Unix epoch", that is January 1, 1970, 00:00:00 UTC. |
| DedicatedMultiRowUniquenessConstraint<C> | Multi-row uniqueness constraint where all involved column families are dedicated only to uniquness constraint. |
| DefaultAnnotationSet | The default annotation set. |
| DistributedMergeSort | |
| DistributedRowLock | Base interface to acquiring and release a row lock Usage: DistributedRowLock lock = new SomeLockImplementation(...); try { lock.acquire(); // Do something ... |
| DoubleSerializer | Uses LongSerializer via translating Doubles to and from raw long bytes form. |
| DynamicComposite | |
| DynamicCompositeSerializer | |
| DynamicCompositeTest |
| EmbeddedCassandra | |
| EmptyBadHostDetectorImpl | |
| EmptyColumn<C> | |
| EmptyColumnList<C> | |
| EmptyConnectionPoolMonitor | |
| EmptyIterator | |
| EmptyKeyspaceTracer | |
| EmptyKeyspaceTracerFactory | |
| EmptyLatencyScoreStrategyImpl | |
| EmptyNodeDiscoveryImpl | |
| EmptyRowsImpl<K, C> | |
| Equality | |
| ExceptionCallback | ExceptionCallback is used in situation where it is not possible to return a checked exception, such as when implementing a custom iterator. |
| ExecuteWithFailover<CL, R> | |
| ExecuteWithRetryTest | |
| ExecuteWithRetryTest.ExecuteWithRetry<T> | |
| Execution<R> | Interface for an operation that can be executed on the cluster. |
| ExponentialBackoff | Unbounded exponential backoff will sleep a random number of intervals within an exponentially increasing number of intervals. |
| ExponentialRetryBackoffStrategy |
| FakeKeyspaceBean | |
| FilteringHostSupplier | Node discovery supplier that only return suppliers that come from both sources |
| FixedRetryBackoffStrategy | |
| FloatSerializer | Uses IntSerializer via translating Float objects to and from raw long bytes form. |
| Host | |
| HostConnectionPool<CL> | Pool of connections for a single host |
| HostConnectionPoolPartition<CL> | |
| HostConnectionPoolPartitionTest | |
| HostDownException | No more connections may be opened on a host and no timeout was specified. |
| HostStats |
| Id | |
| IndexColumnExpression<K, C> | |
| IndexOperationExpression<K, C> | |
| IndexOperator | |
| IndexQuery<K, C> | |
| IndexValueExpression<K, C> | |
| IntegerSerializer | Converts bytes to Integer and vice versa |
| IsDeadConnectionException | Describes an exception after which a connection is no longer usable. |
| IsRetryableException | Defines that an exception is retryable for the context of a single execute with failover. |
| IsTimeoutException |
| JaxbSerializer | Serializes Objects using Jaxb. |
| JmxConnectionPoolMonitor | MBean monitoring for a connection pool |
| JmxConnectionPoolMonitorMBean | |
| JsonRowsWriter | |
| JsonRowsWriter.ErrorHandler |
| KeySlice<K> | Definition of a set of keys. |
| Keyspace | Interface providing access to mutate and query columns from a cassandra keyspace. |
| KeyspaceDefinition | |
| KeyspaceTracerFactory | TODO: Rename to AstyanaxTracerFactory |
| LatencyScoreStrategy | |
| LatencyScoreStrategy.Instance | Single instance of this strategy associated with an endpoint |
| LatencyScoreStrategy.Listener | |
| LatencyScoreStrategyType | |
| LongSerializer | Converts bytes to Long and vise a versa |
| Mapping<T> | Utility for doing object/relational mapping between bean-like instances and Cassandra The mapper stores values in Cassandra and maps in/out to native types. |
| MappingCache | Utility to cache mappers. |
| MappingUtil | Higher level mapping functions. |
| MaxConnsPerHostReachedException | No more connections may be opened on a host and no timeout was specified. |
| MicrosecondsAsyncClock | |
| MicrosecondsClock | |
| MicrosecondsSyncClock | Clock which uses a rolling counter to avoid duplicates. |
| MillisecondsClock | |
| MockCompositeType | |
| MultiRowUniquenessConstraint | Check uniqueness for multiple rows. |
| MutationBatch | Batch mutator which operates at the row level assuming the hierarchy: RowKey -> ColumnFamily -> Mutation. |
| MutationBatchExecutorWithQueue |
| NoAvailableHostsException | |
| NodeDiscovery | Interface for a module that periodically updates the nodes in a connection pool. |
| NodeDiscoveryImpl | Re-discover the ring on a fixed interval to identify new nodes or changes to the ring tokens. |
| NodeDiscoveryMonitor | |
| NodeDiscoveryMonitorManager | |
| NodeDiscoveryMonitorMBean | |
| NodeDiscoveryType | |
| NoOpObjectReadCallback | |
| NoOpObjectWriteCallback | |
| NoOpWriteAheadLog | |
| NotFoundException | |
| NotUniqueException |
| ObjectDeleter | |
| ObjectDirectoryLister | |
| ObjectInfoReader | |
| ObjectMetadata | |
| ObjectReadCallback | |
| ObjectReader | |
| ObjectSerializer | The ObjectSerializer is used to turn objects into their binary representations. |
| ObjectWriteCallback | |
| ObjectWriter | |
| Operation<CL, R> | Callback interface to perform an operation on a client associated with a connection pool's connection resource |
| OperationException | Application exception for an operation executed within the context of the connection pool. |
| OperationResult<R> | |
| OperationResultImpl<R> | |
| OperationTimeoutException | |
| OrderedColumnMap<C> |
| RangeBuilder | Utility builder to construct a ByteBufferRange to be used in a slice query. |
| RangeEndpoint | |
| RateLimiter | Very very simple interface for a rate limiter. |
| RateLimiterTest | |
| RecordReader | |
| RecordWriter | |
| RetryBackoffStrategy | Strategy used to calculate how much to back off for each subsequent attempt to reconnect to a downed host |
| RetryBackoffStrategy.Callback | |
| RetryBackoffStrategy.Instance | |
| RetryNTimes | |
| RetryPolicy | Interface for any retry logic |
| ReverseIndexQuery<K, C, V> | Performs a search on a reverse index and fetches all the matching rows
CFData:K C=V1 C=V2
CFIndex: V1:K
Data and Index column familyThe CFData column family has key of type K and fields or columns of type C. |
| ReverseIndexQuery.IndexEntryCallback<K, V> | |
| ReverseIndexQuery.Task | |
| ReverseIndexQueryTest | |
| RingDescribeHostSupplier | |
| RingDescribeHostSupplierTest | User: mkoch Date: 5/23/12 |
| RingDescribeNodeAutoDiscoveryImplTest | |
| RoundRobinConnectionPoolImpl<CL> | Connection pool implementation using simple round robin. |
| RoundRobinConnectionPoolImplTest | |
| RoundRobinExecuteWithFailover<CL, R> | |
| Row<K, C> | Instance of a row with key type K and column name type C. |
| RowCallback<K, C> | |
| RowCopier<K, C> | |
| RowQuery<K, C> | Interface to narrow down the path and column slices within a query after the keys were seleted using the ColumnFamilyQuery. |
| Rows<K, C> | Interface to a collection or Rows with key type K and column type C. |
| RowSliceQuery<K, C> | Interface to narrow down the path and column slices within a query after the keys were seleted using the ColumnFamilyQuery. |
| RowsWriter | |
| RowUniquenessConstraint<K, C> | Test uniqueness for a single row. |
| RunOnce |
| SchemaDisagreementException | |
| SerializationException | |
| Serializer<T> | Serializes a type T from the given bytes, or vice a versa. |
| SerializerPackage | Grouping of serializers for a single column family. |
| SerializerPackageImpl | Basic implementation of SerializerPackage which can be configured either from a ColumnFamilyDefinition or by manually setting either the ComparatorType or Serializer for keys, columns and values. |
| SerializerPackageImplTest | |
| SerializersTest | |
| SerializerTypeInferer | Utility class that infers the concrete Serializer needed to turn a value into its binary representation |
| SessionEvent | |
| Shards | |
| Shards.Builder | |
| Shards.StringShardBuilder | |
| ShortSerializer | Serializer for Shorts (no pun intended). |
| SimpleAuthenticationCredentials | |
| SimpleHostConnectionPool<CL> | Pool of connections for a single host. |
| SimpleHostConnectionPool.Listener<CL> | Interface to notify the owning connection pool of up/down state changes. |
| SimpleHostConnectionPoolTest | |
| SimpleHostConnectionPoolTest.NoOpListener | |
| SimpleRateLimiterImpl | |
| SleepingRetryPolicy | Base sleeping retry policy with optional count limit. |
| Slf4jConnectionPoolMonitorImpl | |
| SmaLatencyScoreStrategyImpl | |
| SmaLatencyScoreStrategyInstanceImpl | |
| SpecificCompositeSerializer | |
| StaleLockException | |
| Stress | |
| StressSimpleHostConnectionPoolImpl | |
| StressSimpleHostConnectionPoolImpl.NoOpListener | |
| StringSerializer | A StringSerializer translates the byte[] to and from string using utf-8 encoding. |
| StringUtils |
| UniquenessConstraint<K, C> | |
| UniquenessConstraint | |
| UniquenessConstraintTest | |
| UniquenessConstraintViolationMonitor<K, C> | |
| UniquenessConstraintWithPrefix<K> | |
| UnknownComparatorException | |
| UnknownException | |
| UUIDSerializer | A UUIDSerializer translates the byte[] to and from UUID types. |
| UUIDStringSupplier |
| WalException | |
| WriteAheadEntry | |
| WriteAheadLog | Base interface for a write ahead log. |
| WriteAheadMutationBatchExecutor |