Uses of Class
org.apache.accumulo.core.data.Value
Package
Description
-
Uses of Value 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 Value in org.apache.accumulo.core.client.admin.compaction
Modifier and TypeMethodDescriptionCompactionSelector.SelectionParameters.getSample
(CompactableFile cf, SamplerConfiguration sc) -
Uses of Value in org.apache.accumulo.core.client.mapred
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 Value in org.apache.accumulo.core.client.mapreduce
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 Value in org.apache.accumulo.core.client.rfile
Modifier and TypeMethodDescriptionvoid
Append the key and value to the last locality group that was started. -
Uses of Value in org.apache.accumulo.core.client.summary
-
Uses of Value in org.apache.accumulo.core.data
Modifier and TypeMethodDescriptionvoid
Mutation.put
(CharSequence columnFamily, CharSequence columnQualifier, long timestamp, Value value) Puts a modification in this mutation.void
Mutation.put
(CharSequence columnFamily, CharSequence columnQualifier, Value value) Puts a modification in this mutation.void
Mutation.put
(CharSequence columnFamily, CharSequence columnQualifier, ColumnVisibility columnVisibility, long timestamp, Value value) Puts a modification in this mutation.void
Mutation.put
(CharSequence columnFamily, CharSequence columnQualifier, ColumnVisibility columnVisibility, Value value) Puts a modification in this mutation.void
Mutation.put
(org.apache.hadoop.io.Text columnFamily, org.apache.hadoop.io.Text columnQualifier, long timestamp, Value value) Puts a modification in this mutation.void
Mutation.put
(org.apache.hadoop.io.Text columnFamily, org.apache.hadoop.io.Text columnQualifier, Value value) Puts a modification in this mutation.void
Mutation.put
(org.apache.hadoop.io.Text columnFamily, org.apache.hadoop.io.Text columnQualifier, ColumnVisibility columnVisibility, long timestamp, Value value) Puts a modification in this mutation.void
Mutation.put
(org.apache.hadoop.io.Text columnFamily, org.apache.hadoop.io.Text columnQualifier, ColumnVisibility columnVisibility, Value value) Puts a modification in this mutation. -
Uses of Value 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.getTopValue()
Combiner.getTopValue()
DebugIterator.getTopValue()
DevNull.getTopValue()
final Value
OrIterator.getTopValue()
ServerWrappingIterator.getTopValue()
SortedKeyIterator.getTopValue()
SynchronizedServerFilter.getTopValue()
WrappingIterator.getTopValue()
Combiner.ValueIterator.next()
abstract Value
Reduces a list of Values into a single Value.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
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) abstract Value
Reduces a list of Values into a single Value.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 Value in org.apache.accumulo.core.iterators.user
Modifier and TypeFieldDescriptionstatic final Value
RowDeletingIterator.DELETE_ROW_VALUE
static final Value
LargeRowFilter.SUPPRESS_ROW_VALUE
protected Value
IntersectingIterator.value
Modifier and TypeFieldDescriptionIndexedDocIterator.docSource
IntersectingIterator.TermSource.iter
TransformingIterator.keys
protected SortedKeyValueIterator<Key,
Value> RowEncodingIterator.sourceIter
Modifier and TypeMethodDescriptionstatic final Value
WholeColumnFamilyIterator.encodeColumnFamily
(List<Key> keys, List<Value> values) Encode row/cf.static final Value
IntersectingIterator.getTopValue()
LargeRowFilter.getTopValue()
RowDeletingIterator.getTopValue()
RowEncodingIterator.getTopValue()
TransformingIterator.getTopValue()
WholeColumnFamilyIterator.getTopValue()
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) 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
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.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.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 TypeMethodDescriptionabstract boolean
RowFilter.acceptRow
(SortedKeyValueIterator<Key, Value> rowIterator) Implementation should return false to suppress a row.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) 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 Value 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 Value 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)