| Constructor and Description | 
|---|
| RowCacheKey(Pair<java.lang.String,java.lang.String> ksAndCFName,
           DecoratedKey key) | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | CFMetaData. decorateKey(java.nio.ByteBuffer key) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Constants.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Adder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Substracter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Constants.Deleter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.SetterByIndex. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Appender. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Prepender. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.Discarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Lists.DiscarderByIndex. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.SetterByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.AdderByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.SubtracterByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.Putter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Maps.DiscarderByKey. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| abstract void | Operation. execute(DecoratedKey partitionKey,
       UpdateParameters params)Execute the operation. | 
| void | Sets.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.Adder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.Discarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | Sets.ElementDiscarder. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.Setter. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.SetterByField. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| void | UserTypes.DeleterByField. execute(DecoratedKey partitionKey,
       UpdateParameters params) | 
| static UntypedResultSet.Row | UntypedResultSet.Row. fromInternalRow(CFMetaData metadata,
               DecoratedKey key,
               Row row) | 
| Row | UpdateParameters. getPrefetchedRow(DecoratedKey key,
                Clustering clustering)Returns the prefetched row with the already performed modifications. | 
| Constructor and Description | 
|---|
| UpdateParameters(CFMetaData metadata,
                PartitionColumns updatedColumns,
                QueryOptions options,
                long timestamp,
                int ttl,
                java.util.Map<DecoratedKey,Partition> prefetchedRows) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | Selection.ResultSetBuilder. newRow(DecoratedKey partitionKey,
      Clustering clustering)Notifies this  Builderthat a new row is being processed. | 
| Modifier and Type | Field and Description | 
|---|---|
| DecoratedKey | CQL3CasRequest. key | 
| Modifier and Type | Method and Description | 
|---|---|
| static java.nio.ByteBuffer[] | SelectStatement. getComponents(CFMetaData cfm,
             DecoratedKey dk) | 
| SinglePartitionReadCommand | SelectStatement. internalReadForView(DecoratedKey key,
                   int nowInSec)Returns a read command that can be used internally to query all the rows queried by this SELECT for a
 give key (used for materialized views). | 
| Constructor and Description | 
|---|
| CQL3CasRequest(CFMetaData cfm,
              DecoratedKey key,
              boolean isBatch,
              PartitionColumns conditionColumns,
              boolean updatesRegularRows,
              boolean updatesStaticRow) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | BufferDecoratedKey | 
| class  | CachedHashDecoratedKey | 
| class  | NativeDecoratedKey | 
| class  | PreHashedDecoratedKey | 
| Modifier and Type | Field and Description | 
|---|---|
| static java.util.Comparator<DecoratedKey> | DecoratedKey. comparator | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | ColumnFamilyStore. decorateKey(java.nio.ByteBuffer key) | 
| DecoratedKey | CounterMutation. key() | 
| DecoratedKey | IMutation. key() | 
| DecoratedKey | Mutation. key() | 
| DecoratedKey | SinglePartitionReadCommand. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| java.lang.Iterable<DecoratedKey> | ColumnFamilyStore. keySamples(Range<Token> range) | 
| Modifier and Type | Method and Description | 
|---|---|
| ClusteringIndexFilter | DataRange. clusteringIndexFilter(DecoratedKey key)The clustering index filter to use for the provided key. | 
| ClusteringIndexFilter | DataRange.Paging. clusteringIndexFilter(DecoratedKey key) | 
| ClusteringIndexFilter | PartitionRangeReadCommand. clusteringIndexFilter(DecoratedKey key) | 
| abstract ClusteringIndexFilter | ReadCommand. clusteringIndexFilter(DecoratedKey key)The clustering index filter this command to use for the provided key. | 
| ClusteringIndexFilter | SinglePartitionReadCommand. clusteringIndexFilter(DecoratedKey key) | 
| boolean | ColumnFamilyStore. containsCachedParition(DecoratedKey key) | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(boolean isForThrift,
      CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(boolean isForThrift,
      CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter,
      IndexMetadata indexMetadata)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      ColumnFilter columnFilter,
      RowFilter rowFilter,
      DataLimits limits,
      DecoratedKey partitionKey,
      ClusteringIndexFilter clusteringIndexFilter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Clustering name)Creates a new single partition name command for the provided row. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      ColumnFilter columnFilter,
      ClusteringIndexFilter filter)Creates a new read command on a single partition. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      java.util.NavigableSet<Clustering> names)Creates a new single partition name command for the provided rows. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Slice slice)Creates a new single partition slice command for the provided single slice. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. create(CFMetaData metadata,
      int nowInSec,
      DecoratedKey key,
      Slices slices)Creates a new single partition slice command for the provided slices. | 
| static SinglePartitionReadCommand | SinglePartitionReadCommand. fullPartitionRead(CFMetaData metadata,
                 int nowInSec,
                 DecoratedKey key)Creates a new read command that queries a single partition in its entirety. | 
| Partition | Memtable. getPartition(DecoratedKey key) | 
| CachedPartition | ColumnFamilyStore. getRawCachedPartition(DecoratedKey key) | 
| void | ColumnFamilyStore. invalidateCachedPartition(DecoratedKey key) | 
| static PaxosState | SystemKeyspace. loadPaxosState(DecoratedKey key,
              CFMetaData metadata,
              int nowInSec) | 
| UnfilteredRowIterator | StorageHook. makeRowIterator(ColumnFamilyStore cfs,
               SSTableReader sstable,
               DecoratedKey key,
               Slices slices,
               ColumnFilter selectedColumns,
               boolean reversed,
               boolean isForThrift,
               SSTableReadsListener listener) | 
| UnfilteredRowIteratorWithLowerBound | StorageHook. makeRowIteratorWithLowerBound(ColumnFamilyStore cfs,
                             DecoratedKey partitionKey,
                             SSTableReader sstable,
                             ClusteringIndexFilter filter,
                             ColumnFilter selectedColumns,
                             boolean isForThrift,
                             int nowInSec,
                             boolean applyThriftTransformation,
                             SSTableReadsListener listener) | 
| static UnfilteredRowIterator | LegacyLayout. onWireCellstoUnfilteredRowIterator(CFMetaData metadata,
                                  DecoratedKey key,
                                  LegacyLayout.LegacyDeletionInfo delInfo,
                                  java.util.Iterator<LegacyLayout.LegacyCell> cells,
                                  boolean reversed,
                                  SerializationHelper helper) | 
| void | StorageHook. reportRead(java.util.UUID cfid,
          DecoratedKey key) | 
| static RowIterator | EmptyIterators. row(CFMetaData metadata,
   DecoratedKey partitionKey,
   boolean isReverseOrder) | 
| boolean | PartitionRangeReadCommand. selectsClustering(DecoratedKey key,
                 Clustering clustering) | 
| boolean | ReadQuery. selectsClustering(DecoratedKey key,
                 Clustering clustering) | 
| boolean | SinglePartitionReadCommand. selectsClustering(DecoratedKey key,
                 Clustering clustering) | 
| boolean | SinglePartitionReadCommand.Group. selectsClustering(DecoratedKey key,
                 Clustering clustering) | 
| boolean | PartitionRangeReadCommand. selectsKey(DecoratedKey key) | 
| boolean | ReadQuery. selectsKey(DecoratedKey key) | 
| boolean | SinglePartitionReadCommand. selectsKey(DecoratedKey key) | 
| boolean | SinglePartitionReadCommand.Group. selectsKey(DecoratedKey key) | 
| static Mutation.SimpleBuilder | Mutation. simpleBuilder(java.lang.String keyspaceName,
             DecoratedKey partitionKey)Creates a new simple mutuation builder. | 
| java.lang.String | ReadResponse. toDebugString(ReadCommand command,
             DecoratedKey key)Creates a string of the requested partition in this read response suitable for debugging. | 
| static RowIterator | LegacyLayout. toRowIterator(CFMetaData metadata,
             DecoratedKey key,
             java.util.Iterator<LegacyLayout.LegacyCell> cells,
             int nowInSec) | 
| static UnfilteredRowIterator | LegacyLayout. toUnfilteredRowIterator(CFMetaData metadata,
                       DecoratedKey key,
                       LegacyLayout.LegacyDeletionInfo delInfo,
                       java.util.Iterator<LegacyLayout.LegacyCell> cells) | 
| static UnfilteredRowIterator | EmptyIterators. unfilteredRow(CFMetaData metadata,
             DecoratedKey partitionKey,
             boolean isReverseOrder) | 
| static UnfilteredRowIterator | EmptyIterators. unfilteredRow(CFMetaData metadata,
             DecoratedKey partitionKey,
             boolean isReverseOrder,
             Row staticRow,
             DeletionTime partitionDeletion) | 
| Constructor and Description | 
|---|
| Mutation(java.lang.String keyspaceName,
        DecoratedKey key) | 
| Mutation(java.lang.String keyspaceName,
        DecoratedKey key,
        java.util.Map<java.util.UUID,PartitionUpdate> modifications) | 
| MutationBuilder(java.lang.String keyspaceName,
               DecoratedKey key) | 
| SinglePartitionBuilder(ColumnFamilyStore cfs,
                      DecoratedKey key) | 
| SinglePartitionSliceBuilder(ColumnFamilyStore cfs,
                           DecoratedKey key) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract boolean | GroupMaker. isNewGroup(DecoratedKey partitionKey,
          Clustering clustering)Checks if a given row belongs to the same group that the previous row or not. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected DecoratedKey | AbstractSSTableIterator. key | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | AbstractSSTableIterator. partitionKey() | 
| Constructor and Description | 
|---|
| AbstractSSTableIterator(SSTableReader sstable,
                       FileDataInput file,
                       DecoratedKey key,
                       RowIndexEntry indexEntry,
                       Slices slices,
                       ColumnFilter columnFilter,
                       boolean isForThrift,
                       FileHandle ifile) | 
| SSTableIterator(SSTableReader sstable,
               FileDataInput file,
               DecoratedKey key,
               RowIndexEntry indexEntry,
               Slices slices,
               ColumnFilter columns,
               boolean isForThrift,
               FileHandle ifile) | 
| SSTableReversedIterator(SSTableReader sstable,
                       FileDataInput file,
                       DecoratedKey key,
                       RowIndexEntry indexEntry,
                       Slices slices,
                       ColumnFilter columns,
                       boolean isForThrift,
                       FileHandle ifile) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.function.Predicate<java.lang.Long> | CompactionController. getPurgeEvaluator(DecoratedKey key) | 
| java.util.function.Predicate<java.lang.Long> | SSTableSplitter.SplitController. getPurgeEvaluator(DecoratedKey key) | 
| java.lang.Iterable<UnfilteredRowIterator> | CompactionController. shadowSources(DecoratedKey key,
             boolean tombstoneOnly) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected void | CompactionAwareWriter. maybeSwitchWriter(DecoratedKey key)Guaranteed to be called before the first call to realAppend. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract void | DataLimits.Counter. applyToPartition(DecoratedKey partitionKey,
                Row staticRow) | 
| protected java.nio.ByteBuffer | RowFilter.Expression. getValue(CFMetaData metadata,
        DecoratedKey partitionKey,
        Row row) | 
| abstract boolean | RowFilter.Expression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row)Returns whether the provided row satisfied this expression or not. | 
| boolean | RowFilter.SimpleExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter.CustomExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row,
             int nowInSec)Whether the provided row in the provided partition satisfies this filter. | 
| boolean | RowFilter. partitionKeyRestrictionsAreSatisfiedBy(DecoratedKey key,
                                      AbstractType<?> keyValidator)Returns true if all of the expressions within this filter that apply to the partition key are satisfied by
 the given key, false otherwise. | 
| Constructor and Description | 
|---|
| TombstoneOverwhelmingException(int numTombstones,
                              java.lang.String query,
                              CFMetaData metadata,
                              DecoratedKey lastPartitionKey,
                              ClusteringPrefix lastClustering) | 
| Modifier and Type | Method and Description | 
|---|---|
| static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>> | View. select(SSTableSet sstableSet,
      DecoratedKey key) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected DecoratedKey | AbstractBTreePartition. partitionKey | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | AbstractBTreePartition. partitionKey() | 
| DecoratedKey | AtomicBTreePartition. partitionKey() | 
| DecoratedKey | Partition. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| PartitionUpdate | PartitionUpdate.PartitionUpdateSerializer. deserialize(DataInputPlus in,
           int version,
           SerializationHelper.Flag flag,
           DecoratedKey key) | 
| static PartitionUpdate | PartitionUpdate. emptyUpdate(CFMetaData metadata,
           DecoratedKey key)Creates a empty immutable partition update. | 
| static PartitionUpdate | PartitionUpdate. fromBytes(java.nio.ByteBuffer bytes,
         int version,
         DecoratedKey key)Deserialize a partition update from a provided byte buffer. | 
| static PartitionUpdate | PartitionUpdate. fullPartitionDelete(CFMetaData metadata,
                   DecoratedKey key,
                   long timestamp,
                   int nowInSec)Creates an immutable partition update that entirely deletes a given partition. | 
| UnfilteredRowIterators.MergeListener | UnfilteredPartitionIterators.MergeListener. getRowMergeListener(DecoratedKey partitionKey,
                   java.util.List<UnfilteredRowIterator> versions) | 
| protected void | PurgeFunction. onEmptyPartitionPostPurge(DecoratedKey partitionKey) | 
| protected void | PurgeFunction. onNewPartition(DecoratedKey partitionKey) | 
| static PartitionUpdate | PartitionUpdate. singleRowUpdate(CFMetaData metadata,
               DecoratedKey key,
               Row row)Creates an immutable partition update that contains a single row update. | 
| Constructor and Description | 
|---|
| AbstractBTreePartition(CFMetaData metadata,
                      DecoratedKey partitionKey) | 
| AtomicBTreePartition(CFMetaData metadata,
                    DecoratedKey partitionKey,
                    MemtableAllocator allocator) | 
| ImmutableBTreePartition(CFMetaData metadata,
                       DecoratedKey partitionKey,
                       AbstractBTreePartition.Holder holder) | 
| ImmutableBTreePartition(CFMetaData metadata,
                       DecoratedKey partitionKey,
                       PartitionColumns columns,
                       Row staticRow,
                       java.lang.Object[] tree,
                       DeletionInfo deletionInfo,
                       EncodingStats stats) | 
| PartitionUpdate(CFMetaData metadata,
               DecoratedKey key,
               PartitionColumns columns,
               int initialRowCapacity) | 
| Modifier and Type | Field and Description | 
|---|---|
| DecoratedKey | UnfilteredRowIteratorSerializer.Header. key | 
| protected DecoratedKey | AbstractUnfilteredRowIterator. partitionKey | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | AbstractUnfilteredRowIterator. partitionKey() | 
| DecoratedKey | BaseRowIterator. partitionKey()The partition key of the partition this in an iterator over. | 
| DecoratedKey | LazilyInitializedUnfilteredRowIterator. partitionKey() | 
| DecoratedKey | WrappingUnfilteredRowIterator. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| static UnfilteredRowIterator | UnfilteredRowIterators. noRowsIterator(CFMetaData cfm,
              DecoratedKey partitionKey,
              Row staticRow,
              DeletionTime partitionDeletion,
              boolean isReverseOrder)Returns an empty unfiltered iterator for a given partition. | 
| Constructor and Description | 
|---|
| AbstractUnfilteredRowIterator(CFMetaData metadata,
                             DecoratedKey partitionKey,
                             DeletionTime partitionLevelDeletion,
                             PartitionColumns columns,
                             Row staticRow,
                             boolean isReverseOrder,
                             EncodingStats stats) | 
| LazilyInitializedUnfilteredRowIterator(DecoratedKey partitionKey) | 
| RowAndDeletionMergeIterator(CFMetaData metadata,
                           DecoratedKey partitionKey,
                           DeletionTime partitionLevelDeletion,
                           ColumnFilter selection,
                           Row staticRow,
                           boolean isReversed,
                           EncodingStats stats,
                           java.util.Iterator<Row> rows,
                           java.util.Iterator<RangeTombstone> ranges,
                           boolean removeShadowedData) | 
| UnfilteredRowIteratorWithLowerBound(DecoratedKey partitionKey,
                                   SSTableReader sstable,
                                   ClusteringIndexFilter filter,
                                   ColumnFilter selectedColumns,
                                   boolean isForThrift,
                                   int nowInSec,
                                   boolean applyThriftTransformation,
                                   SSTableReadsListener listener) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected DecoratedKey | Transformation. applyToPartitionKey(DecoratedKey key)Applied to the partition key of any rows/unfiltered iterator we are applied to | 
| DecoratedKey | BaseRows. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected DecoratedKey | Transformation. applyToPartitionKey(DecoratedKey key)Applied to the partition key of any rows/unfiltered iterator we are applied to | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | View. matchesViewFilter(DecoratedKey partitionKey,
                 Row baseRow,
                 int nowInSec)Whether a given base row matches the view filter (and thus if is should have a corresponding entry). | 
| boolean | View. mayBeAffectedBy(DecoratedKey partitionKey,
               Row update)Whether the view might be affected by the provided update. | 
| Constructor and Description | 
|---|
| ViewUpdateGenerator(View view,
                   DecoratedKey basePartitionKey,
                   int nowInSec)Creates a new  ViewUpdateBuilder. | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | ByteOrderedPartitioner. decorateKey(java.nio.ByteBuffer key) | 
| DecoratedKey | IPartitioner. decorateKey(java.nio.ByteBuffer key)Transform key to object representation of the on-disk format. | 
| DecoratedKey | LocalPartitioner. decorateKey(java.nio.ByteBuffer key) | 
| DecoratedKey | Murmur3Partitioner. decorateKey(java.nio.ByteBuffer key) | 
| DecoratedKey | OrderPreservingPartitioner. decorateKey(java.nio.ByteBuffer key) | 
| DecoratedKey | RandomPartitioner. decorateKey(java.nio.ByteBuffer key) | 
| Modifier and Type | Method and Description | 
|---|---|
| Index.Indexer | Index. indexerFor(DecoratedKey key,
          PartitionColumns columns,
          int nowInSec,
          OpOrder.Group opGroup,
          IndexTransaction.Type transactionType)Creates an new  Indexerobject for updates to a given partition. | 
| void | SecondaryIndexManager. indexPartition(DecoratedKey key,
              java.util.Set<Index> indexes,
              int pageSize)When building an index against existing data in sstables, add the given partition to the index | 
| CleanupTransaction | SecondaryIndexManager. newCleanupTransaction(DecoratedKey key,
                     PartitionColumns partitionColumns,
                     int nowInSec)Transaction for use when removing partitions during cleanup | 
| CompactionTransaction | SecondaryIndexManager. newCompactionTransaction(DecoratedKey key,
                        PartitionColumns partitionColumns,
                        int versions,
                        int nowInSec)Transaction for use when merging rows during compaction | 
| Modifier and Type | Field and Description | 
|---|---|
| DecoratedKey | IndexEntry. indexValue | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract IndexEntry | CassandraIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry)Used at search time to convert a row in the index table into a simple struct containing the values required
 to retrieve the corresponding row from the base table. | 
| void | CassandraIndex. deleteStaleEntry(DecoratedKey indexKey,
                Clustering indexClustering,
                DeletionTime deletion,
                OpOrder.Group opGroup)Specific to internal indexes, this is called by a
 searcher when it encounters a stale entry in the index | 
| Index.Indexer | CassandraIndex. indexerFor(DecoratedKey key,
          PartitionColumns columns,
          int nowInSec,
          OpOrder.Group opGroup,
          IndexTransaction.Type transactionType) | 
| protected abstract UnfilteredPartitionIterator | CassandraIndexSearcher. queryDataFromIndex(DecoratedKey indexKey,
                  RowIterator indexHits,
                  ReadCommand command,
                  ReadExecutionController executionController) | 
| Constructor and Description | 
|---|
| IndexEntry(DecoratedKey indexValue,
          Clustering indexClustering,
          long timestamp,
          java.nio.ByteBuffer indexedKey,
          Clustering indexedEntryClustering) | 
| Modifier and Type | Method and Description | 
|---|---|
| IndexEntry | ClusteringColumnIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| IndexEntry | CollectionKeyIndexBase. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| IndexEntry | CollectionValueIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| IndexEntry | PartitionKeyIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| IndexEntry | RegularColumnIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| protected UnfilteredPartitionIterator | CompositesSearcher. queryDataFromIndex(DecoratedKey indexKey,
                  RowIterator indexHits,
                  ReadCommand command,
                  ReadExecutionController executionController) | 
| Modifier and Type | Method and Description | 
|---|---|
| IndexEntry | KeysIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| protected UnfilteredPartitionIterator | KeysSearcher. queryDataFromIndex(DecoratedKey indexKey,
                  RowIterator indexHits,
                  ReadCommand command,
                  ReadExecutionController executionController) | 
| Modifier and Type | Method and Description | 
|---|---|
| Index.Indexer | SASIIndex. indexerFor(DecoratedKey key,
          PartitionColumns columns,
          int nowInSec,
          OpOrder.Group opGroup,
          IndexTransaction.Type transactionType) | 
| Modifier and Type | Method and Description | 
|---|---|
| long | ColumnIndex. index(DecoratedKey key,
     Row row) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected com.google.common.base.Function<java.lang.Long,DecoratedKey> | OnDiskIndex. keyFetcher | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.Iterator<DecoratedKey> | TokenTree.OnDiskToken. iterator() | 
| Modifier and Type | Method and Description | 
|---|---|
| OnDiskIndexBuilder | OnDiskIndexBuilder. add(java.nio.ByteBuffer term,
   DecoratedKey key,
   long keyPosition) | 
| void | PerSSTableIndexWriter.Index. add(java.nio.ByteBuffer term,
   DecoratedKey key,
   long keyPosition) | 
| void | PerSSTableIndexWriter. startPartition(DecoratedKey key,
              long curPosition) | 
| Modifier and Type | Method and Description | 
|---|---|
| TokenTree.OnDiskToken | TokenTree. get(long searchToken,
   com.google.common.base.Function<java.lang.Long,DecoratedKey> keyFetcher) | 
| static TokenTree.OnDiskToken | TokenTree.OnDiskToken. getTokenAt(MappedBuffer buffer,
          int idx,
          short leafSize,
          com.google.common.base.Function<java.lang.Long,DecoratedKey> keyFetcher) | 
| RangeIterator<java.lang.Long,Token> | TokenTree. iterator(com.google.common.base.Function<java.lang.Long,DecoratedKey> keyFetcher) | 
| Constructor and Description | 
|---|
| OnDiskIndex(java.io.File index,
           AbstractType<?> cmp,
           com.google.common.base.Function<java.lang.Long,DecoratedKey> keyReader) | 
| OnDiskToken(MappedBuffer buffer,
           long position,
           short leafSize,
           com.google.common.base.Function<java.lang.Long,DecoratedKey> keyFetcher) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentPrefixTrie. get(java.lang.String value) | 
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentSuffixTrie. get(java.lang.String value) | 
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentPrefixTrie. putIfAbsent(java.lang.String value,
           java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> newKeys) | 
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentSuffixTrie. putIfAbsent(java.lang.String value,
           java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> newKeys) | 
| java.lang.Iterable<java.util.concurrent.ConcurrentSkipListSet<DecoratedKey>> | TrieMemIndex.ConcurrentPrefixTrie. search(Expression.Op operator,
      java.lang.String value) | 
| java.lang.Iterable<java.util.concurrent.ConcurrentSkipListSet<DecoratedKey>> | TrieMemIndex.ConcurrentSuffixTrie. search(Expression.Op operator,
      java.lang.String value) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract long | MemIndex. add(DecoratedKey key,
   java.nio.ByteBuffer value) | 
| long | SkipListMemIndex. add(DecoratedKey key,
   java.nio.ByteBuffer value) | 
| long | TrieMemIndex. add(DecoratedKey key,
   java.nio.ByteBuffer value) | 
| long | IndexMemtable. index(DecoratedKey key,
     java.nio.ByteBuffer value) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentPrefixTrie. putIfAbsent(java.lang.String value,
           java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> newKeys) | 
| java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> | TrieMemIndex.ConcurrentSuffixTrie. putIfAbsent(java.lang.String value,
           java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> newKeys) | 
| Constructor and Description | 
|---|
| KeyRangeIterator(java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> keys) | 
| Modifier and Type | Method and Description | 
|---|---|
| UnfilteredRowIterator | QueryController. getPartition(DecoratedKey key,
            ReadExecutionController executionController) | 
| Modifier and Type | Field and Description | 
|---|---|
| DecoratedKey | SSTable. first | 
| DecoratedKey | SSTable. last | 
| DecoratedKey | IndexSummaryBuilder.ReadableBoundary. lastKey | 
| Modifier and Type | Method and Description | 
|---|---|
| protected DecoratedKey | KeyIterator. computeNext() | 
| DecoratedKey | SSTable. decorateKey(java.nio.ByteBuffer key) | 
| static DecoratedKey | SSTable. getMinimalKey(DecoratedKey key)If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
 as large as necessary. | 
| DecoratedKey | ReducingKeyIterator. next() | 
| DecoratedKey | SSTableIdentityIterator. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| Pair<DecoratedKey,DecoratedKey> | IndexSummary.IndexSummarySerializer. deserializeFirstLastKey(java.io.DataInputStream in,
                       IPartitioner partitioner,
                       boolean haveSamplingLevel)Deserializes the first and last key stored in the summary
 Only for use by offline tools like SSTableMetadataViewer, otherwise SSTable.first/last should be used. | 
| Pair<DecoratedKey,DecoratedKey> | IndexSummary.IndexSummarySerializer. deserializeFirstLastKey(java.io.DataInputStream in,
                       IPartitioner partitioner,
                       boolean haveSamplingLevel)Deserializes the first and last key stored in the summary
 Only for use by offline tools like SSTableMetadataViewer, otherwise SSTable.first/last should be used. | 
| Modifier and Type | Method and Description | 
|---|---|
| static SSTableIdentityIterator | SSTableIdentityIterator. create(SSTableReader sstable,
      FileDataInput dfile,
      RowIndexEntry<?> indexEntry,
      DecoratedKey key,
      boolean tombstoneOnly) | 
| static SSTableIdentityIterator | SSTableIdentityIterator. create(SSTableReader sstable,
      RandomAccessReader file,
      DecoratedKey key) | 
| static DecoratedKey | SSTable. getMinimalKey(DecoratedKey key)If the given @param key occupies only part of a larger buffer, allocate a new buffer that is only
 as large as necessary. | 
| IndexSummaryBuilder | IndexSummaryBuilder. maybeAddEntry(DecoratedKey decoratedKey,
             long indexStart) | 
| IndexSummaryBuilder | IndexSummaryBuilder. maybeAddEntry(DecoratedKey decoratedKey,
             long indexStart,
             long indexEnd,
             long dataEnd) | 
| Constructor and Description | 
|---|
| ReadableBoundary(DecoratedKey lastKey,
                long indexLength,
                long dataLength,
                int summaryCount,
                long entriesLength) | 
| SSTableIdentityIterator(SSTableReader sstable,
                       DecoratedKey key,
                       DeletionTime partitionLevelDeletion,
                       java.lang.String filename,
                       SSTableSimpleIterator iterator) | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | SSTableReader. firstKeyBeyond(PartitionPosition token)Finds and returns the first key beyond a given token in this SSTable or null if no such key exists. | 
| DecoratedKey | SSTableReader. keyAt(long indexPosition) | 
| Modifier and Type | Method and Description | 
|---|---|
| java.lang.Iterable<DecoratedKey> | SSTableReader. getKeySamples(Range<Token> range) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | SSTableReader. cacheKey(DecoratedKey key,
        RowIndexEntry info) | 
| SSTableReader | SSTableReader. cloneWithNewStart(DecoratedKey newStart,
                 java.lang.Runnable runOnClose) | 
| SSTableReader | SSTableReader. cloneWithRestoredStart(DecoratedKey restoredStart) | 
| RowIndexEntry | SSTableReader. getCachedPosition(DecoratedKey key,
                 boolean updateStats) | 
| KeyCacheKey | SSTableReader. getCacheKey(DecoratedKey key) | 
| abstract UnfilteredRowIterator | SSTableReader. iterator(DecoratedKey key,
        Slices slices,
        ColumnFilter selectedColumns,
        boolean reversed,
        boolean isForThrift,
        SSTableReadsListener listener) | 
| abstract UnfilteredRowIterator | SSTableReader. iterator(FileDataInput file,
        DecoratedKey key,
        RowIndexEntry indexEntry,
        Slices slices,
        ColumnFilter selectedColumns,
        boolean reversed,
        boolean isForThrift) | 
| static void | SSTableReader. saveSummary(Descriptor descriptor,
           DecoratedKey first,
           DecoratedKey last,
           IndexSummary summary)Save index summary to Summary.db file. | 
| abstract UnfilteredRowIterator | SSTableReader. simpleIterator(FileDataInput file,
              DecoratedKey key,
              RowIndexEntry indexEntry,
              boolean tombstoneOnly) | 
| void | SSTableFlushObserver. startPartition(DecoratedKey key,
              long indexPosition)Called when a new partition in being written to the sstable,
 but before any cells are processed (see  SSTableFlushObserver.nextUnfilteredCluster(Unfiltered)). | 
| Modifier and Type | Method and Description | 
|---|---|
| protected long | BigTableWriter. beforeAppend(DecoratedKey decoratedKey)Perform sanity checks on @param decoratedKey and @return the position in the data file before any data is written | 
| UnfilteredRowIterator | BigTableReader. iterator(DecoratedKey key,
        Slices slices,
        ColumnFilter selectedColumns,
        boolean reversed,
        boolean isForThrift,
        SSTableReadsListener listener) | 
| UnfilteredRowIterator | BigTableReader. iterator(FileDataInput file,
        DecoratedKey key,
        RowIndexEntry indexEntry,
        Slices slices,
        ColumnFilter selectedColumns,
        boolean reversed,
        boolean isForThrift) | 
| UnfilteredRowIterator | BigTableReader. simpleIterator(FileDataInput dfile,
              DecoratedKey key,
              RowIndexEntry position,
              boolean tombstoneOnly) | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | TokenMetadata. decorateKey(java.nio.ByteBuffer key) | 
| Modifier and Type | Method and Description | 
|---|---|
| static RowIterator | StorageProxy. cas(java.lang.String keyspaceName,
   java.lang.String cfName,
   DecoratedKey key,
   CASRequest request,
   ConsistencyLevel consistencyForPaxos,
   ConsistencyLevel consistencyForCommit,
   ClientState state,
   long queryStartNanoTime)Apply @param updates if and only if the current values in the row for @param key
 match the provided @param conditions. | 
| Constructor and Description | 
|---|
| DigestMismatchException(DecoratedKey key,
                       java.nio.ByteBuffer digest1,
                       java.nio.ByteBuffer digest2) | 
| Modifier and Type | Method and Description | 
|---|---|
| static int | QueryPagers. countPaged(CFMetaData metadata,
          DecoratedKey key,
          ColumnFilter columnFilter,
          ClusteringIndexFilter filter,
          DataLimits limits,
          ConsistencyLevel consistencyLevel,
          ClientState state,
          int pageSize,
          int nowInSec,
          boolean isForThrift,
          long queryStartNanoTime)Convenience method that count (live) cells/rows for a given slice of a row, but page underneath. | 
| protected boolean | PartitionRangeQueryPager. isPreviouslyReturnedPartition(DecoratedKey key) | 
| protected boolean | SinglePartitionPager. isPreviouslyReturnedPartition(DecoratedKey key) | 
| protected void | PartitionRangeQueryPager. recordLast(DecoratedKey key,
          Row last) | 
| protected void | SinglePartitionPager. recordLast(DecoratedKey key,
          Row last) | 
| Constructor and Description | 
|---|
| PartitionRangeQueryPager(ReadCommand command,
                        ProtocolVersion protocolVersion,
                        DecoratedKey lastReturnedKey,
                        PagingState.RowMark lastReturnedRow,
                        int remaining,
                        int remainingInPartition) | 
| Modifier and Type | Method and Description | 
|---|---|
| static Commit | Commit. emptyCommit(DecoratedKey key,
           CFMetaData metadata) | 
| static Commit | Commit. newPrepare(DecoratedKey key,
          CFMetaData metadata,
          java.util.UUID ballot) | 
| Constructor and Description | 
|---|
| PaxosState(DecoratedKey key,
          CFMetaData metadata) | 
| PrepareCallback(DecoratedKey key,
               CFMetaData metadata,
               int targets,
               ConsistencyLevel consistency,
               long queryStartNanoTime) | 
| Modifier and Type | Method and Description | 
|---|---|
| DecoratedKey | StreamReader.StreamDeserializer. partitionKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | JsonTransformer. keysToJson(ISSTableScanner currentScanner,
          java.util.stream.Stream<DecoratedKey> keys,
          boolean rawTime,
          CFMetaData metadata,
          java.io.OutputStream out) | 
| Modifier and Type | Method and Description | 
|---|---|
| static void | FBUtilities. sortSampledKeys(java.util.List<DecoratedKey> keys,
               Range<Token> range) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract DecoratedKey | EnsureOnHeap. applyToPartitionKey(DecoratedKey key) | 
| abstract DecoratedKey | MemtableAllocator. clone(DecoratedKey key,
     OpOrder.Group opGroup) | 
| DecoratedKey | MemtableBufferAllocator. clone(DecoratedKey key,
     OpOrder.Group writeOp) | 
| DecoratedKey | NativeAllocator. clone(DecoratedKey key,
     OpOrder.Group writeOp) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract DecoratedKey | EnsureOnHeap. applyToPartitionKey(DecoratedKey key) | 
| abstract DecoratedKey | MemtableAllocator. clone(DecoratedKey key,
     OpOrder.Group opGroup) | 
| DecoratedKey | MemtableBufferAllocator. clone(DecoratedKey key,
     OpOrder.Group writeOp) | 
| DecoratedKey | NativeAllocator. clone(DecoratedKey key,
     OpOrder.Group writeOp) | 
Copyright © 2018 The Apache Software Foundation