Uses of Interface
org.apache.accumulo.core.iterators.SortedKeyValueIterator

Packages that use SortedKeyValueIterator
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.file   
org.apache.accumulo.core.file.map   
org.apache.accumulo.core.file.rfile   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.iterators.user   
org.apache.accumulo.examples.simple.combiner   
org.apache.accumulo.examples.simple.filedata   
org.apache.accumulo.examples.wikisearch.iterator   
org.apache.accumulo.server.iterators   
org.apache.accumulo.server.master.state   
org.apache.accumulo.server.problems   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.test.functional   
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.client
 

Classes in org.apache.accumulo.core.client that implement SortedKeyValueIterator
 class ClientSideIteratorScanner.ScannerTranslator
          A class that wraps a Scanner in a SortedKeyValueIterator so that other accumulo iterators can use it as a source.
 

Methods in org.apache.accumulo.core.client that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> ClientSideIteratorScanner.ScannerTranslator.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.client with parameters of type SortedKeyValueIterator
 void ClientSideIteratorScanner.ScannerTranslator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructor parameters in org.apache.accumulo.core.client with type arguments of type SortedKeyValueIterator
IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
          Constructs an iterator setting using the given class's SimpleName for the iterator name.
IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass, Map<String,String> properties)
          Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified parameters.
IteratorSetting(int priority, String name, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
          Constructs an iterator setting configured for the scan scope with no parameters.
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.client.mock
 

Methods in org.apache.accumulo.core.client.mock that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner)
           
 

Methods in org.apache.accumulo.core.client.mock with parameters of type SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner)
           
 

Constructors in org.apache.accumulo.core.client.mock with parameters of type SortedKeyValueIterator
IteratorAdapter(SortedKeyValueIterator<Key,Value> inner)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.file
 

Subinterfaces of SortedKeyValueIterator in org.apache.accumulo.core.file
 interface FileSKVIterator
           
 

Classes in org.apache.accumulo.core.file that implement SortedKeyValueIterator
static class BloomFilterLayer.Reader
           
 

Methods in org.apache.accumulo.core.file that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.file with parameters of type SortedKeyValueIterator
 void BloomFilterLayer.Reader.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.file.map
 

Classes in org.apache.accumulo.core.file.map that implement SortedKeyValueIterator
static class MapFileOperations.RangeIterator
           
static class MyMapFile.Reader
          Deprecated. Provide access to an existing map.
 

Methods in org.apache.accumulo.core.file.map that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> MapFileOperations.RangeIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> MyMapFile.Reader.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.file.map with parameters of type SortedKeyValueIterator
 void MapFileOperations.RangeIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void MyMapFile.Reader.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructors in org.apache.accumulo.core.file.map with parameters of type SortedKeyValueIterator
MapFileOperations.RangeIterator(SortedKeyValueIterator<Key,Value> reader)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.file.rfile
 

Classes in org.apache.accumulo.core.file.rfile that implement SortedKeyValueIterator
static class RFile.Reader
           
 

Methods in org.apache.accumulo.core.file.rfile that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> RFile.Reader.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.file.rfile with parameters of type SortedKeyValueIterator
 void RFile.Reader.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.iterators
 

Classes in org.apache.accumulo.core.iterators that implement SortedKeyValueIterator
 class AggregatingIterator
          Deprecated. since 1.4, replaced by Combiner
 class ColumnFamilyCounter
           
 class Combiner
          A SortedKeyValueIterator that combines the Values for different versions of a Key into a single Value.
 class DebugIterator
           
 class DevNull
          An iterator that is useful testing...
 class FamilyIntersectingIterator
          Deprecated. since 1.4, replaced by IndexedDocIterator
 class Filter
          A SortedKeyValueIterator that filters entries from its source iterator.
 class FilteringIterator
          Deprecated. since 1.4, replaced by Filter
 class FirstEntryInRowIterator
           
 class LongCombiner
          A TypedValueCombiner that translates each Value to a Long before reducing, then encodes the reduced Long back to a Value.
 class NoLabelIterator
          Deprecated. since 1.4, replaced by ReqVisFilter
 class OrIterator
          An iterator that handles "OR" query constructs on the server side.
 class RegExIterator
          Deprecated. since 1.4, replaced by RegExFilter
 class SkippingIterator
           
 class SortedKeyIterator
           
 class SortedMapIterator
          A simple iterator over a Java SortedMap
 class TypedValueCombiner<V>
          A Combiner that decodes each Value to type V before reducing, then encodes the result of typedReduce back to Value.
 class WrappingIterator
           
 

Fields in org.apache.accumulo.core.iterators declared as SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> OrIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators that return SortedKeyValueIterator
 SortedKeyValueIterator<K,V> SortedKeyValueIterator.deepCopy(IteratorEnvironment env)
          Creates a deep copy of this iterator as though seek had not yet been called.
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Combiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Filter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TypedValueCombiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilyCounter.deepCopy(IteratorEnvironment env)
           
protected  SortedKeyValueIterator<Key,Value> WrappingIterator.getSource()
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters, Map<String,Map<String,String>> iterOpts, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
 SortedKeyValueIterator<Key,Value> IteratorEnvironment.reserveMapFileReader(String mapFileName)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type SortedKeyValueIterator
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
 void LongCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void FirstEntryInRowIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SortedMapIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void WrappingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void NoLabelIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void Combiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void Filter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void FilteringIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void OrIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void DevNull.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void RegExIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void TypedValueCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void ColumnFamilyCounter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void DebugIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SortedKeyValueIterator.init(SortedKeyValueIterator<K,V> source, Map<String,String> options, IteratorEnvironment env)
          Initializes the iterator.
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(IteratorUtil.IteratorScope scope, SortedKeyValueIterator<K,V> source, KeyExtent extent, AccumuloConfiguration conf, List<IterInfo> ssiList, Map<String,Map<String,String>> ssio, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
static
<K extends org.apache.hadoop.io.WritableComparable<?>,V extends org.apache.hadoop.io.Writable>
SortedKeyValueIterator<K,V>
IteratorUtil.loadIterators(SortedKeyValueIterator<K,V> source, Collection<IterInfo> iters, Map<String,Map<String,String>> iterOpts, IteratorEnvironment env, boolean useAccumuloClassLoader)
           
 void IteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
protected  void WrappingIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
 

Constructors in org.apache.accumulo.core.iterators with parameters of type SortedKeyValueIterator
AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators)
          Deprecated.  
Combiner.ValueIterator(SortedKeyValueIterator<Key,Value> source)
          Constructs an iterator over Values whose Keys are versions of the current topKey of the source SortedKeyValueIterator.
DebugIterator(String prefix, SortedKeyValueIterator<Key,Value> source)
           
FilteringIterator(SortedKeyValueIterator<Key,Value> iterator, List<? extends Filter> filters)
          Deprecated.  
OrIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term)
           
VersioningIterator(SortedKeyValueIterator<Key,Value> iterator, int maxVersions)
          Deprecated.  
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.iterators.system
 

Subinterfaces of SortedKeyValueIterator in org.apache.accumulo.core.iterators.system
 interface InterruptibleIterator
           
 

Classes in org.apache.accumulo.core.iterators.system that implement SortedKeyValueIterator
 class ColumnFamilySkippingIterator
           
 class ColumnQualifierFilter
           
 class CountingIterator
           
 class DeletingIterator
           
 class HeapIterator
           
 class MultiIterator
          An iterator capable of iterating over other iterators in sorted order.
 class SequenceFileIterator
           
 class SourceSwitchingIterator
           
 class SynchronizedIterator<K extends WritableComparable<?>,V extends Writable>
          SynchronizedIterator: wrap a SortedKeyValueIterator so that all of its methods are synchronized
 class TimeSettingIterator
           
 class VisibilityFilter
           
 

Methods in org.apache.accumulo.core.iterators.system that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> TimeSettingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> VisibilityFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<K,V> SynchronizedIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnQualifierFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.DataSource.iterator()
           
 

Methods in org.apache.accumulo.core.iterators.system with parameters of type SortedKeyValueIterator
protected  void HeapIterator.addSource(SortedKeyValueIterator<Key,Value> source)
           
 void DeletingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SequenceFileIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void TimeSettingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void CountingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void MultiIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SourceSwitchingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SynchronizedIterator.init(SortedKeyValueIterator<K,V> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructors in org.apache.accumulo.core.iterators.system with parameters of type SortedKeyValueIterator
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source, Set<ByteSequence> colFamSet, boolean inclusive)
           
ColumnQualifierFilter(SortedKeyValueIterator<Key,Value> iterator, HashSet<ByteSequence> columnFamilies, HashMap<ByteSequence,HashSet<ByteSequence>> columnsQualifiers, boolean scanColumns)
           
ColumnQualifierFilter(SortedKeyValueIterator<Key,Value> iterator, HashSet<Column> columns)
           
CountingIterator(SortedKeyValueIterator<Key,Value> source)
           
DeletingIterator(SortedKeyValueIterator<Key,Value> iterator, boolean propogateDeletes)
           
SynchronizedIterator(SortedKeyValueIterator<K,V> source)
           
TimeSettingIterator(SortedKeyValueIterator<Key,Value> source, long time)
           
VisibilityFilter(SortedKeyValueIterator<Key,Value> iterator, Authorizations authorizations, byte[] defaultVisibility)
           
 

Constructor parameters in org.apache.accumulo.core.iterators.system with type arguments of type SortedKeyValueIterator
MultiIterator(List<SortedKeyValueIterator<Key,Value>> readers, boolean init)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.core.iterators.user
 

Classes in org.apache.accumulo.core.iterators.user that implement SortedKeyValueIterator
 class AgeOffFilter
          A filter that ages off key/value pairs based on the Key's timestamp.
 class ColumnAgeOffFilter
          A filter that ages off key/value pairs based on the Key's column and timestamp.
 class GrepIterator
          This iterator provides exact string matching.
 class IndexedDocIterator
          This iterator facilitates document-partitioned indexing.
 class IntersectingIterator
          This iterator facilitates document-partitioned indexing.
 class LargeRowFilter
          This iterator suppresses rows that exceed a specified number of columns.
 class MaxCombiner
          A Combiner that interprets Values as Longs and returns the largest Long among them.
 class MinCombiner
          A Combiner that interprets Values as Longs and returns the smallest Long among them.
 class RegExFilter
          A Filter that matches entries based on Java regular expressions.
 class ReqVisFilter
          A Filter that matches entries with a non-empty ColumnVisibility.
 class RowDeletingIterator
          An iterator for deleting whole rows.
 class RowFilter
          This iterator makes it easy to select rows that meet a given criteria.
 class SummingArrayCombiner
          A Combiner that interprets Values as arrays of Longs and returns an array of element-wise sums.
 class SummingCombiner
          A Combiner that interprets Values as Longs and returns their sum.
 class TimestampFilter
          A Filter that matches entries whose timestamps fall within a range.
 class VersioningIterator
           
 class WholeRowIterator
          The WholeRowIterator is designed to provide row-isolation so that queries see mutations as atomic.
 

Fields in org.apache.accumulo.core.iterators.user declared as SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.docSource
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators.user that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> AgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnAgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RegExFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimestampFilter.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.iterators.user with parameters of type SortedKeyValueIterator
abstract  boolean RowFilter.acceptRow(SortedKeyValueIterator<Key,Value> rowIterator)
          Implementation should return false to suppress a row.
 void IntersectingIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text term, boolean notFlag)
           
 void AgeOffFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void ColumnAgeOffFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void RowDeletingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void LargeRowFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void VersioningIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SummingArrayCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void GrepIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void RegExFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void WholeRowIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void IntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void IndexedDocIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void TimestampFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void RowFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
static String IntersectingIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
 

Constructors in org.apache.accumulo.core.iterators.user with parameters of type SortedKeyValueIterator
IntersectingIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term)
           
IntersectingIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term, boolean notFlag)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.examples.simple.combiner
 

Classes in org.apache.accumulo.examples.simple.combiner that implement SortedKeyValueIterator
 class StatsCombiner
          This combiner calculates the max, min, sum, and count of long integers represented as strings in values.
 

Methods in org.apache.accumulo.examples.simple.combiner with parameters of type SortedKeyValueIterator
 void StatsCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.examples.simple.filedata
 

Classes in org.apache.accumulo.examples.simple.filedata that implement SortedKeyValueIterator
 class ChunkCombiner
          This iterator dedupes chunks and sets their visibilities to the combined visibility of the refs columns.
 

Methods in org.apache.accumulo.examples.simple.filedata that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> ChunkCombiner.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.examples.simple.filedata with parameters of type SortedKeyValueIterator
 void ChunkCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.examples.wikisearch.iterator
 

Classes in org.apache.accumulo.examples.wikisearch.iterator that implement SortedKeyValueIterator
 class AbstractEvaluatingIterator
          This iterator aggregates rows together using the specified key comparator.
 class AndIterator
           
 class BooleanLogicIterator
           
 class EvaluatingIterator
           
 class FieldIndexIterator
          This iterator should only return keys from the fi\0{fieldName}:{fieldValue} part of the shard table.
 class GlobalIndexUidCombiner
           
 class OptimizedQueryIterator
          This iterator internally uses the BooleanLogicIterator to find event UIDs in the field index portion of the partition and uses the EvaluatingIterator to evaluate the events against an expression.
 class ReadAheadIterator
          This iterator takes the source iterator (the one below it in the iterator stack) and puts it in a background thread.
 class TextIndexCombiner
           
 class UniqFieldNameValueIterator
           
 

Fields in org.apache.accumulo.examples.wikisearch.iterator declared as SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> OrIterator.TermSource.iter
           
 SortedKeyValueIterator<Key,Value> AndIterator.TermSource.iter
           
protected  SortedKeyValueIterator<Key,Value> AbstractEvaluatingIterator.iterator
           
 

Methods in org.apache.accumulo.examples.wikisearch.iterator that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> OptimizedQueryIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> BooleanLogicIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FieldIndexIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ReadAheadIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> UniqFieldNameValueIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> EvaluatingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> AndIterator.deepCopy(IteratorEnvironment env)
           
protected  SortedKeyValueIterator<Key,Value> UniqFieldNameValueIterator.getSource()
           
 

Methods in org.apache.accumulo.examples.wikisearch.iterator with parameters of type SortedKeyValueIterator
 void AndIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text term, boolean notFlag)
           
 void AndIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term, boolean notFlag)
           
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
 void OptimizedQueryIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void BooleanLogicIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          init is responsible for setting up the iterator.
 void ReadAheadIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void AbstractEvaluatingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void OrIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void UniqFieldNameValueIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void AndIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void TextIndexCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void GlobalIndexUidCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void DefaultIteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
protected  void UniqFieldNameValueIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
static String AndIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
 

Constructors in org.apache.accumulo.examples.wikisearch.iterator with parameters of type SortedKeyValueIterator
AndIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term)
           
AndIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term, boolean notFlag)
           
OrIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term)
           
OrIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.server.iterators
 

Classes in org.apache.accumulo.server.iterators that implement SortedKeyValueIterator
 class MetadataBulkLoadFilter
          A special iterator for the metadata table that removes inactive bulk load flags
 

Methods in org.apache.accumulo.server.iterators with parameters of type SortedKeyValueIterator
 void MetadataBulkLoadFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.server.master.state
 

Classes in org.apache.accumulo.server.master.state that implement SortedKeyValueIterator
 class TabletStateChangeIterator
           
 

Methods in org.apache.accumulo.server.master.state that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> TabletStateChangeIterator.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.server.master.state with parameters of type SortedKeyValueIterator
 void TabletStateChangeIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.server.problems
 

Classes in org.apache.accumulo.server.problems that implement SortedKeyValueIterator
 class ProblemReportingIterator
           
 

Methods in org.apache.accumulo.server.problems that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> ProblemReportingIterator.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.server.problems with parameters of type SortedKeyValueIterator
 void ProblemReportingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructors in org.apache.accumulo.server.problems with parameters of type SortedKeyValueIterator
ProblemReportingIterator(String table, String resource, boolean continueOnError, SortedKeyValueIterator<Key,Value> source)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.server.tabletserver
 

Methods in org.apache.accumulo.server.tabletserver that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> InMemoryMap.compactionIterator()
           
 SortedKeyValueIterator<Key,Value> TabletIteratorEnvironment.reserveMapFileReader(String mapFileName)
           
 SortedKeyValueIterator<Key,Value> NativeMap.skvIterator()
           
 

Methods in org.apache.accumulo.server.tabletserver with parameters of type SortedKeyValueIterator
 void TabletIteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
 

Uses of SortedKeyValueIterator in org.apache.accumulo.server.test.functional
 

Classes in org.apache.accumulo.server.test.functional that implement SortedKeyValueIterator
 class BadCombiner
           
 class BadIterator
           
 class DropModIter
           
 class SlowIterator
           
 

Methods in org.apache.accumulo.server.test.functional that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> BadIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SlowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DropModIter.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.server.test.functional with parameters of type SortedKeyValueIterator
 void SlowIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void DropModIter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 



Copyright © 2012 The Apache Software Foundation. All Rights Reserved.