Uses of Interface
org.apache.cassandra.db.rows.Row
-
-
Uses of Row in org.apache.cassandra.cql3
Methods in org.apache.cassandra.cql3 that return Row Modifier and Type Method Description Row
UpdateParameters. buildRow()
Row
UpdateParameters. getPrefetchedRow(DecoratedKey key, Clustering<?> clustering)
Returns the prefetched row with the already performed modifications.Methods in org.apache.cassandra.cql3 with parameters of type Row Modifier and Type Method Description static UntypedResultSet.Row
UntypedResultSet.Row. fromInternalRow(TableMetadata metadata, DecoratedKey key, Row row)
-
Uses of Row in org.apache.cassandra.cql3.conditions
Methods in org.apache.cassandra.cql3.conditions with parameters of type Row Modifier and Type Method Description abstract boolean
ColumnCondition.Bound. appliesTo(Row row)
Validates whether this condition applies tocurrent
.protected static Cell<?>
ColumnCondition. getCell(Row row, ColumnMetadata column)
protected static Cell<?>
ColumnCondition. getCell(Row row, ColumnMetadata column, CellPath path)
protected static java.util.Iterator<Cell<?>>
ColumnCondition. getCells(Row row, ColumnMetadata column)
-
Uses of Row in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return Row Modifier and Type Method Description protected Row
ReadCommand.CheckForAbort. applyToRow(Row row)
Row
SimpleBuilders.RowBuilder. build()
Methods in org.apache.cassandra.db that return types with arguments of type Row Modifier and Type Method Description java.util.Comparator<Row>
ClusteringComparator. rowComparator()
A comparator for rows.Methods in org.apache.cassandra.db with parameters of type Row Modifier and Type Method Description protected Row
ReadCommand.CheckForAbort. applyToRow(Row row)
static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder, Row staticRow, DeletionTime partitionDeletion)
-
Uses of Row in org.apache.cassandra.db.columniterator
Fields in org.apache.cassandra.db.columniterator declared as Row Modifier and Type Field Description protected Row
AbstractSSTableIterator. staticRow
Methods in org.apache.cassandra.db.columniterator that return Row Modifier and Type Method Description Row
AbstractSSTableIterator. staticRow()
-
Uses of Row in org.apache.cassandra.db.filter
Methods in org.apache.cassandra.db.filter with parameters of type Row Modifier and Type Method Description protected abstract void
DataLimits.Counter. applyToPartition(DecoratedKey partitionKey, Row staticRow)
protected java.nio.ByteBuffer
RowFilter.Expression. getValue(TableMetadata metadata, DecoratedKey partitionKey, Row row)
protected boolean
DataLimits.Counter. isLive(Row row)
boolean
RowFilter.CustomExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
abstract boolean
RowFilter.Expression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
Returns whether the provided row satisfied this expression or not.boolean
RowFilter. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row, int nowInSec)
Whether the provided row in the provided partition satisfies this filter.boolean
RowFilter.SimpleExpression. isSatisfiedBy(TableMetadata metadata, DecoratedKey partitionKey, Row row)
-
Uses of Row in org.apache.cassandra.db.partitions
Methods in org.apache.cassandra.db.partitions that return Row Modifier and Type Method Description protected Row
PurgeFunction. applyToRow(Row row)
protected Row
PurgeFunction. applyToStatic(Row row)
Row
AbstractBTreePartition. 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
AbstractBTreePartition. lastRow()
Row
AtomicBTreePartition. 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
AbstractBTreePartition. staticRow()
Row
AtomicBTreePartition. staticRow()
Methods in org.apache.cassandra.db.partitions that return types with arguments of type Row Modifier and Type Method Description java.util.Iterator<Row>
AbstractBTreePartition. iterator()
java.util.Iterator<Row>
AtomicBTreePartition. iterator()
Methods in org.apache.cassandra.db.partitions with parameters of type Row Modifier and Type Method Description void
PartitionUpdate.Builder. add(Row row)
Adds a row to this update.protected Row
PurgeFunction. applyToRow(Row row)
protected Row
PurgeFunction. applyToStatic(Row row)
static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, java.nio.ByteBuffer key, Row row)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, DecoratedKey key, Row row)
Creates an immutable partition update that contains a single row update.static PartitionUpdate
PartitionUpdate. singleRowUpdate(TableMetadata metadata, DecoratedKey key, Row row, Row staticRow)
Creates an immutable partition update that contains a single row update.Constructors in org.apache.cassandra.db.partitions with parameters of type Row Constructor Description ImmutableBTreePartition(TableMetadata metadata, DecoratedKey partitionKey, RegularAndStaticColumns columns, Row staticRow, java.lang.Object[] tree, DeletionInfo deletionInfo, EncodingStats stats)
-
Uses of Row in org.apache.cassandra.db.rows
Classes in org.apache.cassandra.db.rows that implement Row Modifier and Type Class Description class
AbstractRow
Base abstract class forRow
implementations.class
BTreeRow
Immutable implementation of a Row object.Fields in org.apache.cassandra.db.rows declared as Row Modifier and Type Field Description static Row
Rows. EMPTY_STATIC_ROW
protected Row
AbstractUnfilteredRowIterator. staticRow
Row
UnfilteredRowIteratorSerializer.Header. staticRow
Methods in org.apache.cassandra.db.rows that return Row Modifier and Type Method Description protected Row
WithOnlyQueriedData. applyToRow(Row row)
protected Row
WithOnlyQueriedData. applyToStatic(Row row)
Row
BTreeRow.Builder. build()
Row
Row.Builder. build()
Builds and return built row.Row
Row.SimpleBuilder. build()
Returns the built row.Row
UnfilteredSerializer. deserializeRowBody(DataInputPlus in, SerializationHeader header, DeserializationHelper helper, int flags, int extendedFlags, Row.Builder builder)
Row
UnfilteredSerializer. deserializeStaticRow(DataInputPlus in, SerializationHeader header, DeserializationHelper helper)
Row
BTreeRow. filter(ColumnFilter filter, DeletionTime activeDeletion, boolean setActiveDeletionToRow, TableMetadata metadata)
Row
BTreeRow. filter(ColumnFilter filter, TableMetadata metadata)
Row
Row. filter(ColumnFilter filter, DeletionTime activeDeletion, boolean setActiveDeletionToRow, TableMetadata metadata)
Returns a copy of this row that: 1) only includes the data for the column included byfilter
.Row
Row. filter(ColumnFilter filter, TableMetadata metadata)
Returns a copy of this row that: 1) only includes the data for the column included byfilter
.Row
BTreeRow. 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)
Row[]
Row.Merger. mergedRows()
Row
UnfilteredRowIterators.MergeListener. onMergedRows(Row merged, Row[] versions)
Called once for every row participating in the merge.Row
BTreeRow. purge(DeletionPurger purger, int nowInSec, boolean enforceStrictLiveness)
Row
Row. purge(DeletionPurger purger, int nowInSec, boolean enforceStrictLiveness)
Returns a copy of this row without any deletion info that should be purged according topurger
.static Row
Rows. removeShadowedCells(Row existing, Row update, DeletionTime rangeDeletion)
Returns a row that is obtained from the given existing row by removing everything that is shadowed by data in the update row.Row
AbstractUnfilteredRowIterator. staticRow()
Row
BaseRowIterator. staticRow()
The static part corresponding to this partition (this can be an empty row but cannot benull
).Row
LazilyInitializedUnfilteredRowIterator. staticRow()
Row
UnfilteredRowIteratorWithLowerBound. staticRow()
Row
WrappingUnfilteredRowIterator. staticRow()
Row
BTreeRow. updateAllTimestamp(long newTimestamp)
Returns a copy of the row where all timestamps for live data have replaced bynewTimestamp
and all deletion timestamp bynewTimestamp - 1
.Row
Row. updateAllTimestamp(long newTimestamp)
Returns a copy of this row where all live timestamp have been replaced bynewTimestamp
and every deletion timestamp bynewTimestamp - 1
.Row
BTreeRow. withOnlyQueriedData(ColumnFilter filter)
Row
Row. withOnlyQueriedData(ColumnFilter filter)
Returns a copy of this row which only include the data queried byfilter
, excluding anything _fetched_ for internal reasons but not queried by the user (seeColumnFilter
for details).Row
BTreeRow. withRowDeletion(DeletionTime newDeletion)
Row
Row. withRowDeletion(DeletionTime deletion)
Returns a copy of this row with the new deletion as row deletion if it is more recent than the current row deletion.Methods in org.apache.cassandra.db.rows with parameters of type Row Modifier and Type Method Description void
Row.Merger. add(int i, Row row)
protected Row
WithOnlyQueriedData. applyToRow(Row row)
protected Row
WithOnlyQueriedData. applyToStatic(Row row)
static EncodingStats
EncodingStats.Collector. collect(Row staticRow, java.util.Iterator<Row> rows, DeletionInfo deletionInfo)
static int
Rows. collectStats(Row row, PartitionStatisticsCollector collector)
Collect statistics on a given row.static Row.Builder
Rows. copy(Row row, Row.Builder builder)
static void
Rows. diff(RowDiffListener diffListener, Row merged, Row... inputs)
Given the result (merged
) of merging multipleinputs
, signals the difference between each input andmerged
todiffListener
.static boolean
UnfilteredSerializer. hasExtendedFlags(Row row)
static Row
Rows. merge(Row row1, Row row2)
static long
Rows. merge(Row existing, Row update, Row.Builder builder)
Merges two rows into the given builder, mainly for merging memtable rows.static UnfilteredRowIterator
UnfilteredRowIterators. noRowsIterator(TableMetadata metadata, DecoratedKey partitionKey, Row staticRow, DeletionTime partitionDeletion, boolean isReverseOrder)
Returns an empty unfiltered iterator for a given partition.Row
UnfilteredRowIterators.MergeListener. onMergedRows(Row merged, Row[] versions)
Called once for every row participating in the merge.static Row
Rows. removeShadowedCells(Row existing, Row update, DeletionTime rangeDeletion)
Returns a row that is obtained from the given existing row by removing everything that is shadowed by data in the update row.void
UnfilteredSerializer. serializeStaticRow(Row row, SerializationHelper helper, DataOutputPlus out, int version)
static UnfilteredRowIterator
UnfilteredRowIterators. singleton(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats encodingStats)
Method parameters in org.apache.cassandra.db.rows with type arguments of type Row Modifier and Type Method Description static EncodingStats
EncodingStats.Collector. collect(Row staticRow, java.util.Iterator<Row> rows, DeletionInfo deletionInfo)
Constructors in org.apache.cassandra.db.rows with parameters of type Row Constructor Description AbstractUnfilteredRowIterator(TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats stats)
RowAndDeletionMergeIterator(TableMetadata 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 parameters in org.apache.cassandra.db.rows with type arguments of type Row Constructor Description RowAndDeletionMergeIterator(TableMetadata 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)
-
Uses of Row in org.apache.cassandra.db.streaming
Methods in org.apache.cassandra.db.streaming that return Row Modifier and Type Method Description Row
CassandraStreamReader.StreamDeserializer. staticRow()
-
Uses of Row in org.apache.cassandra.db.transform
Methods in org.apache.cassandra.db.transform that return Row Modifier and Type Method Description protected Row
DuplicateRowChecker. applyToRow(Row row)
protected Row
Filter. applyToRow(Row row)
protected Row
Transformation. applyToRow(Row row)
Applied to any row we encounter in a rows iteratorprotected Row
DuplicateRowChecker. applyToStatic(Row row)
protected Row
Filter. applyToStatic(Row row)
protected Row
Transformation. applyToStatic(Row row)
Applied to the static row of any rows iterator.Row
BaseRows. staticRow()
Methods in org.apache.cassandra.db.transform with parameters of type Row Modifier and Type Method Description protected Row
DuplicateRowChecker. applyToRow(Row row)
protected Row
Filter. applyToRow(Row row)
protected Row
Transformation. applyToRow(Row row)
Applied to any row we encounter in a rows iteratorprotected Row
DuplicateRowChecker. applyToStatic(Row row)
protected Row
Filter. applyToStatic(Row row)
protected Row
Transformation. applyToStatic(Row row)
Applied to the static row of any rows iterator. -
Uses of Row in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view with parameters of type Row Modifier and Type Method Description void
ViewUpdateGenerator. addBaseTableUpdate(Row existingBaseRow, Row mergedBaseRow)
Adds to this generator the updates to be made to the view given a base table row before and after an update.boolean
View. matchesViewFilter(DecoratedKey partitionKey, Row baseRow, int nowInSec)
Whether a given base row matches the view filter (and thus if is should have a corresponding entry).boolean
View. mayBeAffectedBy(DecoratedKey partitionKey, Row update)
Whether the view might be affected by the provided update. -
Uses of Row in org.apache.cassandra.index
Methods in org.apache.cassandra.index with parameters of type Row Modifier and Type Method Description void
Index.Indexer. insertRow(Row row)
Notification that a new row was inserted into the Memtable holding the partition.void
Index.Indexer. removeRow(Row row)
Notification that a row was removed from the partition.void
Index.Indexer. updateRow(Row oldRowData, Row newRowData)
Notification of a modification to a row in the base table's Memtable. -
Uses of Row in org.apache.cassandra.index.internal
Methods in org.apache.cassandra.index.internal with parameters of type Row Modifier and Type Method Description abstract IndexEntry
CassandraIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
Used at search time to convert a row in the index table into a simple struct containing the values required to retrieve the corresponding row from the base table.abstract boolean
CassandraIndex. isStale(Row row, java.nio.ByteBuffer indexValue, int nowInSec)
Check whether a value retrieved from an index is still valid by comparing it to current row from the base table. -
Uses of Row in org.apache.cassandra.index.internal.composites
Methods in org.apache.cassandra.index.internal.composites with parameters of type Row Modifier and Type Method Description IndexEntry
ClusteringColumnIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
IndexEntry
CollectionKeyIndexBase. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
IndexEntry
CollectionValueIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
IndexEntry
PartitionKeyIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
IndexEntry
RegularColumnIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
boolean
ClusteringColumnIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
boolean
CollectionEntryIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
boolean
CollectionKeyIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
boolean
CollectionValueIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
boolean
PartitionKeyIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
boolean
RegularColumnIndex. isStale(Row data, java.nio.ByteBuffer indexValue, int nowInSec)
-
Uses of Row in org.apache.cassandra.index.internal.keys
Methods in org.apache.cassandra.index.internal.keys with parameters of type Row Modifier and Type Method Description IndexEntry
KeysIndex. decodeEntry(DecoratedKey indexedValue, Row indexEntry)
boolean
KeysIndex. isStale(Row row, java.nio.ByteBuffer indexValue, int nowInSec)
-
Uses of Row in org.apache.cassandra.index.sasi.conf
Methods in org.apache.cassandra.index.sasi.conf with parameters of type Row Modifier and Type Method Description static java.nio.ByteBuffer
ColumnIndex. getValueOf(ColumnMetadata column, Row row, int nowInSecs)
long
ColumnIndex. index(DecoratedKey key, Row row)
-
Uses of Row in org.apache.cassandra.index.sasi.plan
Methods in org.apache.cassandra.index.sasi.plan with parameters of type Row Modifier and Type Method Description boolean
Operation. satisfiedBy(Unfiltered currentCluster, Row staticRow, boolean allowMissingColumns)
Recursive "satisfies" checks based on operation and data from the lower level members using depth-first search and bubbling the results back to the top level caller. -
Uses of Row in org.apache.cassandra.index.transactions
Methods in org.apache.cassandra.index.transactions with parameters of type Row Modifier and Type Method Description void
UpdateTransaction. onInserted(Row row)
void
CleanupTransaction. onRowDelete(Row row)
void
CompactionTransaction. onRowMerge(Row merged, Row... versions)
void
UpdateTransaction. onUpdated(Row existing, Row updated)
-
Uses of Row in org.apache.cassandra.io.sstable
Methods in org.apache.cassandra.io.sstable that return Row Modifier and Type Method Description abstract Row
SSTableSimpleIterator. readStaticRow()
Row
SSTableIdentityIterator. staticRow()
-
Uses of Row in org.apache.cassandra.service.pager
Methods in org.apache.cassandra.service.pager with parameters of type Row Modifier and Type Method Description static PagingState.RowMark
PagingState.RowMark. create(TableMetadata metadata, Row row, ProtocolVersion protocolVersion)
protected void
PartitionRangeQueryPager. recordLast(DecoratedKey key, Row last)
protected void
SinglePartitionPager. recordLast(DecoratedKey key, Row last)
-
Uses of Row in org.apache.cassandra.service.reads.repair
Methods in org.apache.cassandra.service.reads.repair that return Row Modifier and Type Method Description Row
RowIteratorMergeListener. onMergedRows(Row merged, Row[] versions)
Methods in org.apache.cassandra.service.reads.repair with parameters of type Row Modifier and Type Method Description Row
RowIteratorMergeListener. onMergedRows(Row merged, Row[] versions)
-
Uses of Row in org.apache.cassandra.utils.memory
Methods in org.apache.cassandra.utils.memory that return Row Modifier and Type Method Description abstract Row
EnsureOnHeap. applyToRow(Row row)
abstract Row
EnsureOnHeap. applyToStatic(Row row)
Methods in org.apache.cassandra.utils.memory that return types with arguments of type Row Modifier and Type Method Description abstract java.util.Iterator<Row>
EnsureOnHeap. applyToPartition(java.util.Iterator<Row> partition)
abstract SearchIterator<Clustering<?>,Row>
EnsureOnHeap. applyToPartition(SearchIterator<Clustering<?>,Row> partition)
Methods in org.apache.cassandra.utils.memory with parameters of type Row Modifier and Type Method Description abstract Row
EnsureOnHeap. applyToRow(Row row)
abstract Row
EnsureOnHeap. applyToStatic(Row row)
Method parameters in org.apache.cassandra.utils.memory with type arguments of type Row Modifier and Type Method Description abstract java.util.Iterator<Row>
EnsureOnHeap. applyToPartition(java.util.Iterator<Row> partition)
abstract SearchIterator<Clustering<?>,Row>
EnsureOnHeap. applyToPartition(SearchIterator<Clustering<?>,Row> partition)
-