Uses of Class
org.apache.accumulo.core.data.Key

Packages that use Key
org.apache.accumulo.core   
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mapreduce   
org.apache.accumulo.core.client.mapreduce.lib.partition   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.data   
org.apache.accumulo.core.file   
org.apache.accumulo.core.file.keyfunctor   
org.apache.accumulo.core.file.map   
org.apache.accumulo.core.file.rfile   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.aggregation.conf   
org.apache.accumulo.core.iterators.conf   
org.apache.accumulo.core.iterators.filter   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.iterators.user   
org.apache.accumulo.core.trace   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.format   
org.apache.accumulo.core.util.shell   
org.apache.accumulo.core.util.shell.commands   
org.apache.accumulo.examples.simple.combiner   
org.apache.accumulo.examples.simple.dirlist   
org.apache.accumulo.examples.simple.filedata   
org.apache.accumulo.examples.simple.mapreduce   
org.apache.accumulo.examples.wikisearch.iterator   
org.apache.accumulo.examples.wikisearch.logic   
org.apache.accumulo.examples.wikisearch.util   
org.apache.accumulo.server.iterators   
org.apache.accumulo.server.master.state   
org.apache.accumulo.server.monitor.servlets.trace   
org.apache.accumulo.server.problems   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.test   
org.apache.accumulo.server.test.continuous   
org.apache.accumulo.server.test.functional   
org.apache.accumulo.server.test.randomwalk.multitable   
org.apache.accumulo.server.test.randomwalk.sequential   
org.apache.accumulo.server.util   
 

Uses of Key in org.apache.accumulo.core
 

Fields in org.apache.accumulo.core declared as Key
static Key Constants.METADATA_RESERVED_KEYSPACE_START_KEY
           
static Key Constants.METADATA_RESERVED_KEYSPACE_STOP_KEY
           
 

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

Methods in org.apache.accumulo.core.client that return Key
 Key ClientSideIteratorScanner.ScannerTranslator.getTopKey()
           
 

Methods in org.apache.accumulo.core.client that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> ClientSideIteratorScanner.ScannerTranslator.deepCopy(IteratorEnvironment env)
           
 Iterator<Map.Entry<Key,Value>> ClientSideIteratorScanner.iterator()
           
 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>> ScannerBase.iterator()
          Returns an iterator over an accumulo table.
 Iterator<Map.Entry<Key,Value>> RowIterator.next()
          Fetch the next row.
 

Method parameters in org.apache.accumulo.core.client with type arguments of type Key
 void IsolatedScanner.RowBuffer.add(Map.Entry<Key,Value> entry)
           
 void IsolatedScanner.MemoryRowBuffer.add(Map.Entry<Key,Value> entry)
           
 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 Key
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.
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.
 

Uses of Key in org.apache.accumulo.core.client.impl
 

Methods in org.apache.accumulo.core.client.impl that return types with arguments of type Key
 Iterator<Map.Entry<Key,Value>> OfflineScanner.iterator()
           
 Iterator<Map.Entry<Key,Value>> ScannerImpl.iterator()
          Returns an iterator over an accumulo table.
 Iterator<Map.Entry<Key,Value>> TabletServerBatchReader.iterator()
           
 Iterator<Map.Entry<Key,Value>> ScannerOptions.iterator()
           
 Map.Entry<Key,Value> ScannerIterator.next()
           
 Map.Entry<Key,Value> TabletServerBatchReaderIterator.next()
           
 

Methods in org.apache.accumulo.core.client.impl with parameters of type Key
 void TabletServerBatchReaderIterator.ResultReceiver.receive(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Key
static boolean ThriftScanner.getBatchFromServer(AuthInfo credentials, org.apache.hadoop.io.Text startRow, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, boolean skipStartKey, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 

Uses of Key in org.apache.accumulo.core.client.mapreduce
 

Fields in org.apache.accumulo.core.client.mapreduce declared as Key
protected  Key InputFormatBase.RecordReaderBase.currentKey
           
 

Fields in org.apache.accumulo.core.client.mapreduce with type parameters of type Key
protected  Iterator<Map.Entry<Key,Value>> InputFormatBase.RecordReaderBase.scannerIterator
           
 

Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Key
 org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,PeekingIterator<Map.Entry<Key,Value>>> AccumuloRowInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
           
 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.RecordWriter<Key,Value> AccumuloFileOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext job)
           
 

Methods in org.apache.accumulo.core.client.mapreduce with parameters of type Key
 float InputFormatBase.RangeInputSplit.getProgress(Key currentKey)
           
 

Uses of Key in org.apache.accumulo.core.client.mapreduce.lib.partition
 

Methods in org.apache.accumulo.core.client.mapreduce.lib.partition with parameters of type Key
 int KeyRangePartitioner.getPartition(Key key, org.apache.hadoop.io.Writable value, int numPartitions)
           
 

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

Methods in org.apache.accumulo.core.client.mock that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> MockScannerBase.createFilter(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()
           
 

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

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

Uses of Key in org.apache.accumulo.core.data
 

Fields in org.apache.accumulo.core.data declared as Key
 Key KeyValue.key
           
 

Methods in org.apache.accumulo.core.data that return Key
 Key Key.followingKey(PartialKey part)
          Returns a key that will sort immediately after this key.
 Key Range.getEndKey()
           
 Key KeyValue.getKey()
           
 Key Range.getStartKey()
           
 

Methods in org.apache.accumulo.core.data with parameters of type Key
 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.
 

Constructors in org.apache.accumulo.core.data with parameters of type Key
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)
           
KeyValue(Key key, ByteBuffer value)
           
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)
           
 

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

Methods in org.apache.accumulo.core.file that return Key
 Key BloomFilterLayer.Reader.getFirstKey()
           
 Key FileSKVIterator.getFirstKey()
           
 Key BloomFilterLayer.Reader.getLastKey()
           
 Key FileSKVIterator.getLastKey()
           
 Key BloomFilterLayer.Reader.getTopKey()
           
 

Methods in org.apache.accumulo.core.file that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env)
           
static org.apache.hadoop.io.WritableComparable<Key> FileUtil.findLastKey(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, Collection<String> mapFiles)
           
static SortedMap<Double,Key> FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, double minSplit)
           
static SortedMap<Double,Key> FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs, AccumuloConfiguration acuConf, org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, Collection<String> mapFiles, double minSplit, boolean useIndex)
           
 

Methods in org.apache.accumulo.core.file with parameters of type Key
 void FileSKVWriter.append(Key key, Value value)
           
 void BloomFilterLayer.Writer.append(Key key, Value val)
           
 

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

Constructors in org.apache.accumulo.core.file with parameters of type Key
FileUtil.FileInfo(Key firstKey, Key lastKey)
           
 

Uses of Key in org.apache.accumulo.core.file.keyfunctor
 

Methods in org.apache.accumulo.core.file.keyfunctor with parameters of type Key
 org.apache.hadoop.util.bloom.Key ColumnFamilyFunctor.transform(Key acuKey)
           
 org.apache.hadoop.util.bloom.Key KeyFunctor.transform(Key key)
           
 org.apache.hadoop.util.bloom.Key RowFunctor.transform(Key acuKey)
           
 org.apache.hadoop.util.bloom.Key ColumnQualifierFunctor.transform(Key acuKey)
           
 

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

Methods in org.apache.accumulo.core.file.map that return Key
 Key MapFileOperations.RangeIterator.getFirstKey()
           
 Key MyMapFile.Reader.getFirstKey()
           
 Key MapFileOperations.RangeIterator.getLastKey()
           
 Key MyMapFile.Reader.getLastKey()
           
 Key MapFileOperations.RangeIterator.getTopKey()
           
 Key MyMapFile.Reader.getTopKey()
           
 

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

Method parameters in org.apache.accumulo.core.file.map with type arguments of type Key
 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)
           
 

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

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

Methods in org.apache.accumulo.core.file.rfile that return Key
 Key RFile.Reader.getFirstKey()
           
 Key MultiLevelIndex.IndexEntry.getKey()
           
 Key RelativeKey.getKey()
           
 Key RFile.Reader.getLastKey()
           
 Key MultiLevelIndex.Reader.getLastKey()
           
 

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

Methods in org.apache.accumulo.core.file.rfile with parameters of type Key
 void MultiLevelIndex.BufferedWriter.add(Key key, int data, long offset, long compressedSize, long rawSize)
           
 void MultiLevelIndex.Writer.add(Key key, int data, long offset, long compressedSize, long rawSize)
           
 void MultiLevelIndex.BufferedWriter.addLast(Key key, int data, long offset, long compressedSize, long rawSize)
           
 void MultiLevelIndex.Writer.addLast(Key key, int data, long offset, long compressedSize, long rawSize)
           
 void RFile.Writer.append(Key key, Value value)
           
 MultiLevelIndex.Reader.IndexIterator MultiLevelIndex.Reader.lookup(Key key)
           
 

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

Constructors in org.apache.accumulo.core.file.rfile with parameters of type Key
RelativeKey(Key prevKey, Key key)
           
 

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

Fields in org.apache.accumulo.core.iterators with type parameters of type Key
 SortedKeyValueIterator<Key,Value> OrIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators that return Key
 Key SortedMapIterator.getTopKey()
           
 Key WrappingIterator.getTopKey()
           
 Key Combiner.getTopKey()
           
 Key OrIterator.getTopKey()
           
 Key DevNull.getTopKey()
           
 Key AggregatingIterator.getTopKey()
          Deprecated.  
 Key ColumnFamilyCounter.getTopKey()
           
 Key DebugIterator.getTopKey()
           
 

Methods in org.apache.accumulo.core.iterators that return types with arguments of type Key
 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()
           
 SortedKeyValueIterator<Key,Value> IteratorEnvironment.reserveMapFileReader(String mapFileName)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type Key
abstract  boolean Filter.accept(Key k, Value v)
           
abstract  Value Combiner.reduce(Key key, Iterator<Value> iter)
          Reduces a list of Values into a single Value.
 Value TypedValueCombiner.reduce(Key key, Iterator<Value> iter)
           
abstract  V TypedValueCombiner.typedReduce(Key key, Iterator<V> iter)
          Reduces a list of V into a single V.
 

Method parameters in org.apache.accumulo.core.iterators with type arguments of type Key
 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 IteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
protected  void WrappingIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
 

Constructor parameters in org.apache.accumulo.core.iterators with type arguments of type Key
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)
           
SortedMapIterator(SortedMap<Key,Value> map)
           
VersioningIterator(SortedKeyValueIterator<Key,Value> iterator, int maxVersions)
          Deprecated.  
 

Uses of Key in org.apache.accumulo.core.iterators.aggregation.conf
 

Methods in org.apache.accumulo.core.iterators.aggregation.conf with parameters of type Key
 Aggregator AggregatorSet.getAggregator(Key k)
          Deprecated.  
 

Uses of Key in org.apache.accumulo.core.iterators.conf
 

Methods in org.apache.accumulo.core.iterators.conf with parameters of type Key
 boolean ColumnSet.contains(Key key)
           
 K ColumnToClassMapping.getObject(Key key)
           
 

Uses of Key in org.apache.accumulo.core.iterators.filter
 

Methods in org.apache.accumulo.core.iterators.filter with parameters of type Key
 boolean AgeOffFilter.accept(Key k, Value v)
          Deprecated.  
 boolean ColumnAgeOffFilter.accept(Key k, Value v)
          Deprecated.  
 boolean NoLabelFilter.accept(Key k, Value v)
          Deprecated.  
 boolean DeleteFilter.accept(Key key, Value value)
          Deprecated.  
 boolean VisibilityFilter.accept(Key k, Value v)
          Deprecated.  
 boolean Filter.accept(Key k, Value v)
          Deprecated.  
 boolean RegExFilter.accept(Key key, Value value)
          Deprecated.  
 boolean ColumnQualifierFilter.accept(Key key, Value v)
          Deprecated.  
 

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

Methods in org.apache.accumulo.core.iterators.system that return Key
 Key SequenceFileIterator.getFirstKey()
           
 Key SequenceFileIterator.getLastKey()
           
 Key SequenceFileIterator.getTopKey()
           
 Key TimeSettingIterator.getTopKey()
           
 Key HeapIterator.getTopKey()
           
 Key SourceSwitchingIterator.getTopKey()
           
 

Methods in org.apache.accumulo.core.iterators.system that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> TimeSettingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> VisibilityFilter.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 Key
 boolean VisibilityFilter.accept(Key k, Value v)
           
 boolean ColumnQualifierFilter.accept(Key key, Value v)
           
 

Method parameters in org.apache.accumulo.core.iterators.system with type arguments of type Key
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)
           
 

Constructor parameters in org.apache.accumulo.core.iterators.system with type arguments of type Key
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)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> readers, boolean init)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
TimeSettingIterator(SortedKeyValueIterator<Key,Value> source, long time)
           
VisibilityFilter(SortedKeyValueIterator<Key,Value> iterator, Authorizations authorizations, byte[] defaultVisibility)
           
 

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

Fields in org.apache.accumulo.core.iterators.user declared as Key
protected  Key IntersectingIterator.topKey
           
 

Fields in org.apache.accumulo.core.iterators.user with type parameters of type Key
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.docSource
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators.user that return Key
protected  Key IndexedDocIterator.buildDocKey()
           
protected  Key IntersectingIterator.buildFollowingPartitionKey(Key key)
           
protected  Key IntersectingIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term)
           
protected  Key IndexedDocIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term)
           
protected  Key IntersectingIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term, org.apache.hadoop.io.Text docID)
           
protected  Key IndexedDocIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term, org.apache.hadoop.io.Text docID)
           
 Key RowDeletingIterator.getTopKey()
           
 Key LargeRowFilter.getTopKey()
           
 Key WholeRowIterator.getTopKey()
           
 Key IntersectingIterator.getTopKey()
           
 

Methods in org.apache.accumulo.core.iterators.user that return types with arguments of type Key
static SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 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 Key
 boolean AgeOffFilter.accept(Key k, Value v)
          Accepts entries whose timestamps are less than currentTime - threshold.
 boolean ColumnAgeOffFilter.accept(Key k, Value v)
           
 boolean ReqVisFilter.accept(Key k, Value v)
           
 boolean RegExFilter.accept(Key key, Value value)
           
 boolean TimestampFilter.accept(Key k, Value v)
           
protected  Key IntersectingIterator.buildFollowingPartitionKey(Key key)
           
static SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getDocID(Key key)
           
protected  org.apache.hadoop.io.Text IndexedDocIterator.getDocID(Key key)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getPartition(Key key)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getTerm(Key key)
           
protected  org.apache.hadoop.io.Text IndexedDocIterator.getTerm(Key key)
           
static org.apache.hadoop.io.Text IndexedDocIterator.parseDocID(Key key)
           
 List<Long> SummingArrayCombiner.typedReduce(Key key, Iterator<List<Long>> iter)
           
 Long SummingCombiner.typedReduce(Key key, Iterator<Long> iter)
           
 Long MinCombiner.typedReduce(Key key, Iterator<Long> iter)
           
 Long MaxCombiner.typedReduce(Key key, Iterator<Long> iter)
           
 

Method parameters in org.apache.accumulo.core.iterators.user with type arguments of type Key
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)
           
static Value WholeRowIterator.encodeRow(List<Key> keys, List<Value> values)
           
protected  boolean WholeRowIterator.filter(org.apache.hadoop.io.Text currentRow, List<Key> keys, List<Value> values)
           
 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)
           
 

Constructor parameters in org.apache.accumulo.core.iterators.user with type arguments of type Key
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 Key in org.apache.accumulo.core.trace
 

Method parameters in org.apache.accumulo.core.trace with type arguments of type Key
static RemoteSpan TraceFormatter.getRemoteSpan(Map.Entry<Key,Value> entry)
           
 void TraceFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 

Uses of Key in org.apache.accumulo.core.util
 

Methods in org.apache.accumulo.core.util with parameters of type Key
 boolean ColumnFQ.hasColumns(Key key)
           
 

Method parameters in org.apache.accumulo.core.util with type arguments of type Key
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries)
           
static void MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance, SortedMap<Key,Value> tkv, KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(SortedMap<Key,Value> tabletKeyValues, List<ColumnFQ> columns)
           
 

Constructors in org.apache.accumulo.core.util with parameters of type Key
ColumnFQ(Key k)
           
 

Uses of Key in org.apache.accumulo.core.util.format
 

Methods in org.apache.accumulo.core.util.format that return types with arguments of type Key
 Iterator<Map.Entry<Key,Value>> DefaultFormatter.getScannerIterator()
           
 Iterator<Map.Entry<Key,Value>> BinaryFormatter.getScannerIterator()
           
 

Method parameters in org.apache.accumulo.core.util.format with type arguments of type Key
static String DefaultFormatter.formatEntry(Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static String BinaryFormatter.formatEntry(Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static Formatter FormatterFactory.getDefaultFormatter(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
static Formatter FormatterFactory.getFormatter(Class<? extends Formatter> formatterClass, Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void DefaultFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void Formatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void BinaryFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 

Constructor parameters in org.apache.accumulo.core.util.format with type arguments of type Key
DeleterFormatter(BatchWriter writer, Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, Shell shellState, boolean force)
           
 

Uses of Key in org.apache.accumulo.core.util.shell
 

Method parameters in org.apache.accumulo.core.util.shell with type arguments of type Key
 void Shell.printBinaryRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate)
           
 void Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate)
           
 void Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate, Class<? extends Formatter> formatterClass)
           
 

Uses of Key in org.apache.accumulo.core.util.shell.commands
 

Method parameters in org.apache.accumulo.core.util.shell.commands with type arguments of type Key
protected  void ScanCommand.printBinaryRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner)
           
protected  void ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner)
           
protected  void ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner, Class<? extends Formatter> formatter)
           
 

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

Methods in org.apache.accumulo.examples.simple.combiner with parameters of type Key
 Value StatsCombiner.reduce(Key key, Iterator<Value> iter)
           
 

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

Uses of Key in org.apache.accumulo.examples.simple.dirlist
 

Methods in org.apache.accumulo.examples.simple.dirlist that return types with arguments of type Key
 Iterable<Map.Entry<Key,Value>> QueryUtil.exactTermSearch(String term)
          Scans over the index table for files or directories with a given name.
 Iterable<Map.Entry<Key,Value>> QueryUtil.singleRestrictedWildCardSearch(String exp)
          Scans over the index table for files or directories with a given name, prefix, or suffix (indicated by a wildcard '*' at the beginning or end of the term.
 Iterable<Map.Entry<Key,Value>> QueryUtil.singleWildCardSearch(String exp)
          Scans over the index table for files or directories with a given name that can contain a single wildcard '*' anywhere in the term.
 

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

Fields in org.apache.accumulo.examples.simple.filedata declared as Key
protected  Key ChunkInputStream.currentKey
           
 

Fields in org.apache.accumulo.examples.simple.filedata with type parameters of type Key
protected  PeekingIterator<Map.Entry<Key,Value>> ChunkInputStream.source
           
 

Methods in org.apache.accumulo.examples.simple.filedata that return Key
 Key ChunkCombiner.getTopKey()
           
 

Methods in org.apache.accumulo.examples.simple.filedata that return types with arguments of type Key
 org.apache.hadoop.mapreduce.RecordReader<List<Map.Entry<Key,Value>>,InputStream> ChunkInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
           
 SortedKeyValueIterator<Key,Value> ChunkCombiner.deepCopy(IteratorEnvironment env)
           
 List<Map.Entry<Key,Value>> FileDataQuery.getLastRefs()
           
 

Method parameters in org.apache.accumulo.examples.simple.filedata with type arguments of type Key
 void ChunkCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void CharacterHistogram.HistMapper.map(List<Map.Entry<Key,Value>> k, InputStream v, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void ChunkInputStream.setSource(PeekingIterator<Map.Entry<Key,Value>> in)
           
 

Constructor parameters in org.apache.accumulo.examples.simple.filedata with type arguments of type Key
ChunkInputStream(PeekingIterator<Map.Entry<Key,Value>> in)
           
 

Uses of Key in org.apache.accumulo.examples.simple.mapreduce
 

Methods in org.apache.accumulo.examples.simple.mapreduce with parameters of type Key
 void RegexExample.RegexMapper.map(Key row, Value data, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void TableToFile.TTFMapper.map(Key row, Value data, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void RowHash.HashDataMapper.map(Key row, Value data, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void UniqueColumns.UMapper.map(Key key, Value value, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 

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

Fields in org.apache.accumulo.examples.wikisearch.iterator declared as Key
 Key OrIterator.TermSource.topKey
           
 

Fields in org.apache.accumulo.examples.wikisearch.iterator with type parameters of type Key
 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 Key
protected  Key AndIterator.buildFollowingPartitionKey(Key key)
          Return the key that directly follows the given key
static Key BooleanLogicTreeNode.buildKey(Key key)
           
protected  Key AndIterator.buildKey(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text dataLocation)
          Build a key from the given row and dataLocation
protected  Key AndIterator.buildKey(org.apache.hadoop.io.Text row, org.apache.hadoop.io.Text dataLocation, org.apache.hadoop.io.Text term)
          Build a key from the given row, dataLocation, and term
protected  Key OrIterator.buildTopKey(OrIterator.TermSource TS)
          Construct the topKey given the current TermSource
 Key BooleanLogicTreeNode.getAdvanceKey()
           
 Key BooleanLogicTreeNode.getMinUniqueID()
           
abstract  Key AbstractEvaluatingIterator.getReturnKey(Key k)
          When the query expression evaluates to true against the event, the event fields will be serialized into the Value and returned up the iterator stack.
 Key EvaluatingIterator.getReturnKey(Key k)
           
 Key BooleanLogicTreeNode.getTopKey()
           
 Key OptimizedQueryIterator.getTopKey()
           
 Key BooleanLogicIterator.getTopKey()
           
 Key FieldIndexIterator.getTopKey()
           
 Key ReadAheadIterator.getTopKey()
           
 Key AbstractEvaluatingIterator.getTopKey()
           
 Key OrIterator.getTopKey()
           
 Key UniqFieldNameValueIterator.getTopKey()
           
 Key AndIterator.getTopKey()
           
 

Methods in org.apache.accumulo.examples.wikisearch.iterator that return types with arguments of type Key
 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)
           
 HashSet<Key> BooleanLogicTreeNode.getIntersection(HashSet<Key> h)
           
 Iterator<Key> BooleanLogicTreeNode.getSetIterator()
           
protected  SortedKeyValueIterator<Key,Value> UniqFieldNameValueIterator.getSource()
           
 

Methods in org.apache.accumulo.examples.wikisearch.iterator with parameters of type Key
 void BooleanLogicTreeNode.addToSet(Key i)
           
protected  Key AndIterator.buildFollowingPartitionKey(Key key)
          Return the key that directly follows the given key
static Key BooleanLogicTreeNode.buildKey(Key key)
           
abstract  void AbstractEvaluatingIterator.fillMap(EventFields event, Key key, Value value)
          Implementations will need to fill the map with field visibilities, names, and values.
 void EvaluatingIterator.fillMap(EventFields event, Key key, Value value)
           
 ColumnVisibility EvaluatingIterator.getColumnVisibility(Key key)
           
protected  org.apache.hadoop.io.Text OrIterator.getDataLocation(Key key)
          Returns the given key's dataLocation
protected  org.apache.hadoop.io.Text AndIterator.getDataLocation(Key key)
          Returns the given key's dataLocation
protected  org.apache.hadoop.io.Text OrIterator.getDocID(Key key)
          Returns the given key's DocID
protected  org.apache.hadoop.io.Text AndIterator.getDocID(Key key)
          Returns the given key's DocID
protected  org.apache.hadoop.io.Text OrIterator.getPartition(Key key)
          Returns the given key's row
protected  org.apache.hadoop.io.Text AndIterator.getPartition(Key key)
           
abstract  Key AbstractEvaluatingIterator.getReturnKey(Key k)
          When the query expression evaluates to true against the event, the event fields will be serialized into the Value and returned up the iterator stack.
 Key EvaluatingIterator.getReturnKey(Key k)
           
protected  org.apache.hadoop.io.Text OrIterator.getTerm(Key key)
          Returns the given key's term
protected  org.apache.hadoop.io.Text AndIterator.getTerm(Key key)
          Returns the given key's term
protected static String OrIterator.getUID(Key key)
          Returns the given key's UID
protected  String AndIterator.getUID(Key key)
          Returns the given key's UID
 boolean BooleanLogicTreeNode.inSet(Key t)
           
abstract  boolean AbstractEvaluatingIterator.isKeyAccepted(Key key)
          Provides the ability to skip this key and all of the following ones that match using the comparator.
 boolean EvaluatingIterator.isKeyAccepted(Key key)
          Don't accept this key if the colf starts with 'fi'
 boolean BooleanLogicTreeNode.jump(Key jumpKey)
           
 boolean FieldIndexIterator.jump(Key jumpKey)
           
 boolean OrIterator.jump(Key jumpKey)
           
 boolean AndIterator.jump(Key jumpKey)
           
 void BooleanLogicTreeNode.setAdvanceKey(Key advanceKey)
           
 void BooleanLogicTreeNode.setTopKey(Key id)
           
 TermWeight.Info TextIndexCombiner.typedReduce(Key key, Iterator<TermWeight.Info> iter)
           
 Uid.List GlobalIndexUidCombiner.typedReduce(Key key, Iterator<Uid.List> iter)
           
 

Method parameters in org.apache.accumulo.examples.wikisearch.iterator with type arguments of type Key
 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)
           
 HashSet<Key> BooleanLogicTreeNode.getIntersection(HashSet<Key> h)
           
 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)
           
 

Constructor parameters in org.apache.accumulo.examples.wikisearch.iterator with type arguments of type Key
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 Key in org.apache.accumulo.examples.wikisearch.logic
 

Methods in org.apache.accumulo.examples.wikisearch.logic with parameters of type Key
 Document AbstractQueryLogic.createDocument(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.examples.wikisearch.logic with type arguments of type Key
 String AbstractQueryLogic.getResultsKey(Map.Entry<Key,Value> key)
           
 

Uses of Key in org.apache.accumulo.examples.wikisearch.util
 

Fields in org.apache.accumulo.examples.wikisearch.util declared as Key
protected  Key BaseKeyParser.key
           
 

Methods in org.apache.accumulo.examples.wikisearch.util that return Key
 Key BaseKeyParser.getKey()
           
 

Methods in org.apache.accumulo.examples.wikisearch.util with parameters of type Key
 void KeyParser.parse(Key key)
           
 void BaseKeyParser.parse(Key key)
          Parses a Key object into its constituent fields.
 void FieldIndexKeyParser.parse(Key key)
           
 

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

Methods in org.apache.accumulo.server.iterators with parameters of type Key
 boolean MetadataBulkLoadFilter.accept(Key k, Value v)
           
 

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

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

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

Methods in org.apache.accumulo.server.master.state with parameters of type Key
static TabletLocationState MetaDataTableScanner.createTabletLocationState(Key k, Value v)
           
 

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

Uses of Key in org.apache.accumulo.server.monitor.servlets.trace
 

Methods in org.apache.accumulo.server.monitor.servlets.trace that return types with arguments of type Key
 Iterator<Map.Entry<Key,Value>> NullScanner.iterator()
           
 Map.Entry<Key,Value> NullKeyValueIterator.next()
           
 

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

Methods in org.apache.accumulo.server.problems that return Key
 Key ProblemReportingIterator.getTopKey()
           
 

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

Method parameters in org.apache.accumulo.server.problems with type arguments of type Key
static ProblemReport ProblemReport.decodeMetadataEntry(Map.Entry<Key,Value> entry)
           
 void ProblemReportingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

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

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

Methods in org.apache.accumulo.server.tabletserver that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> InMemoryMap.compactionIterator()
           
 Iterator<Map.Entry<Key,Value>> NativeMap.iterator()
           
 Iterator<Map.Entry<Key,Value>> NativeMap.iterator(Key startKey)
           
 SortedKeyValueIterator<Key,Value> TabletIteratorEnvironment.reserveMapFileReader(String mapFileName)
           
 SortedKeyValueIterator<Key,Value> NativeMap.skvIterator()
           
 

Methods in org.apache.accumulo.server.tabletserver with parameters of type Key
 Value NativeMap.get(Key key)
           
 Iterator<Map.Entry<Key,Value>> NativeMap.iterator(Key startKey)
           
 void NativeMap.put(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.server.tabletserver with type arguments of type Key
 void TabletIteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> TabletServer.verifyTabletInformation(KeyExtent extent, TServerInstance instance, SortedMap<Key,Value> tabletsKeyValues, String clientAddress, ZooLock lock)
           
 

Constructors in org.apache.accumulo.server.tabletserver with parameters of type Key
Tablet.KVEntry(Key k, Value v)
           
 

Constructor parameters in org.apache.accumulo.server.tabletserver with type arguments of type Key
Tablet(TabletServer tabletServer, org.apache.hadoop.io.Text location, KeyExtent extent, TabletServerResourceManager.TabletResourceManager trm, SortedMap<Key,Value> tabletsKeyValues)
           
 

Uses of Key in org.apache.accumulo.server.test
 

Methods in org.apache.accumulo.server.test with parameters of type Key
static int VerifyIngest.getCol(Key k)
           
static int VerifyIngest.getRow(Key k)
           
 

Uses of Key in org.apache.accumulo.server.test.continuous
 

Methods in org.apache.accumulo.server.test.continuous with parameters of type Key
 void ContinuousVerify.CMapper.map(Key key, Value data, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 void ContinuousMoru.CMapper.map(Key key, Value data, org.apache.hadoop.mapreduce.Mapper.Context context)
           
 

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

Methods in org.apache.accumulo.server.test.functional that return Key
 Key BadIterator.getTopKey()
           
 

Methods in org.apache.accumulo.server.test.functional that return types with arguments of type Key
 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 Key
 Value BadCombiner.reduce(Key key, Iterator<Value> iter)
           
 

Method parameters in org.apache.accumulo.server.test.functional with type arguments of type Key
 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)
           
 

Uses of Key in org.apache.accumulo.server.test.randomwalk.multitable
 

Methods in org.apache.accumulo.server.test.randomwalk.multitable with parameters of type Key
 void CopyTool.SeqMapClass.map(Key key, Value val, org.apache.hadoop.mapreduce.Mapper.Context output)
           
 

Uses of Key in org.apache.accumulo.server.test.randomwalk.sequential
 

Methods in org.apache.accumulo.server.test.randomwalk.sequential with parameters of type Key
 void MapRedVerifyTool.SeqMapClass.map(Key row, Value data, org.apache.hadoop.mapreduce.Mapper.Context output)
           
 

Uses of Key in org.apache.accumulo.server.util
 

Methods in org.apache.accumulo.server.util that return types with arguments of type Key
 Iterator<Map.Entry<Key,Value>> OfflineMetadataScanner.iterator()
           
 Map<Key,Value> TabletIterator.next()
           
 

Methods in org.apache.accumulo.server.util with parameters of type Key
static MetadataTable.LogEntry MetadataTable.entryFromKeyValue(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.server.util with type arguments of type Key
static boolean MetadataTable.getBatchFromRootTablet(AuthInfo credentials, org.apache.hadoop.io.Text startRow, SortedMap<Key,Value> results, SortedSet<Column> columns, boolean skipStartRow, int size)
           
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataDirectoryEntries(SortedMap<Key,Value> entries)
          convenience method for reading entries from the metadata table
static void MetadataTable.getTabletAndPrevTabletKeyValues(SortedMap<Key,Value> tkv, KeyExtent ke, List<ColumnFQ> columns, AuthInfo credentials)
           
static void MapFilePerformanceTest.runTest(String testName, String[] mapFiles, ArrayList<Key> queries)
          Deprecated.  
static void MapFilePerformanceTest.selectRandomKeys(String input, double percentage, ArrayList<Key> keys)
          Deprecated.  
 



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