Uses of Interface
org.apache.cassandra.db.rows.UnfilteredRowIterator
-
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db
Methods in org.apache.cassandra.db that return UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
ReadCommand.CheckForAbort. applyToPartition(UnfilteredRowIterator partition)
UnfilteredRowIterator
StorageHook. makeRowIterator(ColumnFamilyStore cfs, SSTableReader sstable, DecoratedKey key, Slices slices, ColumnFilter selectedColumns, boolean reversed, SSTableReadsListener listener)
UnfilteredRowIterator
Memtable.MemtableUnfilteredPartitionIterator. next()
UnfilteredRowIterator
SinglePartitionReadCommand. queryMemtableAndDisk(ColumnFamilyStore cfs, ReadExecutionController executionController)
Queries both memtable and sstables to fetch the result of this query.static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder)
static UnfilteredRowIterator
EmptyIterators. unfilteredRow(TableMetadata metadata, DecoratedKey partitionKey, boolean isReverseOrder, Row staticRow, DeletionTime partitionDeletion)
Methods in org.apache.cassandra.db that return types with arguments of type UnfilteredRowIterator Modifier and Type Method Description java.lang.Iterable<UnfilteredRowIterator>
AbstractCompactionController. shadowSources(DecoratedKey key, boolean tombstoneOnly)
Methods in org.apache.cassandra.db with parameters of type UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
ReadCommand.CheckForAbort. applyToPartition(UnfilteredRowIterator partition)
void
ColumnIndex. buildRowIndex(UnfilteredRowIterator iterator)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.columniterator
Classes in org.apache.cassandra.db.columniterator that implement UnfilteredRowIterator Modifier and Type Class Description class
AbstractSSTableIterator
class
SSTableIterator
A Cell Iterator over SSTableclass
SSTableReversedIterator
A Cell Iterator in reversed clustering order over SSTable -
Uses of UnfilteredRowIterator in org.apache.cassandra.db.compaction
Methods in org.apache.cassandra.db.compaction that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
CompactionIterator. next()
Methods in org.apache.cassandra.db.compaction that return types with arguments of type UnfilteredRowIterator Modifier and Type Method Description java.lang.Iterable<UnfilteredRowIterator>
CompactionController. shadowSources(DecoratedKey key, boolean tombstoneOnly)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.compaction.writers
Methods in org.apache.cassandra.db.compaction.writers with parameters of type UnfilteredRowIterator Modifier and Type Method Description boolean
CompactionAwareWriter. append(UnfilteredRowIterator partition)
Writes a partition in an implementation specific wayprotected abstract boolean
CompactionAwareWriter. realAppend(UnfilteredRowIterator partition)
boolean
DefaultCompactionWriter. realAppend(UnfilteredRowIterator partition)
boolean
MajorLeveledCompactionWriter. realAppend(UnfilteredRowIterator partition)
protected boolean
MaxSSTableSizeWriter. realAppend(UnfilteredRowIterator partition)
boolean
SplittingSizeTieredCompactionWriter. realAppend(UnfilteredRowIterator partition)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.filter
Methods in org.apache.cassandra.db.filter that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
DataLimits.Counter. applyTo(UnfilteredRowIterator partition)
UnfilteredRowIterator
DataLimits. filter(UnfilteredRowIterator iter, int nowInSec, boolean countPartitionsWithOnlyStaticData)
UnfilteredRowIterator
ClusteringIndexFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
Returns an iterator that only returns the rows of the provided iterator that this filter selects.UnfilteredRowIterator
ClusteringIndexNamesFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
UnfilteredRowIterator
ClusteringIndexSliceFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
UnfilteredRowIterator
ClusteringIndexFilter. getUnfilteredRowIterator(ColumnFilter columnFilter, Partition partition)
Given a partition, returns a row iterator for the rows of this partition that are selected by this filter.UnfilteredRowIterator
ClusteringIndexNamesFilter. getUnfilteredRowIterator(ColumnFilter columnFilter, Partition partition)
UnfilteredRowIterator
ClusteringIndexSliceFilter. getUnfilteredRowIterator(ColumnFilter columnFilter, Partition partition)
Methods in org.apache.cassandra.db.filter with parameters of type UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
DataLimits.Counter. applyTo(UnfilteredRowIterator partition)
UnfilteredRowIterator
DataLimits. filter(UnfilteredRowIterator iter, int nowInSec, boolean countPartitionsWithOnlyStaticData)
UnfilteredRowIterator
ClusteringIndexFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
Returns an iterator that only returns the rows of the provided iterator that this filter selects.UnfilteredRowIterator
ClusteringIndexNamesFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
UnfilteredRowIterator
ClusteringIndexSliceFilter. filterNotIndexed(ColumnFilter columnFilter, UnfilteredRowIterator iterator)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.partitions
Methods in org.apache.cassandra.db.partitions that return UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
PurgeFunction. applyToPartition(UnfilteredRowIterator partition)
static UnfilteredRowIterator
UnfilteredPartitionIterators. getOnlyElement(UnfilteredPartitionIterator iter, SinglePartitionReadCommand command)
UnfilteredRowIterator
SingletonUnfilteredPartitionIterator. next()
UnfilteredRowIterator
AbstractBTreePartition. unfilteredIterator()
UnfilteredRowIterator
AbstractBTreePartition. unfilteredIterator(ColumnFilter selection, java.util.NavigableSet<Clustering<?>> clusteringsInQueryOrder, boolean reversed)
UnfilteredRowIterator
AbstractBTreePartition. unfilteredIterator(ColumnFilter selection, Slices slices, boolean reversed)
UnfilteredRowIterator
AbstractBTreePartition. unfilteredIterator(AbstractBTreePartition.Holder current, ColumnFilter selection, Slices slices, boolean reversed)
UnfilteredRowIterator
AtomicBTreePartition. unfilteredIterator()
UnfilteredRowIterator
AtomicBTreePartition. unfilteredIterator(ColumnFilter selection, java.util.NavigableSet<Clustering<?>> clusteringsInQueryOrder, boolean reversed)
UnfilteredRowIterator
AtomicBTreePartition. unfilteredIterator(ColumnFilter selection, Slices slices, boolean reversed)
UnfilteredRowIterator
AtomicBTreePartition. unfilteredIterator(AbstractBTreePartition.Holder current, ColumnFilter selection, Slices slices, boolean reversed)
UnfilteredRowIterator
Partition. unfilteredIterator()
Returns an UnfilteredRowIterator over all the rows/RT contained by this partition.UnfilteredRowIterator
Partition. unfilteredIterator(ColumnFilter columns, java.util.NavigableSet<Clustering<?>> clusteringsInQueryOrder, boolean reversed)
Returns an UnfilteredRowIterator over the rows/RT contained by this partition selected by the provided clusterings.UnfilteredRowIterator
Partition. unfilteredIterator(ColumnFilter columns, Slices slices, boolean reversed)
Returns an UnfilteredRowIterator over the rows/RT contained by this partition selected by the provided slices.Methods in org.apache.cassandra.db.partitions with parameters of type UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
PurgeFunction. applyToPartition(UnfilteredRowIterator partition)
protected static AbstractBTreePartition.Holder
AbstractBTreePartition. build(UnfilteredRowIterator iterator, int initialRowCapacity)
protected static AbstractBTreePartition.Holder
AbstractBTreePartition. build(UnfilteredRowIterator iterator, int initialRowCapacity, boolean ordered)
static CachedBTreePartition
CachedBTreePartition. create(UnfilteredRowIterator iterator, int nowInSec)
Creates anArrayBackedCachedPartition
holding all the data of the provided iterator.static CachedBTreePartition
CachedBTreePartition. create(UnfilteredRowIterator iterator, int initialRowCapacity, int nowInSec)
Creates anArrayBackedCachedPartition
holding all the data of the provided iterator.static ImmutableBTreePartition
ImmutableBTreePartition. create(UnfilteredRowIterator iterator)
Creates anImmutableBTreePartition
holding all the data of the provided iterator.static ImmutableBTreePartition
ImmutableBTreePartition. create(UnfilteredRowIterator iterator, boolean ordered)
Creates anImmutableBTreePartition
holding all the data of the provided iterator.static ImmutableBTreePartition
ImmutableBTreePartition. create(UnfilteredRowIterator iterator, int initialRowCapacity)
Creates anImmutableBTreePartition
holding all the data of the provided iterator.static ImmutableBTreePartition
ImmutableBTreePartition. create(UnfilteredRowIterator iterator, int initialRowCapacity, boolean ordered)
Creates anImmutableBTreePartition
holding all the data of the provided iterator.static PartitionUpdate
PartitionUpdate. fromIterator(UnfilteredRowIterator iterator, ColumnFilter filter)
Turns the given iterator into an update.Method parameters in org.apache.cassandra.db.partitions with type arguments of type UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterators.MergeListener
UnfilteredPartitionIterators.MergeListener. getRowMergeListener(DecoratedKey partitionKey, java.util.List<UnfilteredRowIterator> versions)
Constructors in org.apache.cassandra.db.partitions with parameters of type UnfilteredRowIterator Constructor Description SingletonUnfilteredPartitionIterator(UnfilteredRowIterator iter)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.repair
Methods in org.apache.cassandra.db.repair that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
CassandraValidationIterator. next()
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.rows
Classes in org.apache.cassandra.db.rows that implement UnfilteredRowIterator Modifier and Type Class Description class
AbstractUnfilteredRowIterator
class
LazilyInitializedUnfilteredRowIterator
Abstract class to create UnfilteredRowIterator that lazily initialize themselves.class
RowAndDeletionMergeIterator
An iterator that merges a source of rows with the range tombstone and partition level deletion of a give partition.class
UnfilteredRowIteratorWithLowerBound
An unfiltered row iterator with a lower bound retrieved from either the global sstable statistics or the row index lower bounds (if available in the cache).class
WrappingUnfilteredRowIterator
Abstract class to make writing unfiltered iterators that wrap another iterator easier.Fields in org.apache.cassandra.db.rows declared as UnfilteredRowIterator Modifier and Type Field Description protected UnfilteredRowIterator
WrappingUnfilteredRowIterator. wrapped
Methods in org.apache.cassandra.db.rows that return UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
ThrottledUnfilteredIterator. computeNext()
static UnfilteredRowIterator
UnfilteredRowIterators. concat(Unfiltered first, UnfilteredRowIterator rest)
Returns an iterator that concatenate the specified atom with the iterator.static UnfilteredRowIterator
UnfilteredRowIterators. concat(UnfilteredRowIterator iter1, UnfilteredRowIterator iter2)
Returns an iterator that concatenate two atom iterators.UnfilteredRowIterator
UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, ColumnFilter selection, DeserializationHelper.Flag flag)
UnfilteredRowIterator
UnfilteredRowIteratorSerializer. deserialize(DataInputPlus in, int version, TableMetadata metadata, DeserializationHelper.Flag flag, UnfilteredRowIteratorSerializer.Header header)
protected abstract UnfilteredRowIterator
LazilyInitializedUnfilteredRowIterator. initializeIterator()
protected UnfilteredRowIterator
UnfilteredRowIteratorWithLowerBound. initializeIterator()
static UnfilteredRowIterator
UnfilteredRowIterators. loggingIterator(UnfilteredRowIterator iterator, java.lang.String id, boolean fullDetails)
Wraps the provided iterator so it logs the returned atoms for debugging purposes.static UnfilteredRowIterator
UnfilteredRowIterators. merge(java.util.List<UnfilteredRowIterator> iterators)
Returns an iterator that is the result of merging other iterators.static UnfilteredRowIterator
UnfilteredRowIterators. merge(java.util.List<UnfilteredRowIterator> iterators, UnfilteredRowIterators.MergeListener mergeListener)
Returns an iterator that is the result of merging other iterators, and (optionally) using specific MergeListener.static UnfilteredRowIterator
UnfilteredRowIterators. noRowsIterator(TableMetadata metadata, DecoratedKey partitionKey, Row staticRow, DeletionTime partitionDeletion, boolean isReverseOrder)
Returns an empty unfiltered iterator for a given partition.static UnfilteredRowIterator
UnfilteredRowIterators. singleton(Unfiltered unfiltered, TableMetadata metadata, DecoratedKey partitionKey, DeletionTime partitionLevelDeletion, RegularAndStaticColumns columns, Row staticRow, boolean isReverseOrder, EncodingStats encodingStats)
static UnfilteredRowIterator
UnfilteredRowIterators. withOnlyQueriedData(UnfilteredRowIterator iterator, ColumnFilter filter)
Filter the provided iterator to exclude cells that have been fetched but are not queried by the user (see ColumnFilter for detailes).static UnfilteredRowIterator
UnfilteredRowIterators. withValidation(UnfilteredRowIterator iterator, java.lang.String filename)
Validate that the data of the provided iterator is valid, that is that the values it contains are valid for the type they represent, and more generally that the infos stored are sensible.Methods in org.apache.cassandra.db.rows that return types with arguments of type UnfilteredRowIterator Modifier and Type Method Description static CloseableIterator<UnfilteredRowIterator>
ThrottledUnfilteredIterator. throttle(UnfilteredPartitionIterator partitionIterator, int maxBatchSize)
Splits aUnfilteredPartitionIterator
inUnfilteredRowIterator
batches with size no higher than maxBatchSizeMethods in org.apache.cassandra.db.rows with parameters of type UnfilteredRowIterator Modifier and Type Method Description static UnfilteredRowIterator
UnfilteredRowIterators. concat(Unfiltered first, UnfilteredRowIterator rest)
Returns an iterator that concatenate the specified atom with the iterator.static UnfilteredRowIterator
UnfilteredRowIterators. concat(UnfilteredRowIterator iter1, UnfilteredRowIterator iter2)
Returns an iterator that concatenate two atom iterators.static void
UnfilteredRowIterators. digest(UnfilteredRowIterator iterator, Digest digest, int version)
Digests the partition represented by the provided iterator.static RowIterator
UnfilteredRowIterators. filter(UnfilteredRowIterator iter, int nowInSec)
Returns a iterator that only returns rows with only live content.static UnfilteredRowIterator
UnfilteredRowIterators. loggingIterator(UnfilteredRowIterator iterator, java.lang.String id, boolean fullDetails)
Wraps the provided iterator so it logs the returned atoms for debugging purposes.void
UnfilteredRowIteratorSerializer. serialize(UnfilteredRowIterator iterator, ColumnFilter selection, DataOutputPlus out, int version)
void
UnfilteredRowIteratorSerializer. serialize(UnfilteredRowIterator iterator, ColumnFilter selection, DataOutputPlus out, int version, int rowEstimate)
long
UnfilteredRowIteratorSerializer. serializedSize(UnfilteredRowIterator iterator, ColumnFilter selection, int version, int rowEstimate)
static UnfilteredRowIterator
UnfilteredRowIterators. withOnlyQueriedData(UnfilteredRowIterator iterator, ColumnFilter filter)
Filter the provided iterator to exclude cells that have been fetched but are not queried by the user (see ColumnFilter for detailes).static UnfilteredRowIterator
UnfilteredRowIterators. withValidation(UnfilteredRowIterator iterator, java.lang.String filename)
Validate that the data of the provided iterator is valid, that is that the values it contains are valid for the type they represent, and more generally that the infos stored are sensible.Method parameters in org.apache.cassandra.db.rows with type arguments of type UnfilteredRowIterator Modifier and Type Method Description static UnfilteredRowIterator
UnfilteredRowIterators. merge(java.util.List<UnfilteredRowIterator> iterators)
Returns an iterator that is the result of merging other iterators.static UnfilteredRowIterator
UnfilteredRowIterators. merge(java.util.List<UnfilteredRowIterator> iterators, UnfilteredRowIterators.MergeListener mergeListener)
Returns an iterator that is the result of merging other iterators, and (optionally) using specific MergeListener.Constructors in org.apache.cassandra.db.rows with parameters of type UnfilteredRowIterator Constructor Description WrappingUnfilteredRowIterator(UnfilteredRowIterator wrapped)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.streaming
Classes in org.apache.cassandra.db.streaming that implement UnfilteredRowIterator Modifier and Type Class Description static class
CassandraStreamReader.StreamDeserializer
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.transform
Methods in org.apache.cassandra.db.transform that return UnfilteredRowIterator Modifier and Type Method Description static UnfilteredRowIterator
Transformation. apply(UnfilteredRowIterator iterator, Transformation<?> transformation)
UnfilteredRowIterator
RTBoundCloser. applyToPartition(UnfilteredRowIterator partition)
UnfilteredRowIterator
RTBoundValidator. applyToPartition(UnfilteredRowIterator partition)
static UnfilteredRowIterator
RTBoundCloser. close(UnfilteredRowIterator partition)
static UnfilteredRowIterator
MoreRows. extend(UnfilteredRowIterator iterator, MoreRows<? super UnfilteredRowIterator> more)
static UnfilteredRowIterator
MoreRows. extend(UnfilteredRowIterator iterator, MoreRows<? super UnfilteredRowIterator> more, RegularAndStaticColumns columns)
static UnfilteredRowIterator
RTBoundValidator. validate(UnfilteredRowIterator partition, RTBoundValidator.Stage stage, boolean enforceIsClosed)
Method parameters in org.apache.cassandra.db.transform with type arguments of type UnfilteredRowIterator Modifier and Type Method Description static UnfilteredPartitionIterator
Transformation. apply(UnfilteredPartitionIterator iterator, Transformation<? super UnfilteredRowIterator> transformation)
static UnfilteredRowIterator
MoreRows. extend(UnfilteredRowIterator iterator, MoreRows<? super UnfilteredRowIterator> more)
static UnfilteredRowIterator
MoreRows. extend(UnfilteredRowIterator iterator, MoreRows<? super UnfilteredRowIterator> more, RegularAndStaticColumns columns)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.db.view
Methods in org.apache.cassandra.db.view with parameters of type UnfilteredRowIterator Modifier and Type Method Description java.util.Iterator<java.util.Collection<Mutation>>
TableViews. generateViewUpdates(java.util.Collection<View> views, UnfilteredRowIterator updates, UnfilteredRowIterator existings, int nowInSec, boolean separateUpdates)
Given some updates on the base table of this object and the existing values for the rows affected by that update, generates the mutation to be applied to the provided views. -
Uses of UnfilteredRowIterator in org.apache.cassandra.db.virtual
Methods in org.apache.cassandra.db.virtual that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
AbstractVirtualTable.Partition. toRowIterator(TableMetadata metadata, ClusteringIndexFilter clusteringIndexFilter, ColumnFilter columnFilter, long now)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.index
Methods in org.apache.cassandra.index with parameters of type UnfilteredRowIterator Modifier and Type Method Description void
SecondaryIndexManager. deletePartition(UnfilteredRowIterator partition, int nowInSec)
Delete all data from all indexes for this partition. -
Uses of UnfilteredRowIterator in org.apache.cassandra.index.sasi.plan
Methods in org.apache.cassandra.index.sasi.plan that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
QueryController. getPartition(DecoratedKey key, ReadExecutionController executionController)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.io.sstable
Classes in org.apache.cassandra.io.sstable that implement UnfilteredRowIterator Modifier and Type Class Description class
SSTableIdentityIterator
Methods in org.apache.cassandra.io.sstable with parameters of type UnfilteredRowIterator Modifier and Type Method Description boolean
SimpleSSTableMultiWriter. append(UnfilteredRowIterator partition)
boolean
SSTableMultiWriter. append(UnfilteredRowIterator partition)
Writes a partition in an implementation specific wayRowIndexEntry
SSTableRewriter. append(UnfilteredRowIterator partition)
boolean
SSTableTxnWriter. append(UnfilteredRowIterator iterator)
RowIndexEntry
SSTableRewriter. tryAppend(UnfilteredRowIterator partition)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.io.sstable.format
Methods in org.apache.cassandra.io.sstable.format that return UnfilteredRowIterator Modifier and Type Method Description abstract UnfilteredRowIterator
SSTableReader. iterator(DecoratedKey key, Slices slices, ColumnFilter selectedColumns, boolean reversed, SSTableReadsListener listener)
abstract UnfilteredRowIterator
SSTableReader. iterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter selectedColumns, boolean reversed)
abstract UnfilteredRowIterator
SSTableReader. simpleIterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, boolean tombstoneOnly)
Methods in org.apache.cassandra.io.sstable.format with parameters of type UnfilteredRowIterator Modifier and Type Method Description boolean
RangeAwareSSTableWriter. append(UnfilteredRowIterator partition)
abstract RowIndexEntry
SSTableWriter. append(UnfilteredRowIterator iterator)
Appends partition data to this writer. -
Uses of UnfilteredRowIterator in org.apache.cassandra.io.sstable.format.big
Fields in org.apache.cassandra.io.sstable.format.big with type parameters of type UnfilteredRowIterator Modifier and Type Field Description protected java.util.Iterator<UnfilteredRowIterator>
BigTableScanner. iterator
Methods in org.apache.cassandra.io.sstable.format.big that return UnfilteredRowIterator Modifier and Type Method Description protected UnfilteredRowIterator
BigTableScanner.KeyScanningIterator. computeNext()
UnfilteredRowIterator
BigTableReader. iterator(DecoratedKey key, Slices slices, ColumnFilter selectedColumns, boolean reversed, SSTableReadsListener listener)
UnfilteredRowIterator
BigTableReader. iterator(FileDataInput file, DecoratedKey key, RowIndexEntry indexEntry, Slices slices, ColumnFilter selectedColumns, boolean reversed)
UnfilteredRowIterator
BigTableScanner.EmptySSTableScanner. next()
UnfilteredRowIterator
BigTableScanner. next()
UnfilteredRowIterator
BigTableReader. simpleIterator(FileDataInput dfile, DecoratedKey key, RowIndexEntry position, boolean tombstoneOnly)
Methods in org.apache.cassandra.io.sstable.format.big with parameters of type UnfilteredRowIterator Modifier and Type Method Description RowIndexEntry
BigTableWriter. append(UnfilteredRowIterator iterator)
Appends partition data to this writer.boolean
BigTableZeroCopyWriter. append(UnfilteredRowIterator partition)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.repair
Methods in org.apache.cassandra.repair with parameters of type UnfilteredRowIterator Modifier and Type Method Description void
Validator. add(UnfilteredRowIterator partition)
Called (in order) for every row present in the CF. -
Uses of UnfilteredRowIterator in org.apache.cassandra.service.reads
Methods in org.apache.cassandra.service.reads that return UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
ShortReadPartitionsProtection. applyToPartition(UnfilteredRowIterator partition)
Methods in org.apache.cassandra.service.reads with parameters of type UnfilteredRowIterator Modifier and Type Method Description UnfilteredRowIterator
ShortReadPartitionsProtection. applyToPartition(UnfilteredRowIterator partition)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.service.reads.repair
Method parameters in org.apache.cassandra.service.reads.repair with type arguments of type UnfilteredRowIterator Modifier and Type Method Description protected RegularAndStaticColumns
PartitionIteratorMergeListener. columns(java.util.List<UnfilteredRowIterator> versions)
UnfilteredRowIterators.MergeListener
PartitionIteratorMergeListener. getRowMergeListener(DecoratedKey partitionKey, java.util.List<UnfilteredRowIterator> versions)
protected boolean
PartitionIteratorMergeListener. isReversed(java.util.List<UnfilteredRowIterator> versions)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.tools
Method parameters in org.apache.cassandra.tools with type arguments of type UnfilteredRowIterator Modifier and Type Method Description static void
JsonTransformer. toJson(ISSTableScanner currentScanner, java.util.stream.Stream<UnfilteredRowIterator> partitions, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
static void
JsonTransformer. toJsonLines(ISSTableScanner currentScanner, java.util.stream.Stream<UnfilteredRowIterator> partitions, boolean rawTime, TableMetadata metadata, java.io.OutputStream out)
-
Uses of UnfilteredRowIterator in org.apache.cassandra.utils.memory
Methods in org.apache.cassandra.utils.memory that return UnfilteredRowIterator Modifier and Type Method Description abstract UnfilteredRowIterator
EnsureOnHeap. applyToPartition(UnfilteredRowIterator partition)
Methods in org.apache.cassandra.utils.memory with parameters of type UnfilteredRowIterator Modifier and Type Method Description abstract UnfilteredRowIterator
EnsureOnHeap. applyToPartition(UnfilteredRowIterator partition)
-