| Modifier and Type | Method and Description | 
|---|---|
| Row | UpdateParameters. buildRow() | 
| Row | UpdateParameters. getPrefetchedRow(DecoratedKey key,
                Clustering clustering)Returns the prefetched row with the already performed modifications. | 
| 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) | 
| boolean | ColumnCondition.UDTInBound. appliesTo(Row row) | 
| static UntypedResultSet.Row | UntypedResultSet.Row. fromInternalRow(CFMetaData metadata,
               DecoratedKey key,
               Row row) | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Row | ReadCommand.CheckForAbort. applyToRow(Row row) | 
| Row | SimpleBuilders.RowBuilder. build() | 
| 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 | 
|---|---|
| protected Row | ReadCommand.CheckForAbort. applyToRow(Row row) | 
| static UnfilteredRowIterator | EmptyIterators. unfilteredRow(CFMetaData metadata,
             DecoratedKey partitionKey,
             boolean isReverseOrder,
             Row staticRow,
             DeletionTime partitionDeletion) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Row | AbstractSSTableIterator. staticRow | 
| Modifier and Type | Method and Description | 
|---|---|
| Row | AbstractSSTableIterator. staticRow() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected abstract void | DataLimits.Counter. applyToPartition(DecoratedKey partitionKey,
                Row staticRow) | 
| protected java.nio.ByteBuffer | RowFilter.Expression. getValue(CFMetaData metadata,
        DecoratedKey partitionKey,
        Row row) | 
| protected boolean | DataLimits.Counter. isLive(Row row) | 
| abstract boolean | RowFilter.Expression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row)Returns whether the provided row satisfied this expression or not. | 
| boolean | RowFilter.SimpleExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter.CustomExpression. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row) | 
| boolean | RowFilter. isSatisfiedBy(CFMetaData metadata,
             DecoratedKey partitionKey,
             Row row,
             int nowInSec)Whether the provided row in the provided partition satisfies this filter. | 
| Modifier and Type | Method and 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() | 
| Modifier and Type | Method and Description | 
|---|---|
| java.util.Iterator<Row> | AbstractBTreePartition. iterator() | 
| java.util.Iterator<Row> | AtomicBTreePartition. iterator() | 
| java.util.Iterator<Row> | PartitionUpdate. iterator()Returns an iterator that iterates over the rows of this update in clustering order. | 
| SearchIterator<Clustering,Row> | AbstractBTreePartition. 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 | PurgeFunction. applyToRow(Row row) | 
| protected Row | PurgeFunction. applyToStatic(Row row) | 
| static PartitionUpdate | PartitionUpdate. singleRowUpdate(CFMetaData metadata,
               java.nio.ByteBuffer key,
               Row row)Creates an immutable partition update that contains a single row update. | 
| static PartitionUpdate | PartitionUpdate. singleRowUpdate(CFMetaData metadata,
               DecoratedKey key,
               Row row)Creates an immutable partition update that contains a single row update. | 
| Constructor and Description | 
|---|
| ImmutableBTreePartition(CFMetaData metadata,
                       DecoratedKey partitionKey,
                       PartitionColumns columns,
                       Row staticRow,
                       java.lang.Object[] tree,
                       DeletionInfo deletionInfo,
                       EncodingStats stats) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | AbstractRowBase abstract class for  Rowimplementations. | 
| class  | BTreeRowImmutable 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 | 
|---|---|
| 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,
                  SerializationHelper helper,
                  int flags,
                  int extendedFlags,
                  Row.Builder builder) | 
| Row | UnfilteredSerializer. deserializeStaticRow(DataInputPlus in,
                    SerializationHeader header,
                    SerializationHelper helper) | 
| Row | BTreeRow. 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 | BTreeRow. 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 | 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,
     int nowInSec) | 
| Row[] | Row.Merger. mergedRows() | 
| 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 to  purger. | 
| static Row | Rows. removeShadowedCells(Row existing,
                   Row update,
                   DeletionTime rangeDeletion,
                   int nowInSec)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 be  null). | 
| 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 by  newTimestampand
 all deletion timestamp bynewTimestamp - 1. | 
| Row | Row. updateAllTimestamp(long newTimestamp)Returns a copy of this row where all live timestamp have been replaced by  newTimestampand 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 by  filter, excluding anything _fetched_ for
 internal reasons but not queried by the user (seeColumnFilterfor 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. | 
| Modifier and Type | Method and 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 andmergedtodiffListener. | 
| static void | Rows. diff(RowDiffListener diffListener,
    Row merged,
    Row... inputs)Given the result ( merged) of merging multipleinputs, signals the difference between
 each input andmergedtodiffListener. | 
| static boolean | UnfilteredSerializer. hasExtendedFlags(Row row) | 
| static Row | Rows. merge(Row row1,
     Row row2,
     int nowInSec) | 
| static long | Rows. merge(Row existing,
     Row update,
     Row.Builder builder,
     int nowInSec)Merges two rows into the given builder, mainly for merging memtable rows. | 
| static UnfilteredRowIterator | UnfilteredRowIterators. noRowsIterator(CFMetaData cfm,
              DecoratedKey partitionKey,
              Row staticRow,
              DeletionTime partitionDeletion,
              boolean isReverseOrder)Returns an empty unfiltered iterator for a given partition. | 
| void | UnfilteredRowIterators.MergeListener. onMergedRows(Row merged,
            Row[] versions)Called once for every row participating in the merge. | 
| void | 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,
                   int nowInSec)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,
                  SerializationHeader header,
                  DataOutputPlus out,
                  int version) | 
| Modifier and Type | Method and Description | 
|---|---|
| static EncodingStats | EncodingStats.Collector. collect(Row staticRow,
       java.util.Iterator<Row> rows,
       DeletionInfo deletionInfo) | 
| 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 | 
|---|---|
| protected Row | Filter. applyToRow(Row row) | 
| protected Row | Transformation. applyToRow(Row row)Applied to any row we encounter in a rows iterator | 
| protected Row | Filter. applyToStatic(Row row) | 
| protected Row | Transformation. applyToStatic(Row row)Applied to the static row of any rows iterator. | 
| Row | BaseRows. staticRow() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected Row | Filter. applyToRow(Row row) | 
| protected Row | Transformation. applyToRow(Row row)Applied to any row we encounter in a rows iterator | 
| protected Row | Filter. applyToStatic(Row row) | 
| protected Row | Transformation. applyToStatic(Row row)Applied to the static row of any rows iterator. | 
| Modifier and Type | Method and 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. | 
| Modifier and Type | Method and 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. | 
| Modifier and Type | Method and 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. | 
| Modifier and Type | Method and 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| IndexEntry | KeysIndex. decodeEntry(DecoratedKey indexedValue,
           Row indexEntry) | 
| boolean | KeysIndex. isStale(Row row,
       java.nio.ByteBuffer indexValue,
       int nowInSec) | 
| Modifier and Type | Method and Description | 
|---|---|
| static java.nio.ByteBuffer | ColumnIndex. getValueOf(ColumnDefinition column,
          Row row,
          int nowInSecs) | 
| long | ColumnIndex. index(DecoratedKey key,
     Row row) | 
| Modifier and Type | Method and 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. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | UpdateTransaction. onInserted(Row row) | 
| void | CleanupTransaction. onRowDelete(Row row) | 
| void | CompactionTransaction. onRowMerge(Row merged,
          Row... versions) | 
| void | CompactionTransaction. onRowMerge(Row merged,
          Row... versions) | 
| void | UpdateTransaction. onUpdated(Row existing,
         Row updated) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Row | SSTableSimpleIterator. readStaticRow() | 
| Row | SSTableIdentityIterator. staticRow() | 
| Modifier and Type | Method and Description | 
|---|---|
| static PagingState.RowMark | PagingState.RowMark. create(CFMetaData metadata,
      Row row,
      ProtocolVersion protocolVersion) | 
| protected void | PartitionRangeQueryPager. 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 | 
|---|---|
| abstract Row | EnsureOnHeap. applyToRow(Row row) | 
| abstract Row | EnsureOnHeap. applyToStatic(Row row) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract java.util.Iterator<Row> | EnsureOnHeap. applyToPartition(java.util.Iterator<Row> partition) | 
| abstract SearchIterator<Clustering,Row> | EnsureOnHeap. applyToPartition(SearchIterator<Clustering,Row> partition) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract Row | EnsureOnHeap. applyToRow(Row row) | 
| abstract Row | EnsureOnHeap. applyToStatic(Row row) | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract java.util.Iterator<Row> | EnsureOnHeap. applyToPartition(java.util.Iterator<Row> partition) | 
| abstract SearchIterator<Clustering,Row> | EnsureOnHeap. applyToPartition(SearchIterator<Clustering,Row> partition) | 
Copyright © 2018 The Apache Software Foundation