Modifier and Type | Method and Description |
---|---|
Row |
UpdateParameters.buildRow() |
Row |
UpdateParameters.getPrefetchedRow(DecoratedKey key,
Clustering clustering) |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
ColumnCondition.Bound.appliesTo(Row row)
Validates whether this condition applies to
current . |
boolean |
ColumnCondition.CollectionInBound.appliesTo(Row row) |
static UntypedResultSet.Row |
UntypedResultSet.Row.fromInternalRow(CFMetaData metadata,
DecoratedKey key,
Row row) |
Modifier and Type | Method and Description |
---|---|
static Row |
LegacyLayout.extractStaticColumns(CFMetaData metadata,
DataInputPlus in,
Columns statics) |
Row |
LegacyLayout.CellGrouper.getRow() |
Modifier and Type | Method and Description |
---|---|
java.util.Comparator<Row> |
ClusteringComparator.rowComparator()
A comparator for rows.
|
Modifier and Type | Method and Description |
---|---|
static java.util.Iterator<LegacyLayout.LegacyCell> |
LegacyLayout.fromRowIterator(CFMetaData metadata,
java.util.Iterator<Row> iterator,
Row staticRow) |
Modifier and Type | Method and Description |
---|---|
static java.util.Iterator<LegacyLayout.LegacyCell> |
LegacyLayout.fromRowIterator(CFMetaData metadata,
java.util.Iterator<Row> iterator,
Row staticRow) |
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) |
void |
DataLimits.Counter.newRow(Row row) |
Modifier and Type | Method and Description |
---|---|
void |
PerColumnSecondaryIndex.indexRow(DecoratedKey key,
Row row,
OpOrder.Group opGroup,
int nowInSec) |
Modifier and Type | Method and Description |
---|---|
abstract CompositesIndex.IndexedEntry |
CompositesIndex.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexIncludingCollectionKey.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnClusteringKey.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnCollectionValue.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnPartitionKey.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
CompositesIndex.IndexedEntry |
CompositesIndexOnRegular.decodeEntry(DecoratedKey indexedValue,
Row indexEntry) |
abstract boolean |
CompositesIndex.isStale(Row row,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnClusteringKey.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnCollectionKey.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnCollectionKeyAndValue.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnCollectionValue.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnPartitionKey.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
boolean |
CompositesIndexOnRegular.isStale(Row data,
java.nio.ByteBuffer indexValue,
int nowInSec) |
Modifier and Type | Method and Description |
---|---|
void |
KeysIndex.indexRow(DecoratedKey key,
Row row,
OpOrder.Group opGroup,
int nowInSec) |
Modifier and Type | Field and Description |
---|---|
protected java.util.List<Row> |
AbstractThreadUnsafePartition.rows |
Modifier and Type | Method and Description |
---|---|
protected Row |
AlteringUnfilteredPartitionIterator.computeNext(DecoratedKey partitionKey,
Row row) |
protected Row |
AlteringUnfilteredPartitionIterator.computeNextStatic(DecoratedKey partitionKey,
Row row) |
Row |
AbstractThreadUnsafePartition.getRow(Clustering clustering) |
Row |
AtomicBTreePartition.getRow(Clustering clustering) |
Row |
Partition.getRow(Clustering clustering)
Returns the row corresponding to the provided clustering, or null if there is not such row.
|
Row |
ArrayBackedCachedPartition.lastRow() |
Row |
CachedPartition.lastRow()
The last row in this cached partition (in order words, the row with the
biggest clustering that the partition contains).
|
Row |
CountingRowIterator.next() |
abstract Row |
AbstractThreadUnsafePartition.staticRow() |
Row |
ArrayBackedPartition.staticRow() |
Row |
FilteredPartition.staticRow() |
Row |
PartitionUpdate.staticRow() |
Modifier and Type | Method and Description |
---|---|
java.util.Iterator<Row> |
AbstractThreadUnsafePartition.iterator()
Returns an iterator that iterators over the rows of this update in clustering order.
|
java.util.Iterator<Row> |
PartitionUpdate.iterator()
Returns an iterator that iterates over the rows of this update in clustering order.
|
SearchIterator<Clustering,Row> |
AbstractThreadUnsafePartition.searchIterator(ColumnFilter columns,
boolean reversed) |
SearchIterator<Clustering,Row> |
AtomicBTreePartition.searchIterator(ColumnFilter columns,
boolean reversed) |
SearchIterator<Clustering,Row> |
Partition.searchIterator(ColumnFilter columns,
boolean reversed)
Returns an iterator that allows to search specific rows efficiently.
|
Modifier and Type | Method and Description |
---|---|
void |
PartitionUpdate.add(Row row)
Adds a row to this update.
|
protected Row |
AlteringUnfilteredPartitionIterator.computeNext(DecoratedKey partitionKey,
Row row) |
protected Row |
AlteringUnfilteredPartitionIterator.computeNextStatic(DecoratedKey partitionKey,
Row row) |
static PartitionUpdate |
PartitionUpdate.singleRowUpdate(CFMetaData metadata,
DecoratedKey key,
Row row)
Creates an immutable partition update that contains a single row update.
|
Constructor and Description |
---|
ArrayBackedPartition(CFMetaData metadata,
DecoratedKey partitionKey,
PartitionColumns columns,
Row staticRow,
java.util.List<Row> rows,
DeletionInfo deletionInfo,
EncodingStats stats) |
Constructor and Description |
---|
AbstractThreadUnsafePartition(CFMetaData metadata,
DecoratedKey key,
PartitionColumns columns,
java.util.List<Row> rows) |
ArrayBackedPartition(CFMetaData metadata,
DecoratedKey partitionKey,
PartitionColumns columns,
Row staticRow,
java.util.List<Row> rows,
DeletionInfo deletionInfo,
EncodingStats stats) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractRow
Base abstract class for
Row implementations. |
class |
BTreeBackedRow
Immutable implementation of a Row object.
|
Modifier and Type | Field and Description |
---|---|
static Row |
Rows.EMPTY_STATIC_ROW |
protected Row |
AbstractUnfilteredRowIterator.staticRow |
Row |
UnfilteredRowIteratorSerializer.Header.staticRow |
Modifier and Type | Method and Description |
---|---|
Row |
BTreeBackedRow.Builder.build() |
Row |
Row.Builder.build()
Builds and return built row.
|
protected Row |
AlteringUnfilteredRowIterator.computeNext(Row row) |
protected Row |
AlteringUnfilteredRowIterator.computeNextStatic(Row row) |
Row |
UnfilteredSerializer.deserializeRowBody(DataInputPlus in,
SerializationHeader header,
SerializationHelper helper,
int flags,
Row.Builder builder) |
Row |
UnfilteredSerializer.deserializeStaticRow(DataInputPlus in,
SerializationHeader header,
SerializationHelper helper) |
Row |
BTreeBackedRow.filter(ColumnFilter filter,
CFMetaData metadata) |
Row |
Row.filter(ColumnFilter filter,
CFMetaData metadata)
Returns a copy of this row that:
1) only includes the data for the column included by
filter . |
Row |
BTreeBackedRow.filter(ColumnFilter filter,
DeletionTime activeDeletion,
boolean setActiveDeletionToRow,
CFMetaData metadata) |
Row |
Row.filter(ColumnFilter filter,
DeletionTime activeDeletion,
boolean setActiveDeletionToRow,
CFMetaData metadata)
Returns a copy of this row that:
1) only includes the data for the column included by
filter . |
Row |
BTreeBackedRow.markCounterLocalToBeCleared() |
Row |
Row.markCounterLocalToBeCleared()
Returns a copy of this row where all counter cells have they "local" shard marked for clearing.
|
Row |
Row.Merger.merge(DeletionTime activeDeletion) |
static Row |
Rows.merge(Row row1,
Row row2,
int nowInSec) |
Row[] |
Row.Merger.mergedRows() |
Row |
WrappingRowIterator.next() |
Row |
BTreeBackedRow.purge(DeletionPurger purger,
int nowInSec) |
Row |
Row.purge(DeletionPurger purger,
int nowInSec)
Returns a copy of this row without any deletion info that should be purged according to
purger . |
Row |
AbstractUnfilteredRowIterator.staticRow() |
Row |
AlteringUnfilteredRowIterator.staticRow() |
Row |
LazilyInitializedUnfilteredRowIterator.staticRow() |
Row |
RowIterator.staticRow()
The static part corresponding to this partition (this can be an empty
row).
|
Row |
UnfilteredRowIterator.staticRow()
The static part corresponding to this partition (this can be an empty
row).
|
Row |
WrappingRowIterator.staticRow() |
Row |
WrappingUnfilteredRowIterator.staticRow() |
Row |
BTreeBackedRow.updateAllTimestamp(long newTimestamp)
Returns a copy of the row where all timestamps for live data have replaced by
newTimestamp and
all deletion timestamp by newTimestamp - 1 . |
Row |
Row.updateAllTimestamp(long newTimestamp)
returns a copy of this row where all live timestamp have been replaced by
newTimestamp and every deletion timestamp
by newTimestamp - 1 . |
Modifier and Type | Method and Description |
---|---|
void |
Row.Merger.add(int i,
Row row) |
static int |
Rows.collectStats(Row row,
PartitionStatisticsCollector collector)
Collect statistics ont a given row.
|
protected Row |
AlteringUnfilteredRowIterator.computeNext(Row row) |
protected Row |
AlteringUnfilteredRowIterator.computeNextStatic(Row row) |
static Row.Builder |
Rows.copy(Row row,
Row.Builder builder) |
static void |
Rows.diff(Row merged,
Columns columns,
Row[] inputs,
RowDiffListener diffListener)
Given the result (
merged ) of merging multiple inputs , signals the difference between
each input and merged to diffListener . |
static void |
Rows.diff(Row merged,
Columns columns,
Row[] inputs,
RowDiffListener diffListener)
Given the result (
merged ) of merging multiple inputs , signals the difference between
each input and merged to diffListener . |
static void |
Rows.merge(Row row1,
Row row2,
Columns mergedColumns,
Row.Builder builder,
int nowInSec) |
static long |
Rows.merge(Row existing,
Row update,
Columns mergedColumns,
Row.Builder builder,
int nowInSec,
SecondaryIndexManager.Updater indexUpdater) |
static Row |
Rows.merge(Row row1,
Row row2,
int nowInSec) |
void |
UnfilteredRowIterators.MergeListener.onMergedRows(Row merged,
Columns columns,
Row[] versions) |
void |
UnfilteredRowIterators.MergeListener.onMergedRows(Row merged,
Columns columns,
Row[] versions) |
void |
UnfilteredSerializer.serialize(Row row,
SerializationHeader header,
DataOutputPlus out,
int version) |
long |
UnfilteredSerializer.serializedSize(Row row,
SerializationHeader header,
int version) |
Constructor and Description |
---|
AbstractUnfilteredRowIterator(CFMetaData metadata,
DecoratedKey partitionKey,
DeletionTime partitionLevelDeletion,
PartitionColumns columns,
Row staticRow,
boolean isReverseOrder,
EncodingStats stats) |
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) |
Constructor and Description |
---|
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 |
---|---|
abstract Row |
SSTableSimpleIterator.readStaticRow() |
Row |
SSTableIdentityIterator.staticRow() |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
Row |
StreamReader.StreamDeserializer.staticRow() |
Modifier and Type | Method and Description |
---|---|
MemtableAllocator.DataReclaimer |
MemtableAllocator.DataReclaimer.reclaim(Row row) |
MemtableAllocator.DataReclaimer |
MemtableAllocator.DataReclaimer.reclaimImmediately(Row row) |
Copyright © 2015 The Apache Software Foundation