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.trace   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.format   
org.apache.accumulo.core.util.shell   
 

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 types with arguments of type Key
 java.util.Iterator<java.util.Map.Entry<Key,Value>> Scanner.iterator()
          Returns an iterator over a accumulo table.
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.RowBuffer.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.MemoryRowBuffer.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> BatchScanner.iterator()
          Returns an iterator over a accumulo table.
 

Method parameters in org.apache.accumulo.core.client with type arguments of type Key
 void IsolatedScanner.RowBuffer.add(java.util.Map.Entry<Key,Value> entry)
           
 void IsolatedScanner.MemoryRowBuffer.add(java.util.Map.Entry<Key,Value> entry)
           
 

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
 java.util.Iterator<java.util.Map.Entry<Key,Value>> ScannerImpl.iterator()
          Returns an iterator over a accumulo table.
 java.util.Iterator<java.util.Map.Entry<Key,Value>> TabletServerBatchReader.iterator()
           
 java.util.Map.Entry<Key,Value> TabletServerBatchReaderIterator.next()
           
 java.util.Map.Entry<Key,Value> ScannerIterator.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, java.lang.String server, java.util.SortedMap<Key,Value> results, java.util.SortedSet<Column> fetchedColumns, boolean skipStartKey, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 

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

Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Key
 org.apache.hadoop.mapreduce.RecordReader<Key,Value> AccumuloInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit inSplit, org.apache.hadoop.mapreduce.TaskAttemptContext attempt)
           
 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 AccumuloInputFormat.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)
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> MockScanner.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> MockBatchScanner.iterator()
           
 

Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Key
 SortedKeyValueIterator<Key,Value> MockScannerBase.createFilter(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)
          determines the order of keys in the MapFiles we must then just make sure that *'s are not ever stored
 int Key.compareTo(Key other, PartialKey part)
           
 boolean Range.contains(Key key)
           
 boolean Key.equals(Key other, PartialKey part)
           
 void Key.set(Key k)
           
 

Constructors in org.apache.accumulo.core.data with parameters of type Key
Key(Key other)
           
KeyValue(Key key, byte[] value)
           
Range(Key startKey, boolean startKeyInclusive, Key endKey, boolean endKeyInclusive)
           
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 FileSKVIterator.getFirstKey()
           
 Key FileCFSkippingIterator.getFirstKey()
           
 Key BloomFilterLayer.Reader.getFirstKey()
           
 Key FileSKVIterator.getLastKey()
           
 Key FileCFSkippingIterator.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> FileCFSkippingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env)
           
static org.apache.hadoop.io.WritableComparable<Key> FileUtil.findLastKey(java.util.Collection<java.lang.String> mapFiles)
           
static java.util.SortedMap<java.lang.Double,Key> FileUtil.findMidPoint(org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, java.util.Collection<java.lang.String> mapFiles, double minSplit)
           
static java.util.SortedMap<java.lang.Double,Key> FileUtil.findMidPoint(org.apache.hadoop.io.Text prevEndRow, org.apache.hadoop.io.Text endRow, java.util.Collection<java.lang.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, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 

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

Constructor parameters in org.apache.accumulo.core.file with type arguments of type Key
FileCFSkippingIterator(SortedKeyValueIterator<Key,Value> src, java.util.Set<ByteSequence> colFamSet, boolean inclusive)
           
 

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 MyMapFile.Reader.getFirstKey()
           
 Key MapFileOperations.RangeIterator.getFirstKey()
           
 Key MyMapFile.Reader.getLastKey()
           
 Key MapFileOperations.RangeIterator.getLastKey()
           
 Key MyMapFile.Reader.getTopKey()
           
 Key MapFileOperations.RangeIterator.getTopKey()
           
 

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

Method parameters in org.apache.accumulo.core.file.map with type arguments of type Key
 void MyMapFile.Reader.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void MapFileOperations.RangeIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.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 RFile.IndexEntry.getKey()
           
 Key RelativeKey.getKey()
           
 Key RFile.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 RFile.Writer.append(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.core.file.rfile with type arguments of type Key
 void RFile.Reader.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.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> FamilyIntersectingIterator.docSource
           
 SortedKeyValueIterator<Key,Value> OrIterator.TermSource.iter
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators that return Key
protected  Key FamilyIntersectingIterator.buildDocKey()
           
protected  Key IntersectingIterator.buildFollowingPartitionKey(Key key)
           
protected  Key FamilyIntersectingIterator.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)
           
protected  Key FamilyIntersectingIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term, org.apache.hadoop.io.Text docID)
           
protected  Key IntersectingIterator.buildKey(org.apache.hadoop.io.Text partition, org.apache.hadoop.io.Text term, org.apache.hadoop.io.Text docID)
           
 Key SequenceFileIterator.getFirstKey()
          Deprecated.  
 Key SequenceFileIterator.getLastKey()
          Deprecated.  
 Key ScanCache.getTopKey()
           
 Key LargeRowFilter.getTopKey()
           
 Key WrappingIterator.getTopKey()
           
 Key ColumnFamilyCounter.getTopKey()
           
 Key RowDeletingIterator.getTopKey()
           
 Key DevNull.getTopKey()
           
 Key SequenceFileIterator.getTopKey()
          Deprecated.  
 Key WholeRowIterator.getTopKey()
           
 Key HeapIterator.getTopKey()
           
 Key SourceSwitchingIterator.getTopKey()
           
 Key OrIterator.getTopKey()
           
 Key SortedMapIterator.getTopKey()
           
 Key IntersectingIterator.getTopKey()
           
 Key AggregatingIterator.getTopKey()
           
 Key DebugIterator.getTopKey()
           
 

Methods in org.apache.accumulo.core.iterators that return types with arguments of type Key
static java.util.SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
abstract  SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilyCounter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FamilyIntersectingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.deepCopy(IteratorEnvironment env)
           
protected  SortedKeyValueIterator<Key,Value> WrappingIterator.getSource()
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.DataSource.iterator()
           
 SortedKeyValueIterator<Key,Value> IteratorEnvironment.reserveMapFileReader(java.lang.String mapFileName)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type Key
protected  Key IntersectingIterator.buildFollowingPartitionKey(Key key)
           
static java.util.SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
protected  org.apache.hadoop.io.Text FamilyIntersectingIterator.getDocID(Key key)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getDocID(Key key)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getPartition(Key key)
           
protected  org.apache.hadoop.io.Text FamilyIntersectingIterator.getTerm(Key key)
           
protected  org.apache.hadoop.io.Text IntersectingIterator.getTerm(Key key)
           
 void ScanCache.invalidate(Key key)
           
 

Method parameters in org.apache.accumulo.core.iterators with type arguments of type Key
protected  void HeapIterator.addSource(SortedKeyValueIterator<Key,Value> source)
           
 void IntersectingIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text term, boolean notFlag)
           
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
static Value WholeRowIterator.encodeRow(java.util.List<Key> keys, java.util.List<Value> values)
           
protected  boolean WholeRowIterator.filter(org.apache.hadoop.io.Text currentRow, java.util.List<Key> keys, java.util.List<Value> values)
           
 void FilteringIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void CountingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void GrepIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ScanCache.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void LargeRowFilter.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void WrappingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void MultiIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ColumnFamilyCounter.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void RowDeletingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DevNull.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SequenceFileIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
          Deprecated.  
 void WholeRowIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void FirstEntryInRowIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SourceSwitchingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void OrIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DeletingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void RegExIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SortedMapIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void NoLabelIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void FamilyIntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void IntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void VersioningIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DebugIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ScanCache.setAuthorityIterator(SortedKeyValueIterator<Key,Value> authorityIter)
           
protected  void WrappingIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
static java.lang.String IntersectingIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
 

Constructor parameters in org.apache.accumulo.core.iterators with type arguments of type Key
AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source, java.util.Set<ByteSequence> colFamSet, boolean inclusive)
           
CountingIterator(SortedKeyValueIterator<Key,Value> source)
           
DebugIterator(java.lang.String prefix, SortedKeyValueIterator<Key,Value> source)
           
DeletingIterator(SortedKeyValueIterator<Key,Value> iterator, boolean propogateDeletes)
           
FilteringIterator(SortedKeyValueIterator<Key,Value> iterator, java.util.List<? extends Filter> filters)
           
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)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> readers, boolean init)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
OrIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term)
           
SortedMapIterator(java.util.SortedMap<Key,Value> map)
           
SystemScanIterator(SortedKeyValueIterator<Key,Value> iterator, Authorizations authorizations, byte[] defaultLabels, java.util.HashSet<Column> hsc)
           
VersioningIterator(SortedKeyValueIterator<Key,Value> iterator, int maxVersions)
           
 

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)
           
 

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

Methods in org.apache.accumulo.core.iterators.conf with parameters of type 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 NoLabelFilter.accept(Key k, Value v)
           
 boolean Filter.accept(Key k, Value v)
           
 boolean DeleteFilter.accept(Key key, Value value)
           
 boolean ColumnAgeOffFilter.accept(Key k, Value v)
           
 boolean AgeOffFilter.accept(Key k, Value v)
           
 boolean RegExFilter.accept(Key key, Value value)
           
 boolean VisibilityFilter.accept(Key k, Value v)
           
 boolean ColumnQualifierFilter.accept(Key key, Value v)
           
 

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(java.util.Map.Entry<Key,Value> entry)
           
 void TraceFormatter.initialize(java.lang.Iterable<java.util.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 java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataLocationEntries(java.util.SortedMap<Key,Value> entries)
           
static void MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance, java.util.SortedMap<Key,Value> tkv, KeyExtent ke, java.util.List<ColumnFQ> columns, AuthInfo credentials)
           
static java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(java.util.SortedMap<Key,Value> tabletKeyValues, java.util.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
 java.util.Iterator<java.util.Map.Entry<Key,Value>> DefaultFormatter.getScannerIterator()
           
 

Method parameters in org.apache.accumulo.core.util.format with type arguments of type Key
static java.lang.String DefaultFormatter.formatEntry(java.util.Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static Formatter FormatterFactory.getDefaultFormatter(java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
static Formatter FormatterFactory.getFormatter(java.lang.Class<? extends Formatter> formatterClass, java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void Formatter.initialize(java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void DefaultFormatter.initialize(java.lang.Iterable<java.util.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, java.lang.Iterable<java.util.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
protected  void Shell.ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner)
           
 



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