|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of DecoratedKey in org.apache.cassandra.cache |
---|
Constructors in org.apache.cassandra.cache with parameters of type DecoratedKey | |
---|---|
RowCacheKey(java.util.UUID cfId,
DecoratedKey key)
|
Uses of DecoratedKey in org.apache.cassandra.db |
---|
Fields in org.apache.cassandra.db declared as DecoratedKey | |
---|---|
DecoratedKey |
Row.key
|
DecoratedKey |
SliceQueryPager.key
|
Fields in org.apache.cassandra.db with type parameters of type DecoratedKey | |
---|---|
static java.util.Comparator<DecoratedKey> |
DecoratedKey.comparator
|
Methods in org.apache.cassandra.db that return types with arguments of type DecoratedKey | |
---|---|
java.util.Iterator<java.util.Map.Entry<DecoratedKey,ColumnFamily>> |
Memtable.getEntryIterator(RowPosition startWith,
RowPosition stopAt)
|
static java.util.Map<DecoratedKey,ColumnFamily> |
SystemTable.getSchema(java.lang.String cfName)
|
java.lang.Iterable<DecoratedKey> |
ColumnFamilyStore.keySamples(Range<Token> range)
|
Methods in org.apache.cassandra.db with parameters of type DecoratedKey | |
---|---|
void |
ColumnFamilyStore.apply(DecoratedKey key,
ColumnFamily columnFamily,
SecondaryIndexManager.Updater indexer)
Insert/Update the column family for this key. |
boolean |
ColumnFamilyStore.containsCachedRow(DecoratedKey key)
|
ColumnFamily |
Memtable.getColumnFamily(DecoratedKey key)
|
ColumnFamily |
ColumnFamilyStore.getColumnFamily(DecoratedKey key,
QueryPath path,
java.nio.ByteBuffer start,
java.nio.ByteBuffer finish,
boolean reversed,
int limit)
|
static OnDiskAtomIterator |
Memtable.getNamesIterator(DecoratedKey key,
ColumnFamily cf,
NamesQueryFilter filter)
|
ColumnFamily |
ColumnFamilyStore.getRawCachedRow(DecoratedKey key)
|
static OnDiskAtomIterator |
Memtable.getSliceIterator(DecoratedKey key,
ColumnFamily cf,
SliceQueryFilter filter)
obtain an iterator of columns in this memtable in the specified order starting from a given column. |
static void |
Table.indexRow(DecoratedKey key,
ColumnFamilyStore cfs,
java.util.Set<java.lang.String> idxNames)
|
void |
ColumnFamilyStore.invalidateCachedRow(DecoratedKey key)
|
ColumnFamilyStore.ViewFragment |
ColumnFamilyStore.markReferenced(DecoratedKey key)
|
void |
ColumnFamilyStore.maybeUpdateRowCache(DecoratedKey key,
ColumnFamily columnFamily)
|
static void |
CounterColumn.mergeAndRemoveOldShards(DecoratedKey key,
ColumnFamily cf,
int gcBefore,
int mergeBefore)
|
static void |
CounterColumn.mergeAndRemoveOldShards(DecoratedKey key,
ColumnFamily cf,
int gcBefore,
int mergeBefore,
boolean sendToOtherReplica)
There is two phase to the removal of old shards. |
Constructors in org.apache.cassandra.db with parameters of type DecoratedKey | |
---|---|
Row(DecoratedKey key,
ColumnFamily cf)
|
|
SliceQueryPager(ColumnFamilyStore cfs,
DecoratedKey key,
ColumnSlice[] slices)
|
Uses of DecoratedKey in org.apache.cassandra.db.columniterator |
---|
Fields in org.apache.cassandra.db.columniterator declared as DecoratedKey | |
---|---|
DecoratedKey |
SSTableNamesIterator.key
|
Methods in org.apache.cassandra.db.columniterator that return DecoratedKey | |
---|---|
DecoratedKey |
LazyColumnIterator.getKey()
|
DecoratedKey |
OnDiskAtomIterator.getKey()
|
DecoratedKey |
SSTableNamesIterator.getKey()
|
DecoratedKey |
SSTableSliceIterator.getKey()
|
Constructors in org.apache.cassandra.db.columniterator with parameters of type DecoratedKey | |
---|---|
LazyColumnIterator(DecoratedKey key,
IColumnIteratorFactory subIteratorFactory)
|
|
SSTableNamesIterator(SSTableReader sstable,
DecoratedKey key,
java.util.SortedSet<java.nio.ByteBuffer> columns)
|
|
SSTableNamesIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
java.util.SortedSet<java.nio.ByteBuffer> columns,
RowIndexEntry indexEntry)
|
|
SSTableSliceIterator(SSTableReader sstable,
DecoratedKey key,
ColumnSlice[] slices,
boolean reversed)
|
|
SSTableSliceIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
ColumnSlice[] slices,
boolean reversed,
RowIndexEntry indexEntry)
An iterator for a slice within an SSTable |
Uses of DecoratedKey in org.apache.cassandra.db.compaction |
---|
Fields in org.apache.cassandra.db.compaction declared as DecoratedKey | |
---|---|
DecoratedKey |
AbstractCompactedRow.key
|
Methods in org.apache.cassandra.db.compaction with parameters of type DecoratedKey | |
---|---|
void |
CompactionController.invalidateCachedRow(DecoratedKey key)
|
static ColumnFamily |
PrecompactedRow.removeDeletedAndOldShards(DecoratedKey key,
boolean shouldPurge,
CompactionController controller,
ColumnFamily cf)
|
static ColumnFamily |
PrecompactedRow.removeDeletedAndOldShards(DecoratedKey key,
CompactionController controller,
ColumnFamily cf)
|
void |
CompactionController.removeDeletedInCache(DecoratedKey key)
|
boolean |
CompactionController.shouldPurge(DecoratedKey key,
long maxDeletionTimestamp)
|
Constructors in org.apache.cassandra.db.compaction with parameters of type DecoratedKey | |
---|---|
AbstractCompactedRow(DecoratedKey key)
|
|
PrecompactedRow(DecoratedKey key,
ColumnFamily cf)
it is caller's responsibility to call removeDeleted + removeOldShards from the cf before calling this constructor |
Uses of DecoratedKey in org.apache.cassandra.db.filter |
---|
Fields in org.apache.cassandra.db.filter declared as DecoratedKey | |
---|---|
DecoratedKey |
QueryFilter.key
|
Methods in org.apache.cassandra.db.filter with parameters of type DecoratedKey | |
---|---|
static QueryFilter |
QueryFilter.getIdentityFilter(DecoratedKey key,
QueryPath path)
return a QueryFilter object that includes every column in the row. |
OnDiskAtomIterator |
IDiskAtomFilter.getMemtableColumnIterator(ColumnFamily cf,
DecoratedKey key)
returns an iterator that returns columns from the given memtable matching the Filter criteria in sorted order. |
OnDiskAtomIterator |
NamesQueryFilter.getMemtableColumnIterator(ColumnFamily cf,
DecoratedKey key)
|
OnDiskAtomIterator |
QueryFilter.getMemtableColumnIterator(ColumnFamily cf,
DecoratedKey key)
|
OnDiskAtomIterator |
SliceQueryFilter.getMemtableColumnIterator(ColumnFamily cf,
DecoratedKey key)
|
static QueryFilter |
QueryFilter.getNamesFilter(DecoratedKey key,
QueryPath path,
java.nio.ByteBuffer column)
convenience method for creating a name filter matching a single column |
static QueryFilter |
QueryFilter.getNamesFilter(DecoratedKey key,
QueryPath path,
java.util.SortedSet<java.nio.ByteBuffer> columns)
|
static QueryFilter |
QueryFilter.getSliceFilter(DecoratedKey key,
QueryPath path,
java.nio.ByteBuffer start,
java.nio.ByteBuffer finish,
boolean reversed,
int limit)
|
ISSTableColumnIterator |
IDiskAtomFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key)
returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order. |
ISSTableColumnIterator |
NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key)
|
ISSTableColumnIterator |
SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
DecoratedKey key)
|
ISSTableColumnIterator |
IDiskAtomFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry)
Get an iterator that returns columns from the given SSTable using the opened file matching the Filter criteria in sorted order. |
ISSTableColumnIterator |
NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry)
|
ISSTableColumnIterator |
QueryFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry)
|
ISSTableColumnIterator |
SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable,
FileDataInput file,
DecoratedKey key,
RowIndexEntry indexEntry)
|
Constructors in org.apache.cassandra.db.filter with parameters of type DecoratedKey | |
---|---|
QueryFilter(DecoratedKey key,
QueryPath path,
IDiskAtomFilter filter)
|
Uses of DecoratedKey in org.apache.cassandra.db.index |
---|
Methods in org.apache.cassandra.db.index that return DecoratedKey | |
---|---|
DecoratedKey |
SecondaryIndex.getIndexKeyFor(java.nio.ByteBuffer value)
Returns the decoratedKey for a column value |
Methods in org.apache.cassandra.db.index with parameters of type DecoratedKey | |
---|---|
abstract void |
PerRowSecondaryIndex.delete(DecoratedKey key)
cleans up deleted columns from cassandra cleanup compaction |
void |
SecondaryIndexManager.deleteFromIndexes(DecoratedKey key,
java.util.List<IColumn> indexedColumnsInRow)
Delete all columns from all indexes for this row. |
SecondaryIndexManager.Updater |
SecondaryIndexManager.updaterFor(DecoratedKey key,
boolean includeRowIndexes)
This helper acts as a closure around the indexManager and row key to ensure that down in Memtable's ColumnFamily implementation, the index can get updated. |
Uses of DecoratedKey in org.apache.cassandra.dht |
---|
Methods in org.apache.cassandra.dht that return DecoratedKey | |
---|---|
DecoratedKey |
AbstractByteOrderedPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
|
DecoratedKey |
IPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
Deprecated. Used by SSTables before version 'e'. Convert the on disk representation to a DecoratedKey object |
DecoratedKey |
LocalPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
|
DecoratedKey |
Murmur3Partitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
|
DecoratedKey |
OrderPreservingPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
|
DecoratedKey |
RandomPartitioner.convertFromDiskFormat(java.nio.ByteBuffer fromdisk)
|
DecoratedKey |
AbstractByteOrderedPartitioner.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.io.sstable |
---|
Fields in org.apache.cassandra.io.sstable declared as DecoratedKey | |
---|---|
protected DecoratedKey |
AbstractSSTableSimpleWriter.currentKey
|
DecoratedKey |
SSTable.first
|
DecoratedKey |
SSTable.last
|
protected DecoratedKey |
SSTableScanner.FilteredKeyScanningIterator.nextKey
|
Methods in org.apache.cassandra.io.sstable that return DecoratedKey | |
---|---|
protected DecoratedKey |
KeyIterator.computeNext()
|
DecoratedKey |
SSTableReader.decodeKey(java.nio.ByteBuffer bytes)
|
static DecoratedKey |
SSTableReader.decodeKey(IPartitioner p,
Descriptor d,
java.nio.ByteBuffer bytes)
Conditionally use the deprecated 'IPartitioner.convertFromDiskFormat' method. |
DecoratedKey |
SSTableIdentityIterator.getKey()
|
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()
|
Methods in org.apache.cassandra.io.sstable that return types with arguments of type DecoratedKey | |
---|---|
java.util.List<DecoratedKey> |
IndexSummary.getKeys()
|
java.util.Collection<DecoratedKey> |
SSTableReader.getKeySamples()
|
java.lang.Iterable<DecoratedKey> |
SSTableReader.getKeySamples(Range<Token> range)
|
Methods in org.apache.cassandra.io.sstable with parameters of type DecoratedKey | |
---|---|
void |
IndexSummary.addEntry(DecoratedKey key,
long indexPosition)
|
void |
SSTableWriter.append(DecoratedKey decoratedKey,
ColumnFamily cf)
|
long |
SSTableWriter.appendFromStream(DecoratedKey key,
CFMetaData metadata,
long dataSize,
java.io.DataInput in)
|
void |
SSTableReader.cacheKey(DecoratedKey key,
RowIndexEntry info)
|
RowIndexEntry |
SSTableReader.getCachedPosition(DecoratedKey key,
boolean updateStats)
|
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. |
void |
IndexSummary.maybeAddEntry(DecoratedKey decoratedKey,
long indexPosition)
|
protected abstract void |
AbstractSSTableSimpleWriter.writeRow(DecoratedKey key,
ColumnFamily columnFamily)
|
protected void |
SSTableSimpleUnsortedWriter.writeRow(DecoratedKey key,
ColumnFamily columnFamily)
|
protected void |
SSTableSimpleWriter.writeRow(DecoratedKey key,
ColumnFamily columnFamily)
|
Constructors in org.apache.cassandra.io.sstable with parameters of type DecoratedKey | |
---|---|
SSTableIdentityIterator(CFMetaData metadata,
java.io.DataInput file,
java.lang.String filename,
DecoratedKey key,
long dataStart,
long dataSize,
IColumnSerializer.Flag flag)
|
|
SSTableIdentityIterator(SSTableReader sstable,
RandomAccessReader file,
DecoratedKey key,
long dataStart,
long dataSize)
Used to iterate through the columns of a row. |
|
SSTableIdentityIterator(SSTableReader sstable,
RandomAccessReader file,
DecoratedKey key,
long dataStart,
long dataSize,
boolean checkData)
Used to iterate through the columns of a row. |
Uses of DecoratedKey in org.apache.cassandra.service |
---|
Fields in org.apache.cassandra.service declared as DecoratedKey | |
---|---|
protected DecoratedKey |
AbstractRowResolver.key
|
Methods in org.apache.cassandra.service with parameters of type DecoratedKey | |
---|---|
static java.util.List<IAsyncResult> |
RowDataResolver.scheduleRepairs(ColumnFamily resolved,
java.lang.String table,
DecoratedKey key,
java.util.List<ColumnFamily> versions,
java.util.List<java.net.InetAddress> endpoints)
For each row version, compare with resolved (the superset of all row versions); if it is missing anything, send a mutation to the endpoint it come from. |
Constructors in org.apache.cassandra.service with parameters of type DecoratedKey | |
---|---|
DigestMismatchException(DecoratedKey key,
java.nio.ByteBuffer digest1,
java.nio.ByteBuffer digest2)
|
Uses of DecoratedKey in org.apache.cassandra.thrift |
---|
Methods in org.apache.cassandra.thrift that return types with arguments of type DecoratedKey | |
---|---|
protected java.util.Map<DecoratedKey,ColumnFamily> |
CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level)
|
Uses of DecoratedKey in org.apache.cassandra.utils |
---|
Method parameters in org.apache.cassandra.utils with type arguments of type DecoratedKey | |
---|---|
static void |
FBUtilities.sortSampledKeys(java.util.List<DecoratedKey> keys,
Range<Token> range)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |