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

Packages that use Key
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mapred   
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.system   
org.apache.accumulo.core.iterators.user   
org.apache.accumulo.core.metadata   
org.apache.accumulo.core.tabletserver.log   
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   
 

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>> ScannerBase.iterator()
          Returns an iterator over an accumulo table.
 Iterator<Map.Entry<Key,Value>> IsolatedScanner.iterator()
           
 Iterator<Map.Entry<Key,Value>> IsolatedScanner.MemoryRowBuffer.iterator()
           
 Iterator<Map.Entry<Key,Value>> ClientSideIteratorScanner.iterator()
           
 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.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.
IteratorSetting(int priority, String name, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass, Map<String,String> properties)
          Constructs an iterator setting using the provided name and the provided class's name for the scan scope with the provided 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>> TabletServerBatchReader.iterator()
           
 Iterator<Map.Entry<Key,Value>> ScannerOptions.iterator()
           
 Iterator<Map.Entry<Key,Value>> ScannerImpl.iterator()
          Returns an iterator over an accumulo table.
 Iterator<Map.Entry<Key,Value>> OfflineScanner.iterator()
           
 Map.Entry<Key,Value> TabletServerBatchReaderIterator.next()
           
 Map.Entry<Key,Value> ScannerIterator.next()
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Key
static boolean ThriftScanner.getBatchFromServer(Instance instance, Credentials credentials, Range range, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 void TabletServerBatchReaderIterator.ResultReceiver.receive(List<Map.Entry<Key,Value>> entries)
           
 

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

Fields in org.apache.accumulo.core.client.mapred declared as Key
protected  Key AbstractInputFormat.AbstractRecordReader.currentKey
           
 

Fields in org.apache.accumulo.core.client.mapred with type parameters of type Key
protected  Iterator<Map.Entry<Key,Value>> AbstractInputFormat.AbstractRecordReader.scannerIterator
           
 

Methods in org.apache.accumulo.core.client.mapred that return types with arguments of type Key
 org.apache.hadoop.mapred.RecordReader<org.apache.hadoop.io.Text,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.RecordReader<Key,Value> AccumuloMultiTableInputFormat.getRecordReader(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter)
           
 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.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)
           
 

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

Fields in org.apache.accumulo.core.client.mapreduce declared as Key
protected  Key AbstractInputFormat.AbstractRecordReader.currentKey
          The Key that is used to determine progress in the current InputSplit.
 

Fields in org.apache.accumulo.core.client.mapreduce with type parameters of type Key
protected  Iterator<Map.Entry<Key,Value>> AbstractInputFormat.AbstractRecordReader.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> AccumuloMultiTableInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit inputSplit, 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 context)
           
 

Methods in org.apache.accumulo.core.client.mapreduce with parameters of type Key
 float 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>> MockScannerBase.iterator()
           
 Iterator<Map.Entry<Key,Value>> MockScanner.iterator()
           
 Iterator<Map.Entry<Key,Value>> MockBatchScanner.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
 

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 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)
          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.
 

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

Methods in org.apache.accumulo.core.file that return Key
 Key FileSKVIterator.getFirstKey()
           
 Key BloomFilterLayer.Reader.getFirstKey()
           
 Key FileSKVIterator.getLastKey()
           
 Key BloomFilterLayer.Reader.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)
           
 

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)
           
 

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 RowFunctor.transform(Key acuKey)
           
 org.apache.hadoop.util.bloom.Key KeyFunctor.transform(Key key)
           
 org.apache.hadoop.util.bloom.Key ColumnQualifierFunctor.transform(Key acuKey)
           
 org.apache.hadoop.util.bloom.Key ColumnFamilyFunctor.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 MapFileOperations.RangeIterator.getLastKey()
           
 Key MapFileOperations.RangeIterator.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)
           
 

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)
           
 

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 RelativeKey.getKey()
           
 Key MultiLevelIndex.IndexEntry.getKey()
           
 Key RFile.Reader.getLastKey()
           
 Key MultiLevelIndex.Reader.getLastKey()
           
 Key BlockIndex.BlockIndexEntry.getPrevKey()
           
 

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)
           
static RelativeKey.SkippR RelativeKey.fastSkip(DataInput in, Key seekKey, MutableByteSequence value, Key prevKey, Key currKey)
           
 MultiLevelIndex.Reader.IndexIterator MultiLevelIndex.Reader.lookup(Key key)
           
 BlockIndex.BlockIndexEntry BlockIndex.seekBlock(Key startKey, ABlockReader cacheBlock)
           
 void RelativeKey.setPrevKey(Key pk)
           
 

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
BlockIndex.BlockIndexEntry(int pos, int entriesLeft, Key prevKey)
           
BlockIndex.BlockIndexEntry(Key key)
           
RelativeKey(Key prevKey, Key key)
          This constructor is used when constructing a key for writing to an output stream
 

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 WrappingIterator.getTopKey()
           
 Key SortedMapIterator.getTopKey()
           
 Key OrIterator.getTopKey()
           
 Key DevNull.getTopKey()
           
 Key DebugIterator.getTopKey()
           
 Key Combiner.getTopKey()
           
 Key ColumnFamilyCounter.getTopKey()
           
 Key AggregatingIterator.getTopKey()
          Deprecated.  
 

Methods in org.apache.accumulo.core.iterators that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TypedValueCombiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Filter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Combiner.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)
           
 Value TypedValueCombiner.reduce(Key key, Iterator<Value> iter)
           
abstract  Value Combiner.reduce(Key key, Iterator<Value> iter)
          Reduces a list of Values into a single Value.
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 WrappingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void TypedValueCombiner.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 OrIterator.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 FirstEntryInRowIterator.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 DevNull.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 Combiner.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 AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 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)
           
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.system
 

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

Methods in org.apache.accumulo.core.iterators.system that return types with arguments of type Key
 SortedKeyValueIterator<Key,Value> VisibilityFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimeSettingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> StatsIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> MapFileIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LocalityGroupIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnQualifierFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilySkippingIterator.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 TimeSettingIterator.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 SequenceFileIterator.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 MapFileIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void LocalityGroupIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void DeletingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void CountingIterator.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, Set<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)
           
StatsIterator(SortedKeyValueIterator<Key,Value> source, AtomicLong seekCounter, AtomicLong readCounter)
           
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
           
protected  ArrayList<Pair<Key,Value>> TransformingIterator.keys
           
protected  SortedKeyValueIterator<Key,Value> RowEncodingIterator.sourceIter
           
 

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)
           
protected  Key TransformingIterator.copyPartialKey(Key key, PartialKey part)
          Creates a copy of key, copying only the parts of the key specified in part.
 Key WholeColumnFamilyIterator.getTopKey()
           
 Key TransformingIterator.getTopKey()
           
 Key RowEncodingIterator.getTopKey()
           
 Key RowDeletingIterator.getTopKey()
           
 Key LargeRowFilter.getTopKey()
           
 Key IntersectingIterator.getTopKey()
           
protected  Key TransformingIterator.replaceColumnFamily(Key originalKey, org.apache.hadoop.io.Text newColFam)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColFam as the column family.
protected  Key TransformingIterator.replaceColumnQualifier(Key originalKey, org.apache.hadoop.io.Text newColQual)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColQual as the column qualifier.
protected  Key TransformingIterator.replaceColumnVisibility(Key originalKey, org.apache.hadoop.io.Text newColVis)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColVis as the column visibility.
protected  Key TransformingIterator.replaceKeyParts(Key originalKey, org.apache.hadoop.io.Text newColQual, org.apache.hadoop.io.Text newColVis)
          Make a new key with a column qualifier, and column visibility.
protected  Key TransformingIterator.replaceKeyParts(Key originalKey, org.apache.hadoop.io.Text newColFam, org.apache.hadoop.io.Text newColQual, org.apache.hadoop.io.Text newColVis)
          Make a new key with a column family, column qualifier, and column visibility.
 

Methods in org.apache.accumulo.core.iterators.user that return types with arguments of type Key
static SortedMap<Key,Value> WholeColumnFamilyIterator.decodeColumnFamily(Key rowKey, Value rowValue)
          Decode whole row/cf out of value.
static SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 SortedKeyValueIterator<Key,Value> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WholeColumnFamilyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TransformingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimestampFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowFilter.deepCopy(IteratorEnvironment env)
           
abstract  SortedKeyValueIterator<Key,Value> RowEncodingIterator.deepCopy(IteratorEnvironment env)
          Implement deepCopy.
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RegExFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnSliceFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnAgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> AgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedMap<Key,Value> WholeRowIterator.rowDecoder(Key rowKey, Value rowValue)
           
abstract  SortedMap<Key,Value> RowEncodingIterator.rowDecoder(Key rowKey, Value rowValue)
          Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.
 

Methods in org.apache.accumulo.core.iterators.user with parameters of type Key
 boolean VisibilityFilter.accept(Key k, Value v)
           
 boolean TimestampFilter.accept(Key k, Value v)
           
 boolean ReqVisFilter.accept(Key k, Value v)
           
 boolean RegExFilter.accept(Key key, Value value)
           
 boolean GrepIterator.accept(Key k, Value v)
           
 boolean ColumnSliceFilter.accept(Key key, Value value)
           
 boolean ColumnAgeOffFilter.accept(Key k, Value v)
           
 boolean AgeOffFilter.accept(Key k, Value v)
          Accepts entries whose timestamps are less than currentTime - threshold.
 void TransformingIterator.KVBuffer.append(Key key, Value val)
           
protected  Key IntersectingIterator.buildFollowingPartitionKey(Key key)
           
protected  boolean TransformingIterator.canSee(Key key)
          Indicates whether or not the user is able to see key.
protected  boolean TransformingIterator.canSeeColumnFamily(Key key)
          Indicates whether or not key can be seen, according to the fetched column families for this iterator.
protected  Key TransformingIterator.copyPartialKey(Key key, PartialKey part)
          Creates a copy of key, copying only the parts of the key specified in part.
static SortedMap<Key,Value> WholeColumnFamilyIterator.decodeColumnFamily(Key rowKey, Value rowValue)
          Decode whole row/cf out of value.
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)
           
protected  boolean TransformingIterator.includeTransformedKey(Key transformedKey)
          Determines whether or not to include transformedKey in the output.
protected  boolean TransformingIterator.isSetAfterPart(Key key, PartialKey part)
          Indicates whether or not any part of key excluding part is set.
static org.apache.hadoop.io.Text IndexedDocIterator.parseDocID(Key key)
           
protected  Key TransformingIterator.replaceColumnFamily(Key originalKey, org.apache.hadoop.io.Text newColFam)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColFam as the column family.
protected  Key TransformingIterator.replaceColumnQualifier(Key originalKey, org.apache.hadoop.io.Text newColQual)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColQual as the column qualifier.
protected  Key TransformingIterator.replaceColumnVisibility(Key originalKey, org.apache.hadoop.io.Text newColVis)
          Make a new key with all parts (including delete flag) coming from originalKey but use newColVis as the column visibility.
protected  Key TransformingIterator.replaceKeyParts(Key originalKey, org.apache.hadoop.io.Text newColQual, org.apache.hadoop.io.Text newColVis)
          Make a new key with a column qualifier, and column visibility.
protected  Key TransformingIterator.replaceKeyParts(Key originalKey, org.apache.hadoop.io.Text newColFam, org.apache.hadoop.io.Text newColQual, org.apache.hadoop.io.Text newColVis)
          Make a new key with a column family, column qualifier, and column visibility.
protected  void VersioningIterator.reseek(Key key)
           
 SortedMap<Key,Value> WholeRowIterator.rowDecoder(Key rowKey, Value rowValue)
           
abstract  SortedMap<Key,Value> RowEncodingIterator.rowDecoder(Key rowKey, Value rowValue)
          Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.
 BigDecimal BigDecimalCombiner.BigDecimalSummingCombiner.typedReduce(Key key, Iterator<BigDecimal> iter)
           
 BigDecimal BigDecimalCombiner.BigDecimalMaxCombiner.typedReduce(Key key, Iterator<BigDecimal> iter)
           
 BigDecimal BigDecimalCombiner.BigDecimalMinCombiner.typedReduce(Key key, Iterator<BigDecimal> iter)
           
 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)
          Deprecated. since 1.6.0
static Value WholeColumnFamilyIterator.encodeColumnFamily(List<Key> keys, List<Value> values)
          Encode row/cf.
static Value WholeRowIterator.encodeRow(List<Key> keys, List<Value> values)
           
protected  boolean WholeColumnFamilyIterator.filter(org.apache.hadoop.io.Text currentRow, List<Key> keys, List<Value> values)
           
protected  boolean RowEncodingIterator.filter(org.apache.hadoop.io.Text currentRow, List<Key> keys, List<Value> values)
           
 void WholeColumnFamilyIterator.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 VersioningIterator.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 TimestampFilter.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 RowFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void RowEncodingIterator.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 RegExFilter.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 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 GrepIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void ColumnSliceFilter.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 BigDecimalCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void AgeOffFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 Value WholeRowIterator.rowEncoder(List<Key> keys, List<Value> values)
           
abstract  Value RowEncodingIterator.rowEncoder(List<Key> keys, List<Value> values)
          Take a stream of keys and values.
static String IntersectingIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
protected abstract  void TransformingIterator.transformRange(SortedKeyValueIterator<Key,Value> input, TransformingIterator.KVBuffer output)
          Transforms input.
 

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.metadata
 

Method parameters in org.apache.accumulo.core.metadata with type arguments of type Key
static TabletLocator.TabletLocations MetadataLocationObtainer.getMetadataLocationEntries(SortedMap<Key,Value> entries)
           
 

Uses of Key in org.apache.accumulo.core.tabletserver.log
 

Methods in org.apache.accumulo.core.tabletserver.log with parameters of type Key
static LogEntry LogEntry.fromKeyValue(Key key, Value value)
           
 

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)
           
 

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()
           
 

Method parameters in org.apache.accumulo.core.util.format with type arguments of type Key
protected  void StatisticsDisplayFormatter.aggregateStats(Map.Entry<Key,Value> entry)
           
protected  void ShardedTableDistributionFormatter.aggregateStats(Map.Entry<Key,Value> entry)
           
protected abstract  void AggregatingFormatter.aggregateStats(Map.Entry<Key,Value> next)
          Generate statistics from each Map.Entry, called for each entry to be iterated over.
static String DefaultFormatter.formatEntry(Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static String BinaryFormatter.formatEntry(Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static String DefaultFormatter.formatEntry(Map.Entry<Key,Value> entry, DateFormat timestampFormat)
           
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 HexFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void Formatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void DefaultFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void DateStringFormatter.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.printBinaryRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate, Shell.PrintLine outFile)
           
 void Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate, Class<? extends Formatter> formatterClass)
           
 void Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner, boolean printTimestamps, boolean paginate, Class<? extends Formatter> formatterClass, Shell.PrintLine outFile)
           
 

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.printBinaryRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner, Shell.PrintFile outFile)
           
protected  void ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner, Class<? extends Formatter> formatter)
           
protected  void ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, Iterable<Map.Entry<Key,Value>> scanner, Class<? extends Formatter> formatter, Shell.PrintFile outFile)
           
 



Copyright © 2015 Apache Accumulo Project. All rights reserved.