Interface | Description |
---|---|
Clusterable<T> |
Common class for objects that are identified by a clustering prefix, and can be thus sorted by a
ClusteringComparator . |
Clustering<V> | |
ClusteringBound<V> |
The start or end of a range of clusterings, either inclusive or exclusive.
|
ClusteringBoundary<V> |
The threshold between two different ranges, i.e.
|
ClusteringBoundOrBoundary<V> |
This class defines a threshold between ranges of clusterings.
|
ClusteringPrefix<V> |
A clustering prefix is the unit of what a
ClusteringComparator can compare. |
ColumnFamilyStoreMBean |
The MBean interface for ColumnFamilyStore
|
DeletionInfo |
A combination of a top-level (partition) tombstone and range tombstones describing the deletions
within a partition.
|
DeletionPurger | |
DisallowedDirectoriesMBean | |
IMutation | |
KeyspaceWriteHandler | |
Mutation.SimpleBuilder |
Interface for building mutations geared towards human.
|
PartitionPosition | |
PartitionRangeReadQuery |
A
ReadQuery for a range of partitions. |
ReadQuery |
Generic abstraction for read queries.
|
RowIndexEntry.IndexInfoRetriever |
Base class to access
IndexInfo objects. |
RowIndexEntry.IndexSerializer<T> | |
SinglePartitionReadQuery |
A
ReadQuery for a single partition. |
Slices.InOrderTester |
In simple object that allows to test the inclusion of rows in those slices assuming those rows
are passed (to
Slices.InOrderTester.includes(org.apache.cassandra.db.Clustering<?>) ) in clustering order (or reverse clustering ordered, depending
of the argument passed to Slices.inOrderTester(boolean) ). |
StorageHook | |
SystemKeyspace.TriFunction<A,B,C,D> | |
TableWriteHandler | |
WriteContext |
Issued by the keyspace write handler and used in the write path (as expected), as well as the read path
and some async index building code.
|
Class | Description |
---|---|
AbstractArrayClusteringPrefix | |
AbstractBufferClusteringPrefix | |
AbstractCompactionController |
AbstractCompactionController allows custom implementations of the CompactionController for use in tooling, without being tied to the SSTableReader and local filesystem
|
AbstractOnHeapClusteringPrefix<V> | |
AbstractReadCommandBuilder | |
AbstractReadCommandBuilder.PartitionRangeBuilder | |
AbstractReadCommandBuilder.SinglePartitionBuilder | |
ArrayClustering | |
ArrayClusteringBound | |
ArrayClusteringBoundary | |
ArrayClusteringBoundOrBoundary | |
BufferClustering |
The clustering column values for a row.
|
BufferClusteringBound | |
BufferClusteringBoundary | |
BufferClusteringBoundOrBoundary | |
BufferDecoratedKey | |
CachedHashDecoratedKey | |
CassandraKeyspaceWriteHandler | |
CassandraTableWriteHandler | |
CassandraWriteContext | |
CBuilder |
Allows to build ClusteringPrefixes, either Clustering or ClusteringBound.
|
ClockAndCount | |
Clustering.Serializer |
Serializer for Clustering object.
|
ClusteringBoundOrBoundary.Serializer | |
ClusteringComparator |
A comparator of clustering prefixes (or more generally of
Clusterable }. |
ClusteringPrefix.Deserializer |
Helper class that makes the deserialization of clustering prefixes faster.
|
ClusteringPrefix.Serializer | |
ColumnFamilyStore | |
ColumnFamilyStore.RefViewFragment | |
ColumnFamilyStore.ViewFragment | |
ColumnIndex |
Column index builder used by
BigTableWriter . |
Columns |
An immutable and sorted list of (non-PK) columns for a given table.
|
Columns.Serializer | |
CounterMutation | |
CounterMutation.CounterMutationSerializer | |
CounterMutationVerbHandler | |
DataRange |
Groups both the range of partitions to query, and the clustering index filter to
apply for each partition (for a (partition) range query).
|
DataRange.Paging |
Specialized
DataRange used for the paging case. |
DataRange.Serializer | |
DecoratedKey |
Represents a decorated key, handy for certain operations
where just working with strings gets slow.
|
DeletionTime |
Information on deletion of a storage engine object.
|
DeletionTime.Serializer | |
Digest | |
Directories |
Encapsulate handling of paths to the data files.
|
Directories.DataDirectories |
Data directories used to store keyspace data.
|
Directories.DataDirectory | |
Directories.SnapshotSizeDetails | |
Directories.SSTableLister | |
DisallowedDirectories | |
DiskBoundaries | |
DiskBoundaryManager | |
EmptyIterators | |
ExpirationDateOverflowHandling | |
Keyspace |
It represents a Keyspace.
|
LivenessInfo |
Stores the information relating to the liveness of the primary key columns of a row.
|
Memtable | |
Memtable.LastCommitLogPosition | |
Memtable.MemtableUnfilteredPartitionIterator | |
MultiCBuilder |
Builder that allow to build multiple Clustering/ClusteringBound at the same time.
|
MutableDeletionInfo |
A mutable implementation of
DeletionInfo . |
MutableDeletionInfo.Builder |
Builds DeletionInfo object from (in order) range tombstone markers.
|
Mutation | |
Mutation.MutationSerializer | |
Mutation.PartitionUpdateCollector |
Collects finalized partition updates
|
MutationVerbHandler | |
NativeClustering | |
NativeDecoratedKey | |
PartitionPosition.ForKey | |
PartitionPosition.RowPositionSerializer | |
PartitionRangeReadCommand |
A read command that selects a (part of a) range of partitions.
|
PreHashedDecoratedKey | |
RangeTombstone |
A range tombstone is a tombstone that covers a slice/range of rows.
|
RangeTombstoneList |
Data structure holding the range tombstones of a ColumnFamily.
|
ReadCommand |
General interface for storage-engine read commands (common to both range and
single partition commands).
|
ReadCommand.SelectionDeserializer | |
ReadCommand.Serializer | |
ReadCommandVerbHandler | |
ReadExecutionController | |
ReadRepairVerbHandler | |
ReadResponse | |
RegularAndStaticColumns |
Columns (or a subset of the columns) that a partition contains.
|
RegularAndStaticColumns.Builder | |
RowIndexEntry<T> |
Binary format of
RowIndexEntry is defined as follows:
{@code
(long) position (64 bit long, vint encoded)
(int) serialized size of data that follows (32 bit int, vint encoded)
-- following for indexed entries only (so serialized size > 0)
(int) DeletionTime.localDeletionTime
(long) DeletionTime.markedForDeletionAt
(int) number of IndexInfo objects (32 bit int, vint encoded)
(*) serialized IndexInfo objects, see below
(*) offsets of serialized IndexInfo objects, since version "ma" (3.0)
Each IndexInfo object's offset is relative to the first IndexInfo object. |
RowIndexEntry.Serializer | |
SchemaCQLHelper |
Helper methods to represent TableMetadata and related objects in CQL format
|
SerializationHeader | |
SerializationHeader.Component |
We need the TableMetadata to properly deserialize a SerializationHeader but it's clunky to pass that to
a SSTable component, so we use this temporary object to delay the actual need for the metadata.
|
SerializationHeader.Serializer | |
SimpleBuilders | |
SimpleBuilders.MutationBuilder | |
SimpleBuilders.PartitionUpdateBuilder | |
SimpleBuilders.RowBuilder | |
SinglePartitionReadCommand |
A read command that selects a (part of a) single partition.
|
SinglePartitionReadCommand.Group |
Groups multiple single partition read commands.
|
SinglePartitionReadQuery.Group<T extends SinglePartitionReadQuery> |
Groups multiple single partition read queries.
|
SizeEstimatesRecorder |
A very simplistic/crude partition count/size estimator.
|
Slice |
A slice represents the selection of a range of rows.
|
Slice.Serializer | |
Slices |
Represents the selection of multiple range of rows within a partition.
|
Slices.Builder |
Builder to create
Slices objects. |
Slices.Serializer | |
SnapshotCommand | |
SnapshotDetailsTabularData | |
SSTableImporter | |
SSTableImporter.Options | |
SystemKeyspace | |
SystemKeyspace.AvailableRanges | |
SystemKeyspaceMigrator40 |
Migrate 3.0 versions of some tables to 4.0.
|
TruncateRequest |
A truncate operation descriptor
|
TruncateResponse |
This message is sent back the truncate operation and basically specifies if
the truncate succeeded.
|
TruncateResponse.TruncateResponseSerializer | |
TruncateVerbHandler | |
TypeSizes | |
UnfilteredDeserializer |
Helper class to deserialize Unfiltered object from disk efficiently.
|
UnfilteredValidation |
Handles unfiltered validation - if configured, it checks if the provided unfiltered has
invalid deletions (if the local deletion time is negative or if the ttl is negative) and
then either logs or throws an exception if so.
|
VirtualTablePartitionRangeReadQuery |
A read query that selects a (part of a) range of partitions of a virtual table.
|
VirtualTableReadQuery |
Base class for the
ReadQuery implementations use to query virtual tables. |
VirtualTableSinglePartitionReadQuery |
A read query that selects a (part of a) single partition of a virtual table.
|
VirtualTableSinglePartitionReadQuery.Group |
Groups multiple single partition read queries.
|
WindowsFailedSnapshotTracker |
Enum | Description |
---|---|
ClusteringPrefix.Kind |
The kind of clustering prefix this actually is.
|
ConsistencyLevel | |
Directories.FileAction | |
Directories.FileType |
The type of files that can be listed by SSTableLister, we never return txn logs,
use LifecycleTransaction.getFiles() if you need txn logs.
|
Directories.OnTxnErr |
How to handle a failure to read a txn log file.
|
ExpirationDateOverflowHandling.ExpirationDateOverflowPolicy | |
PartitionPosition.Kind | |
ReadCommand.Kind | |
SystemKeyspace.BootstrapState | |
WriteType |
Exception | Description |
---|---|
KeyspaceNotDefinedException | |
MutationExceededMaxSizeException |
Copyright © 2009- The Apache Software Foundation