Uses of Class
org.apache.cassandra.db.DecoratedKey

Packages that use DecoratedKey
org.apache.cassandra.cache   
org.apache.cassandra.db   
org.apache.cassandra.db.columniterator   
org.apache.cassandra.db.compaction   
org.apache.cassandra.db.filter   
org.apache.cassandra.db.index   
org.apache.cassandra.db.index.keys   
org.apache.cassandra.dht   
org.apache.cassandra.io.sstable   
org.apache.cassandra.service   
org.apache.cassandra.thrift   
org.apache.cassandra.utils   
 

Uses of DecoratedKey in org.apache.cassandra.cache
 

Classes in org.apache.cassandra.cache with type parameters of type DecoratedKey
 class AutoSavingKeyCache<K extends Pair<Descriptor,DecoratedKey>,V>
           
 class AutoSavingRowCache<K extends DecoratedKey,V>
           
 

Methods in org.apache.cassandra.cache that return types with arguments of type DecoratedKey
 ICache<DecoratedKey,ColumnFamily> ConcurrentLinkedHashCacheProvider.create(int capacity, java.lang.String tableName, java.lang.String cfName)
           
 ICache<DecoratedKey,ColumnFamily> IRowCacheProvider.create(int capacity, java.lang.String tableName, java.lang.String cfName)
           
 ICache<DecoratedKey,ColumnFamily> SerializingCacheProvider.create(int capacity, java.lang.String tableName, java.lang.String cfName)
           
 java.util.Set<DecoratedKey> AutoSavingCache.readSaved()
           
 

Uses of DecoratedKey in org.apache.cassandra.db
 

Fields in org.apache.cassandra.db declared as DecoratedKey
 DecoratedKey<?> Row.key
           
 

Fields in org.apache.cassandra.db with type parameters of type DecoratedKey
static java.util.Comparator<DecoratedKey> DecoratedKey.comparator
           
 AutoSavingCache<Pair<Descriptor,DecoratedKey>,java.lang.Long> ColumnFamilyStore.keyCache
           
 AutoSavingCache<DecoratedKey,ColumnFamily> ColumnFamilyStore.rowCache
           
 

Methods in org.apache.cassandra.db that return types with arguments of type DecoratedKey
 java.lang.Iterable<DecoratedKey> ColumnFamilyStore.allKeySamples()
           
 java.util.Iterator<java.util.Map.Entry<DecoratedKey,ColumnFamily>> Memtable.getEntryIterator(DecoratedKey startWith)
           
 AutoSavingCache<Pair<Descriptor,DecoratedKey>,java.lang.Long> ColumnFamilyStore.getKeyCache()
           
 AutoSavingCache<Pair<Descriptor,DecoratedKey>,java.lang.Long> DataTracker.getKeyCache()
           
 java.lang.Iterable<DecoratedKey> ColumnFamilyStore.keySamples(Range range)
           
 

Methods in org.apache.cassandra.db with parameters of type DecoratedKey
 void ColumnFamilyStore.apply(DecoratedKey key, ColumnFamily columnFamily)
          Insert/Update the column family for this key.
 int DecoratedKey.compareTo(DecoratedKey other)
           
 ColumnFamily Memtable.getColumnFamily(DecoratedKey key)
           
 ColumnFamily ColumnFamilyStore.getColumnFamily(DecoratedKey key, QueryPath path, java.nio.ByteBuffer start, java.nio.ByteBuffer finish, boolean reversed, int limit)
           
 java.util.Iterator<java.util.Map.Entry<DecoratedKey,ColumnFamily>> Memtable.getEntryIterator(DecoratedKey startWith)
           
static CloseableIterator<Row> RowIteratorFactory.getIterator(java.lang.Iterable<Memtable> memtables, java.util.Collection<SSTableReader> sstables, DecoratedKey startWith, DecoratedKey stopAt, QueryFilter filter, AbstractType comparator, ColumnFamilyStore cfs)
          Get a row iterator over the provided memtables and sstables, between the provided keys and filtered by the queryfilter.
static CloseableIterator<Row> RowIteratorFactory.getIterator(java.lang.Iterable<Memtable> memtables, java.util.Collection<SSTableReader> sstables, DecoratedKey startWith, DecoratedKey stopAt, QueryFilter filter, AbstractType comparator, ColumnFamilyStore cfs)
          Get a row iterator over the provided memtables and sstables, between the provided keys and filtered by the queryfilter.
static IColumnIterator Memtable.getNamesIterator(DecoratedKey key, ColumnFamily cf, NamesQueryFilter filter)
           
 ColumnFamily ColumnFamilyStore.getRawCachedRow(DecoratedKey key)
          raw cached row -- does not fetch the row if it is not present.
static IColumnIterator Memtable.getSliceIterator(DecoratedKey key, ColumnFamily cf, SliceQueryFilter filter, AbstractType typeComparator)
          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.SortedSet<java.nio.ByteBuffer> indexedColumns)
           
 void ColumnFamilyStore.invalidateCachedRow(DecoratedKey key)
           
 boolean ColumnFamilyStore.isKeyInRemainingSSTables(DecoratedKey key, java.util.Set<? extends SSTable> sstablesToIgnore)
          Uses bloom filters to check if key may be present in any sstable in this ColumnFamilyStore, minus a set of provided ones.
 ColumnFamilyStore.ViewFragment ColumnFamilyStore.markReferenced(DecoratedKey key)
           
 ColumnFamilyStore.ViewFragment ColumnFamilyStore.markReferenced(DecoratedKey startWith, DecoratedKey stopAt)
           
 ColumnFamilyStore.ViewFragment ColumnFamilyStore.markReferenced(DecoratedKey startWith, DecoratedKey stopAt)
           
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.
 void ColumnFamilyStore.updateRowCache(DecoratedKey key, ColumnFamily columnFamily)
           
 

Constructors in org.apache.cassandra.db with parameters of type DecoratedKey
Row(DecoratedKey<?> key, ColumnFamily cf)
           
 

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 IColumnIterator.getKey()
           
 DecoratedKey SSTableNamesIterator.getKey()
           
 DecoratedKey SSTableSliceIterator.getKey()
           
 

Constructors in org.apache.cassandra.db.columniterator with parameters of type DecoratedKey
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)
           
SSTableSliceIterator(SSTableReader sstable, DecoratedKey key, java.nio.ByteBuffer startColumn, java.nio.ByteBuffer finishColumn, boolean reversed)
           
SSTableSliceIterator(SSTableReader sstable, FileDataInput file, DecoratedKey key, java.nio.ByteBuffer startColumn, java.nio.ByteBuffer finishColumn, boolean reversed)
          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, CompactionController controller, ColumnFamily cf)
           
static ColumnFamily PrecompactedRow.removeDeletedAndOldShards(DecoratedKey key, boolean shouldPurge, CompactionController controller, ColumnFamily cf)
           
 void CompactionController.removeDeletedInCache(DecoratedKey key)
           
 boolean CompactionController.shouldPurge(DecoratedKey key)
           
 

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.
 IColumnIterator IFilter.getMemtableColumnIterator(ColumnFamily cf, DecoratedKey<?> key, AbstractType comparator)
          returns an iterator that returns columns from the given memtable matching the Filter criteria in sorted order.
 IColumnIterator NamesQueryFilter.getMemtableColumnIterator(ColumnFamily cf, DecoratedKey<?> key, AbstractType comparator)
           
 IColumnIterator QueryFilter.getMemtableColumnIterator(ColumnFamily cf, DecoratedKey<?> key, AbstractType comparator)
           
 IColumnIterator SliceQueryFilter.getMemtableColumnIterator(ColumnFamily cf, DecoratedKey<?> key, AbstractType comparator)
           
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)
           
 IColumnIterator IFilter.getSSTableColumnIterator(SSTableReader sstable, DecoratedKey<?> key)
          returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order.
 IColumnIterator NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable, DecoratedKey<?> key)
           
 IColumnIterator SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable, DecoratedKey<?> key)
           
 IColumnIterator IFilter.getSSTableColumnIterator(SSTableReader sstable, FileDataInput file, DecoratedKey<?> key)
          Get an iterator that returns columns from the given SSTable using the opened file matching the Filter criteria in sorted order.
 IColumnIterator NamesQueryFilter.getSSTableColumnIterator(SSTableReader sstable, FileDataInput file, DecoratedKey<?> key)
           
 IColumnIterator QueryFilter.getSSTableColumnIterator(SSTableReader sstable, FileDataInput file, DecoratedKey<?> key)
           
 IColumnIterator SliceQueryFilter.getSSTableColumnIterator(SSTableReader sstable, FileDataInput file, DecoratedKey<?> key)
           
 

Constructors in org.apache.cassandra.db.filter with parameters of type DecoratedKey
QueryFilter(DecoratedKey<?> key, QueryPath path, IFilter filter)
           
 

Uses of DecoratedKey in org.apache.cassandra.db.index
 

Methods in org.apache.cassandra.db.index that return DecoratedKey
 DecoratedKey<LocalToken> SecondaryIndexManager.getIndexKeyFor(java.nio.ByteBuffer name, 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 PerColumnSecondaryIndex.deleteColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn col)
          Delete a column from the index
abstract  void PerRowSecondaryIndex.deleteFromIndex(DecoratedKey<?> key, java.util.List<IColumn> indexedColumnsInRow)
          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
abstract  void PerColumnSecondaryIndex.insertColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn col)
          insert a column to the index
abstract  void PerColumnSecondaryIndex.updateColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn col)
          update a column from the index
 

Uses of DecoratedKey in org.apache.cassandra.db.index.keys
 

Methods in org.apache.cassandra.db.index.keys with parameters of type DecoratedKey
 void KeysIndex.deleteColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn column)
           
 void KeysIndex.insertColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn column)
           
 void KeysIndex.updateColumn(DecoratedKey<?> valueKey, java.nio.ByteBuffer rowKey, IColumn col)
           
 

Uses of DecoratedKey in org.apache.cassandra.dht
 

Methods in org.apache.cassandra.dht that return DecoratedKey
 DecoratedKey<BytesToken> AbstractByteOrderedPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
           
 DecoratedKey<T> IPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
          Deprecated. Used by SSTables before version 'e'. Convert the on disk representation to a DecoratedKey object
 DecoratedKey<LocalToken> LocalPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
           
 DecoratedKey<StringToken> OrderPreservingPartitioner.convertFromDiskFormat(java.nio.ByteBuffer key)
           
 DecoratedKey<BigIntegerToken> RandomPartitioner.convertFromDiskFormat(java.nio.ByteBuffer fromdisk)
           
 DecoratedKey<BytesToken> AbstractByteOrderedPartitioner.decorateKey(java.nio.ByteBuffer key)
           
 DecoratedKey<T> IPartitioner.decorateKey(java.nio.ByteBuffer key)
          Transform key to object representation of the on-disk format.
 DecoratedKey<LocalToken> LocalPartitioner.decorateKey(java.nio.ByteBuffer key)
           
 DecoratedKey<StringToken> OrderPreservingPartitioner.decorateKey(java.nio.ByteBuffer key)
           
 DecoratedKey<BigIntegerToken> 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<?> IndexSummary.KeyPosition.key
           
 DecoratedKey SSTable.last
           
 

Methods in org.apache.cassandra.io.sstable that return DecoratedKey
protected  DecoratedKey<?> KeyIterator.computeNext()
           
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
 InstrumentingCache<Pair<Descriptor,DecoratedKey>,java.lang.Long> SSTableReader.getKeyCache()
           
 java.util.Collection<DecoratedKey> SSTableReader.getKeySamples()
           
 java.lang.Iterable<DecoratedKey> SSTableReader.getKeySamples(Range 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, java.nio.ByteBuffer value)
           
 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, java.lang.Long info)
           
 java.lang.Long SSTableReader.getCachedPosition(DecoratedKey key, boolean updateStats)
           
 FileDataInput SSTableReader.getFileDataInput(DecoratedKey decoratedKey, int bufferSize)
           
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.
 long SSTableReader.getPosition(DecoratedKey decoratedKey, SSTableReader.Operator op)
           
 void IndexSummary.maybeAddEntry(DecoratedKey<?> decoratedKey, long indexPosition)
           
 void SSTableScanner.seekTo(DecoratedKey<?> seekKey)
           
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)
           
 

Method parameters in org.apache.cassandra.io.sstable with type arguments of type DecoratedKey
static java.util.Collection<SSTableReader> SSTableReader.batchOpen(java.util.Set<java.util.Map.Entry<Descriptor,java.util.Set<Component>>> entries, java.util.Set<DecoratedKey> savedKeys, DataTracker tracker, CFMetaData metadata, IPartitioner partitioner)
           
static SSTableReader SSTableReader.open(Descriptor descriptor, java.util.Set<Component> components, java.util.Set<DecoratedKey> savedKeys, DataTracker tracker, CFMetaData metadata, IPartitioner partitioner)
           
 

Constructors in org.apache.cassandra.io.sstable with parameters of type DecoratedKey
IndexSummary.KeyPosition(DecoratedKey<?> key, long indexPosition)
           
SSTableIdentityIterator(CFMetaData metadata, java.io.DataInput file, 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> RowRepairResolver.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 range)
           
 



Copyright © 2012 The Apache Software Foundation