| Modifier and Type | Method and Description | 
|---|---|
| Key | ClientSideIteratorScanner.ScannerTranslator. getTopKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> | ClientSideIteratorScanner.ScannerTranslator. deepCopy(org.apache.accumulo.core.iterators.IteratorEnvironment env) | 
| Iterator<Map.Entry<Key,Value>> | IsolatedScanner. iterator() | 
| Iterator<Map.Entry<Key,Value>> | IsolatedScanner.RowBuffer. iterator() | 
| Iterator<Map.Entry<Key,Value>> | IsolatedScanner.MemoryRowBuffer. iterator() | 
| Iterator<Map.Entry<Key,Value>> | ClientSideIteratorScanner. iterator() | 
| Iterator<Map.Entry<Key,Value>> | ScannerBase. iterator()Returns an iterator over an accumulo table. | 
| Iterator<Map.Entry<Key,Value>> | RowIterator. next()Fetch the next row. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | IsolatedScanner.RowBuffer. add(Map.Entry<Key,Value> entry) | 
| void | IsolatedScanner.MemoryRowBuffer. add(Map.Entry<Key,Value> entry) | 
| void | ClientSideIteratorScanner.ScannerTranslator. init(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> source,
    Map<String,String> options,
    org.apache.accumulo.core.iterators.IteratorEnvironment env) | 
| Constructor and Description | 
|---|
| IteratorSetting(int priority,
               Class<? extends org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value>> iteratorClass)Constructs an iterator setting using the given class's SimpleName for the iterator name. | 
| IteratorSetting(int priority,
               Class<? extends org.apache.accumulo.core.iterators.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 org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value>> iteratorClass)Constructs an iterator setting configured for the scan scope with no parameters. | 
| RowIterator(Iterable<Map.Entry<Key,Value>> iterable)Create an iterator from an Iterable. | 
| RowIterator(Iterator<Map.Entry<Key,Value>> iterator)Create an iterator from an (ordered) sequence of KeyValue pairs. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Key | InputFormatBase.RecordReaderBase. currentKey | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Iterator<Map.Entry<Key,Value>> | InputFormatBase.RecordReaderBase. scannerIterator | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.mapred.RecordReader<Key,Value> | AccumuloInputFormat. getRecordReader(org.apache.hadoop.mapred.InputSplit split,
               org.apache.hadoop.mapred.JobConf job,
               org.apache.hadoop.mapred.Reporter reporter) | 
| org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,org.apache.accumulo.core.util.PeekingIterator<Map.Entry<Key,Value>>> | AccumuloRowInputFormat. getRecordReader(org.apache.hadoop.mapred.InputSplit split,
               org.apache.hadoop.mapred.JobConf job,
               org.apache.hadoop.mapred.Reporter reporter) | 
| org.apache.hadoop.mapred.RecordWriter<Key,Value> | AccumuloFileOutputFormat. getRecordWriter(org.apache.hadoop.fs.FileSystem ignored,
               org.apache.hadoop.mapred.JobConf job,
               String name,
               org.apache.hadoop.util.Progressable progress) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Key | InputFormatBase.RecordReaderBase. currentKey | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Iterator<Map.Entry<Key,Value>> | InputFormatBase.RecordReaderBase. scannerIterator | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.mapreduce.RecordReader<Key,Value> | AccumuloInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,org.apache.accumulo.core.util.PeekingIterator<Map.Entry<Key,Value>>> | AccumuloRowInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
                  org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| org.apache.hadoop.mapreduce.RecordWriter<Key,Value> | AccumuloFileOutputFormat. getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) | 
| Modifier and Type | Method and Description | 
|---|---|
| float | RangeInputSplit. getProgress(Key currentKey) | 
| Modifier and Type | Method and Description | 
|---|---|
| int | KeyRangePartitioner. getPartition(Key key,
            org.apache.hadoop.io.Writable value,
            int numPartitions) | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> | MockScannerBase. createFilter(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> inner) | 
| Iterator<Map.Entry<Key,Value>> | MockBatchScanner. iterator() | 
| Iterator<Map.Entry<Key,Value>> | MockScannerBase. iterator() | 
| Iterator<Map.Entry<Key,Value>> | MockScanner. iterator() | 
| Map.Entry<Key,Value> | IteratorAdapter. next() | 
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> | MockScannerBase. createFilter(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> inner) | 
| Constructor and Description | 
|---|
| IteratorAdapter(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key,Value> inner) | 
| Modifier and Type | Method and Description | 
|---|---|
| Key | Key. followingKey(PartialKey part)Returns a key that will sort immediately after this key. | 
| Key | Range. getEndKey() | 
| Key | Range. getStartKey() | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | Range. afterEndKey(Key key) | 
| boolean | Range. beforeStartKey(Key key) | 
| int | Key. compareTo(Key other)Compare all elements of a key. | 
| int | Key. compareTo(Key other,
         PartialKey part)Compare elements of a key given by a  PartialKey. | 
| boolean | Range. contains(Key key) | 
| boolean | Key. equals(Key other,
      PartialKey part)Compare part of a key. | 
| void | Key. set(Key k)Sets this key's row, column family, column qualifier, column visibility, timestamp, and delete marker to be the same as another key's. | 
| Constructor and Description | 
|---|
| Key(Key other)Creates a key with the same row, column family, column qualifier, column visibility, timestamp, and delete marker as the given key. | 
| KeyValue(Key key,
        byte[] value)Creates a new key/value pair. | 
| KeyValue(Key key,
        ByteBuffer value)Creates a new key/value pair. | 
| KeyValue(Key key,
        Value value)Creates a new key/value pair. | 
| Range(Key start,
     boolean startKeyInclusive,
     boolean infiniteStartKey,
     Key stop,
     boolean stopKeyInclusive,
     boolean infiniteStopKey)Creates a range from start to stop. | 
| Range(Key startKey,
     boolean startKeyInclusive,
     Key endKey,
     boolean endKeyInclusive)Creates a range from startKey to endKey | 
| Range(Key startKey,
     Key endKey)Creates a range from startKey inclusive to endKey inclusive | 
| Range(Key start,
     Key stop,
     boolean startKeyInclusive,
     boolean stopKeyInclusive,
     boolean infiniteStartKey,
     boolean infiniteStopKey)Creates a range from start to stop. | 
Copyright © 2011-2016 The Apache Software Foundation. All Rights Reserved.