Modifier and Type | Field and Description |
---|---|
static Key |
Constants.METADATA_RESERVED_KEYSPACE_START_KEY |
static Key |
Constants.METADATA_RESERVED_KEYSPACE_STOP_KEY |
Modifier and Type | Method and Description |
---|---|
Key |
ClientSideIteratorScanner.ScannerTranslator.getTopKey() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
ClientSideIteratorScanner.ScannerTranslator.deepCopy(IteratorEnvironment env) |
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>> |
ScannerBase.iterator()
Returns an iterator over an accumulo table.
|
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>> |
ScannerOptions.iterator() |
Iterator<Map.Entry<Key,Value>> |
ScannerImpl.iterator()
Returns an iterator over an accumulo table.
|
Iterator<Map.Entry<Key,Value>> |
TabletServerBatchReader.iterator() |
Iterator<Map.Entry<Key,Value>> |
OfflineScanner.iterator() |
Map.Entry<Key,Value> |
ScannerIterator.next() |
Map.Entry<Key,Value> |
TabletServerBatchReaderIterator.next() |
Modifier and Type | Method and Description |
---|---|
void |
TabletServerBatchReaderIterator.ResultReceiver.receive(List<Map.Entry<Key,Value>> entries) |
Modifier and Type | Field and Description |
---|---|
protected Key |
InputFormatBase.RecordReaderBase.currentKey |
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 Key |
InputFormatBase.RecordReaderBase.currentKey |
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 |
---|---|
float |
RangeInputSplit.getProgress(Key currentKey) |
Modifier and Type | Method and Description |
---|---|
int |
KeyRangePartitioner.getPartition(Key key,
org.apache.hadoop.io.Writable value,
int numPartitions) |
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>> |
MockScannerBase.iterator() |
Iterator<Map.Entry<Key,Value>> |
MockScanner.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 | Field and Description |
---|---|
Key |
KeyValue.key |
Modifier and Type | Method and Description |
---|---|
Key |
Key.followingKey(PartialKey part)
Returns a key that will sort immediately after this key.
|
Key |
Range.getEndKey() |
Key |
KeyValue.getKey() |
Key |
Range.getStartKey() |
Modifier and Type | Method and Description |
---|---|
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.
|
Constructor and Description |
---|
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) |
KeyValue(Key key,
ByteBuffer value) |
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.
|
Modifier and Type | Method and Description |
---|---|
Key |
BloomFilterLayer.Reader.getFirstKey() |
Key |
FileSKVIterator.getFirstKey() |
Key |
BloomFilterLayer.Reader.getLastKey() |
Key |
FileSKVIterator.getLastKey() |
Key |
BloomFilterLayer.Reader.getTopKey() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env) |
static org.apache.hadoop.io.WritableComparable<Key> |
FileUtil.findLastKey(org.apache.hadoop.fs.FileSystem fs,
AccumuloConfiguration acuConf,
Collection<String> mapFiles) |
static SortedMap<Double,Key> |
FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs,
AccumuloConfiguration acuConf,
org.apache.hadoop.io.Text prevEndRow,
org.apache.hadoop.io.Text endRow,
Collection<String> mapFiles,
double minSplit) |
static SortedMap<Double,Key> |
FileUtil.findMidPoint(org.apache.hadoop.fs.FileSystem fs,
AccumuloConfiguration acuConf,
org.apache.hadoop.io.Text prevEndRow,
org.apache.hadoop.io.Text endRow,
Collection<String> mapFiles,
double minSplit,
boolean useIndex) |
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) |
Constructor and Description |
---|
FileUtil.FileInfo(Key firstKey,
Key lastKey) |
Modifier and Type | Method and Description |
---|---|
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) |
org.apache.hadoop.util.bloom.Key |
RowFunctor.transform(Key acuKey) |
Modifier and Type | Method and Description |
---|---|
Key |
MapFileOperations.RangeIterator.getFirstKey() |
Key |
MapFileOperations.RangeIterator.getLastKey() |
Key |
MapFileOperations.RangeIterator.getTopKey() |
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 |
---|---|
Key |
RFile.Reader.getFirstKey() |
Key |
MultiLevelIndex.IndexEntry.getKey() |
Key |
RelativeKey.getKey() |
Key |
MultiLevelIndex.Reader.getLastKey() |
Key |
RFile.Reader.getLastKey() |
Key |
BlockIndex.BlockIndexEntry.getPrevKey() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
RFile.Reader.deepCopy(IteratorEnvironment env) |
Modifier and Type | Method and Description |
---|---|
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,
org.apache.accumulo.core.file.rfile.RelativeKey.MByteSequence 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) |
Modifier and Type | Method and Description |
---|---|
void |
RFile.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env) |
Constructor and Description |
---|
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
|
Modifier and Type | Field and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
OrIterator.TermSource.iter |
Modifier and Type | Method and Description |
---|---|
Key |
DebugIterator.getTopKey() |
Key |
DevNull.getTopKey() |
Key |
WrappingIterator.getTopKey() |
Key |
SortedMapIterator.getTopKey() |
Key |
AggregatingIterator.getTopKey()
Deprecated.
|
Key |
ColumnFamilyCounter.getTopKey() |
Key |
OrIterator.getTopKey() |
Key |
Combiner.getTopKey() |
Modifier and Type | Method and Description |
---|---|
abstract boolean |
Filter.accept(Key k,
Value v) |
abstract Value |
Combiner.reduce(Key key,
Iterator<Value> iter)
Reduces a list of Values into a single Value.
|
Value |
TypedValueCombiner.reduce(Key key,
Iterator<Value> iter) |
abstract V |
TypedValueCombiner.typedReduce(Key key,
Iterator<V> iter)
Reduces a list of V into a single 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 |
---|---|
Aggregator |
AggregatorSet.getAggregator(Key k)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
boolean |
ColumnSet.contains(Key key) |
K |
ColumnToClassMapping.getObject(Key key) |
Modifier and Type | Method and Description |
---|---|
Key |
SequenceFileIterator.getFirstKey() |
Key |
MapFileIterator.getFirstKey() |
Key |
SequenceFileIterator.getLastKey() |
Key |
MapFileIterator.getLastKey() |
Key |
HeapIterator.getTopKey() |
Key |
SequenceFileIterator.getTopKey() |
Key |
MapFileIterator.getTopKey() |
Key |
SourceSwitchingIterator.getTopKey() |
Key |
TimeSettingIterator.getTopKey() |
Modifier and Type | Method and Description |
---|---|
SortedKeyValueIterator<Key,Value> |
VisibilityFilter.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
StatsIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
MapFileIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
ColumnQualifierFilter.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
TimeSettingIterator.deepCopy(IteratorEnvironment env) |
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.DataSource.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
VisibilityFilter.accept(Key k,
Value v) |
boolean |
ColumnQualifierFilter.accept(Key key,
Value v) |
Modifier and Type | Field and Description |
---|---|
protected Key |
IntersectingIterator.topKey |
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 |
---|---|
protected 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 |
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,
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) |
protected Key |
TransformingIterator.copyPartialKey(Key key,
PartialKey part)
Creates a copy of
key , copying only the parts of the key specified in part . |
Key |
TransformingIterator.getTopKey() |
Key |
RowDeletingIterator.getTopKey() |
Key |
LargeRowFilter.getTopKey() |
Key |
WholeRowIterator.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.
|
Modifier and Type | Method and Description |
---|---|
boolean |
GrepIterator.accept(Key k,
Value v) |
boolean |
ReqVisFilter.accept(Key k,
Value v) |
boolean |
VisibilityFilter.accept(Key k,
Value v) |
boolean |
TimestampFilter.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.
|
boolean |
RegExFilter.accept(Key key,
Value value) |
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> |
WholeRowIterator.decodeRow(Key rowKey,
Value rowValue) |
protected org.apache.hadoop.io.Text |
IndexedDocIterator.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 |
IndexedDocIterator.getTerm(Key key) |
protected org.apache.hadoop.io.Text |
IntersectingIterator.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) |
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 |
MinCombiner.typedReduce(Key key,
Iterator<Long> iter) |
Long |
MaxCombiner.typedReduce(Key key,
Iterator<Long> iter) |
Long |
SummingCombiner.typedReduce(Key key,
Iterator<Long> iter) |
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 |
---|---|
boolean |
ColumnFQ.hasColumns(Key key) |
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) |
Constructor and Description |
---|
ColumnFQ(Key k) |
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 |
BinaryFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
Formatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
HexFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps) |
void |
DefaultFormatter.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) |
Copyright © 2014 Apache Accumulo Project. All Rights Reserved.