Modifier and Type | Method and Description |
---|---|
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. |
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.
|
protected UnfilteredRowIterator |
SinglePartitionNamesCommand.queryMemtableAndDiskInternal(ColumnFamilyStore cfs,
boolean copyOnHeap) |
protected abstract UnfilteredRowIterator |
SinglePartitionReadCommand.queryMemtableAndDiskInternal(ColumnFamilyStore cfs,
boolean copyOnHeap) |
protected UnfilteredRowIterator |
SinglePartitionSliceCommand.queryMemtableAndDiskInternal(ColumnFamilyStore cfs,
boolean copyOnHeap) |
static UnfilteredRowIterator |
LegacyLayout.toUnfilteredRowIterator(CFMetaData metadata,
DecoratedKey key,
DeletionInfo delInfo,
java.util.Iterator<LegacyLayout.LegacyCell> cells) |
UnfilteredRowIterator |
RowUpdateBuilder.unfilteredIterator() |
Modifier and Type | Method and Description |
---|---|
static Pair<DeletionInfo,java.util.Iterator<LegacyLayout.LegacyCell>> |
LegacyLayout.fromUnfilteredRowIterator(UnfilteredRowIterator iterator) |
static ColumnIndex |
ColumnIndex.writeAndBuildIndex(UnfilteredRowIterator iterator,
SequentialWriter output,
SerializationHeader header,
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 |
---|---|
abstract boolean |
CompactionAwareWriter.append(UnfilteredRowIterator partition)
Writes a partition in an implementation specific way
|
boolean |
DefaultCompactionWriter.append(UnfilteredRowIterator partition) |
boolean |
MajorLeveledCompactionWriter.append(UnfilteredRowIterator partition) |
boolean |
MaxSSTableSizeWriter.append(UnfilteredRowIterator partition) |
boolean |
SplittingSizeTieredCompactionWriter.append(UnfilteredRowIterator partition) |
Modifier and Type | Method and Description |
---|---|
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.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 | Method and Description |
---|---|
void |
SecondaryIndexManager.deleteFromIndexes(UnfilteredRowIterator partition,
OpOrder.Group opGroup,
int nowInSec)
Delete all data from all indexes for this partition.
|
abstract void |
PerRowSecondaryIndex.index(java.nio.ByteBuffer key,
UnfilteredRowIterator atoms)
Index the given partition.
|
void |
SecondaryIndexManager.indexPartition(UnfilteredRowIterator partition,
OpOrder.Group opGroup,
java.util.Set<SecondaryIndex> allIndexes,
int nowInSec)
When building an index against existing data, add the given partition to the index
|
Modifier and Type | Class and Description |
---|---|
class |
AtomicBTreePartition.SlicesIterator |
class |
CountingUnfilteredRowIterator |
Modifier and Type | Method and Description |
---|---|
protected UnfilteredRowIterator |
AlteringUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter) |
UnfilteredRowIterator |
CountingUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter) |
protected UnfilteredRowIterator |
WrappingUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter)
Given the next UnfilteredRowIterator from the wrapped partition iterator, return
the (potentially modified) UnfilteredRowIterator to return.
|
static UnfilteredRowIterator |
UnfilteredPartitionIterators.getOnlyElement(UnfilteredPartitionIterator iter,
SinglePartitionReadCommand<?> command) |
UnfilteredRowIterator |
PurgingPartitionIterator.next() |
UnfilteredRowIterator |
SingletonUnfilteredPartitionIterator.next() |
UnfilteredRowIterator |
WrappingUnfilteredPartitionIterator.next() |
UnfilteredRowIterator |
AbstractThreadUnsafePartition.unfilteredIterator() |
UnfilteredRowIterator |
AtomicBTreePartition.unfilteredIterator() |
UnfilteredRowIterator |
Partition.unfilteredIterator()
Returns an UnfilteredRowIterator over all the rows/RT contained by this partition.
|
UnfilteredRowIterator |
AbstractThreadUnsafePartition.unfilteredIterator(ColumnFilter columns,
Slices slices,
boolean reversed) |
UnfilteredRowIterator |
AtomicBTreePartition.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 |
---|---|
protected UnfilteredRowIterator |
AlteringUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter) |
UnfilteredRowIterator |
CountingUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter) |
protected UnfilteredRowIterator |
WrappingUnfilteredPartitionIterator.computeNext(UnfilteredRowIterator iter)
Given the next UnfilteredRowIterator from the wrapped partition iterator, return
the (potentially modified) UnfilteredRowIterator to return.
|
static ArrayBackedPartition |
ArrayBackedPartition.create(UnfilteredRowIterator iterator)
Creates an
ArrayBackedPartition holding all the data of the provided iterator. |
static ArrayBackedCachedPartition |
ArrayBackedCachedPartition.create(UnfilteredRowIterator iterator,
int nowInSec)
Creates an
ArrayBackedCachedPartition holding all the data of the provided iterator. |
static ArrayBackedPartition |
ArrayBackedPartition.create(UnfilteredRowIterator iterator,
int initialRowCapacity)
Creates an
ArrayBackedPartition holding all the data of the provided iterator. |
static ArrayBackedCachedPartition |
ArrayBackedCachedPartition.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 |
---|
CountingUnfilteredRowIterator(UnfilteredRowIterator iter,
DataLimits.Counter counter) |
SingletonUnfilteredPartitionIterator(UnfilteredRowIterator iter,
boolean isForThrift) |
Modifier and Type | Interface and Description |
---|---|
interface |
SliceableUnfilteredRowIterator |
Modifier and Type | Class and Description |
---|---|
class |
AbstractUnfilteredRowIterator |
class |
AlteringUnfilteredRowIterator
Class that makes it easier to write unfiltered iterators that filter or modify
the returned unfiltered.
|
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,
SerializationHelper.Flag flag) |
UnfilteredRowIterator |
UnfilteredRowIteratorSerializer.deserialize(DataInputPlus in,
int version,
CFMetaData metadata,
SerializationHelper.Flag flag,
UnfilteredRowIteratorSerializer.Header header) |
static UnfilteredRowIterator |
UnfilteredRowIterators.emptyIterator(CFMetaData cfm,
DecoratedKey partitionKey,
boolean isReverseOrder)
Returns an empty atom iterator for a given partition.
|
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.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) |
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,
DataOutputPlus out,
int version) |
void |
UnfilteredRowIteratorSerializer.serialize(UnfilteredRowIterator iterator,
DataOutputPlus out,
int version,
int rowEstimate) |
void |
UnfilteredRowIteratorSerializer.serialize(UnfilteredRowIterator iterator,
DataOutputPlus out,
SerializationHeader header,
int version,
int rowEstimate) |
long |
UnfilteredRowIteratorSerializer.serializedSize(UnfilteredRowIterator iterator,
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 |
---|
AlteringUnfilteredRowIterator(UnfilteredRowIterator wrapped) |
WrappingUnfilteredRowIterator(UnfilteredRowIterator wrapped) |
Modifier and Type | Class and Description |
---|---|
class |
SSTableIdentityIterator |
Modifier and Type | Method and Description |
---|---|
RowIndexEntry |
SSTableRewriter.append(UnfilteredRowIterator partition) |
RowIndexEntry |
SSTableTxnWriter.append(UnfilteredRowIterator iterator) |
RowIndexEntry |
SSTableRewriter.tryAppend(UnfilteredRowIterator partition) |
Modifier and Type | Method and Description |
---|---|
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 |
---|---|
protected UnfilteredRowIterator |
ThriftResultsMerger.computeNext(UnfilteredRowIterator iter) |
static UnfilteredRowIterator |
ThriftResultsMerger.maybeWrap(UnfilteredRowIterator iterator,
int nowInSec) |
Modifier and Type | Method and Description |
---|---|
protected UnfilteredRowIterator |
ThriftResultsMerger.computeNext(UnfilteredRowIterator iter) |
static UnfilteredRowIterator |
ThriftResultsMerger.maybeWrap(UnfilteredRowIterator iterator,
int nowInSec) |
Copyright © 2015 The Apache Software Foundation