Modifier and Type | Method and Description |
---|---|
abstract boolean |
ColumnCondition.Bound.appliesTo(ColumnNameBuilder rowPrefix,
ColumnFamily current,
long now)
Validates whether this condition applies to
current . |
protected java.util.Iterator<Column> |
ColumnCondition.Bound.collectionColumns(ColumnNameBuilder collectionPrefix,
ColumnFamily cf,
long now) |
void |
Constants.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Substracter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Constants.Deleter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.SetterByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Appender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Prepender.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Lists.DiscarderByIndex.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.SetterByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.Putter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Maps.DiscarderByKey.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
abstract void |
Operation.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder namePrefix,
UpdateParameters params)
Execute the operation.
|
void |
Sets.Setter.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Sets.Adder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
void |
Sets.Discarder.execute(java.nio.ByteBuffer rowKey,
ColumnFamily cf,
ColumnNameBuilder prefix,
UpdateParameters params) |
Modifier and Type | Method and Description |
---|---|
void |
DeleteStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
abstract void |
ModificationStatement.addUpdateForKey(ColumnFamily updates,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
void |
UpdateStatement.addUpdateForKey(ColumnFamily cf,
java.nio.ByteBuffer key,
ColumnNameBuilder builder,
UpdateParameters params) |
void |
ModificationStatement.addUpdatesAndConditions(java.nio.ByteBuffer key,
ColumnNameBuilder clusteringPrefix,
ColumnFamily updates,
CQL3CasConditions conditions,
java.util.List<java.nio.ByteBuffer> variables,
long now) |
boolean |
CQL3CasConditions.appliesTo(ColumnFamily current) |
static ResultSet |
ModificationStatement.buildCasResultSet(java.lang.String ksName,
java.nio.ByteBuffer key,
java.lang.String cfName,
ColumnFamily cf,
java.lang.Iterable<ColumnIdentifier> columnsWithConditions,
boolean isBatch) |
Modifier and Type | Class and Description |
---|---|
static class |
ColumnFamily.Factory<T extends ColumnFamily> |
Modifier and Type | Class and Description |
---|---|
class |
AbstractThreadUnsafeSortedColumns |
class |
ArrayBackedSortedColumns
A ColumnFamily backed by an ArrayList.
|
class |
AtomicSortedColumns
A thread-safe and atomic ISortedColumns implementation.
|
class |
EmptyColumns |
class |
TreeMapBackedSortedColumns |
class |
UnsortedColumns
A ColumnFamily that allows inserting in any order, even unsorted.
|
Modifier and Type | Field and Description |
---|---|
ColumnFamily |
Row.cf |
Modifier and Type | Method and Description |
---|---|
<T extends ColumnFamily> |
ColumnFamily.cloneMeShallow(ColumnFamily.Factory<T> factory,
boolean reversedInsertOrder) |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
RowMutation.addOrGet(CFMetaData cfm) |
ColumnFamily |
RowMutation.addOrGet(CFMetaData cfm,
ColumnFamily.Factory factory) |
ColumnFamily |
RowMutation.addOrGet(java.lang.String cfName) |
ColumnFamily |
ArrayBackedSortedColumns.cloneMe() |
ColumnFamily |
AtomicSortedColumns.cloneMe() |
abstract ColumnFamily |
ColumnFamily.cloneMe()
Clones the column map.
|
ColumnFamily |
EmptyColumns.cloneMe() |
ColumnFamily |
TreeMapBackedSortedColumns.cloneMe() |
ColumnFamily |
UnsortedColumns.cloneMe() |
ColumnFamily |
ColumnFamily.cloneMeShallow() |
ColumnFamily |
ColumnFamilySerializer.deserialize(java.io.DataInput in,
ColumnFamily.Factory factory,
ColumnSerializer.Flag flag,
int version) |
ColumnFamily |
ColumnFamilySerializer.deserialize(java.io.DataInput in,
ColumnSerializer.Flag flag,
int version) |
ColumnFamily |
ColumnFamilySerializer.deserialize(java.io.DataInput in,
int version) |
ColumnFamily |
ColumnFamilySerializer.deserializeFromSSTable(java.io.DataInput in,
Descriptor.Version version) |
ColumnFamily |
ColumnFamily.diff(ColumnFamily cfComposite) |
static ColumnFamily |
ColumnFamily.diff(ColumnFamily cf1,
ColumnFamily cf2) |
static ColumnFamily |
ColumnFamily.fromBytes(java.nio.ByteBuffer bytes) |
ColumnFamily |
Memtable.getColumnFamily(DecoratedKey key) |
ColumnFamily |
ColumnFamilyStore.getColumnFamily(DecoratedKey key,
java.nio.ByteBuffer start,
java.nio.ByteBuffer finish,
boolean reversed,
int limit,
long timestamp) |
ColumnFamily |
ColumnFamilyStore.getColumnFamily(QueryFilter filter)
get a list of columns starting from a given column, in a specified order.
|
ColumnFamily |
RowMutation.getColumnFamily(java.util.UUID cfId) |
ColumnFamily |
ColumnFamilyStore.getRawCachedRow(DecoratedKey key) |
ColumnFamily |
CollationController.getTopLevelColumns() |
ColumnFamily |
ColumnFamilyStore.getTopLevelColumns(QueryFilter filter,
int gcBefore) |
static ColumnFamily |
ColumnFamilyStore.removeDeleted(ColumnFamily cf,
int gcBefore)
Removes deleted columns and purges gc-able tombstones.
|
static ColumnFamily |
ColumnFamilyStore.removeDeleted(ColumnFamily cf,
int gcBefore,
SecondaryIndexManager.Updater indexer) |
static ColumnFamily |
ColumnFamilyStore.removeDeletedCF(ColumnFamily cf,
int gcBefore)
Purges gc-able top-level and range tombstones, returning `cf` if there are any columns or tombstones left,
null otherwise.
|
Modifier and Type | Method and Description |
---|---|
java.util.Collection<ColumnFamily> |
CounterMutation.getColumnFamilies() |
java.util.Collection<ColumnFamily> |
IMutation.getColumnFamilies() |
java.util.Collection<ColumnFamily> |
RowMutation.getColumnFamilies() |
static java.util.Map<DecoratedKey,ColumnFamily> |
SystemKeyspace.getSchema(java.lang.String cfName) |
Modifier and Type | Method and Description |
---|---|
void |
RowMutation.add(ColumnFamily columnFamily) |
void |
ColumnFamily.addAll(ColumnFamily cf,
Allocator allocator) |
void |
ArrayBackedSortedColumns.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation) |
void |
AtomicSortedColumns.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation) |
abstract void |
ColumnFamily.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation)
Adds all the columns of a given column map to this column map.
|
void |
EmptyColumns.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation) |
void |
TreeMapBackedSortedColumns.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation)
We need to go through each column in the column container and resolve it before adding
|
void |
UnsortedColumns.addAll(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation) |
long |
AtomicSortedColumns.addAllWithSizeDelta(ColumnFamily cm,
Allocator allocator,
com.google.common.base.Function<Column,Column> transformation,
SecondaryIndexManager.Updater indexer)
This is only called by Memtable.resolve, so only AtomicSortedColumns needs to implement it.
|
void |
ColumnFamilyStore.apply(DecoratedKey key,
ColumnFamily columnFamily,
SecondaryIndexManager.Updater indexer)
Insert/Update the column family for this key.
|
ColumnIndex |
ColumnIndex.Builder.build(ColumnFamily cf)
Serializes the index into in-memory structure with all required components
such as Bloom Filter, index block size, IndexInfo list
|
long |
ColumnFamilySerializer.contentSerializedSize(ColumnFamily cf,
TypeSizes typeSizes,
int version) |
void |
ColumnFamily.delete(ColumnFamily columns)
If `columns` has any tombstones (top-level or range tombstones), they will be applied to this set of columns.
|
static void |
SuperColumns.deserializerSuperColumnFamily(java.io.DataInput in,
ColumnFamily cf,
ColumnSerializer.Flag flag,
int version) |
ColumnFamily |
ColumnFamily.diff(ColumnFamily cfComposite) |
static ColumnFamily |
ColumnFamily.diff(ColumnFamily cf1,
ColumnFamily cf2) |
static java.nio.ByteBuffer |
ColumnFamily.digest(ColumnFamily cf) |
int |
DataRange.getLiveCount(ColumnFamily data,
long now) |
static ColumnFamily |
ColumnFamilyStore.removeDeleted(ColumnFamily cf,
int gcBefore)
Removes deleted columns and purges gc-able tombstones.
|
static ColumnFamily |
ColumnFamilyStore.removeDeleted(ColumnFamily cf,
int gcBefore,
SecondaryIndexManager.Updater indexer) |
static ColumnFamily |
ColumnFamilyStore.removeDeletedCF(ColumnFamily cf,
int gcBefore)
Purges gc-able top-level and range tombstones, returning `cf` if there are any columns or tombstones left,
null otherwise.
|
static long |
ColumnFamilyStore.removeDeletedColumnsOnly(ColumnFamily cf,
int gcBefore) |
static long |
ColumnFamilyStore.removeDeletedColumnsOnly(ColumnFamily cf,
int gcBefore,
SecondaryIndexManager.Updater indexer)
Removes only per-cell tombstones, cells that are shadowed by a row-level or range tombstone, or
columns that have been dropped from the schema (for CQL3 tables only).
|
void |
ColumnFamily.resolve(ColumnFamily cf) |
void |
ColumnFamily.resolve(ColumnFamily cf,
Allocator allocator) |
void |
ColumnFamilySerializer.serialize(ColumnFamily cf,
java.io.DataOutput out,
int version) |
long |
ColumnFamilySerializer.serializedSize(ColumnFamily cf,
int version) |
long |
ColumnFamilySerializer.serializedSize(ColumnFamily cf,
TypeSizes typeSizes,
int version) |
static long |
SuperColumns.serializedSize(ColumnFamily scf,
TypeSizes typeSizes,
int version) |
void |
ColumnFamilySerializer.serializeForSSTable(ColumnFamily cf,
java.io.DataOutput out) |
static void |
SuperColumns.serializeSuperColumnFamily(ColumnFamily scf,
java.io.DataOutput out,
int version) |
Constructor and Description |
---|
ColumnIndex.Builder(ColumnFamily cf,
java.nio.ByteBuffer key,
java.io.DataOutput output) |
Row(java.nio.ByteBuffer key,
ColumnFamily updates) |
Row(DecoratedKey key,
ColumnFamily cf) |
RowMutation(java.nio.ByteBuffer key,
ColumnFamily cf) |
RowMutation(java.lang.String keyspaceName,
java.nio.ByteBuffer key,
ColumnFamily cf) |
Constructor and Description |
---|
RowMutation(java.lang.String keyspaceName,
java.nio.ByteBuffer key,
java.util.Map<java.util.UUID,ColumnFamily> modifications) |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
LazyColumnIterator.getColumnFamily() |
ColumnFamily |
OnDiskAtomIterator.getColumnFamily() |
ColumnFamily |
SSTableNamesIterator.getColumnFamily() |
ColumnFamily |
SSTableSliceIterator.getColumnFamily() |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
PrecompactedRow.getFullColumnFamily() |
static ColumnFamily |
PrecompactedRow.removeDeleted(DecoratedKey key,
boolean shouldPurge,
CompactionController controller,
ColumnFamily cf) |
static ColumnFamily |
PrecompactedRow.removeDeleted(DecoratedKey key,
CompactionController controller,
ColumnFamily cf) |
Modifier and Type | Method and Description |
---|---|
static void |
PrecompactedRow.merge(ColumnFamily returnCF,
java.util.List<CloseableIterator<Column>> data,
SecondaryIndexManager.Updater indexer) |
static ColumnFamily |
PrecompactedRow.removeDeleted(DecoratedKey key,
boolean shouldPurge,
CompactionController controller,
ColumnFamily cf) |
static ColumnFamily |
PrecompactedRow.removeDeleted(DecoratedKey key,
CompactionController controller,
ColumnFamily cf) |
Constructor and Description |
---|
PrecompactedRow(DecoratedKey key,
ColumnFamily cf) |
Modifier and Type | Method and Description |
---|---|
abstract ColumnFamily |
ExtendedFilter.prune(DecoratedKey key,
ColumnFamily data) |
ColumnFamily |
ExtendedFilter.WithClauses.prune(DecoratedKey rowKey,
ColumnFamily data) |
Modifier and Type | Method and Description |
---|---|
static void |
QueryFilter.collateColumns(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<Column>> toCollate,
IDiskAtomFilter filter,
int gcBefore,
long timestamp) |
void |
QueryFilter.collateColumns(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<Column>> toCollate,
int gcBefore) |
void |
QueryFilter.collateOnDiskAtom(ColumnFamily returnCF,
java.util.Iterator<? extends OnDiskAtom> toCollate,
int gcBefore)
When there is only a single source of atoms, we can skip the collate step
|
static void |
QueryFilter.collateOnDiskAtom(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<? extends OnDiskAtom>> toCollate,
IDiskAtomFilter filter,
int gcBefore,
long timestamp) |
void |
QueryFilter.collateOnDiskAtom(ColumnFamily returnCF,
java.util.List<? extends java.util.Iterator<? extends OnDiskAtom>> toCollate,
int gcBefore) |
void |
IDiskAtomFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Column> reducedColumns,
int gcBefore,
long now)
collects columns from reducedColumns into returnCF.
|
void |
NamesQueryFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Column> reducedColumns,
int gcBefore,
long now) |
void |
SliceQueryFilter.collectReducedColumns(ColumnFamily container,
java.util.Iterator<Column> reducedColumns,
int gcBefore,
long now) |
ColumnCounter |
ColumnCounter.countAll(ColumnFamily container) |
static java.util.Iterator<Column> |
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. |
OnDiskAtomIterator |
QueryFilter.getColumnFamilyIterator(ColumnFamily cf) |
OnDiskAtomIterator |
IDiskAtomFilter.getColumnFamilyIterator(DecoratedKey key,
ColumnFamily cf)
returns an iterator that returns columns from the given columnFamily
matching the Filter criteria in sorted order.
|
OnDiskAtomIterator |
NamesQueryFilter.getColumnFamilyIterator(DecoratedKey key,
ColumnFamily cf) |
OnDiskAtomIterator |
SliceQueryFilter.getColumnFamilyIterator(DecoratedKey key,
ColumnFamily cf) |
abstract IDiskAtomFilter |
ExtendedFilter.getExtraFilter(DecoratedKey key,
ColumnFamily data)
Returns a filter to query the columns from the clause that the initial slice filter may not have caught.
|
IDiskAtomFilter |
ExtendedFilter.WithClauses.getExtraFilter(DecoratedKey rowKey,
ColumnFamily data) |
int |
IDiskAtomFilter.getLiveCount(ColumnFamily cf,
long now) |
int |
NamesQueryFilter.getLiveCount(ColumnFamily cf,
long now) |
int |
SliceQueryFilter.getLiveCount(ColumnFamily cf,
long now) |
abstract boolean |
ExtendedFilter.isSatisfiedBy(DecoratedKey rowKey,
ColumnFamily data,
ColumnNameBuilder builder) |
boolean |
ExtendedFilter.WithClauses.isSatisfiedBy(DecoratedKey rowKey,
ColumnFamily data,
ColumnNameBuilder builder) |
int |
ExtendedFilter.lastCounted(ColumnFamily data) |
abstract ColumnFamily |
ExtendedFilter.prune(DecoratedKey key,
ColumnFamily data) |
ColumnFamily |
ExtendedFilter.WithClauses.prune(DecoratedKey rowKey,
ColumnFamily data) |
void |
SliceQueryFilter.trim(ColumnFamily cf,
int trimTo,
long now) |
Modifier and Type | Method and Description |
---|---|
abstract void |
PerRowSecondaryIndex.index(java.nio.ByteBuffer rowKey,
ColumnFamily cf)
Index the given row.
|
void |
SecondaryIndexManager.indexRow(java.nio.ByteBuffer key,
ColumnFamily cf)
When building an index against existing data, add the given row to the index
|
SecondaryIndexManager.Updater |
SecondaryIndexManager.updaterFor(DecoratedKey key,
ColumnFamily cf)
This helper acts as a closure around the indexManager
and updated cf data to ensure that down in
Memtable's ColumnFamily implementation, the index
can get updated.
|
Modifier and Type | Method and Description |
---|---|
abstract boolean |
CompositesIndex.isStale(CompositesIndex.IndexedEntry entry,
ColumnFamily data,
long now) |
boolean |
CompositesIndexOnClusteringKey.isStale(CompositesIndex.IndexedEntry entry,
ColumnFamily data,
long now) |
boolean |
CompositesIndexOnPartitionKey.isStale(CompositesIndex.IndexedEntry entry,
ColumnFamily data,
long now) |
boolean |
CompositesIndexOnRegular.isStale(CompositesIndex.IndexedEntry entry,
ColumnFamily data,
long now) |
Modifier and Type | Method and Description |
---|---|
boolean |
KeysIndex.isIndexEntryStale(java.nio.ByteBuffer indexedValue,
ColumnFamily data,
long now) |
Modifier and Type | Field and Description |
---|---|
protected ColumnFamily |
AbstractSSTableSimpleWriter.columnFamily |
Modifier and Type | Method and Description |
---|---|
protected abstract ColumnFamily |
AbstractSSTableSimpleWriter.getColumnFamily() |
ColumnFamily |
SSTableIdentityIterator.getColumnFamily() |
protected ColumnFamily |
SSTableSimpleUnsortedWriter.getColumnFamily() |
protected ColumnFamily |
SSTableSimpleWriter.getColumnFamily() |
ColumnFamily |
SSTableIdentityIterator.getColumnFamilyWithColumns(ColumnFamily.Factory containerFactory) |
Modifier and Type | Method and Description |
---|---|
void |
SSTableWriter.append(DecoratedKey decoratedKey,
ColumnFamily cf) |
static RowIndexEntry |
SSTableWriter.rawAppend(ColumnFamily cf,
long startPosition,
DecoratedKey key,
java.io.DataOutput out) |
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) |
Modifier and Type | Method and Description |
---|---|
static ColumnFamily |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
java.nio.ByteBuffer key,
CASConditions conditions,
ColumnFamily updates,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
Modifier and Type | Method and Description |
---|---|
boolean |
CASConditions.appliesTo(ColumnFamily current)
Returns whether the provided CF, that represents the values fetched using the
readFilter(), match the CAS conditions this object stands for.
|
static ColumnFamily |
StorageProxy.cas(java.lang.String keyspaceName,
java.lang.String cfName,
java.nio.ByteBuffer key,
CASConditions conditions,
ColumnFamily updates,
ConsistencyLevel consistencyForPaxos,
ConsistencyLevel consistencyForCommit)
Apply @param updates if and only if the current values in the row for @param key
match the provided @param conditions.
|
static java.util.List<AsyncOneResponse> |
RowDataResolver.scheduleRepairs(ColumnFamily resolved,
java.lang.String keyspaceName,
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.
|
Modifier and Type | Method and Description |
---|---|
static java.util.List<AsyncOneResponse> |
RowDataResolver.scheduleRepairs(ColumnFamily resolved,
java.lang.String keyspaceName,
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.
|
Modifier and Type | Method and Description |
---|---|
static java.util.Iterator<ColumnFamily> |
QueryPagers.pageRowLocally(ColumnFamilyStore cfs,
java.nio.ByteBuffer key,
int pageSize)
Convenience method to (locally) page an internal row.
|
Modifier and Type | Field and Description |
---|---|
ColumnFamily |
Commit.update |
Modifier and Type | Method and Description |
---|---|
static Commit |
Commit.newProposal(java.nio.ByteBuffer key,
java.util.UUID ballot,
ColumnFamily update) |
Constructor and Description |
---|
Commit(java.nio.ByteBuffer key,
java.util.UUID ballot,
ColumnFamily update) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Map<DecoratedKey,ColumnFamily> |
CassandraServer.readColumnFamily(java.util.List<ReadCommand> commands,
ConsistencyLevel consistency_level) |
Modifier and Type | Method and Description |
---|---|
static void |
Tracing.addColumn(ColumnFamily cf,
java.nio.ByteBuffer name,
java.net.InetAddress address) |
static void |
Tracing.addColumn(ColumnFamily cf,
java.nio.ByteBuffer name,
int value) |
static void |
Tracing.addColumn(ColumnFamily cf,
java.nio.ByteBuffer name,
long value) |
static void |
Tracing.addColumn(ColumnFamily cf,
java.nio.ByteBuffer name,
java.lang.String value) |
void |
Tracing.addParameterColumns(ColumnFamily cf,
java.util.Map<java.lang.String,java.lang.String> rawPayload) |
Modifier and Type | Method and Description |
---|---|
ColumnFamily |
TriggerExecutor.execute(java.nio.ByteBuffer key,
ColumnFamily updates) |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<RowMutation> |
ITrigger.augment(java.nio.ByteBuffer key,
ColumnFamily update)
Called exactly once per CF update, returned mutations are atomically updated.
|
ColumnFamily |
TriggerExecutor.execute(java.nio.ByteBuffer key,
ColumnFamily updates) |
Copyright © 2014 The Apache Software Foundation