Uses of Interface
org.apache.cassandra.utils.CloseableIterator
-
-
Uses of CloseableIterator in org.apache.cassandra.db.compaction
Classes in org.apache.cassandra.db.compaction that implement CloseableIterator Modifier and Type Class Description class
CompactionIterator
Merge multiple iterators over the content of sstable into a "compacted" iterator. -
Uses of CloseableIterator in org.apache.cassandra.db.memtable
Classes in org.apache.cassandra.db.memtable that implement CloseableIterator Modifier and Type Class Description static class
ShardedSkipListMemtable.MemtableUnfilteredPartitionIterator
-
Uses of CloseableIterator in org.apache.cassandra.db.partitions
Subinterfaces of CloseableIterator in org.apache.cassandra.db.partitions Modifier and Type Interface Description interface
BasePartitionIterator<I extends BaseRowIterator<?>>
interface
PartitionIterator
An iterator over a number of (filtered) partition.interface
UnfilteredPartitionIterator
An iterator over a number of unfiltered partitions (i.e.Classes in org.apache.cassandra.db.partitions that implement CloseableIterator Modifier and Type Class Description class
AbstractUnfilteredPartitionIterator
class
SingletonUnfilteredPartitionIterator
-
Uses of CloseableIterator in org.apache.cassandra.db.repair
Classes in org.apache.cassandra.db.repair that implement CloseableIterator Modifier and Type Class Description class
CassandraValidationIterator
-
Uses of CloseableIterator in org.apache.cassandra.db.rows
Subinterfaces of CloseableIterator in org.apache.cassandra.db.rows Modifier and Type Interface Description interface
BaseRowIterator<U extends Unfiltered>
A common interface for Row and Unfiltered, that permits sharing of the (majority) common methods and functionalityinterface
RowIterator
An iterator over rows belonging to a partition.interface
UnfilteredRowIterator
An iterator over the rows of a given partition that also includes deletion informations.interface
WrappingUnfilteredRowIterator
Abstract class to make writing unfiltered iterators that wrap another iterator easier.Classes in org.apache.cassandra.db.rows that implement CloseableIterator Modifier and Type Class Description class
AbstractUnfilteredRowIterator
class
LazilyInitializedUnfilteredRowIterator
Abstract class to create UnfilteredRowIterator that lazily initializes itself.class
RowAndDeletionMergeIterator
An iterator that merges a source of rows with the range tombstone and partition level deletion of a give partition.class
ThrottledUnfilteredIterator
A utility class to split the givenUnfilteredRowIterator
into smaller chunks each having at mostThrottledUnfilteredIterator.throttle
+ 1 unfiltereds.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).Methods in org.apache.cassandra.db.rows that return CloseableIterator Modifier and Type Method Description static CloseableIterator<UnfilteredRowIterator>
ThrottledUnfilteredIterator. throttle(UnfilteredPartitionIterator partitionIterator, int maxBatchSize)
Splits aUnfilteredPartitionIterator
inUnfilteredRowIterator
batches with size no higher than maxBatchSize -
Uses of CloseableIterator in org.apache.cassandra.db.streaming
Classes in org.apache.cassandra.db.streaming that implement CloseableIterator Modifier and Type Class Description static class
CassandraStreamReader.StreamDeserializer
-
Uses of CloseableIterator in org.apache.cassandra.db.transform
Classes in org.apache.cassandra.db.transform that implement CloseableIterator Modifier and Type Class Description class
BasePartitions<R extends BaseRowIterator<?>,I extends BasePartitionIterator<? extends BaseRowIterator<?>>>
class
BaseRows<R extends Unfiltered,I extends BaseRowIterator<? extends Unfiltered>>
class
FilteredPartitions
class
FilteredRows
-
Uses of CloseableIterator in org.apache.cassandra.index.sai.utils
Classes in org.apache.cassandra.index.sai.utils that implement CloseableIterator Modifier and Type Class Description class
InMemoryPartitionIterator
class
InMemoryUnfilteredPartitionIterator
-
Uses of CloseableIterator in org.apache.cassandra.index.sasi.disk
Classes in org.apache.cassandra.index.sasi.disk that implement CloseableIterator Modifier and Type Class Description static class
AbstractTokenTreeBuilder.LevelIterator
-
Uses of CloseableIterator in org.apache.cassandra.io.sstable
Subinterfaces of CloseableIterator in org.apache.cassandra.io.sstable Modifier and Type Interface Description interface
ISSTableScanner
An ISSTableScanner is an abstraction allowing multiple SSTableScanners to be chained together under the hood.Classes in org.apache.cassandra.io.sstable that implement CloseableIterator Modifier and Type Class Description class
AbstractSSTableIterator<RIE extends AbstractRowIndexEntry>
class
EmptySSTableScanner
class
KeyIterator
class
ReducingKeyIterator
Caller must acquire and release references to the sstables used here.class
SSTableIdentityIterator
class
SSTableSimpleIterator
Utility class to handle deserializing atom from sstables. -
Uses of CloseableIterator in org.apache.cassandra.io.sstable.format
Classes in org.apache.cassandra.io.sstable.format that implement CloseableIterator Modifier and Type Class Description class
SSTableScanner<S extends SSTableReader,E extends AbstractRowIndexEntry,I extends SSTableScanner.BaseKeyScanningIterator>
class
SSTableScanner.BaseKeyScanningIterator
-
Uses of CloseableIterator in org.apache.cassandra.io.sstable.format.big
Classes in org.apache.cassandra.io.sstable.format.big that implement CloseableIterator Modifier and Type Class Description class
BigTableScanner
protected class
BigTableScanner.BigScanningIterator
class
SSTableIterator
A Cell Iterator over SSTableclass
SSTableReversedIterator
A Cell Iterator in reversed clustering order over SSTable -
Uses of CloseableIterator in org.apache.cassandra.io.sstable.format.bti
Classes in org.apache.cassandra.io.sstable.format.bti that implement CloseableIterator Modifier and Type Class Description class
BtiTableScanner
protected class
BtiTableScanner.BtiScanningIterator
-
Uses of CloseableIterator in org.apache.cassandra.repair
Classes in org.apache.cassandra.repair that implement CloseableIterator Modifier and Type Class Description class
ValidationPartitionIterator
-
Uses of CloseableIterator in org.apache.cassandra.service.pager
Classes in org.apache.cassandra.service.pager that implement CloseableIterator Modifier and Type Class Description class
AggregationQueryPager.AggregationPartitionIterator
PartitionIterator
for queries without Group By but with aggregates.class
AggregationQueryPager.GroupByPartitionIterator
PartitionIterator
that automatically fetch a new sub-page of data if needed when the current iterator is exhausted. -
Uses of CloseableIterator in org.apache.cassandra.service.paxos.uncommitted
Methods in org.apache.cassandra.service.paxos.uncommitted that return CloseableIterator Modifier and Type Method Description CloseableIterator<PaxosKeyState>
PaxosUncommittedIndex. flushIterator(Memtable flushing)
CloseableIterator<PaxosKeyState>
PaxosUncommittedTracker.UpdateSupplier. flushIterator(Memtable paxos)
static CloseableIterator<PaxosKeyState>
PaxosKeyState. mergeUncommitted(CloseableIterator<PaxosKeyState>... iterators)
CloseableIterator<PaxosKeyState>
PaxosUncommittedIndex. repairIterator(TableId tableId, java.util.Collection<Range<Token>> ranges)
CloseableIterator<PaxosKeyState>
PaxosUncommittedTracker.UpdateSupplier. repairIterator(TableId tableId, java.util.Collection<Range<Token>> ranges)
static CloseableIterator<UncommittedPaxosKey>
PaxosKeyState. toUncommittedInfo(CloseableIterator<PaxosKeyState> iter)
CloseableIterator<UncommittedPaxosKey>
PaxosUncommittedTracker. uncommittedKeyIterator(TableId tableId, java.util.Collection<Range<Token>> ranges)
Methods in org.apache.cassandra.service.paxos.uncommitted with parameters of type CloseableIterator Modifier and Type Method Description static CloseableIterator<PaxosKeyState>
PaxosKeyState. mergeUncommitted(CloseableIterator<PaxosKeyState>... iterators)
static CloseableIterator<UncommittedPaxosKey>
PaxosKeyState. toUncommittedInfo(CloseableIterator<PaxosKeyState> iter)
-
Uses of CloseableIterator in org.apache.cassandra.service.reads.range
Classes in org.apache.cassandra.service.reads.range that implement CloseableIterator Modifier and Type Class Description class
RangeCommandIterator
class
ScanAllRangesCommandIterator
A customRangeCommandIterator
that queries all replicas required by consistency level at once with data range specify inPartitionRangeReadCommand
. -
Uses of CloseableIterator in org.apache.cassandra.utils
Subinterfaces of CloseableIterator in org.apache.cassandra.utils Modifier and Type Interface Description interface
IMergeIterator<In,Out>
Classes in org.apache.cassandra.utils that implement CloseableIterator Modifier and Type Class Description class
AbstractIterator<V>
class
MergeIterator<In,Out>
Merges sorted input iterators which individually contain unique items.static class
MerkleTree.TreeRangeIterator
Returns the leaf (range) of a given tree in increasing order.Methods in org.apache.cassandra.utils that return CloseableIterator Modifier and Type Method Description static <T> CloseableIterator<T>
FBUtilities. closeableIterator(java.util.Iterator<T> iterator)
static <T> CloseableIterator<T>
CloseableIterator. empty()
static <T> CloseableIterator<T>
CloseableIterator. wrap(java.util.Iterator<T> iter)
-