Modifier and Type | Method and Description |
---|---|
Value |
ClientSideIteratorScanner.ScannerTranslator.getTopValue() |
Modifier and Type | Method and Description |
---|---|
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.RowBuffer.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.
|
Modifier and Type | Method and Description |
---|---|
void |
IsolatedScanner.RowBuffer.add(Map.Entry<Key,Value> entry) |
void |
IsolatedScanner.MemoryRowBuffer.add(Map.Entry<Key,Value> entry) |
void |
ClientSideIteratorScanner.ScannerTranslator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Constructor and Description |
---|
IteratorSetting(int priority,
Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
Constructs an iterator setting using the given class's SimpleName for the iterator name.
|
IteratorSetting(int priority,
Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass,
Map<String,String> properties)
Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified
parameters.
|
IteratorSetting(int priority,
String name,
Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
Constructs an iterator setting configured for the scan scope with no parameters.
|
RowIterator(Iterable<Map.Entry<Key,Value>> iterable)
Create an iterator from an Iterable.
|
RowIterator(Iterator<Map.Entry<Key,Value>> iterator)
Create an iterator from an (ordered) sequence of KeyValue pairs.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Map.Entry<Key,Value>> |
ScannerImpl.iterator()
Returns an iterator over an accumulo table.
|
Iterator<Map.Entry<Key,Value>> |
ScannerOptions.iterator() |
Iterator<Map.Entry<Key,Value>> |
OfflineScanner.iterator() |
Iterator<Map.Entry<Key,Value>> |
TabletServerBatchReader.iterator() |
Map.Entry<Key,Value> |
TabletServerBatchReaderIterator.next() |
Map.Entry<Key,Value> |
ScannerIterator.next() |
Modifier and Type | Method and Description |
---|---|
void |
TabletServerBatchReaderIterator.ResultReceiver.receive(List<Map.Entry<Key,Value>> entries) |
Modifier and Type | Field and Description |
---|---|
protected Iterator<Map.Entry<Key,Value>> |
InputFormatBase.RecordReaderBase.scannerIterator |
Modifier and Type | Method and Description |
---|---|
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.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.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) |
Modifier and Type | Field and Description |
---|---|
protected Value |
InputFormatBase.RecordReaderBase.currentValue |
Modifier and Type | Field and Description |
---|---|
protected Iterator<Map.Entry<Key,Value>> |
InputFormatBase.RecordReaderBase.scannerIterator |
Modifier and Type | Method and Description |
---|---|
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.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.RecordWriter<Key,Value> |
AccumuloFileOutputFormat.getRecordWriter(org.apache.hadoop.mapreduce.TaskAttemptContext context) |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner) |
Iterator<Map.Entry<Key,Value>> |
MockBatchScanner.iterator() |
Iterator<Map.Entry<Key,Value>> |
MockScanner.iterator() |
Iterator<Map.Entry<Key,Value>> |
MockScannerBase.iterator() |
Map.Entry<Key,Value> |
IteratorAdapter.next() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner) |
Constructor and Description |
---|
IteratorAdapter(SortedKeyValueIterator<Key,Value> inner) |
Modifier and Type | Method and Description |
---|---|
static Value |
KeyExtent.encodePrevEndRow(org.apache.hadoop.io.Text per) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.io.Text |
KeyExtent.decodePrevEndRow(Value ibw) |
void |
Mutation.put(CharSequence columnFamily,
CharSequence columnQualifier,
ColumnVisibility columnVisibility,
long timestamp,
Value value) |
void |
Mutation.put(CharSequence columnFamily,
CharSequence columnQualifier,
ColumnVisibility columnVisibility,
Value value) |
void |
Mutation.put(CharSequence columnFamily,
CharSequence columnQualifier,
long timestamp,
Value value) |
void |
Mutation.put(CharSequence columnFamily,
CharSequence columnQualifier,
Value value) |
void |
Mutation.put(org.apache.hadoop.io.Text columnFamily,
org.apache.hadoop.io.Text columnQualifier,
ColumnVisibility columnVisibility,
long timestamp,
Value value) |
void |
Mutation.put(org.apache.hadoop.io.Text columnFamily,
org.apache.hadoop.io.Text columnQualifier,
ColumnVisibility columnVisibility,
Value value) |
void |
Mutation.put(org.apache.hadoop.io.Text columnFamily,
org.apache.hadoop.io.Text columnQualifier,
long timestamp,
Value value) |
void |
Mutation.put(org.apache.hadoop.io.Text columnFamily,
org.apache.hadoop.io.Text columnQualifier,
Value value) |
Constructor and Description |
---|
KeyExtent(org.apache.hadoop.io.Text flattenedExtent,
Value prevEndRow) |
KeyValue(Key key,
Value value)
Creates a new key/value pair.
|
Value(Value ibw)
Set the new Value to a copy of the contents of the passed
ibw . |
Modifier and Type | Method and Description |
---|---|
Value |
BloomFilterLayer.Reader.getTopValue() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
FileSKVWriter.append(Key key,
Value value) |
void |
BloomFilterLayer.Writer.append(Key key,
Value val) |
Modifier and Type | Method and Description |
---|---|
void |
BloomFilterLayer.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
Value |
MapFileOperations.RangeIterator.getTopValue() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
MapFileOperations.RangeIterator.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
MapFileOperations.RangeIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Constructor and Description |
---|
MapFileOperations.RangeIterator(SortedKeyValueIterator<Key,Value> reader) |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
RFile.Reader.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
RFile.Writer.append(Key key,
Value value) |
Modifier and Type | Method and Description |
---|---|
void |
RFile.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Modifier and Type | Field and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
OrIterator.TermSource.iter |
Modifier and Type | Method and Description |
---|---|
Value |
Combiner.getTopValue() |
Value |
DevNull.getTopValue() |
Value |
SortedMapIterator.getTopValue() |
Value |
DebugIterator.getTopValue() |
Value |
AggregatingIterator.getTopValue()
Deprecated.
|
Value |
SortedKeyIterator.getTopValue() |
Value |
WrappingIterator.getTopValue() |
Value |
ColumnFamilyCounter.getTopValue() |
Value |
OrIterator.getTopValue() |
Value |
Combiner.ValueIterator.next() |
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.
|
Modifier and Type | Method and Description |
---|---|
abstract boolean |
Filter.accept(Key k,
Value v) |
Constructor and Description |
---|
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.
|
Modifier and Type | Method and Description |
---|---|
Value |
StringMin.aggregate()
Deprecated.
|
Value |
NumSummation.aggregate()
Deprecated.
|
Value |
LongSummation.aggregate()
Deprecated.
|
Value |
StringSummation.aggregate()
Deprecated.
|
Value |
NumArraySummation.aggregate()
Deprecated.
|
Value |
StringMax.aggregate()
Deprecated.
|
Value |
Aggregator.aggregate()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
StringMin.collect(Value value)
Deprecated.
|
void |
NumSummation.collect(Value value)
Deprecated.
|
void |
LongSummation.collect(Value value)
Deprecated.
|
void |
StringSummation.collect(Value value)
Deprecated.
|
void |
NumArraySummation.collect(Value value)
Deprecated.
|
void |
StringMax.collect(Value value)
Deprecated.
|
void |
Aggregator.collect(Value value)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
Value |
HeapIterator.getTopValue() |
Value |
TimeSettingIterator.getTopValue() |
Value |
MapFileIterator.getTopValue() |
Value |
SequenceFileIterator.getTopValue() |
Value |
SourceSwitchingIterator.getTopValue() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
ColumnQualifierFilter.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
TimeSettingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
MapFileIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
StatsIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
VisibilityFilter.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.DataSource.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
ColumnQualifierFilter.accept(Key key,
Value v) |
boolean |
VisibilityFilter.accept(Key k,
Value v) |
Modifier and Type | Field and Description |
---|---|
static Value |
RowDeletingIterator.DELETE_ROW_VALUE |
static Value |
LargeRowFilter.SUPPRESS_ROW_VALUE |
protected Value |
IntersectingIterator.value |
Modifier and Type | Field and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
IndexedDocIterator.docSource |
SortedKeyValueIterator<Key,Value> |
IntersectingIterator.TermSource.iter |
protected ArrayList<Pair<Key,Value>> |
TransformingIterator.keys |
Modifier and Type | Method and Description |
---|---|
static Value |
WholeRowIterator.encodeRow(List<Key> keys,
List<Value> values) |
Value |
WholeRowIterator.getTopValue() |
Value |
LargeRowFilter.getTopValue() |
Value |
RowDeletingIterator.getTopValue() |
Value |
TransformingIterator.getTopValue() |
Value |
IntersectingIterator.getTopValue() |
Modifier and Type | Method and Description |
---|---|
boolean |
TimestampFilter.accept(Key k,
Value v) |
boolean |
AgeOffFilter.accept(Key k,
Value v)
Accepts entries whose timestamps are less than currentTime - threshold.
|
boolean |
GrepIterator.accept(Key k,
Value v) |
boolean |
RegExFilter.accept(Key key,
Value value) |
boolean |
ColumnAgeOffFilter.accept(Key k,
Value v) |
boolean |
ColumnSliceFilter.accept(Key key,
Value value) |
boolean |
ReqVisFilter.accept(Key k,
Value v) |
boolean |
VisibilityFilter.accept(Key k,
Value v) |
void |
TransformingIterator.KVBuffer.append(Key key,
Value val) |
static SortedMap<Key,Value> |
WholeRowIterator.decodeRow(Key rowKey,
Value rowValue) |
Constructor and Description |
---|
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) |
Modifier and Type | Method and Description |
---|---|
static RemoteSpan |
TraceFormatter.getRemoteSpan(Map.Entry<Key,Value> entry) |
void |
TraceFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
Modifier and Type | Method and Description |
---|---|
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(SortedMap<Key,Value> tabletKeyValues,
List<ColumnFQ> columns) |
Modifier and Type | Method and Description |
---|---|
static void |
ColumnFQ.put(Mutation m,
ColumnFQ cfq,
Value v)
Deprecated.
since 1.5, use
ColumnFQ.put(Mutation, Value) instead |
void |
ColumnFQ.put(Mutation m,
Value v) |
Modifier and Type | Method and Description |
---|---|
static Pair<SortedMap<KeyExtent,org.apache.hadoop.io.Text>,List<KeyExtent>> |
MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries) |
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(SortedMap<Key,Value> tabletKeyValues,
List<ColumnFQ> columns) |
Modifier and Type | Method and Description |
---|---|
Iterator<Map.Entry<Key,Value>> |
BinaryFormatter.getScannerIterator() |
Iterator<Map.Entry<Key,Value>> |
DefaultFormatter.getScannerIterator() |
Modifier and Type | Method and Description |
---|---|
static String |
BinaryFormatter.formatEntry(Map.Entry<Key,Value> entry,
boolean showTimestamps) |
static String |
DefaultFormatter.formatEntry(Map.Entry<Key,Value> entry,
boolean showTimestamps) |
static Formatter |
FormatterFactory.getDefaultFormatter(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
static Formatter |
FormatterFactory.getFormatter(Class<? extends Formatter> formatterClass,
Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
Formatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
BinaryFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
DefaultFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
HexFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
Constructor and Description |
---|
DeleterFormatter(BatchWriter writer,
Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps,
Shell shellState,
boolean force) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
Value |
StatsCombiner.reduce(Key key,
Iterator<Value> iter) |
Modifier and Type | Method and Description |
---|---|
void |
StatsCombiner.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Value |
StatsCombiner.reduce(Key key,
Iterator<Value> iter) |
Modifier and Type | Method and Description |
---|---|
Iterable<Map.Entry<Key,Value>> |
QueryUtil.exactTermSearch(String term)
Scans over the index table for files or directories with a given name.
|
Iterable<Map.Entry<Key,Value>> |
QueryUtil.singleRestrictedWildCardSearch(String exp)
Scans over the index table for files or directories with a given name, prefix, or suffix (indicated by a wildcard '*' at the beginning or end of the term.
|
Iterable<Map.Entry<Key,Value>> |
QueryUtil.singleWildCardSearch(String exp)
Scans over the index table for files or directories with a given name that can contain a single wildcard '*' anywhere in the term.
|
Modifier and Type | Field and Description |
---|---|
protected PeekingIterator<Map.Entry<Key,Value>> |
ChunkInputStream.source |
Modifier and Type | Method and Description |
---|---|
Value |
ChunkCombiner.getTopValue() |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.mapreduce.RecordReader<List<Map.Entry<Key,Value>>,InputStream> |
ChunkInputFormat.createRecordReader(org.apache.hadoop.mapreduce.InputSplit split,
org.apache.hadoop.mapreduce.TaskAttemptContext context) |
SortedKeyValueIterator<Key,Value> |
ChunkCombiner.deepCopy(IteratorEnvironment env) |
List<Map.Entry<Key,Value>> |
FileDataQuery.getLastRefs() |
Modifier and Type | Method and Description |
---|---|
void |
ChunkCombiner.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
void |
CharacterHistogram.HistMapper.map(List<Map.Entry<Key,Value>> k,
InputStream v,
org.apache.hadoop.mapreduce.Mapper.Context context) |
void |
ChunkInputStream.setSource(PeekingIterator<Map.Entry<Key,Value>> in) |
Constructor and Description |
---|
ChunkInputStream(PeekingIterator<Map.Entry<Key,Value>> in) |
Modifier and Type | Method and Description |
---|---|
void |
RegexExample.RegexMapper.map(Key row,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context context) |
void |
TableToFile.TTFMapper.map(Key row,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context context) |
void |
RowHash.HashDataMapper.map(Key row,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context context) |
void |
UniqueColumns.UMapper.map(Key key,
Value value,
org.apache.hadoop.mapreduce.Mapper.Context context) |
Modifier and Type | Field and Description |
---|---|
Iterator<Map.Entry<Key,Value>> |
ProxyServer.ScannerPlusIterator.iterator |
Modifier and Type | Method and Description |
---|---|
boolean |
MetadataBulkLoadFilter.accept(Key k,
Value v) |
Modifier and Type | Method and Description |
---|---|
void |
MetadataBulkLoadFilter.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
Value |
TServerInstance.asMutationValue() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
TabletStateChangeIterator.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
static TabletLocationState |
MetaDataTableScanner.createTabletLocationState(Key k,
Value v) |
Modifier and Type | Method and Description |
---|---|
void |
TabletStateChangeIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Constructor and Description |
---|
TServerInstance(Value address,
org.apache.hadoop.io.Text session) |
Modifier and Type | Method and Description |
---|---|
Iterator<Map.Entry<Key,Value>> |
NullScanner.iterator() |
Map.Entry<Key,Value> |
NullKeyValueIterator.next() |
Modifier and Type | Method and Description |
---|---|
Value |
ProblemReportingIterator.getTopValue() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
ProblemReportingIterator.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
static ProblemReport |
ProblemReport.decodeMetadataEntry(Map.Entry<Key,Value> entry) |
void |
ProblemReportingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Constructor and Description |
---|
ProblemReportingIterator(String table,
String resource,
boolean continueOnError,
SortedKeyValueIterator<Key,Value> source) |
Modifier and Type | Class and Description |
---|---|
class |
MemValue |
Modifier and Type | Method and Description |
---|---|
Value |
NativeMap.get(Key key) |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
InMemoryMap.compactionIterator() |
Iterator<Map.Entry<Key,Value>> |
NativeMap.iterator() |
Iterator<Map.Entry<Key,Value>> |
NativeMap.iterator(Key startKey) |
SortedKeyValueIterator<Key,Value> |
TabletIteratorEnvironment.reserveMapFileReader(String mapFileName) |
SortedKeyValueIterator<Key,Value> |
NativeMap.skvIterator() |
Modifier and Type | Method and Description |
---|---|
void |
NativeMap.put(Key key,
Value value) |
static int |
MemValue.splitKVCount(Value v)
Takes a Value and will take out the embedded kvCount, and then return that value while replacing the Value with the original unembedded version
|
Modifier and Type | Method and Description |
---|---|
void |
Compactor.CountingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
void |
TabletIteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter) |
static Pair<org.apache.hadoop.io.Text,KeyExtent> |
TabletServer.verifyTabletInformation(KeyExtent extent,
TServerInstance instance,
SortedMap<Key,Value> tabletsKeyValues,
String clientAddress,
ZooLock lock) |
Constructor and Description |
---|
MemValue(Value value,
int kv) |
Tablet.KVEntry(Key k,
Value v) |
Constructor and Description |
---|
Compactor.CountingIterator(SortedKeyValueIterator<Key,Value> source) |
Tablet(TabletServer tabletServer,
org.apache.hadoop.io.Text location,
KeyExtent extent,
TabletServerResourceManager.TabletResourceManager trm,
SortedMap<Key,Value> tabletsKeyValues) |
Modifier and Type | Method and Description |
---|---|
Iterator<Map.Entry<Key,Value>> |
OfflineMetadataScanner.iterator() |
Map<Key,Value> |
TabletIterator.next() |
Modifier and Type | Method and Description |
---|---|
static MetadataTable.LogEntry |
MetadataTable.entryFromKeyValue(Key key,
Value value) |
Modifier and Type | Method and Description |
---|---|
static KeyExtent |
MetadataTable.fixSplit(org.apache.hadoop.io.Text metadataEntry,
SortedMap<ColumnFQ,Value> columns,
TServerInstance tserver,
TCredentials credentials,
ZooLock lock) |
static SortedMap<KeyExtent,org.apache.hadoop.io.Text> |
MetadataTable.getMetadataDirectoryEntries(SortedMap<Key,Value> entries)
convenience method for reading entries from the metadata table
|
Modifier and Type | Method and Description |
---|---|
void |
ContinuousVerify.CMapper.map(Key key,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context context) |
void |
ContinuousMoru.CMapper.map(Key key,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context context) |
Modifier and Type | Method and Description |
---|---|
Value |
BadCombiner.reduce(Key key,
Iterator<Value> iter) |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
BadIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
SlowIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
DropModIter.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
void |
SlowIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
void |
DropModIter.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Value |
BadCombiner.reduce(Key key,
Iterator<Value> iter) |
Modifier and Type | Method and Description |
---|---|
void |
CopyTool.SeqMapClass.map(Key key,
Value val,
org.apache.hadoop.mapreduce.Mapper.Context output) |
Modifier and Type | Method and Description |
---|---|
void |
MapRedVerifyTool.SeqMapClass.map(Key row,
Value data,
org.apache.hadoop.mapreduce.Mapper.Context output) |
Copyright © 2015 Apache Accumulo Project. All Rights Reserved.