Modifier and Type | Method and Description |
---|---|
void |
CFMetaData.validateColumns(java.lang.Iterable<Cell> columns) |
Modifier and Type | Method and Description |
---|---|
Cell |
CQL3Row.getColumn(ColumnIdentifier name) |
Cell |
UpdateParameters.makeColumn(CellName name,
java.nio.ByteBuffer value) |
Cell |
UpdateParameters.makeTombstone(CellName name) |
Modifier and Type | Method and Description |
---|---|
java.util.List<Cell> |
CQL3Row.getCollection(ColumnIdentifier name) |
java.util.List<Cell> |
UpdateParameters.getPrefetchedList(java.nio.ByteBuffer rowKey,
ColumnIdentifier cql3ColumnName) |
Modifier and Type | Method and Description |
---|---|
java.util.Iterator<CQL3Row> |
CQL3Row.Builder.group(java.util.Iterator<Cell> cells) |
Modifier and Type | Method and Description |
---|---|
void |
Selection.ResultSetBuilder.add(Cell c) |
Modifier and Type | Class and Description |
---|---|
class |
CounterCell
A column that represents a partitioned counter.
|
class |
CounterUpdateCell
A counter update while it hasn't been applied yet by the leader replica.
|
class |
DeletedCell |
class |
ExpiringCell
Alternative to Cell that have an expiring time.
|
Modifier and Type | Method and Description |
---|---|
static Cell |
Cell.create(CellName name,
java.nio.ByteBuffer value,
long timestamp,
int ttl,
CFMetaData metadata) |
static Cell |
ExpiringCell.create(CellName name,
java.nio.ByteBuffer value,
long timestamp,
int timeToLive,
int localExpirationTime,
int expireBefore,
ColumnSerializer.Flag flag) |
Cell |
ColumnSerializer.deserialize(java.io.DataInput in) |
Cell |
ColumnSerializer.deserialize(java.io.DataInput in,
ColumnSerializer.Flag flag) |
Cell |
ColumnSerializer.deserialize(java.io.DataInput in,
ColumnSerializer.Flag flag,
int expireBefore) |
Cell |
Cell.diff(Cell cell) |
Cell |
CounterCell.diff(Cell cell) |
Cell |
CounterUpdateCell.diff(Cell cell) |
Cell |
ArrayBackedSortedColumns.getColumn(CellName name) |
Cell |
AtomicBTreeColumns.getColumn(CellName name) |
abstract Cell |
ColumnFamily.getColumn(CellName name)
Get a column given its name, returning null if the column is not
present.
|
Cell |
Cell.localCopy(ColumnFamilyStore cfs,
AbstractAllocator allocator) |
Cell |
CounterCell.localCopy(ColumnFamilyStore cfs,
AbstractAllocator allocator) |
Cell |
CounterUpdateCell.localCopy(ColumnFamilyStore cfs,
AbstractAllocator allocator) |
Cell |
DeletedCell.localCopy(ColumnFamilyStore cfs,
AbstractAllocator allocator) |
Cell |
ExpiringCell.localCopy(ColumnFamilyStore cfs,
AbstractAllocator allocator) |
Cell |
CounterCell.markLocalToBeCleared() |
Cell |
Cell.reconcile(Cell cell) |
Cell |
Cell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
CounterCell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
CounterUpdateCell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
DeletedCell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
Cell.withUpdatedName(CellName newName) |
Cell |
CounterCell.withUpdatedName(CellName newName) |
Cell |
DeletedCell.withUpdatedName(CellName newName) |
Cell |
ExpiringCell.withUpdatedName(CellName newName) |
Cell |
Cell.withUpdatedTimestamp(long newTimestamp) |
Cell |
DeletedCell.withUpdatedTimestamp(long newTimestamp) |
Cell |
ExpiringCell.withUpdatedTimestamp(long newTimestamp) |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Cell> |
ArrayBackedSortedColumns.getReverseSortedColumns() |
java.util.Collection<Cell> |
AtomicBTreeColumns.getReverseSortedColumns() |
abstract java.util.Collection<Cell> |
ColumnFamily.getReverseSortedColumns()
Returns the columns of this column map as a collection.
|
java.util.Collection<Cell> |
ArrayBackedSortedColumns.getSortedColumns() |
java.util.Collection<Cell> |
AtomicBTreeColumns.getSortedColumns() |
abstract java.util.Collection<Cell> |
ColumnFamily.getSortedColumns()
Returns the columns of this column map as a collection.
|
java.util.Iterator<Cell> |
ColumnFamily.iterator() |
java.util.Iterator<Cell> |
ArrayBackedSortedColumns.iterator(ColumnSlice[] slices) |
java.util.Iterator<Cell> |
AtomicBTreeColumns.iterator(ColumnSlice[] slices) |
abstract java.util.Iterator<Cell> |
ColumnFamily.iterator(ColumnSlice[] slices)
Returns an iterator over the columns of this map that returns only the matching @param slices.
|
java.lang.Iterable<Cell> |
AtomicBTreeColumns.Delta.reclaimed() |
java.util.Iterator<Cell> |
ColumnFamily.reverseIterator() |
java.util.Iterator<Cell> |
ArrayBackedSortedColumns.reverseIterator(ColumnSlice[] slices) |
java.util.Iterator<Cell> |
AtomicBTreeColumns.reverseIterator(ColumnSlice[] slices) |
abstract java.util.Iterator<Cell> |
ColumnFamily.reverseIterator(ColumnSlice[] slices)
Returns a reversed iterator over the columns of this map that returns only the matching @param slices.
|
Modifier and Type | Method and Description |
---|---|
void |
ArrayBackedSortedColumns.addColumn(Cell cell) |
void |
AtomicBTreeColumns.addColumn(Cell column) |
abstract void |
ColumnFamily.addColumn(Cell cell)
Adds a cell to this cell map.
|
void |
ColumnFamily.addIfRelevant(Cell cell,
DeletionInfo.InOrderTester tester,
int gcBefore) |
Cell |
Cell.diff(Cell cell) |
Cell |
CounterCell.diff(Cell cell) |
Cell |
CounterUpdateCell.diff(Cell cell) |
protected void |
AtomicBTreeColumns.Delta.insert(Cell insert) |
boolean |
DeletionInfo.isDeleted(Cell cell)
Return whether a given cell is deleted by the container having this deletion info.
|
boolean |
DeletionInfo.InOrderTester.isDeleted(Cell cell) |
boolean |
RangeTombstone.Tracker.isDeleted(Cell cell) |
Cell |
Cell.reconcile(Cell cell) |
Cell |
Cell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
CounterCell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
CounterUpdateCell.reconcile(Cell cell,
AbstractAllocator allocator) |
Cell |
DeletedCell.reconcile(Cell cell,
AbstractAllocator allocator) |
void |
ColumnSerializer.serialize(Cell cell,
java.io.DataOutput out) |
long |
ColumnSerializer.serializedSize(Cell cell,
TypeSizes typeSizes) |
protected void |
AtomicBTreeColumns.Delta.swap(Cell old,
Cell updated) |
Modifier and Type | Method and Description |
---|---|
AtomicBTreeColumns.Delta |
AtomicBTreeColumns.addAllWithSizeDelta(ColumnFamily cm,
AbstractAllocator allocator,
com.google.common.base.Function<Cell,Cell> transformation,
SecondaryIndexManager.Updater indexer,
AtomicBTreeColumns.Delta delta)
This is only called by Memtable.resolve, so only AtomicBTreeColumns needs to implement it.
|
AtomicBTreeColumns.Delta |
AtomicBTreeColumns.addAllWithSizeDelta(ColumnFamily cm,
AbstractAllocator allocator,
com.google.common.base.Function<Cell,Cell> transformation,
SecondaryIndexManager.Updater indexer,
AtomicBTreeColumns.Delta delta)
This is only called by Memtable.resolve, so only AtomicBTreeColumns needs to implement it.
|
Modifier and Type | Method and Description |
---|---|
java.util.Comparator<Cell> |
AbstractCellNameType.columnComparator() |
java.util.Comparator<Cell> |
CellNameType.columnComparator() |
java.util.Comparator<Cell> |
AbstractCellNameType.columnReverseComparator() |
java.util.Comparator<Cell> |
CellNameType.columnReverseComparator() |
Modifier and Type | Method and Description |
---|---|
static java.lang.String |
CellNames.getColumnsString(CellNameType type,
java.lang.Iterable<Cell> columns) |
Modifier and Type | Method and Description |
---|---|
protected Cell |
ColumnSlice.NavigableSetIterator.computeNext() |
Modifier and Type | Method and Description |
---|---|
static java.util.Iterator<Cell> |
QueryFilter.gatherTombstones(ColumnFamily returnCF,
java.util.Iterator<? extends OnDiskAtom> iter)
Given an iterator of on disk atom, returns an iterator that filters the tombstone range
markers adding them to
returnCF and returns the normal column. |
java.util.Comparator<Cell> |
IDiskAtomFilter.getColumnComparator(CellNameType comparator) |
java.util.Comparator<Cell> |
NamesQueryFilter.getColumnComparator(CellNameType comparator) |
java.util.Comparator<Cell> |
SliceQueryFilter.getColumnComparator(CellNameType comparator) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnCounter.count(Cell cell,
DeletionInfo.InOrderTester tester) |
void |
ColumnCounter.GroupByPrefix.count(Cell cell,
DeletionInfo.InOrderTester tester) |
protected static boolean |
ColumnCounter.isLive(Cell cell,
DeletionInfo.InOrderTester tester,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
static void |
QueryFilter.collateColumns(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<Cell>> toCollate,
IDiskAtomFilter filter,
int gcBefore,
long timestamp) |
void |
QueryFilter.collateColumns(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<Cell>> toCollate,
int gcBefore) |
void |
IDiskAtomFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Cell> reducedColumns,
int gcBefore,
long now)
collects columns from reducedColumns into returnCF.
|
void |
NamesQueryFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Cell> reducedColumns,
int gcBefore,
long now) |
void |
SliceQueryFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Cell> reducedColumns,
int gcBefore,
long now) |
Constructor and Description |
---|
ColumnSlice.NavigableSetIterator(java.util.NavigableSet<Cell> set,
ColumnSlice[] slices) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractSimplePerColumnSecondaryIndex.delete(java.nio.ByteBuffer rowKey,
Cell cell) |
void |
AbstractSimplePerColumnSecondaryIndex.delete(java.nio.ByteBuffer rowKey,
Cell cell,
OpOrder.Group opGroup) |
abstract void |
PerColumnSecondaryIndex.delete(java.nio.ByteBuffer rowKey,
Cell col,
OpOrder.Group opGroup)
Delete a column from the index.
|
protected abstract java.nio.ByteBuffer |
AbstractSimplePerColumnSecondaryIndex.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
boolean |
SecondaryIndexManager.indexes(Cell cell) |
void |
AbstractSimplePerColumnSecondaryIndex.insert(java.nio.ByteBuffer rowKey,
Cell cell) |
void |
AbstractSimplePerColumnSecondaryIndex.insert(java.nio.ByteBuffer rowKey,
Cell cell,
OpOrder.Group opGroup) |
abstract void |
PerColumnSecondaryIndex.insert(java.nio.ByteBuffer rowKey,
Cell col,
OpOrder.Group opGroup)
insert a column to the index
|
void |
SecondaryIndexManager.Updater.insert(Cell cell)
called when constructing the index against pre-existing data
|
protected abstract CellName |
AbstractSimplePerColumnSecondaryIndex.makeIndexColumnName(java.nio.ByteBuffer rowKey,
Cell cell) |
void |
SecondaryIndexManager.Updater.remove(Cell current)
called when lazy-updating the index during compaction (CASSANDRA-2897)
|
void |
AbstractSimplePerColumnSecondaryIndex.update(java.nio.ByteBuffer rowKey,
Cell cell) |
void |
AbstractSimplePerColumnSecondaryIndex.update(java.nio.ByteBuffer rowKey,
Cell oldCol,
Cell col,
OpOrder.Group opGroup) |
abstract void |
PerColumnSecondaryIndex.update(java.nio.ByteBuffer rowKey,
Cell oldCol,
Cell col,
OpOrder.Group opGroup)
update a column from the index
|
void |
SecondaryIndexManager.Updater.update(Cell oldCell,
Cell cell)
called when updating the index from a memtable
|
boolean |
PerColumnSecondaryIndex.validate(Cell cell) |
boolean |
PerRowSecondaryIndex.validate(Cell cell) |
abstract boolean |
SecondaryIndex.validate(Cell cell) |
boolean |
SecondaryIndexManager.validate(Cell cell) |
Modifier and Type | Method and Description |
---|---|
void |
SecondaryIndexManager.deleteFromIndexes(DecoratedKey key,
java.util.List<Cell> indexedColumnsInRow,
OpOrder.Group opGroup)
Delete all columns from all indexes for this row.
|
Modifier and Type | Method and Description |
---|---|
abstract CompositesIndex.IndexedEntry |
CompositesIndex.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnClusteringKey.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnCollectionKey.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnCollectionValue.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnPartitionKey.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnRegular.decodeEntry(DecoratedKey indexedValue,
Cell indexEntry) |
protected java.nio.ByteBuffer |
CompositesIndexOnClusteringKey.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected java.nio.ByteBuffer |
CompositesIndexOnCollectionKey.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected java.nio.ByteBuffer |
CompositesIndexOnCollectionValue.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected java.nio.ByteBuffer |
CompositesIndexOnPartitionKey.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected java.nio.ByteBuffer |
CompositesIndexOnRegular.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected CellName |
CompositesIndex.makeIndexColumnName(java.nio.ByteBuffer rowKey,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
protected java.nio.ByteBuffer |
KeysIndex.getIndexedValue(java.nio.ByteBuffer rowKey,
Cell cell) |
protected CellName |
KeysIndex.makeIndexColumnName(java.nio.ByteBuffer rowKey,
Cell cell) |
Modifier and Type | Method and Description |
---|---|
protected java.util.List<Cell> |
CollectionType.enforceLimit(java.util.List<Cell> cells) |
Modifier and Type | Method and Description |
---|---|
protected java.util.List<Cell> |
CollectionType.enforceLimit(java.util.List<Cell> cells) |
abstract java.nio.ByteBuffer |
CollectionType.serialize(java.util.List<Cell> cells) |
java.nio.ByteBuffer |
ListType.serialize(java.util.List<Cell> cells) |
java.nio.ByteBuffer |
MapType.serialize(java.util.List<Cell> cells)
Creates the same output than serialize, but from the internal representation.
|
java.nio.ByteBuffer |
SetType.serialize(java.util.List<Cell> cells) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordReader<java.nio.ByteBuffer,java.util.SortedMap<CellName,Cell>> |
ColumnFamilyInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit inputSplit,
org.apache.hadoop.mapreduce.TaskAttemptContext taskAttemptContext) |
java.util.SortedMap<CellName,Cell> |
ColumnFamilyRecordReader.createValue() |
java.util.SortedMap<CellName,Cell> |
ColumnFamilyRecordReader.getCurrentValue() |
org.apache.hadoop.mapred.RecordReader<java.nio.ByteBuffer,java.util.SortedMap<CellName,Cell>> |
ColumnFamilyInputFormat.getRecordReader(org.apache.hadoop.mapred.InputSplit split,
org.apache.hadoop.mapred.JobConf jobConf,
org.apache.hadoop.mapred.Reporter reporter) |
Modifier and Type | Method and Description |
---|---|
boolean |
ColumnFamilyRecordReader.next(java.nio.ByteBuffer key,
java.util.SortedMap<CellName,Cell> value) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.pig.data.Tuple |
AbstractCassandraStorage.columnToTuple(Cell col,
AbstractCassandraStorage.CfInfo cfInfo,
AbstractType comparator)
convert a column to a tuple
|
Modifier and Type | Method and Description |
---|---|
java.util.List<ColumnOrSuperColumn> |
CassandraServer.thriftifyColumns(java.util.Collection<Cell> cells,
boolean reverseOrder,
long now) |
Modifier and Type | Method and Description |
---|---|
Cell |
ContextAllocator.apply(Cell column) |
Modifier and Type | Method and Description |
---|---|
Cell |
ContextAllocator.apply(Cell column) |
Copyright © 2014 The Apache Software Foundation