Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
LegacyLayout.deserializeLegacyPartition(DataInputPlus in,
int version,
SerializationHelper.Flag flag,
java.nio.ByteBuffer key) |
abstract UnfilteredRowIterator |
Slices.makeSliceIterator(SliceableUnfilteredRowIterator iter)
Given a sliceable row iterator, returns a row iterator that only return rows selected by the slice of
this
Slices object. |
UnfilteredRowIterator |
Memtable.MemtableUnfilteredPartitionIterator.next() |
static UnfilteredRowIterator |
LegacyLayout.onWireCellstoUnfilteredRowIterator(CFMetaData metadata,
DecoratedKey key,
LegacyLayout.LegacyDeletionInfo delInfo,
java.util.Iterator<LegacyLayout.LegacyCell> cells,
boolean reversed,
SerializationHelper helper) |
UnfilteredRowIterator |
SinglePartitionReadCommand.queryMemtableAndDisk(ColumnFamilyStore cfs,
OpOrder.Group readOp)
Queries both memtable and sstables to fetch the result of this query.
|
UnfilteredRowIterator |
SinglePartitionReadCommand.queryMemtableAndDisk(ColumnFamilyStore cfs,
ReadExecutionController executionController) |
static UnfilteredRowIterator |
LegacyLayout.toUnfilteredRowIterator(CFMetaData metadata,
DecoratedKey key,
LegacyLayout.LegacyDeletionInfo delInfo,
java.util.Iterator<LegacyLayout.LegacyCell> cells) |
UnfilteredRowIterator |
RowUpdateBuilder.unfilteredIterator() |
static UnfilteredRowIterator |
EmptyIterators.unfilteredRow(CFMetaData metadata,
DecoratedKey partitionKey,
boolean isReverseOrder) |
static UnfilteredRowIterator |
EmptyIterators.unfilteredRow(CFMetaData metadata,
DecoratedKey partitionKey,
boolean isReverseOrder,
Row staticRow,
DeletionTime partitionDeletion) |
protected UnfilteredRowIterator |
ReadCommand.withStateTracking(UnfilteredRowIterator iter) |
Modifier and Type | Method and Description |
---|---|
static LegacyLayout.LegacyUnfilteredPartition |
LegacyLayout.fromUnfilteredRowIterator(UnfilteredRowIterator iterator) |
static void |
LegacyLayout.serializeAsLegacyPartition(UnfilteredRowIterator partition,
DataOutputPlus out,
int version) |
static long |
LegacyLayout.serializedSizeAsLegacyPartition(UnfilteredRowIterator partition,
int version) |
protected UnfilteredRowIterator |
ReadCommand.withStateTracking(UnfilteredRowIterator iter) |
static ColumnIndex |
ColumnIndex.writeAndBuildIndex(UnfilteredRowIterator iterator,
SequentialWriter output,
SerializationHeader header,
java.util.Collection<SSTableFlushObserver> observers,
Version version) |
Modifier and Type | Class and Description |
---|---|
class |
SSTableIterator
A Cell Iterator over SSTable
|
class |
SSTableReversedIterator
A Cell Iterator in reversed clustering order over SSTable
|
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
CompactionIterator.next() |
Modifier and Type | Method and Description |
---|---|
boolean |
CompactionAwareWriter.append(UnfilteredRowIterator partition)
Writes a partition in an implementation specific way
|
protected 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) |
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
DataLimits.Counter.applyTo(UnfilteredRowIterator partition) |
UnfilteredRowIterator |
ClusteringIndexFilter.filter(SliceableUnfilteredRowIterator iterator)
Returns an iterator that only returns the rows of the provided sliceable iterator that this filter selects.
|
UnfilteredRowIterator |
ClusteringIndexNamesFilter.filter(SliceableUnfilteredRowIterator iter) |
UnfilteredRowIterator |
ClusteringIndexSliceFilter.filter(SliceableUnfilteredRowIterator iterator) |
UnfilteredRowIterator |
DataLimits.filter(UnfilteredRowIterator iter,
int nowInSec) |
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) |
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
DataLimits.Counter.applyTo(UnfilteredRowIterator partition) |
UnfilteredRowIterator |
DataLimits.filter(UnfilteredRowIterator iter,
int nowInSec) |
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) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBTreePartition.SliceableIterator |
class |
AbstractBTreePartition.SlicesIterator |
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
PurgeFunction.applyToPartition(UnfilteredRowIterator partition) |
static UnfilteredRowIterator |
UnfilteredPartitionIterators.getOnlyElement(UnfilteredPartitionIterator iter,
SinglePartitionReadCommand command) |
UnfilteredRowIterator |
SingletonUnfilteredPartitionIterator.next() |
UnfilteredRowIterator |
AbstractBTreePartition.unfilteredIterator() |
UnfilteredRowIterator |
Partition.unfilteredIterator()
Returns an UnfilteredRowIterator over all the rows/RT contained by this partition.
|
UnfilteredRowIterator |
AbstractBTreePartition.unfilteredIterator(AbstractBTreePartition.Holder current,
ColumnFilter selection,
Slices slices,
boolean reversed) |
UnfilteredRowIterator |
AbstractBTreePartition.unfilteredIterator(ColumnFilter selection,
Slices slices,
boolean reversed) |
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.
|
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
PurgeFunction.applyToPartition(UnfilteredRowIterator partition) |
protected static AbstractBTreePartition.Holder |
AbstractBTreePartition.build(UnfilteredRowIterator iterator,
int initialRowCapacity) |
static ImmutableBTreePartition |
ImmutableBTreePartition.create(UnfilteredRowIterator iterator)
Creates an
ImmutableBTreePartition holding all the data of the provided iterator. |
static CachedBTreePartition |
CachedBTreePartition.create(UnfilteredRowIterator iterator,
int nowInSec)
Creates an
ArrayBackedCachedPartition holding all the data of the provided iterator. |
static ImmutableBTreePartition |
ImmutableBTreePartition.create(UnfilteredRowIterator iterator,
int initialRowCapacity)
Creates an
ImmutableBTreePartition holding all the data of the provided iterator. |
static CachedBTreePartition |
CachedBTreePartition.create(UnfilteredRowIterator iterator,
int initialRowCapacity,
int nowInSec)
Creates an
ArrayBackedCachedPartition holding all the data of the provided iterator. |
static PartitionUpdate |
PartitionUpdate.fromIterator(UnfilteredRowIterator iterator)
Turns the given iterator into an update.
|
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterators.MergeListener |
UnfilteredPartitionIterators.MergeListener.getRowMergeListener(DecoratedKey partitionKey,
java.util.List<UnfilteredRowIterator> versions) |
Constructor and Description |
---|
SingletonUnfilteredPartitionIterator(UnfilteredRowIterator iter,
boolean isForThrift) |
Modifier and Type | Interface and Description |
---|---|
interface |
SliceableUnfilteredRowIterator |
Modifier and Type | Class and 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 |
WrappingUnfilteredRowIterator
Abstract class to make writing unfiltered iterators that wrap another iterator
easier.
|
Modifier and Type | Field and Description |
---|---|
protected UnfilteredRowIterator |
WrappingUnfilteredRowIterator.wrapped |
Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
UnfilteredRowIterators.cloningIterator(UnfilteredRowIterator iterator,
AbstractAllocator allocator) |
static UnfilteredRowIterator |
UnfilteredRowIterators.concat(UnfilteredRowIterator iter1,
UnfilteredRowIterator iter2)
Returns an iterator that concatenate two atom iterators.
|
UnfilteredRowIterator |
UnfilteredRowIteratorSerializer.deserialize(DataInputPlus in,
int version,
CFMetaData metadata,
ColumnFilter selection,
SerializationHelper.Flag flag) |
UnfilteredRowIterator |
UnfilteredRowIteratorSerializer.deserialize(DataInputPlus in,
int version,
CFMetaData metadata,
SerializationHelper.Flag flag,
UnfilteredRowIteratorSerializer.Header header) |
protected abstract UnfilteredRowIterator |
LazilyInitializedUnfilteredRowIterator.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,
int nowInSec)
Returns an iterator that is the result of merging other iterators.
|
static UnfilteredRowIterator |
UnfilteredRowIterators.merge(java.util.List<UnfilteredRowIterator> iterators,
int nowInSec,
UnfilteredRowIterators.MergeListener mergeListener)
Returns an iterator that is the result of merging other iterators, and (optionally) using
specific MergeListener.
|
static UnfilteredRowIterator |
UnfilteredRowIterators.noRowsIterator(CFMetaData cfm,
DecoratedKey partitionKey,
Row staticRow,
DeletionTime partitionDeletion,
boolean isReverseOrder)
Returns an empty atom iterator for a given partition.
|
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.
|
Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
UnfilteredRowIterators.cloningIterator(UnfilteredRowIterator iterator,
AbstractAllocator allocator) |
static UnfilteredRowIterator |
UnfilteredRowIterators.concat(UnfilteredRowIterator iter1,
UnfilteredRowIterator iter2)
Returns an iterator that concatenate two atom iterators.
|
static void |
UnfilteredRowIterators.digest(UnfilteredRowIterator iterator,
java.security.MessageDigest 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) |
void |
UnfilteredRowIteratorSerializer.serialize(UnfilteredRowIterator iterator,
SerializationHeader header,
ColumnFilter selection,
DataOutputPlus out,
int version,
int rowEstimate) |
long |
UnfilteredRowIteratorSerializer.serializedSize(UnfilteredRowIterator iterator,
ColumnFilter selection,
int version,
int rowEstimate) |
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.
|
Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
UnfilteredRowIterators.merge(java.util.List<UnfilteredRowIterator> iterators,
int nowInSec)
Returns an iterator that is the result of merging other iterators.
|
static UnfilteredRowIterator |
UnfilteredRowIterators.merge(java.util.List<UnfilteredRowIterator> iterators,
int nowInSec,
UnfilteredRowIterators.MergeListener mergeListener)
Returns an iterator that is the result of merging other iterators, and (optionally) using
specific MergeListener.
|
Constructor and Description |
---|
WrappingUnfilteredRowIterator(UnfilteredRowIterator wrapped) |
Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
Transformation.apply(UnfilteredRowIterator iterator,
Transformation<?> transformation) |
static UnfilteredRowIterator |
MoreRows.extend(UnfilteredRowIterator iterator,
MoreRows<? super UnfilteredRowIterator> more) |
Modifier and Type | Method and Description |
---|---|
static UnfilteredRowIterator |
Transformation.apply(UnfilteredRowIterator iterator,
Transformation<?> transformation) |
static UnfilteredRowIterator |
MoreRows.extend(UnfilteredRowIterator iterator,
MoreRows<? super UnfilteredRowIterator> more) |
static RowIterator |
FilteredRows.filter(UnfilteredRowIterator iterator,
int nowInSecs)
Filter any RangeTombstoneMarker from the iterator, transforming it into a RowIterator.
|
Modifier and Type | Method and Description |
---|---|
static UnfilteredPartitionIterator |
Transformation.apply(UnfilteredPartitionIterator iterator,
Transformation<? super UnfilteredRowIterator> transformation) |
static UnfilteredRowIterator |
MoreRows.extend(UnfilteredRowIterator iterator,
MoreRows<? super UnfilteredRowIterator> more) |
Modifier and Type | Method and Description |
---|---|
void |
SecondaryIndexManager.deletePartition(UnfilteredRowIterator partition,
int nowInSec)
Delete all data from all indexes for this partition.
|
void |
SecondaryIndexManager.indexPartition(UnfilteredRowIterator partition,
OpOrder.Group opGroup,
java.util.Set<Index> indexes,
int nowInSec)
When building an index against existing data in sstables, add the given partition to the index
|
Modifier and Type | Class and Description |
---|---|
class |
SSTableIdentityIterator |
Modifier and Type | Method and Description |
---|---|
boolean |
SSTableMultiWriter.append(UnfilteredRowIterator partition)
Writes a partition in an implementation specific way
|
RowIndexEntry |
SSTableRewriter.append(UnfilteredRowIterator partition) |
boolean |
SSTableTxnWriter.append(UnfilteredRowIterator iterator) |
boolean |
SimpleSSTableMultiWriter.append(UnfilteredRowIterator partition) |
RowIndexEntry |
SSTableRewriter.tryAppend(UnfilteredRowIterator partition) |
Modifier and Type | Method and Description |
---|---|
boolean |
RangeAwareSSTableWriter.append(UnfilteredRowIterator partition) |
abstract RowIndexEntry |
SSTableWriter.append(UnfilteredRowIterator iterator)
Appends partition data to this writer.
|
Modifier and Type | Field and Description |
---|---|
protected java.util.Iterator<UnfilteredRowIterator> |
BigTableScanner.iterator |
Modifier and Type | Method and Description |
---|---|
protected UnfilteredRowIterator |
BigTableScanner.KeyScanningIterator.computeNext() |
UnfilteredRowIterator |
BigTableScanner.next() |
UnfilteredRowIterator |
BigTableScanner.EmptySSTableScanner.next() |
Modifier and Type | Method and Description |
---|---|
RowIndexEntry |
BigTableWriter.append(UnfilteredRowIterator iterator)
Appends partition data to this writer.
|
Modifier and Type | Method and Description |
---|---|
void |
Validator.add(UnfilteredRowIterator partition)
Called (in order) for every row present in the CF.
|
Modifier and Type | Class and Description |
---|---|
static class |
StreamReader.StreamDeserializer |
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
ThriftResultsMerger.applyToPartition(UnfilteredRowIterator iter) |
static UnfilteredRowIterator |
ThriftResultsMerger.maybeWrap(UnfilteredRowIterator iterator,
int nowInSec) |
Modifier and Type | Method and Description |
---|---|
UnfilteredRowIterator |
ThriftResultsMerger.applyToPartition(UnfilteredRowIterator iter) |
static UnfilteredRowIterator |
ThriftResultsMerger.maybeWrap(UnfilteredRowIterator iterator,
int nowInSec) |
Copyright © 2016 The Apache Software Foundation