Constructor and Description |
---|
RowCacheKey(java.util.UUID cfId,
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.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) |
static UntypedResultSet.Row |
UntypedResultSet.Row.fromInternalRow(CFMetaData metadata,
DecoratedKey key,
Row row) |
Row |
UpdateParameters.getPrefetchedRow(DecoratedKey key,
Clustering clustering) |
Constructor and Description |
---|
UpdateParameters(CFMetaData metadata,
PartitionColumns updatedColumns,
QueryOptions options,
long timestamp,
int ttl,
java.util.Map<DecoratedKey,Partition> prefetchedRows,
boolean validateIndexedColumns) |
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) |
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 for thrift.
|
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,
ColumnFilter columnFilter,
ClusteringIndexFilter filter)
Creates a new read command on a single partition.
|
static SinglePartitionReadCommand |
SinglePartitionSliceCommand.create(CFMetaData metadata,
int nowInSec,
DecoratedKey key,
Slice slice)
Creates a new single partition slice command for the provided single slice.
|
static SinglePartitionReadCommand |
SinglePartitionSliceCommand.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) |
static void |
Keyspace.indexPartition(DecoratedKey key,
ColumnFamilyStore cfs,
java.util.Set<Index> indexes) |
void |
ColumnFamilyStore.invalidateCachedPartition(DecoratedKey key) |
static PaxosState |
SystemKeyspace.loadPaxosState(DecoratedKey key,
CFMetaData metadata) |
void |
ColumnFamilyStore.maybeUpdateRowCache(DecoratedKey key) |
static UnfilteredRowIterator |
LegacyLayout.onWireCellstoUnfilteredRowIterator(CFMetaData metadata,
DecoratedKey key,
LegacyLayout.LegacyDeletionInfo delInfo,
java.util.Iterator<LegacyLayout.LegacyCell> cells,
boolean reversed,
SerializationHelper helper) |
boolean |
PartitionRangeReadCommand.selects(DecoratedKey partitionKey,
Clustering clustering) |
abstract boolean |
ReadCommand.selects(DecoratedKey partitionKey,
Clustering clustering)
Whether the provided row, identified by its primary key components, is selected by
this read command.
|
boolean |
SinglePartitionReadCommand.selects(DecoratedKey partitionKey,
Clustering clustering) |
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) |
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) |
SinglePartitionBuilder(ColumnFamilyStore cfs,
DecoratedKey key) |
SinglePartitionNamesCommand(boolean isDigest,
int digestVersion,
boolean isForThrift,
CFMetaData metadata,
int nowInSec,
ColumnFilter columnFilter,
RowFilter rowFilter,
DataLimits limits,
DecoratedKey partitionKey,
ClusteringIndexNamesFilter clusteringIndexFilter) |
SinglePartitionNamesCommand(CFMetaData metadata,
int nowInSec,
ColumnFilter columnFilter,
RowFilter rowFilter,
DataLimits limits,
DecoratedKey partitionKey,
ClusteringIndexNamesFilter clusteringIndexFilter) |
SinglePartitionReadCommand(boolean isDigest,
int digestVersion,
boolean isForThrift,
CFMetaData metadata,
int nowInSec,
ColumnFilter columnFilter,
RowFilter rowFilter,
DataLimits limits,
DecoratedKey partitionKey,
F clusteringIndexFilter) |
SinglePartitionSliceBuilder(ColumnFamilyStore cfs,
DecoratedKey key) |
SinglePartitionSliceCommand(boolean isDigest,
int digestVersion,
boolean isForThrift,
CFMetaData metadata,
int nowInSec,
ColumnFilter columnFilter,
RowFilter rowFilter,
DataLimits limits,
DecoratedKey partitionKey,
ClusteringIndexSliceFilter clusteringIndexFilter) |
SinglePartitionSliceCommand(CFMetaData metadata,
int nowInSec,
ColumnFilter columnFilter,
RowFilter rowFilter,
DataLimits limits,
DecoratedKey partitionKey,
ClusteringIndexSliceFilter clusteringIndexFilter) |
Constructor and Description |
---|
SSTableIterator(SSTableReader sstable,
DecoratedKey key,
ColumnFilter columns,
boolean isForThrift) |
SSTableIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry,
ColumnFilter columns,
boolean isForThrift) |
SSTableReversedIterator(SSTableReader sstable,
DecoratedKey key,
ColumnFilter columns,
boolean isForThrift) |
SSTableReversedIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry,
ColumnFilter columns,
boolean isForThrift) |
Modifier and Type | Method and Description |
---|---|
void |
CompactionController.invalidateCachedPartition(DecoratedKey key) |
long |
CompactionController.maxPurgeableTimestamp(DecoratedKey key) |
long |
SSTableSplitter.SplitController.maxPurgeableTimestamp(DecoratedKey key) |
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 java.nio.ByteBuffer |
RowFilter.Expression.getValue(DecoratedKey partitionKey,
Row row) |
abstract boolean |
RowFilter.Expression.isSatisfiedBy(DecoratedKey partitionKey,
Row row)
Returns whether the provided row satisfied this expression or not.
|
void |
DataLimits.Counter.newPartition(DecoratedKey partitionKey,
Row staticRow) |
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 |
Partition.partitionKey() |
Modifier and Type | Method and Description |
---|---|
protected RangeTombstoneMarker |
AlteringUnfilteredPartitionIterator.computeNext(DecoratedKey partitionKey,
RangeTombstoneMarker marker) |
protected Row |
AlteringUnfilteredPartitionIterator.computeNext(DecoratedKey partitionKey,
Row row) |
protected Row |
AlteringUnfilteredPartitionIterator.computeNextStatic(DecoratedKey partitionKey,
Row row) |
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 |
PurgingPartitionIterator.onEmptyPartitionPostPurge(DecoratedKey partitionKey) |
protected void |
PurgingPartitionIterator.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 |
LazilyInitializedUnfilteredRowIterator.partitionKey() |
DecoratedKey |
RowIterator.partitionKey()
The partition key of the partition this in an iterator over.
|
DecoratedKey |
UnfilteredRowIterator.partitionKey()
The partition key of the partition this in an iterator over.
|
DecoratedKey |
WrappingRowIterator.partitionKey() |
DecoratedKey |
WrappingUnfilteredRowIterator.partitionKey() |
Modifier and Type | Method and Description |
---|---|
static RowIterator |
RowIterators.emptyIterator(CFMetaData cfm,
DecoratedKey partitionKey,
boolean isReverseOrder) |
static UnfilteredRowIterator |
UnfilteredRowIterators.emptyIterator(CFMetaData cfm,
DecoratedKey partitionKey,
boolean isReverseOrder) |
static RowIterator |
RowIterators.iterator(CFMetaData cfm,
DecoratedKey partitionKey,
boolean isReverseOrder,
java.util.Iterator<Row> iterator) |
static UnfilteredRowIterator |
UnfilteredRowIterators.noRowsIterator(CFMetaData cfm,
DecoratedKey partitionKey,
Row staticRow,
DeletionTime partitionDeletion,
boolean isReverseOrder)
Returns an empty atom 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) |
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,
int nowInSec,
OpOrder.Group opGroup,
IndexTransaction.Type transactionType)
Factory method for write time event handlers.
|
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,
int nowInSec,
OpOrder.Group opGroup,
IndexTransaction.Type transactionType) |
protected abstract UnfilteredPartitionIterator |
CassandraIndexSearcher.queryDataFromIndex(DecoratedKey indexKey,
RowIterator indexHits,
ReadCommand command,
ReadOrderGroup orderGroup) |
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,
ReadOrderGroup orderGroup) |
Modifier and Type | Method and Description |
---|---|
IndexEntry |
KeysIndex.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
protected UnfilteredPartitionIterator |
KeysSearcher.queryDataFromIndex(DecoratedKey indexKey,
RowIterator indexHits,
ReadCommand command,
ReadOrderGroup orderGroup) |
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 |
---|---|
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,
RandomAccessReader file,
DecoratedKey key)
Used to iterate through the columns of a row.
|
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.
|
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 SliceableUnfilteredRowIterator |
SSTableReader.iterator(DecoratedKey key,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift) |
abstract SliceableUnfilteredRowIterator |
SSTableReader.iterator(FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift) |
static void |
SSTableReader.saveSummary(Descriptor descriptor,
DecoratedKey first,
DecoratedKey last,
SegmentedFile.Builder ibuilder,
SegmentedFile.Builder dbuilder,
IndexSummary summary)
Save index summary to Summary.db file.
|
Modifier and Type | Method and Description |
---|---|
SliceableUnfilteredRowIterator |
BigTableReader.iterator(DecoratedKey key,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift) |
SliceableUnfilteredRowIterator |
BigTableReader.iterator(FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry,
ColumnFilter selectedColumns,
boolean reversed,
boolean isForThrift) |
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)
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)
Convenience method that count (live) cells/rows for a given slice of a row, but page underneath.
|
protected boolean |
RangeNamesQueryPager.isPreviouslyReturnedPartition(DecoratedKey key) |
protected boolean |
RangeSliceQueryPager.isPreviouslyReturnedPartition(DecoratedKey key) |
protected boolean |
SinglePartitionPager.isPreviouslyReturnedPartition(DecoratedKey key) |
protected void |
RangeNamesQueryPager.recordLast(DecoratedKey key,
Row last) |
protected void |
RangeSliceQueryPager.recordLast(DecoratedKey key,
Row last) |
protected void |
SinglePartitionPager.recordLast(DecoratedKey key,
Row last) |
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) |
Modifier and Type | Method and Description |
---|---|
DecoratedKey |
StreamReader.StreamDeserializer.newPartition() |
DecoratedKey |
StreamReader.StreamDeserializer.partitionKey() |
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 |
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 |
MemtableAllocator.clone(DecoratedKey key,
OpOrder.Group opGroup) |
DecoratedKey |
MemtableBufferAllocator.clone(DecoratedKey key,
OpOrder.Group writeOp) |
DecoratedKey |
NativeAllocator.clone(DecoratedKey key,
OpOrder.Group writeOp) |
MemtableAllocator.DataReclaimer |
MemtableAllocator.DataReclaimer.reclaimImmediately(DecoratedKey key) |
Copyright © 2015 The Apache Software Foundation