Uses of Class
org.apache.cassandra.db.DecoratedKey
-
-
Uses of DecoratedKey in org.apache.cassandra.cache
Constructors in org.apache.cassandra.cache with parameters of type DecoratedKey Constructor Description RowCacheKey(TableMetadata metadata, DecoratedKey key)
-
Uses of DecoratedKey in org.apache.cassandra.cql3
Methods in org.apache.cassandra.cql3 with parameters of type DecoratedKey Modifier and Type Method Description void
Constants.Adder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Deleter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Constants.Substracter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Appender. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Discarder. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.DiscarderByIndex. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Prepender. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Lists.SetterByIndex. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.DiscarderByKey. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.Putter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
Maps.SetterByKey. execute(DecoratedKey partitionKey, UpdateParameters params)
abstract void
Operation. execute(DecoratedKey partitionKey, UpdateParameters params)
Execute the operation.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
Sets.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.DeleterByField. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.Setter. execute(DecoratedKey partitionKey, UpdateParameters params)
void
UserTypes.SetterByField. execute(DecoratedKey partitionKey, UpdateParameters params)
static UntypedResultSet.Row
UntypedResultSet.Row. fromInternalRow(TableMetadata metadata, DecoratedKey key, Row row)
Row
UpdateParameters. getPrefetchedRow(DecoratedKey key, Clustering<?> clustering)
Returns the prefetched row with the already performed modifications.Constructor parameters in org.apache.cassandra.cql3 with type arguments of type DecoratedKey Constructor Description UpdateParameters(TableMetadata metadata, RegularAndStaticColumns updatedColumns, QueryOptions options, long timestamp, int nowInSec, int ttl, java.util.Map<DecoratedKey,Partition> prefetchedRows)
-
Uses of DecoratedKey in org.apache.cassandra.cql3.selection
Methods in org.apache.cassandra.cql3.selection with parameters of type DecoratedKey Modifier and Type Method Description void
ResultSetBuilder. newRow(DecoratedKey partitionKey, Clustering<?> clustering)
Notifies thisBuilder
that a new row is being processed. -
Uses of DecoratedKey in org.apache.cassandra.cql3.statements
Fields in org.apache.cassandra.cql3.statements declared as DecoratedKey Modifier and Type Field Description DecoratedKey
CQL3CasRequest. key
Methods in org.apache.cassandra.cql3.statements with parameters of type DecoratedKey Modifier and Type Method Description static java.nio.ByteBuffer[]
SelectStatement. getComponents(TableMetadata metadata, DecoratedKey dk)
PartitionUpdate.Builder
UpdatesCollector. getPartitionUpdateBuilder(TableMetadata metadata, DecoratedKey dk, ConsistencyLevel consistency)
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).Constructors in org.apache.cassandra.cql3.statements with parameters of type DecoratedKey Constructor Description CQL3CasRequest(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns conditionColumns, boolean updatesRegularRows, boolean updatesStaticRow)
-
Uses of DecoratedKey in org.apache.cassandra.db
Subclasses of DecoratedKey in org.apache.cassandra.db Modifier and Type Class Description class
BufferDecoratedKey
class
CachedHashDecoratedKey
class
NativeDecoratedKey
class
PreHashedDecoratedKey
Fields in org.apache.cassandra.db with type parameters of type DecoratedKey Modifier and Type Field Description static java.util.Comparator<DecoratedKey>
DecoratedKey. comparator
Methods in org.apache.cassandra.db that return DecoratedKey Modifier and Type Method Description DecoratedKey
ColumnFamilyStore. decorateKey(java.nio.ByteBuffer key)
DecoratedKey
CounterMutation. key()
DecoratedKey
IMutation. key()
DecoratedKey
Mutation. key()
DecoratedKey
Mutation.PartitionUpdateCollector. key()
DecoratedKey
SinglePartitionReadCommand. partitionKey()
DecoratedKey
SinglePartitionReadQuery. partitionKey()
Returns the key of the partition queried by thisReadQuery
DecoratedKey
VirtualTableSinglePartitionReadQuery. partitionKey()
Methods in org.apache.cassandra.db that return types with arguments of type DecoratedKey Modifier and Type Method Description java.lang.Iterable<DecoratedKey>
ColumnFamilyStore. keySamples(Range<Token> range)
Methods in org.apache.cassandra.db with parameters of type DecoratedKey Modifier and Type Method 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(TableMetadata 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(TableMetadata metadata, int nowInSec, DecoratedKey key, Clustering<?> name)
Creates a new single partition name command for the provided row.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, int nowInSec, DecoratedKey key, ColumnFilter columnFilter, ClusteringIndexFilter filter)
Creates a new read command on a single partition.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, int nowInSec, DecoratedKey key, Slice slice)
Creates a new single partition slice command for the provided single slice.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata metadata, int nowInSec, DecoratedKey key, Slices slices)
Creates a new single partition slice command for the provided slices.static SinglePartitionReadCommand
SinglePartitionReadCommand. create(TableMetadata 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(TableMetadata 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 SinglePartitionReadQuery
SinglePartitionReadQuery. create(TableMetadata metadata, int nowInSec, DecoratedKey key, ColumnFilter columnFilter, ClusteringIndexFilter filter)
Creates a new read query on a single partition.static SinglePartitionReadQuery
SinglePartitionReadQuery. create(TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter)
Creates a new read query on a single partition.static VirtualTableSinglePartitionReadQuery
VirtualTableSinglePartitionReadQuery. create(TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter)
static SinglePartitionReadCommand
SinglePartitionReadCommand. fullPartitionRead(TableMetadata metadata, int nowInSec, DecoratedKey key)
Creates a new read command that queries a single partition in its entirety.Directories.DataDirectory
DiskBoundaries. getCorrectDiskForKey(DecoratedKey key)
Partition
Memtable. getPartition(DecoratedKey key)
abstract java.util.function.LongPredicate
AbstractCompactionController. getPurgeEvaluator(DecoratedKey key)
CachedPartition
ColumnFamilyStore. getRawCachedPartition(DecoratedKey key)
static void
UnfilteredValidation. handleInvalid(TableMetadata metadata, DecoratedKey key, SSTableReader sstable, java.lang.String invalidContent)
void
ColumnFamilyStore. invalidateCachedPartition(DecoratedKey key)
static PaxosState
SystemKeyspace. loadPaxosState(DecoratedKey key, TableMetadata metadata, int nowInSec)
UnfilteredRowIterator
StorageHook. makeRowIterator(ColumnFamilyStore cfs, SSTableReader sstable, DecoratedKey key, Slices slices, ColumnFilter selectedColumns, boolean reversed, SSTableReadsListener listener)
UnfilteredRowIteratorWithLowerBound
StorageHook. makeRowIteratorWithLowerBound(ColumnFamilyStore cfs, DecoratedKey partitionKey, SSTableReader sstable, ClusteringIndexFilter filter, ColumnFilter selectedColumns, SSTableReadsListener listener)
static void
UnfilteredValidation. maybeValidateUnfiltered(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey key, SSTableReader sstable)
void
StorageHook. reportRead(TableId tableId, DecoratedKey key)
static RowIterator
EmptyIterators. row(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder)
default boolean
PartitionRangeReadQuery. selectsClustering(DecoratedKey key, Clustering<?> clustering)
boolean
ReadQuery. selectsClustering(DecoratedKey key, Clustering<?> clustering)
boolean
SinglePartitionReadQuery.Group. selectsClustering(DecoratedKey key, Clustering<?> clustering)
default boolean
SinglePartitionReadQuery. selectsClustering(DecoratedKey key, Clustering<?> clustering)
default boolean
PartitionRangeReadQuery. selectsKey(DecoratedKey key)
boolean
ReadQuery. selectsKey(DecoratedKey key)
boolean
SinglePartitionReadQuery.Group. selectsKey(DecoratedKey key)
default boolean
SinglePartitionReadQuery. selectsKey(DecoratedKey key)
java.lang.Iterable<UnfilteredRowIterator>
AbstractCompactionController. shadowSources(DecoratedKey key, boolean tombstoneOnly)
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 UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder)
static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder, Row staticRow, DeletionTime partitionDeletion)
Method parameters in org.apache.cassandra.db with type arguments of type DecoratedKey Modifier and Type Method Description static SinglePartitionReadCommand.Group
SinglePartitionReadCommand.Group. create(TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, java.util.List<DecoratedKey> partitionKeys, ClusteringIndexFilter clusteringIndexFilter)
static VirtualTableSinglePartitionReadQuery.Group
VirtualTableSinglePartitionReadQuery.Group. create(TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, java.util.List<DecoratedKey> partitionKeys, ClusteringIndexFilter clusteringIndexFilter)
static SinglePartitionReadQuery.Group<? extends SinglePartitionReadQuery>
SinglePartitionReadQuery. createGroup(TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, java.util.List<DecoratedKey> partitionKeys, ClusteringIndexFilter clusteringIndexFilter)
Constructors in org.apache.cassandra.db with parameters of type DecoratedKey Constructor Description Mutation(java.lang.String keyspaceName, DecoratedKey key, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications, long approxCreatedAtNanos)
Mutation(java.lang.String keyspaceName, DecoratedKey key, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications, long approxCreatedAtNanos, boolean cdcEnabled)
MutationBuilder(java.lang.String keyspaceName, DecoratedKey key)
PartitionUpdateCollector(java.lang.String keyspaceName, DecoratedKey key)
SinglePartitionBuilder(ColumnFamilyStore cfs, DecoratedKey key)
SinglePartitionReadCommand(boolean isDigest, int digestVersion, boolean acceptsTransient, TableMetadata metadata, int nowInSec, ColumnFilter columnFilter, RowFilter rowFilter, DataLimits limits, DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, IndexMetadata index)
-
Uses of DecoratedKey in org.apache.cassandra.db.aggregation
Methods in org.apache.cassandra.db.aggregation with parameters of type DecoratedKey Modifier and Type Method 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. -
Uses of DecoratedKey in org.apache.cassandra.db.columniterator
Fields in org.apache.cassandra.db.columniterator declared as DecoratedKey Modifier and Type Field Description protected DecoratedKey
AbstractSSTableIterator. key
Methods in org.apache.cassandra.db.columniterator that return DecoratedKey Modifier and Type Method Description DecoratedKey
AbstractSSTableIterator. partitionKey()
Constructors in org.apache.cassandra.db.columniterator with parameters of type DecoratedKey Constructor Description AbstractSSTableIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columnFilter, FileHandle ifile)
SSTableIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columns, FileHandle ifile)
SSTableReversedIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter columns, FileHandle ifile)
-
Uses of DecoratedKey in org.apache.cassandra.db.compaction
Methods in org.apache.cassandra.db.compaction with parameters of type DecoratedKey Modifier and Type Method Description boolean
Verifier.RangeOwnHelper. check(DecoratedKey key)
check if the given key is contained in any of the given ranges Must be called in sorted order - key should be increasingjava.util.function.LongPredicate
CompactionController. getPurgeEvaluator(DecoratedKey key)
java.util.function.LongPredicate
SSTableSplitter.SplitController. getPurgeEvaluator(DecoratedKey key)
java.lang.Iterable<UnfilteredRowIterator>
CompactionController. shadowSources(DecoratedKey key, boolean tombstoneOnly)
void
Verifier.RangeOwnHelper. validate(DecoratedKey key)
check if the given key is contained in any of the given ranges Must be called in sorted order - key should be increasing -
Uses of DecoratedKey in org.apache.cassandra.db.compaction.writers
Methods in org.apache.cassandra.db.compaction.writers with parameters of type DecoratedKey Modifier and Type Method Description protected void
CompactionAwareWriter. maybeSwitchWriter(DecoratedKey key)
Guaranteed to be called before the first call to realAppend. -
Uses of DecoratedKey in org.apache.cassandra.db.filter
Methods in org.apache.cassandra.db.filter with parameters of type DecoratedKey Modifier and Type Method Description protected abstract void
DataLimits.Counter. applyToPartition(DecoratedKey partitionKey, Row staticRow)
protected java.nio.ByteBuffer
RowFilter.Expression. getValue(TableMetadata metadata, DecoratedKey partitionKey, Row row)
boolean
RowFilter.CustomExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
abstract boolean
RowFilter.Expression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
Returns whether the provided row satisfied this expression or not.boolean
RowFilter. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row, int nowInSec)
Whether the provided row in the provided partition satisfies this filter.boolean
RowFilter.SimpleExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
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.Constructors in org.apache.cassandra.db.filter with parameters of type DecoratedKey Constructor Description TombstoneOverwhelmingException(int numTombstones, java.lang.String query, TableMetadata metadata, DecoratedKey lastPartitionKey, ClusteringPrefix<?> lastClustering)
-
Uses of DecoratedKey in org.apache.cassandra.db.lifecycle
Methods in org.apache.cassandra.db.lifecycle with parameters of type DecoratedKey Modifier and Type Method Description static com.google.common.base.Function<View,java.lang.Iterable<SSTableReader>>
View. select(SSTableSet sstableSet, DecoratedKey key)
-
Uses of DecoratedKey in org.apache.cassandra.db.partitions
Fields in org.apache.cassandra.db.partitions declared as DecoratedKey Modifier and Type Field Description protected DecoratedKey
AbstractBTreePartition. partitionKey
Methods in org.apache.cassandra.db.partitions that return DecoratedKey Modifier and Type Method Description DecoratedKey
AbstractBTreePartition. partitionKey()
DecoratedKey
AtomicBTreePartition. partitionKey()
DecoratedKey
Partition. partitionKey()
DecoratedKey
PartitionUpdate.Builder. partitionKey()
Methods in org.apache.cassandra.db.partitions with parameters of type DecoratedKey Modifier and Type Method Description static PartitionUpdate
PartitionUpdate. emptyUpdate(TableMetadata metadata, DecoratedKey key)
Creates a empty immutable partition update.static PartitionUpdate
PartitionUpdate. fullPartitionDelete(TableMetadata 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(TableMetadata metadata, DecoratedKey key, Row row)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, DecoratedKey key, Row row, Row staticRow)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. unsafeConstruct(TableMetadata metadata, DecoratedKey key, AbstractBTreePartition.Holder holder, MutableDeletionInfo deletionInfo, boolean canHaveShadowedData)
Constructors in org.apache.cassandra.db.partitions with parameters of type DecoratedKey Constructor Description AbstractBTreePartition(DecoratedKey partitionKey)
AtomicBTreePartition(TableMetadataRef metadata, DecoratedKey partitionKey, MemtableAllocator allocator)
Builder(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns columnDefinitions, int size)
Builder(TableMetadata metadata, DecoratedKey key, RegularAndStaticColumns columns, int initialRowCapacity, boolean canHaveShadowedData)
ImmutableBTreePartition(TableMetadata metadata, DecoratedKey partitionKey, AbstractBTreePartition.Holder holder)
ImmutableBTreePartition(TableMetadata metadata, DecoratedKey partitionKey, RegularAndStaticColumns columns, Row staticRow, java.lang.Object[] tree, DeletionInfo deletionInfo, EncodingStats stats)
-
Uses of DecoratedKey in org.apache.cassandra.db.rows
Fields in org.apache.cassandra.db.rows declared as DecoratedKey Modifier and Type Field Description DecoratedKey
UnfilteredRowIteratorSerializer.Header. key
protected DecoratedKey
AbstractUnfilteredRowIterator. partitionKey
Methods in org.apache.cassandra.db.rows that return DecoratedKey Modifier and Type Method Description DecoratedKey
AbstractUnfilteredRowIterator. partitionKey()
DecoratedKey
BaseRowIterator. partitionKey()
The partition key of the partition this in an iterator over.DecoratedKey
LazilyInitializedUnfilteredRowIterator. partitionKey()
DecoratedKey
WrappingUnfilteredRowIterator. partitionKey()
Methods in org.apache.cassandra.db.rows with parameters of type DecoratedKey Modifier and Type Method Description static UnfilteredRowIterator
UnfilteredRowIterators. noRowsIterator(TableMetadata metadata, DecoratedKey partitionKey, Row staticRow, DeletionTime partitionDeletion, boolean isReverseOrder)
Returns an empty unfiltered iterator for a given partition.static UnfilteredRowIterator
UnfilteredRowIterators. singleton(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats encodingStats)
Constructors in org.apache.cassandra.db.rows with parameters of type DecoratedKey Constructor Description AbstractUnfilteredRowIterator(TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats stats)
LazilyInitializedUnfilteredRowIterator(DecoratedKey partitionKey)
RowAndDeletionMergeIterator(TableMetadata 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, SSTableReadsListener listener)
-
Uses of DecoratedKey in org.apache.cassandra.db.streaming
Fields in org.apache.cassandra.db.streaming declared as DecoratedKey Modifier and Type Field Description DecoratedKey
CassandraStreamHeader. firstKey
Methods in org.apache.cassandra.db.streaming that return DecoratedKey Modifier and Type Method Description DecoratedKey
CassandraStreamReader.StreamDeserializer. partitionKey()
Methods in org.apache.cassandra.db.streaming with parameters of type DecoratedKey Modifier and Type Method Description CassandraStreamHeader.Builder
CassandraStreamHeader.Builder. withFirstKey(DecoratedKey firstKey)
-
Uses of DecoratedKey in org.apache.cassandra.db.transform
Methods in org.apache.cassandra.db.transform that return DecoratedKey Modifier and Type Method Description protected DecoratedKey
Transformation. applyToPartitionKey(DecoratedKey key)
Applied to the partition key of any rows/unfiltered iterator we are applied toDecoratedKey
BaseRows. partitionKey()
Methods in org.apache.cassandra.db.transform with parameters of type DecoratedKey Modifier and Type Method Description protected DecoratedKey
Transformation. applyToPartitionKey(DecoratedKey key)
Applied to the partition key of any rows/unfiltered iterator we are applied to -
Uses of DecoratedKey in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view with parameters of type DecoratedKey Modifier and Type Method 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.Constructors in org.apache.cassandra.db.view with parameters of type DecoratedKey Constructor Description ViewUpdateGenerator(View view, DecoratedKey basePartitionKey, int nowInSec)
Creates a newViewUpdateBuilder
. -
Uses of DecoratedKey in org.apache.cassandra.db.virtual
Fields in org.apache.cassandra.db.virtual with type parameters of type DecoratedKey Modifier and Type Field Description protected java.util.NavigableMap<DecoratedKey,AbstractVirtualTable.Partition>
AbstractVirtualTable.AbstractDataSet. partitions
Methods in org.apache.cassandra.db.virtual that return DecoratedKey Modifier and Type Method Description DecoratedKey
AbstractVirtualTable.Partition. key()
DecoratedKey
VirtualMutation. key()
Methods in org.apache.cassandra.db.virtual with parameters of type DecoratedKey Modifier and Type Method Description AbstractVirtualTable.DataSet
AbstractVirtualTable. data(DecoratedKey partitionKey)
Provide aAbstractVirtualTable.DataSet
that is potentially restricted to the provided partition - but is allowed to contain other partitions.AbstractVirtualTable.DataSet
InternodeInboundTable. data(DecoratedKey partitionKey)
AbstractVirtualTable.DataSet
InternodeOutboundTable. data(DecoratedKey partitionKey)
AbstractVirtualTable.Partition
AbstractVirtualTable.AbstractDataSet. getPartition(DecoratedKey key)
AbstractVirtualTable.Partition
AbstractVirtualTable.DataSet. getPartition(DecoratedKey partitionKey)
UnfilteredPartitionIterator
AbstractVirtualTable. select(DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, ColumnFilter columnFilter)
UnfilteredPartitionIterator
VirtualTable. select(DecoratedKey partitionKey, ClusteringIndexFilter clusteringIndexFilter, ColumnFilter columnFilter)
Selects the rows from a single partition.Constructors in org.apache.cassandra.db.virtual with parameters of type DecoratedKey Constructor Description VirtualMutation(java.lang.String keyspaceName, DecoratedKey partitionKey, com.google.common.collect.ImmutableMap<TableId,PartitionUpdate> modifications)
Constructor parameters in org.apache.cassandra.db.virtual with type arguments of type DecoratedKey Constructor Description AbstractDataSet(java.util.NavigableMap<DecoratedKey,AbstractVirtualTable.Partition> partitions)
-
Uses of DecoratedKey in org.apache.cassandra.dht
Methods in org.apache.cassandra.dht that return DecoratedKey Modifier and Type Method 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)
-
Uses of DecoratedKey in org.apache.cassandra.index
Methods in org.apache.cassandra.index with parameters of type DecoratedKey Modifier and Type Method Description Index.Indexer
Index. indexerFor(DecoratedKey key, RegularAndStaticColumns columns, int nowInSec, WriteContext ctx, IndexTransaction.Type transactionType)
Creates an newIndexer
object 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 indexCleanupTransaction
SecondaryIndexManager. newCleanupTransaction(DecoratedKey key, RegularAndStaticColumns regularAndStaticColumns, int nowInSec)
Transaction for use when removing partitions during cleanupCompactionTransaction
SecondaryIndexManager. newCompactionTransaction(DecoratedKey key, RegularAndStaticColumns regularAndStaticColumns, int versions, int nowInSec)
Transaction for use when merging rows during compaction -
Uses of DecoratedKey in org.apache.cassandra.index.internal
Fields in org.apache.cassandra.index.internal declared as DecoratedKey Modifier and Type Field Description DecoratedKey
IndexEntry. indexValue
Methods in org.apache.cassandra.index.internal with parameters of type DecoratedKey Modifier and Type Method 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, WriteContext ctx)
Specific to internal indexes, this is called by a searcher when it encounters a stale entry in the indexIndex.Indexer
CassandraIndex. indexerFor(DecoratedKey key, RegularAndStaticColumns columns, int nowInSec, WriteContext ctx, IndexTransaction.Type transactionType)
protected abstract UnfilteredPartitionIterator
CassandraIndexSearcher. queryDataFromIndex(DecoratedKey indexKey, RowIterator indexHits, ReadCommand command, ReadExecutionController executionController)
Constructors in org.apache.cassandra.index.internal with parameters of type DecoratedKey Constructor Description IndexEntry(DecoratedKey indexValue, Clustering<?> indexClustering, long timestamp, java.nio.ByteBuffer indexedKey, Clustering<?> indexedEntryClustering)
-
Uses of DecoratedKey in org.apache.cassandra.index.internal.composites
Methods in org.apache.cassandra.index.internal.composites with parameters of type DecoratedKey Modifier and Type Method 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)
-
Uses of DecoratedKey in org.apache.cassandra.index.internal.keys
Methods in org.apache.cassandra.index.internal.keys with parameters of type DecoratedKey Modifier and Type Method Description IndexEntry
KeysIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
protected UnfilteredPartitionIterator
KeysSearcher. queryDataFromIndex(DecoratedKey indexKey, RowIterator indexHits, ReadCommand command, ReadExecutionController executionController)
-
Uses of DecoratedKey in org.apache.cassandra.index.sasi
Methods in org.apache.cassandra.index.sasi with parameters of type DecoratedKey Modifier and Type Method Description Index.Indexer
SASIIndex. indexerFor(DecoratedKey key, RegularAndStaticColumns columns, int nowInSec, WriteContext context, IndexTransaction.Type transactionType)
-
Uses of DecoratedKey in org.apache.cassandra.index.sasi.conf
Methods in org.apache.cassandra.index.sasi.conf with parameters of type DecoratedKey Modifier and Type Method Description long
ColumnIndex. index(DecoratedKey key, Row row)
-
Uses of DecoratedKey in org.apache.cassandra.index.sasi.disk
Fields in org.apache.cassandra.index.sasi.disk with type parameters of type DecoratedKey Modifier and Type Field Description protected com.google.common.base.Function<java.lang.Long,DecoratedKey>
OnDiskIndex. keyFetcher
Methods in org.apache.cassandra.index.sasi.disk that return types with arguments of type DecoratedKey Modifier and Type Method Description java.util.Iterator<DecoratedKey>
TokenTree.OnDiskToken. iterator()
Methods in org.apache.cassandra.index.sasi.disk with parameters of type DecoratedKey Modifier and Type Method 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)
Method parameters in org.apache.cassandra.index.sasi.disk with type arguments of type DecoratedKey Modifier and Type Method 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 parameters in org.apache.cassandra.index.sasi.disk with type arguments of type DecoratedKey Constructor 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)
-
Uses of DecoratedKey in org.apache.cassandra.index.sasi.memory
Methods in org.apache.cassandra.index.sasi.memory that return types with arguments of type DecoratedKey Modifier and Type Method 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)
Methods in org.apache.cassandra.index.sasi.memory with parameters of type DecoratedKey Modifier and Type Method 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)
Method parameters in org.apache.cassandra.index.sasi.memory with type arguments of type DecoratedKey Modifier and Type Method 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 parameters in org.apache.cassandra.index.sasi.memory with type arguments of type DecoratedKey Constructor Description KeyRangeIterator(java.util.concurrent.ConcurrentSkipListSet<DecoratedKey> keys, int size)
-
Uses of DecoratedKey in org.apache.cassandra.index.sasi.plan
Methods in org.apache.cassandra.index.sasi.plan with parameters of type DecoratedKey Modifier and Type Method Description UnfilteredRowIterator
QueryController. getPartition(DecoratedKey key, ReadExecutionController executionController)
-
Uses of DecoratedKey in org.apache.cassandra.io.sstable
Fields in org.apache.cassandra.io.sstable declared as DecoratedKey Modifier and Type Field Description DecoratedKey
SSTable. first
DecoratedKey
SSTable. last
DecoratedKey
IndexSummaryBuilder.ReadableBoundary. lastKey
Methods in org.apache.cassandra.io.sstable that return DecoratedKey Modifier and Type Method 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()
Methods in org.apache.cassandra.io.sstable that return types with arguments of type DecoratedKey Modifier and Type Method Description Pair<DecoratedKey,DecoratedKey>
IndexSummary.IndexSummarySerializer. deserializeFirstLastKey(java.io.DataInputStream in, IPartitioner partitioner)
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)
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.Methods in org.apache.cassandra.io.sstable with parameters of type DecoratedKey Modifier and Type Method 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)
Constructors in org.apache.cassandra.io.sstable with parameters of type DecoratedKey Constructor 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)
-
Uses of DecoratedKey in org.apache.cassandra.io.sstable.format
Fields in org.apache.cassandra.io.sstable.format declared as DecoratedKey Modifier and Type Field Description protected DecoratedKey
SSTableReaderBuilder. first
protected DecoratedKey
SSTableReaderBuilder. last
Methods in org.apache.cassandra.io.sstable.format that return DecoratedKey Modifier and Type Method 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)
Methods in org.apache.cassandra.io.sstable.format that return types with arguments of type DecoratedKey Modifier and Type Method Description java.lang.Iterable<DecoratedKey>
SSTableReader. getKeySamples(Range<Token> range)
Methods in org.apache.cassandra.io.sstable.format with parameters of type DecoratedKey Modifier and Type Method 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, SSTableReadsListener listener)
abstract UnfilteredRowIterator
SSTableReader. iterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter selectedColumns, boolean reversed)
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 (seeSSTableFlushObserver.nextUnfilteredCluster(Unfiltered)
). -
Uses of DecoratedKey in org.apache.cassandra.io.sstable.format.big
Methods in org.apache.cassandra.io.sstable.format.big with parameters of type DecoratedKey Modifier and Type Method 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 writtenUnfilteredRowIterator
BigTableReader. iterator(DecoratedKey key, Slices slices, ColumnFilter selectedColumns, boolean reversed, SSTableReadsListener listener)
UnfilteredRowIterator
BigTableReader. iterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter selectedColumns, boolean reversed)
UnfilteredRowIterator
BigTableReader. simpleIterator(FileDataInput dfile, DecoratedKey key, RowIndexEntry position, boolean tombstoneOnly)
-
Uses of DecoratedKey in org.apache.cassandra.locator
Methods in org.apache.cassandra.locator that return DecoratedKey Modifier and Type Method Description DecoratedKey
TokenMetadata. decorateKey(java.nio.ByteBuffer key)
Methods in org.apache.cassandra.locator with parameters of type DecoratedKey Modifier and Type Method Description static ReplicaPlan.ForPaxosWrite
ReplicaPlans. forPaxos(Keyspace keyspace, DecoratedKey key, ConsistencyLevel consistencyForPaxos)
Construct the plan for a paxos round - NOT the write or read consistency level for either the write or comparison, but for the paxos linearisation agreement. -
Uses of DecoratedKey in org.apache.cassandra.service
Methods in org.apache.cassandra.service with parameters of type DecoratedKey Modifier and Type Method Description static RowIterator
StorageProxy. cas(java.lang.String keyspaceName, java.lang.String cfName, DecoratedKey key, CASRequest request, ConsistencyLevel consistencyForPaxos, ConsistencyLevel consistencyForCommit, ClientState state, int nowInSeconds, long queryStartNanoTime)
Apply @param updates if and only if the current values in the row for @param key match the provided @param conditions. -
Uses of DecoratedKey in org.apache.cassandra.service.pager
Methods in org.apache.cassandra.service.pager with parameters of type DecoratedKey Modifier and Type Method Description 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)
Constructors in org.apache.cassandra.service.pager with parameters of type DecoratedKey Constructor Description PartitionRangeQueryPager(PartitionRangeReadQuery query, ProtocolVersion protocolVersion, DecoratedKey lastReturnedKey, PagingState.RowMark lastReturnedRow, int remaining, int remainingInPartition)
-
Uses of DecoratedKey in org.apache.cassandra.service.paxos
Methods in org.apache.cassandra.service.paxos with parameters of type DecoratedKey Modifier and Type Method Description static Commit
Commit. emptyCommit(DecoratedKey key, TableMetadata metadata)
static Commit
Commit. newPrepare(DecoratedKey key, TableMetadata metadata, java.util.UUID ballot)
Constructors in org.apache.cassandra.service.paxos with parameters of type DecoratedKey Constructor Description PaxosState(DecoratedKey key, TableMetadata metadata)
PrepareCallback(DecoratedKey key, TableMetadata metadata, int targets, ConsistencyLevel consistency, long queryStartNanoTime)
-
Uses of DecoratedKey in org.apache.cassandra.service.reads
Methods in org.apache.cassandra.service.reads that return DecoratedKey Modifier and Type Method Description DecoratedKey
AbstractReadExecutor. getKey()
-
Uses of DecoratedKey in org.apache.cassandra.service.reads.repair
Methods in org.apache.cassandra.service.reads.repair with parameters of type DecoratedKey Modifier and Type Method Description UnfilteredRowIterators.MergeListener
PartitionIteratorMergeListener. getRowMergeListener(DecoratedKey partitionKey, java.util.List<UnfilteredRowIterator> versions)
void
BlockingReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
NoopReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
ReadOnlyReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
void
ReadRepair. repairPartition(DecoratedKey partitionKey, java.util.Map<Replica,Mutation> mutations, ReplicaPlan.ForTokenWrite writePlan)
Repairs a partition _after_ receiving data responses.Constructors in org.apache.cassandra.service.reads.repair with parameters of type DecoratedKey Constructor Description BlockingPartitionRepair(DecoratedKey key, java.util.Map<Replica,Mutation> repairs, ReplicaPlan.ForTokenWrite writePlan)
BlockingPartitionRepair(DecoratedKey key, java.util.Map<Replica,Mutation> repairs, ReplicaPlan.ForTokenWrite writePlan, java.util.function.Predicate<InetAddressAndPort> shouldBlockOn)
RowIteratorMergeListener(DecoratedKey partitionKey, RegularAndStaticColumns columns, boolean isReversed, ReplicaPlan.ForRead<E> readPlan, ReadCommand command, ReadRepair readRepair)
-
Uses of DecoratedKey in org.apache.cassandra.tools
Method parameters in org.apache.cassandra.tools with type arguments of type DecoratedKey Modifier and Type Method Description static void
JsonTransformer. keysToJson(ISSTableScanner currentScanner, java.util.stream.Stream<DecoratedKey> keys, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
-
Uses of DecoratedKey in org.apache.cassandra.utils
Method parameters in org.apache.cassandra.utils with type arguments of type DecoratedKey Modifier and Type Method Description static void
FBUtilities. sortSampledKeys(java.util.List<DecoratedKey> keys, Range<Token> range)
-
Uses of DecoratedKey in org.apache.cassandra.utils.memory
Methods in org.apache.cassandra.utils.memory that return DecoratedKey Modifier and Type Method Description abstract DecoratedKey
EnsureOnHeap. applyToPartitionKey(DecoratedKey key)
DecoratedKey
ByteBufferCloner. clone(DecoratedKey key)
DecoratedKey
Cloner. clone(DecoratedKey key)
Clones the specified key.DecoratedKey
NativeAllocator. clone(DecoratedKey key, OpOrder.Group writeOp)
Methods in org.apache.cassandra.utils.memory with parameters of type DecoratedKey Modifier and Type Method Description abstract DecoratedKey
EnsureOnHeap. applyToPartitionKey(DecoratedKey key)
DecoratedKey
ByteBufferCloner. clone(DecoratedKey key)
DecoratedKey
Cloner. clone(DecoratedKey key)
Clones the specified key.DecoratedKey
NativeAllocator. clone(DecoratedKey key, OpOrder.Group writeOp)
-