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   
 

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
           
 

Methods in org.apache.accumulo.core.file.map that return SortedKeyValueIterator
 SortedKeyValueIterator<Key,Value> MapFileOperations.RangeIterator.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)
           
 

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 (timestamps) 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 FirstEntryInRowIterator
           
 class LongCombiner
          A TypedValueCombiner that translates each Value to a Long before reducing, then encodes the reduced Long back to a Value.
 class OrIterator
          An iterator that handles "OR" query constructs on the server side.
 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
          A convenience class for implementing iterators that select, but do not modify, entries read from a source iterator.
 

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<Key,Value> TypedValueCombiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Combiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 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> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilyCounter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Filter.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<IteratorSetting> iterators, 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, String context)
           
 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 TypedValueCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void Combiner.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 SortedMapIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void LongCombiner.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 AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void WrappingIterator.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 ColumnFamilyCounter.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 Filter.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<IteratorSetting> iterators, 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, String context)
           
 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)
           
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 MapFileIterator
           
 class MultiIterator
          An iterator capable of iterating over other iterators in sorted order.
 class SequenceFileIterator
           
 class SourceSwitchingIterator
           
 class StatsIterator
           
 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> ColumnQualifierFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimeSettingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> MapFileIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> StatsIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<K,V> SynchronizedIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> VisibilityFilter.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 MultiIterator.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 TimeSettingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void MapFileIterator.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 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)
           
StatsIterator(SortedKeyValueIterator<Key,Value> source, AtomicLong seekCounter, AtomicLong readCounter)
           
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 TransformingIterator
          The TransformingIterator allows portions of a key (except for the row) to be transformed.
 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> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimestampFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> AgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RegExFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnAgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TransformingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.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 WholeRowIterator.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 AgeOffFilter.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 LargeRowFilter.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 RowFilter.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 TransformingIterator.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 VisibilityFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void IntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
static String IntersectingIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
protected abstract  void TransformingIterator.transformRange(SortedKeyValueIterator<Key,Value> input, TransformingIterator.KVBuffer output)
          Transforms input.
 

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)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.