|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of Value in org.apache.accumulo.core.client |
---|
Methods in org.apache.accumulo.core.client that return Value | |
---|---|
Value |
ClientSideIteratorScanner.ScannerTranslator.getTopValue()
|
Methods in org.apache.accumulo.core.client that return types with arguments of type Value | |
---|---|
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>> |
ClientSideIteratorScanner.iterator()
|
Iterator<Map.Entry<Key,Value>> |
ScannerBase.iterator()
Returns an iterator over an accumulo table. |
Iterator<Map.Entry<Key,Value>> |
RowIterator.next()
Fetch the next row. |
Method parameters in org.apache.accumulo.core.client with type arguments of type Value | |
---|---|
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 parameters in org.apache.accumulo.core.client with type arguments of type Value | |
---|---|
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. |
Uses of Value in org.apache.accumulo.core.client.impl |
---|
Methods in org.apache.accumulo.core.client.impl that return types with arguments of type Value | |
---|---|
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>> |
ScannerOptions.iterator()
|
Iterator<Map.Entry<Key,Value>> |
OfflineScanner.iterator()
|
Map.Entry<Key,Value> |
ScannerIterator.next()
|
Map.Entry<Key,Value> |
TabletServerBatchReaderIterator.next()
|
Methods in org.apache.accumulo.core.client.impl with parameters of type Value | |
---|---|
void |
TabletServerBatchReaderIterator.ResultReceiver.receive(Key key,
Value value)
|
Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Value | |
---|---|
static boolean |
ThriftScanner.getBatchFromServer(AuthInfo credentials,
org.apache.hadoop.io.Text startRow,
KeyExtent extent,
String server,
SortedMap<Key,Value> results,
SortedSet<Column> fetchedColumns,
boolean skipStartKey,
int size,
Authorizations authorizations,
boolean retry,
AccumuloConfiguration conf)
|
Uses of Value in org.apache.accumulo.core.client.mapreduce |
---|
Fields in org.apache.accumulo.core.client.mapreduce declared as Value | |
---|---|
protected Value |
InputFormatBase.RecordReaderBase.currentValue
|
Fields in org.apache.accumulo.core.client.mapreduce with type parameters of type Value | |
---|---|
protected Iterator<Map.Entry<Key,Value>> |
InputFormatBase.RecordReaderBase.scannerIterator
|
Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Value | |
---|---|
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 job)
|
Uses of Value in org.apache.accumulo.core.client.mock |
---|
Methods in org.apache.accumulo.core.client.mock that return types with arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner)
|
Iterator<Map.Entry<Key,Value>> |
MockScannerBase.iterator()
|
Iterator<Map.Entry<Key,Value>> |
MockScanner.iterator()
|
Iterator<Map.Entry<Key,Value>> |
MockBatchScanner.iterator()
|
Map.Entry<Key,Value> |
IteratorAdapter.next()
|
Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
MockScannerBase.createFilter(SortedKeyValueIterator<Key,Value> inner)
|
Constructor parameters in org.apache.accumulo.core.client.mock with type arguments of type Value | |
---|---|
IteratorAdapter(SortedKeyValueIterator<Key,Value> inner)
|
Uses of Value in org.apache.accumulo.core.data |
---|
Methods in org.apache.accumulo.core.data that return Value | |
---|---|
static Value |
KeyExtent.encodePrevEndRow(org.apache.hadoop.io.Text per)
|
Value |
KeyValue.getValue()
|
Value |
KeyValue.setValue(Value value)
|
Methods in org.apache.accumulo.core.data with parameters of type Value | |
---|---|
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)
|
Value |
KeyValue.setValue(Value value)
|
Constructors in org.apache.accumulo.core.data with parameters of type Value | |
---|---|
KeyExtent(org.apache.hadoop.io.Text flattenedExtent,
Value prevEndRow)
|
|
Value(Value ibw)
Set the new Value to a copy of the contents of the passed ibw . |
Uses of Value in org.apache.accumulo.core.file |
---|
Methods in org.apache.accumulo.core.file that return Value | |
---|---|
Value |
BloomFilterLayer.Reader.getTopValue()
|
Methods in org.apache.accumulo.core.file that return types with arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
BloomFilterLayer.Reader.deepCopy(IteratorEnvironment env)
|
Methods in org.apache.accumulo.core.file with parameters of type Value | |
---|---|
void |
BloomFilterLayer.Writer.append(Key key,
Value val)
|
void |
FileSKVWriter.append(Key key,
Value value)
|
Method parameters in org.apache.accumulo.core.file with type arguments of type Value | |
---|---|
void |
BloomFilterLayer.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
Uses of Value in org.apache.accumulo.core.file.map |
---|
Methods in org.apache.accumulo.core.file.map that return Value | |
---|---|
Value |
MapFileOperations.RangeIterator.getTopValue()
|
Value |
MyMapFile.Reader.getTopValue()
|
Methods in org.apache.accumulo.core.file.map that return types with arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
MapFileOperations.RangeIterator.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
MyMapFile.Reader.deepCopy(IteratorEnvironment env)
|
Method parameters in org.apache.accumulo.core.file.map with type arguments of type Value | |
---|---|
void |
MapFileOperations.RangeIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
MyMapFile.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
Constructor parameters in org.apache.accumulo.core.file.map with type arguments of type Value | |
---|---|
MapFileOperations.RangeIterator(SortedKeyValueIterator<Key,Value> reader)
|
Uses of Value in org.apache.accumulo.core.file.rfile |
---|
Methods in org.apache.accumulo.core.file.rfile that return types with arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
RFile.Reader.deepCopy(IteratorEnvironment env)
|
Methods in org.apache.accumulo.core.file.rfile with parameters of type Value | |
---|---|
void |
RFile.Writer.append(Key key,
Value value)
|
Method parameters in org.apache.accumulo.core.file.rfile with type arguments of type Value | |
---|---|
void |
RFile.Reader.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
Uses of Value in org.apache.accumulo.core.iterators |
---|
Fields in org.apache.accumulo.core.iterators with type parameters of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
OrIterator.TermSource.iter
|
Methods in org.apache.accumulo.core.iterators that return Value | |
---|---|
Value |
AggregatingIterator.getTopValue()
Deprecated. |
Value |
SortedMapIterator.getTopValue()
|
Value |
DebugIterator.getTopValue()
|
Value |
WrappingIterator.getTopValue()
|
Value |
OrIterator.getTopValue()
|
Value |
ColumnFamilyCounter.getTopValue()
|
Value |
SortedKeyIterator.getTopValue()
|
Value |
DevNull.getTopValue()
|
Value |
Combiner.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. |
Methods in org.apache.accumulo.core.iterators with parameters of type Value | |
---|---|
abstract boolean |
Filter.accept(Key k,
Value v)
|
Constructor parameters in org.apache.accumulo.core.iterators with type arguments of type Value | |
---|---|
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)
|
|
FilteringIterator(SortedKeyValueIterator<Key,Value> iterator,
List<? extends Filter> filters)
Deprecated. |
|
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. |
Uses of Value in org.apache.accumulo.core.iterators.aggregation |
---|
Methods in org.apache.accumulo.core.iterators.aggregation that return Value | |
---|---|
Value |
StringMin.aggregate()
Deprecated. |
Value |
StringMax.aggregate()
Deprecated. |
Value |
Aggregator.aggregate()
Deprecated. |
Value |
LongSummation.aggregate()
Deprecated. |
Value |
NumArraySummation.aggregate()
Deprecated. |
Value |
StringSummation.aggregate()
Deprecated. |
Value |
NumSummation.aggregate()
Deprecated. |
Methods in org.apache.accumulo.core.iterators.aggregation with parameters of type Value | |
---|---|
void |
StringMin.collect(Value value)
Deprecated. |
void |
StringMax.collect(Value value)
Deprecated. |
void |
Aggregator.collect(Value value)
Deprecated. |
void |
LongSummation.collect(Value value)
Deprecated. |
void |
NumArraySummation.collect(Value value)
Deprecated. |
void |
StringSummation.collect(Value value)
Deprecated. |
void |
NumSummation.collect(Value value)
Deprecated. |
Uses of Value in org.apache.accumulo.core.iterators.filter |
---|
Methods in org.apache.accumulo.core.iterators.filter with parameters of type Value | |
---|---|
boolean |
Filter.accept(Key k,
Value v)
Deprecated. |
boolean |
VisibilityFilter.accept(Key k,
Value v)
Deprecated. |
boolean |
ColumnAgeOffFilter.accept(Key k,
Value v)
Deprecated. |
boolean |
NoLabelFilter.accept(Key k,
Value v)
Deprecated. |
boolean |
DeleteFilter.accept(Key key,
Value value)
Deprecated. |
boolean |
AgeOffFilter.accept(Key k,
Value v)
Deprecated. |
boolean |
RegExFilter.accept(Key key,
Value value)
Deprecated. |
boolean |
ColumnQualifierFilter.accept(Key key,
Value v)
Deprecated. |
Uses of Value in org.apache.accumulo.core.iterators.system |
---|
Methods in org.apache.accumulo.core.iterators.system that return Value | |
---|---|
Value |
HeapIterator.getTopValue()
|
Value |
TimeSettingIterator.getTopValue()
|
Value |
SequenceFileIterator.getTopValue()
|
Value |
SourceSwitchingIterator.getTopValue()
|
Methods in org.apache.accumulo.core.iterators.system that return types with arguments of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
VisibilityFilter.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
TimeSettingIterator.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
ColumnQualifierFilter.deepCopy(IteratorEnvironment env)
|
SortedKeyValueIterator<Key,Value> |
SourceSwitchingIterator.DataSource.iterator()
|
Methods in org.apache.accumulo.core.iterators.system with parameters of type Value | |
---|---|
boolean |
VisibilityFilter.accept(Key k,
Value v)
|
boolean |
ColumnQualifierFilter.accept(Key key,
Value v)
|
Method parameters in org.apache.accumulo.core.iterators.system with type arguments of type Value | |
---|---|
protected void |
HeapIterator.addSource(SortedKeyValueIterator<Key,Value> source)
|
void |
TimeSettingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
CountingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
MultiIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
DeletingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
SequenceFileIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
void |
SourceSwitchingIterator.init(SortedKeyValueIterator<Key,Value> source,
Map<String,String> options,
IteratorEnvironment env)
|
Uses of Value in org.apache.accumulo.core.iterators.user |
---|
Fields in org.apache.accumulo.core.iterators.user declared as Value | |
---|---|
static Value |
RowDeletingIterator.DELETE_ROW_VALUE
|
static Value |
LargeRowFilter.SUPPRESS_ROW_VALUE
|
protected Value |
IntersectingIterator.value
|
Fields in org.apache.accumulo.core.iterators.user with type parameters of type Value | |
---|---|
SortedKeyValueIterator<Key,Value> |
IndexedDocIterator.docSource
|
SortedKeyValueIterator<Key,Value> |
IntersectingIterator.TermSource.iter
|
Methods in org.apache.accumulo.core.iterators.user that return Value | |
---|---|
static Value |
WholeRowIterator.encodeRow(List<Key> keys,
List<Value> values)
|
Value |
IntersectingIterator.getTopValue()
|
Value |
RowDeletingIterator.getTopValue()
|
Value |
LargeRowFilter.getTopValue()
|
Value |
WholeRowIterator.getTopValue()
|
Methods in org.apache.accumulo.core.iterators.user with parameters of type Value | |
---|---|
boolean |
ColumnAgeOffFilter.accept(Key k,
Value v)
|
boolean |
TimestampFilter.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)
|
boolean |
ReqVisFilter.accept(Key k,
Value v)
|
static SortedMap<Key,Value> |
WholeRowIterator.decodeRow(Key rowKey,
Value rowValue)
|
Constructor parameters in org.apache.accumulo.core.iterators.user with type arguments of type Value | |
---|---|
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)
|
Uses of Value in org.apache.accumulo.core.trace |
---|
Method parameters in org.apache.accumulo.core.trace with type arguments of type Value | |
---|---|
static RemoteSpan |
TraceFormatter.getRemoteSpan(Map.Entry<Key,Value> entry)
|
void |
TraceFormatter.initialize(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps)
|
Uses of Value in org.apache.accumulo.core.util |
---|
Methods in org.apache.accumulo.core.util that return types with arguments of type Value | |
---|---|
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(Instance instance,
KeyExtent ke,
List<ColumnFQ> columns,
AuthInfo credentials)
|
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(SortedMap<Key,Value> tabletKeyValues,
List<ColumnFQ> columns)
|
Methods in org.apache.accumulo.core.util with parameters of type Value | |
---|---|
static void |
ColumnFQ.put(Mutation m,
ColumnFQ cfq,
Value v)
|
Method parameters in org.apache.accumulo.core.util with type arguments of type Value | |
---|---|
static Pair<SortedMap<KeyExtent,org.apache.hadoop.io.Text>,List<KeyExtent>> |
MetadataTable.getMetadataLocationEntries(SortedMap<Key,Value> entries)
|
static void |
MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance,
SortedMap<Key,Value> tkv,
KeyExtent ke,
List<ColumnFQ> columns,
AuthInfo credentials)
|
static SortedMap<org.apache.hadoop.io.Text,SortedMap<ColumnFQ,Value>> |
MetadataTable.getTabletEntries(SortedMap<Key,Value> tabletKeyValues,
List<ColumnFQ> columns)
|
Uses of Value in org.apache.accumulo.core.util.format |
---|
Methods in org.apache.accumulo.core.util.format that return types with arguments of type Value | |
---|---|
Iterator<Map.Entry<Key,Value>> |
DefaultFormatter.getScannerIterator()
|
Iterator<Map.Entry<Key,Value>> |
BinaryFormatter.getScannerIterator()
|
Method parameters in org.apache.accumulo.core.util.format with type arguments of type Value | |
---|---|
static String |
DefaultFormatter.formatEntry(Map.Entry<Key,Value> entry,
boolean showTimestamps)
|
static String |
BinaryFormatter.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 |
DefaultFormatter.initialize(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)
|
Constructor parameters in org.apache.accumulo.core.util.format with type arguments of type Value | |
---|---|
DeleterFormatter(BatchWriter writer,
Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps,
Shell shellState,
boolean force)
|
Uses of Value in org.apache.accumulo.core.util.shell |
---|
Method parameters in org.apache.accumulo.core.util.shell with type arguments of type Value | |
---|---|
void |
Shell.printBinaryRecords(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps,
boolean paginate)
|
void |
Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps,
boolean paginate)
|
void |
Shell.printRecords(Iterable<Map.Entry<Key,Value>> scanner,
boolean printTimestamps,
boolean paginate,
Class<? extends Formatter> formatterClass)
|
Uses of Value in org.apache.accumulo.core.util.shell.commands |
---|
Method parameters in org.apache.accumulo.core.util.shell.commands with type arguments of type Value | |
---|---|
protected void |
ScanCommand.printBinaryRecords(org.apache.commons.cli.CommandLine cl,
Shell shellState,
Iterable<Map.Entry<Key,Value>> scanner)
|
protected void |
ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl,
Shell shellState,
Iterable<Map.Entry<Key,Value>> scanner)
|
protected void |
ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl,
Shell shellState,
Iterable<Map.Entry<Key,Value>> scanner,
Class<? extends Formatter> formatter)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |