Uses of Class
org.apache.accumulo.core.data.Key
Package
Description
Mock framework for Accumulo
-
Uses of Key in org.apache.accumulo.core.client
Modifier and TypeMethodDescriptionClientSideIteratorScanner.ScannerTranslator.deepCopy
(org.apache.accumulo.core.iterators.IteratorEnvironment env) Deprecated.ClientSideIteratorScanner.iterator()
IsolatedScanner.iterator()
IsolatedScanner.MemoryRowBuffer.iterator()
IsolatedScanner.RowBuffer.iterator()
ScannerBase.iterator()
Returns an iterator over an accumulo table.RowIterator.next()
Fetch the next row.Modifier and TypeMethodDescriptionvoid
void
ModifierConstructorDescriptionIteratorSetting
(int priority, Class<? extends org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value>> iteratorClass) Constructs an iterator setting using the given class's SimpleName for the iterator name.IteratorSetting
(int priority, Class<? extends org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value>> iteratorClass, Map<String, String> properties) Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified parameters.IteratorSetting
(int priority, String name, Class<? extends org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value>> iteratorClass) Constructs an iterator setting configured for the scan scope with no parameters.IteratorSetting
(int priority, String name, Class<? extends org.apache.accumulo.core.iterators.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.mapred
Modifier and TypeFieldDescriptionprotected Key
AbstractInputFormat.AbstractRecordReader.currentKey
Modifier and TypeMethodDescriptionAccumuloInputFormat.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) 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<org.apache.hadoop.io.Text,
org.apache.accumulo.core.util.PeekingIterator<Map.Entry<Key, Value>>> AccumuloRowInputFormat.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) 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
Modifier and TypeFieldDescriptionprotected Key
AbstractInputFormat.AbstractRecordReader.currentKey
The Key that is used to determine progress in the current InputSplit.Modifier and TypeMethodDescriptionAccumuloInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) AccumuloMultiTableInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit inputSplit, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,
org.apache.accumulo.core.util.PeekingIterator<Map.Entry<Key, Value>>> AccumuloRowInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) AccumuloFileOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) -
Uses of Key in org.apache.accumulo.core.client.mapreduce.lib.partition
Modifier and TypeMethodDescriptionint
KeyRangePartitioner.getPartition
(Key key, org.apache.hadoop.io.Writable value, int numPartitions) -
Uses of Key in org.apache.accumulo.core.client.mock
Modifier and TypeMethodDescriptionMockScannerBase.createFilter
(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value> inner) Deprecated.MockBatchScanner.iterator()
Deprecated.MockScanner.iterator()
Deprecated.MockScannerBase.iterator()
Deprecated.Modifier and TypeMethodDescriptionMockScannerBase.createFilter
(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value> inner) Deprecated.ModifierConstructorDescriptionIteratorAdapter
(org.apache.accumulo.core.iterators.SortedKeyValueIterator<Key, Value> inner) Deprecated. -
Uses of Key in org.apache.accumulo.core.client.rfile
Modifier and TypeMethodDescriptionvoid
Append the key and value to the last locality group that was started. -
Uses of Key in org.apache.accumulo.core.client.sample
Modifier and TypeMethodDescriptionboolean
boolean
protected abstract void
AbstractHashSampler.hash
(DataOutput hasher, Key k) Subclass must override this method and hash some portion of the key.protected void
RowColumnSampler.hash
(DataOutput hasher, Key k) protected void
RowSampler.hash
(DataOutput hasher, Key k) -
Uses of Key in org.apache.accumulo.core.data
Modifier and TypeMethodDescriptionKey.followingKey
(PartialKey part) Returns a key that will sort immediately after this key.Range.getEndKey()
Gets the ending key, or null if the end is positive infinity.Range.getStartKey()
Gets the start key, or null if the start is negative infinity.Modifier and TypeMethodDescriptionboolean
Range.afterEndKey
(Key key) Determines if the given key is after the ending key of this range.boolean
Range.beforeStartKey
(Key key) Determines if the given key is before the start key of this range.int
int
Key.compareTo
(Key other, PartialKey part) Compares elements of a key given by aPartialKey
.boolean
Determines if the given key falls within this range.boolean
Key.equals
(Key other, PartialKey part) Compares part of a key.void
Sets this key's row, column family, column qualifier, column visibility, timestamp, and delete marker to be the same as another key's.ModifierConstructorDescriptionCreates a key with the same row, column family, column qualifier, column visibility, timestamp, and delete marker as the given key.Creates a new key/value pair.KeyValue
(Key key, ByteBuffer value) Creates a new key/value pair.Creates a new key/value pair.protected
Range
(Key start, boolean startKeyInclusive, boolean infiniteStartKey, Key stop, boolean stopKeyInclusive, boolean infiniteStopKey) Creates a range from start to stop.Creates a range from startKey to 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.