Uses of Class
org.apache.accumulo.core.data.Key
Package
Description
-
Uses of Key in org.apache.accumulo.core.client
Modifier and TypeMethodDescriptionClientSideIteratorScanner.iterator()
IsolatedScanner.iterator()
IsolatedScanner.MemoryRowBuffer.iterator()
IsolatedScanner.RowBuffer.iterator()
ScannerBase.iterator()
Returns an iterator over an accumulo table.RowIterator.next()
Fetch the next row.ScannerBase.stream()
Stream the Scanner results sequentially from this scanner's iteratorModifier and TypeMethodDescriptionvoid
void
default void
ScannerBase.forEach
(BiConsumer<? super Key, ? super Value> keyValueConsumer) Iterates through Scanner results.ModifierConstructorDescriptionIteratorSetting
(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.admin.compaction
Modifier and TypeMethodDescriptionCompactionSelector.SelectionParameters.getSample
(CompactableFile cf, SamplerConfiguration sc) -
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) Deprecated.AccumuloMultiTableInputFormat.getRecordReader
(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter) Deprecated.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) Deprecated.AccumuloFileOutputFormat.getRecordWriter
(org.apache.hadoop.fs.FileSystem ignored, org.apache.hadoop.mapred.JobConf job, String name, org.apache.hadoop.util.Progressable progress) Deprecated. -
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) Deprecated.AccumuloMultiTableInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit inputSplit, org.apache.hadoop.mapreduce.TaskAttemptContext context) Deprecated.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) Deprecated.AccumuloFileOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) Deprecated. -
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) Deprecated. -
Uses of Key in org.apache.accumulo.core.client.rfile
Modifier and TypeMethodDescriptionvoid
This method has the same behavior asRFileWriter.append(Key, Value)
.void
RFileWriter.append
(Key key, CharSequence value) This method has the same behavior asRFileWriter.append(Key, Value)
.void
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.client.summary
-
Uses of Key in org.apache.accumulo.core.data
Modifier and TypeMethodDescriptionKeyBuilder.Build.build()
Build aKey
from this builder.Key.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. -
Uses of Key in org.apache.accumulo.core.iterators
Modifier and TypeFieldDescriptionprotected final SortedKeyValueIterator<Key,
Value> ServerWrappingIterator.source
protected final SortedKeyValueIterator<Key,
Value> SynchronizedServerFilter.source
Modifier and TypeMethodDescriptionColumnFamilyCounter.getTopKey()
Combiner.getTopKey()
DebugIterator.getTopKey()
DevNull.getTopKey()
final Key
OrIterator.getTopKey()
ServerWrappingIterator.getTopKey()
SynchronizedServerFilter.getTopKey()
WrappingIterator.getTopKey()
Modifier and TypeMethodDescriptionColumnFamilyCounter.deepCopy
(IteratorEnvironment env) Combiner.deepCopy
(IteratorEnvironment env) DevNull.deepCopy
(IteratorEnvironment env) Filter.deepCopy
(IteratorEnvironment env) FirstEntryInRowIterator.deepCopy
(IteratorEnvironment env) OrIterator.deepCopy
(IteratorEnvironment env) abstract SortedKeyValueIterator<Key,
Value> ServerFilter.deepCopy
(IteratorEnvironment env) ServerWrappingIterator.deepCopy
(IteratorEnvironment env) SortedKeyIterator.deepCopy
(IteratorEnvironment env) abstract SortedKeyValueIterator<Key,
Value> SynchronizedServerFilter.deepCopy
(IteratorEnvironment env) TypedValueCombiner.deepCopy
(IteratorEnvironment env) WrappingIterator.deepCopy
(IteratorEnvironment env) protected SortedKeyValueIterator<Key,
Value> WrappingIterator.getSource()
IteratorAdapter.next()
default SortedKeyValueIterator<Key,
Value> IteratorEnvironment.reserveMapFileReader
(String mapFileName) Deprecated.since 2.0.0.Modifier and TypeMethodDescriptionabstract boolean
abstract boolean
protected abstract boolean
abstract Value
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.Modifier and TypeMethodDescriptionvoid
ColumnFamilyCounter.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
DebugIterator.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
Filter.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
LongCombiner.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
ServerFilter.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) void
ServerWrappingIterator.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) void
SynchronizedServerFilter.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
WrappingIterator.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) default void
IteratorEnvironment.registerSideChannel
(SortedKeyValueIterator<Key, Value> iter) Deprecated.since 2.0.0.protected void
WrappingIterator.setSource
(SortedKeyValueIterator<Key, Value> source) void
OrIterator.setTerms
(SortedKeyValueIterator<Key, Value> source, Collection<String> terms, IteratorEnvironment env) ModifierConstructorDescriptionDebugIterator
(String prefix, SortedKeyValueIterator<Key, Value> source) ServerFilter
(SortedKeyValueIterator<Key, Value> source) TermSource
(SortedKeyValueIterator<Key, Value> iter, org.apache.hadoop.io.Text term) ValueIterator
(SortedKeyValueIterator<Key, Value> source) Constructs an iterator over Values whose Keys are versions of the current topKey of the source SortedKeyValueIterator. -
Uses of Key in org.apache.accumulo.core.iterators.user
Modifier and TypeFieldDescriptionIndexedDocIterator.docSource
IntersectingIterator.TermSource.iter
TransformingIterator.keys
protected SortedKeyValueIterator<Key,
Value> RowEncodingIterator.sourceIter
Modifier and TypeMethodDescriptionprotected Key
IndexedDocIterator.buildDocKey()
protected Key
IntersectingIterator.buildFollowingPartitionKey
(Key key) protected Key
IndexedDocIterator.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, org.apache.hadoop.io.Text docID) protected Key
IntersectingIterator.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
TransformingIterator.copyPartialKey
(Key key, PartialKey part) Creates a copy ofkey
, copying only the parts of the key specified inpart
.CfCqSliceSeekingFilter.getNextKeyHint
(Key k, Value v) abstract Key
SeekingFilter.getNextKeyHint
(Key k, Value v) Whenever the subclass returns AdvanceResult.USE_HINT from its filter predicate, this method will be called to see how far to advance the source iterator.IntersectingIterator.getTopKey()
LargeRowFilter.getTopKey()
RowDeletingIterator.getTopKey()
RowEncodingIterator.getTopKey()
TransformingIterator.getTopKey()
WholeColumnFamilyIterator.getTopKey()
protected Key
TransformingIterator.replaceColumnFamily
(Key originalKey, org.apache.hadoop.io.Text newColFam) Make a new key with all parts (including delete flag) coming fromoriginalKey
but usenewColFam
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 fromoriginalKey
but usenewColQual
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 fromoriginalKey
but usenewColVis
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.Modifier and TypeMethodDescriptionWholeColumnFamilyIterator.decodeColumnFamily
(Key rowKey, Value rowValue) Decode whole row/cf out of value.AgeOffFilter.deepCopy
(IteratorEnvironment env) CfCqSliceFilter.deepCopy
(IteratorEnvironment env) CfCqSliceSeekingFilter.deepCopy
(IteratorEnvironment env) ColumnAgeOffFilter.deepCopy
(IteratorEnvironment env) ColumnSliceFilter.deepCopy
(IteratorEnvironment env) GrepIterator.deepCopy
(IteratorEnvironment env) IndexedDocIterator.deepCopy
(IteratorEnvironment env) IntersectingIterator.deepCopy
(IteratorEnvironment env) LargeRowFilter.deepCopy
(IteratorEnvironment env) RegExFilter.deepCopy
(IteratorEnvironment env) RowDeletingIterator.deepCopy
(IteratorEnvironment env) RowEncodingIterator.deepCopy
(IteratorEnvironment env) RowFilter.deepCopy
(IteratorEnvironment env) SeekingFilter.deepCopy
(IteratorEnvironment env) TimestampFilter.deepCopy
(IteratorEnvironment env) TransformingIterator.deepCopy
(IteratorEnvironment env) WholeColumnFamilyIterator.deepCopy
(IteratorEnvironment env) RowEncodingIterator.rowDecoder
(Key rowKey, Value rowValue) Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.WholeRowIterator.rowDecoder
(Key rowKey, Value rowValue) Modifier and TypeMethodDescriptionboolean
Accepts entries whose timestamps are less than currentTime - threshold.boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
void
protected Key
IntersectingIterator.buildFollowingPartitionKey
(Key key) protected boolean
Indicates whether or not the user is able to seekey
.protected boolean
TransformingIterator.canSeeColumnFamily
(Key key) Indicates whether or notkey
can be seen, according to the fetched column families for this iterator.protected Key
TransformingIterator.copyPartialKey
(Key key, PartialKey part) Creates a copy ofkey
, copying only the parts of the key specified inpart
.WholeColumnFamilyIterator.decodeColumnFamily
(Key rowKey, Value rowValue) Decode whole row/cf out of value.abstract SeekingFilter.FilterResult
Subclasses must provide an implementation which examines the given key and value and determines (1) whether to accept the KV pair and (2) how far to advance the source iterator past the key.protected org.apache.hadoop.io.Text
protected org.apache.hadoop.io.Text
CfCqSliceSeekingFilter.getNextKeyHint
(Key k, Value v) abstract Key
SeekingFilter.getNextKeyHint
(Key k, Value v) Whenever the subclass returns AdvanceResult.USE_HINT from its filter predicate, this method will be called to see how far to advance the source iterator.protected org.apache.hadoop.io.Text
IntersectingIterator.getPartition
(Key key) protected org.apache.hadoop.io.Text
protected org.apache.hadoop.io.Text
protected boolean
TransformingIterator.includeTransformedKey
(Key transformedKey) Determines whether or not to includetransformedKey
in the output.protected boolean
TransformingIterator.isSetAfterPart
(Key key, PartialKey part) Indicates whether or not any part ofkey
excludingpart
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 fromoriginalKey
but usenewColFam
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 fromoriginalKey
but usenewColQual
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 fromoriginalKey
but usenewColVis
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
RowEncodingIterator.rowDecoder
(Key rowKey, Value rowValue) Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.WholeRowIterator.rowDecoder
(Key rowKey, Value rowValue) BigDecimalCombiner.BigDecimalMaxCombiner.typedReduce
(Key key, Iterator<BigDecimal> iter) BigDecimalCombiner.BigDecimalMinCombiner.typedReduce
(Key key, Iterator<BigDecimal> iter) BigDecimalCombiner.BigDecimalSummingCombiner.typedReduce
(Key key, Iterator<BigDecimal> iter) MaxCombiner.typedReduce
(Key key, Iterator<Long> iter) MinCombiner.typedReduce
(Key key, Iterator<Long> iter) SummingArrayCombiner.typedReduce
(Key key, Iterator<List<Long>> iter) SummingCombiner.typedReduce
(Key key, Iterator<Long> iter) Modifier and TypeMethodDescriptionabstract boolean
RowFilter.acceptRow
(SortedKeyValueIterator<Key, Value> rowIterator) Implementation should return false to suppress a row.static final Value
WholeColumnFamilyIterator.encodeColumnFamily
(List<Key> keys, List<Value> values) Encode row/cf.static final Value
protected boolean
RowEncodingIterator.filter
(org.apache.hadoop.io.Text currentRow, List<Key> keys, List<Value> values) protected boolean
WholeColumnFamilyIterator.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
BigDecimalCombiner.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) void
CfCqSliceFilter.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) void
CfCqSliceSeekingFilter.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
ColumnSliceFilter.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
IndexedDocIterator.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
LargeRowFilter.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
RowDeletingIterator.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
RowFilter.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) void
SeekingFilter.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
TimestampFilter.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
VersioningIterator.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
WholeColumnFamilyIterator.init
(SortedKeyValueIterator<Key, Value> source, Map<String, String> options, IteratorEnvironment env) abstract Value
RowEncodingIterator.rowEncoder
(List<Key> keys, List<Value> values) Take a stream of keys and values.WholeRowIterator.rowEncoder
(List<Key> keys, List<Value> values) static String
IntersectingIterator.stringTopKey
(SortedKeyValueIterator<Key, Value> iter) protected abstract void
TransformingIterator.transformRange
(SortedKeyValueIterator<Key, Value> input, TransformingIterator.KVBuffer output) Transformsinput
.ModifierConstructorDescriptionTermSource
(SortedKeyValueIterator<Key, Value> iter, org.apache.hadoop.io.Text term) TermSource
(SortedKeyValueIterator<Key, Value> iter, org.apache.hadoop.io.Text term, boolean notFlag) -
Uses of Key in org.apache.accumulo.hadoop.mapred
Modifier and TypeMethodDescriptionAccumuloInputFormat.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.hadoop.mapreduce
Modifier and TypeMethodDescriptionAccumuloInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) org.apache.hadoop.mapreduce.RecordReader<org.apache.hadoop.io.Text,
org.apache.accumulo.core.util.PeekingIterator<Map.Entry<Key, Value>>> AccumuloRowInputFormat.createRecordReader
(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context) AccumuloFileOutputFormat.getRecordWriter
(org.apache.hadoop.mapreduce.TaskAttemptContext context) -
Uses of Key in org.apache.accumulo.hadoop.mapreduce.partition
Modifier and TypeMethodDescriptionint
KeyRangePartitioner.getPartition
(Key key, org.apache.hadoop.io.Writable value, int numPartitions)