Uses of Class
org.apache.accumulo.core.data.Value

Packages that use Value
org.apache.accumulo.core.client   
org.apache.accumulo.core.client.impl   
org.apache.accumulo.core.client.mapred   
org.apache.accumulo.core.client.mapreduce   
org.apache.accumulo.core.client.mock   
org.apache.accumulo.core.data   
org.apache.accumulo.core.file   
org.apache.accumulo.core.file.map   
org.apache.accumulo.core.file.rfile   
org.apache.accumulo.core.iterators   
org.apache.accumulo.core.iterators.aggregation   
org.apache.accumulo.core.iterators.system   
org.apache.accumulo.core.iterators.user   
org.apache.accumulo.core.trace   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.format   
org.apache.accumulo.core.util.shell   
org.apache.accumulo.core.util.shell.commands   
org.apache.accumulo.examples.simple.combiner   
org.apache.accumulo.examples.simple.dirlist   
org.apache.accumulo.examples.simple.filedata   
org.apache.accumulo.examples.simple.mapreduce   
org.apache.accumulo.proxy   
org.apache.accumulo.server.iterators   
org.apache.accumulo.server.master.state   
org.apache.accumulo.server.monitor.servlets.trace   
org.apache.accumulo.server.problems   
org.apache.accumulo.server.tabletserver   
org.apache.accumulo.server.util   
org.apache.accumulo.test.continuous   
org.apache.accumulo.test.functional   
org.apache.accumulo.test.randomwalk.multitable   
org.apache.accumulo.test.randomwalk.sequential   
 

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>> 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.
 

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>> 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()
           
 

Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Value
 void TabletServerBatchReaderIterator.ResultReceiver.receive(List<Map.Entry<Key,Value>> entries)
           
 

Uses of Value in org.apache.accumulo.core.client.mapred
 

Fields in org.apache.accumulo.core.client.mapred with type parameters of type Value
protected  Iterator<Map.Entry<Key,Value>> InputFormatBase.RecordReaderBase.scannerIterator
           
 

Methods in org.apache.accumulo.core.client.mapred that return types with arguments of type Value
 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)
           
 

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 context)
           
 

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>> MockBatchScanner.iterator()
           
 Iterator<Map.Entry<Key,Value>> MockScanner.iterator()
           
 Iterator<Map.Entry<Key,Value>> MockScannerBase.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 FileSKVWriter.append(Key key, Value value)
           
 void BloomFilterLayer.Writer.append(Key key, Value val)
           
 

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()
           
 

Methods in org.apache.accumulo.core.file.map that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> MapFileOperations.RangeIterator.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)
           
 

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 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.
 

Methods in org.apache.accumulo.core.iterators that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> TypedValueCombiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Combiner.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilyCounter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> Filter.deepCopy(IteratorEnvironment env)
           
protected  SortedKeyValueIterator<Key,Value> WrappingIterator.getSource()
           
 SortedKeyValueIterator<Key,Value> IteratorEnvironment.reserveMapFileReader(String mapFileName)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type Value
abstract  boolean Filter.accept(Key k, Value v)
           
 

Method parameters in org.apache.accumulo.core.iterators with type arguments of type Value
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
 void TypedValueCombiner.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 DevNull.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void SortedMapIterator.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 DebugIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
          Deprecated.  
 void WrappingIterator.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 ColumnFamilyCounter.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 Filter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 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.
 void IteratorEnvironment.registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
           
protected  void WrappingIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
 

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)
           
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 NumSummation.aggregate()
          Deprecated.  
 Value LongSummation.aggregate()
          Deprecated.  
 Value StringSummation.aggregate()
          Deprecated.  
 Value NumArraySummation.aggregate()
          Deprecated.  
 Value StringMax.aggregate()
          Deprecated.  
 Value Aggregator.aggregate()
          Deprecated.  
 

Methods in org.apache.accumulo.core.iterators.aggregation with parameters of type Value
 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.  
 

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 MapFileIterator.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> 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()
           
 

Methods in org.apache.accumulo.core.iterators.system with parameters of type Value
 boolean ColumnQualifierFilter.accept(Key key, Value v)
           
 boolean VisibilityFilter.accept(Key k, 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 DeletingIterator.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 CountingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void TimeSettingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 void MapFileIterator.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)
           
 

Constructor parameters in org.apache.accumulo.core.iterators.system with type arguments of type Value
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source, Set<ByteSequence> colFamSet, boolean inclusive)
           
ColumnQualifierFilter(SortedKeyValueIterator<Key,Value> iterator, HashSet<ByteSequence> columnFamilies, HashMap<ByteSequence,HashSet<ByteSequence>> columnsQualifiers, boolean scanColumns)
           
ColumnQualifierFilter(SortedKeyValueIterator<Key,Value> iterator, HashSet<Column> columns)
           
CountingIterator(SortedKeyValueIterator<Key,Value> source)
           
DeletingIterator(SortedKeyValueIterator<Key,Value> iterator, boolean propogateDeletes)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> readers, boolean init)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
           
MultiIterator(List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
StatsIterator(SortedKeyValueIterator<Key,Value> source, AtomicLong seekCounter, AtomicLong readCounter)
           
TimeSettingIterator(SortedKeyValueIterator<Key,Value> source, long time)
           
VisibilityFilter(SortedKeyValueIterator<Key,Value> iterator, Authorizations authorizations, byte[] defaultVisibility)
           
 

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
           
protected  ArrayList<Pair<Key,Value>> TransformingIterator.keys
           
 

Methods in org.apache.accumulo.core.iterators.user that return Value
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()
           
 

Methods in org.apache.accumulo.core.iterators.user that return types with arguments of type Value
static SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 SortedKeyValueIterator<Key,Value> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TimestampFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> AgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RegExFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnAgeOffFilter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> TransformingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IndexedDocIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.core.iterators.user with parameters of type Value
 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 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)
           
 

Method parameters in org.apache.accumulo.core.iterators.user with type arguments of type Value
abstract  boolean RowFilter.acceptRow(SortedKeyValueIterator<Key,Value> rowIterator)
          Implementation should return false to suppress a row.
 void IntersectingIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text term, boolean notFlag)
           
static Value WholeRowIterator.encodeRow(List<Key> keys, List<Value> values)
           
protected  boolean WholeRowIterator.filter(org.apache.hadoop.io.Text currentRow, List<Key> keys, List<Value> values)
           
 void WholeRowIterator.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 AgeOffFilter.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 SummingArrayCombiner.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 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 RowFilter.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 RowDeletingIterator.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 IndexedDocIterator.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 IntersectingIterator.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)
          Transforms input.
 

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(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)
          Deprecated. since 1.5, use ColumnFQ.put(Mutation, Value) instead
 void ColumnFQ.put(Mutation m, 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 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>> BinaryFormatter.getScannerIterator()
           
 Iterator<Map.Entry<Key,Value>> DefaultFormatter.getScannerIterator()
           
 

Method parameters in org.apache.accumulo.core.util.format with type arguments of type Value
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 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.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)
           
 

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.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)
           
 

Uses of Value in org.apache.accumulo.examples.simple.combiner
 

Methods in org.apache.accumulo.examples.simple.combiner that return Value
 Value StatsCombiner.reduce(Key key, Iterator<Value> iter)
           
 

Method parameters in org.apache.accumulo.examples.simple.combiner with type arguments of type Value
 void StatsCombiner.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 Value StatsCombiner.reduce(Key key, Iterator<Value> iter)
           
 

Uses of Value in org.apache.accumulo.examples.simple.dirlist
 

Methods in org.apache.accumulo.examples.simple.dirlist that return types with arguments of type Value
 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.
 

Uses of Value in org.apache.accumulo.examples.simple.filedata
 

Fields in org.apache.accumulo.examples.simple.filedata with type parameters of type Value
protected  PeekingIterator<Map.Entry<Key,Value>> ChunkInputStream.source
           
 

Methods in org.apache.accumulo.examples.simple.filedata that return Value
 Value ChunkCombiner.getTopValue()
           
 

Methods in org.apache.accumulo.examples.simple.filedata that return types with arguments of type Value
 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()
           
 

Method parameters in org.apache.accumulo.examples.simple.filedata with type arguments of type Value
 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 parameters in org.apache.accumulo.examples.simple.filedata with type arguments of type Value
ChunkInputStream(PeekingIterator<Map.Entry<Key,Value>> in)
           
 

Uses of Value in org.apache.accumulo.examples.simple.mapreduce
 

Methods in org.apache.accumulo.examples.simple.mapreduce with parameters of type Value
 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)
           
 

Uses of Value in org.apache.accumulo.proxy
 

Fields in org.apache.accumulo.proxy with type parameters of type Value
 Iterator<Map.Entry<Key,Value>> ProxyServer.ScannerPlusIterator.iterator
           
 

Uses of Value in org.apache.accumulo.server.iterators
 

Methods in org.apache.accumulo.server.iterators with parameters of type Value
 boolean MetadataBulkLoadFilter.accept(Key k, Value v)
           
 

Method parameters in org.apache.accumulo.server.iterators with type arguments of type Value
 void MetadataBulkLoadFilter.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Uses of Value in org.apache.accumulo.server.master.state
 

Methods in org.apache.accumulo.server.master.state that return Value
 Value TServerInstance.asMutationValue()
           
 

Methods in org.apache.accumulo.server.master.state that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> TabletStateChangeIterator.deepCopy(IteratorEnvironment env)
           
 

Methods in org.apache.accumulo.server.master.state with parameters of type Value
static TabletLocationState MetaDataTableScanner.createTabletLocationState(Key k, Value v)
           
 

Method parameters in org.apache.accumulo.server.master.state with type arguments of type Value
 void TabletStateChangeIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructors in org.apache.accumulo.server.master.state with parameters of type Value
TServerInstance(Value address, org.apache.hadoop.io.Text session)
           
 

Uses of Value in org.apache.accumulo.server.monitor.servlets.trace
 

Methods in org.apache.accumulo.server.monitor.servlets.trace that return types with arguments of type Value
 Iterator<Map.Entry<Key,Value>> NullScanner.iterator()
           
 Map.Entry<Key,Value> NullKeyValueIterator.next()
           
 

Uses of Value in org.apache.accumulo.server.problems
 

Methods in org.apache.accumulo.server.problems that return Value
 Value ProblemReportingIterator.getTopValue()
           
 

Methods in org.apache.accumulo.server.problems that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> ProblemReportingIterator.deepCopy(IteratorEnvironment env)
           
 

Method parameters in org.apache.accumulo.server.problems with type arguments of type Value
static ProblemReport ProblemReport.decodeMetadataEntry(Map.Entry<Key,Value> entry)
           
 void ProblemReportingIterator.init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
           
 

Constructor parameters in org.apache.accumulo.server.problems with type arguments of type Value
ProblemReportingIterator(String table, String resource, boolean continueOnError, SortedKeyValueIterator<Key,Value> source)
           
 

Uses of Value in org.apache.accumulo.server.tabletserver
 

Subclasses of Value in org.apache.accumulo.server.tabletserver
 class MemValue
           
 

Methods in org.apache.accumulo.server.tabletserver that return Value
 Value NativeMap.get(Key key)
           
 

Methods in org.apache.accumulo.server.tabletserver that return types with arguments of type Value
 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()
           
 

Methods in org.apache.accumulo.server.tabletserver with parameters of type Value
 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
 

Method parameters in org.apache.accumulo.server.tabletserver with type arguments of type Value
 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)
           
 

Constructors in org.apache.accumulo.server.tabletserver with parameters of type Value
MemValue(Value value, int kv)
           
Tablet.KVEntry(Key k, Value v)
           
 

Constructor parameters in org.apache.accumulo.server.tabletserver with type arguments of type Value
Compactor.CountingIterator(SortedKeyValueIterator<Key,Value> source)
           
Tablet(TabletServer tabletServer, org.apache.hadoop.io.Text location, KeyExtent extent, TabletServerResourceManager.TabletResourceManager trm, SortedMap<Key,Value> tabletsKeyValues)
           
 

Uses of Value in org.apache.accumulo.server.util
 

Methods in org.apache.accumulo.server.util that return types with arguments of type Value
 Iterator<Map.Entry<Key,Value>> OfflineMetadataScanner.iterator()
           
 Map<Key,Value> TabletIterator.next()
           
 

Methods in org.apache.accumulo.server.util with parameters of type Value
static MetadataTable.LogEntry MetadataTable.entryFromKeyValue(Key key, Value value)
           
 

Method parameters in org.apache.accumulo.server.util with type arguments of type Value
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
 

Uses of Value in org.apache.accumulo.test.continuous
 

Methods in org.apache.accumulo.test.continuous with parameters of type Value
 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)
           
 

Uses of Value in org.apache.accumulo.test.functional
 

Methods in org.apache.accumulo.test.functional that return Value
 Value BadCombiner.reduce(Key key, Iterator<Value> iter)
           
 

Methods in org.apache.accumulo.test.functional that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> BadIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SlowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DropModIter.deepCopy(IteratorEnvironment env)
           
 

Method parameters in org.apache.accumulo.test.functional with type arguments of type Value
 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)
           
 

Uses of Value in org.apache.accumulo.test.randomwalk.multitable
 

Methods in org.apache.accumulo.test.randomwalk.multitable with parameters of type Value
 void CopyTool.SeqMapClass.map(Key key, Value val, org.apache.hadoop.mapreduce.Mapper.Context output)
           
 

Uses of Value in org.apache.accumulo.test.randomwalk.sequential
 

Methods in org.apache.accumulo.test.randomwalk.sequential with parameters of type Value
 void MapRedVerifyTool.SeqMapClass.map(Key row, Value data, org.apache.hadoop.mapreduce.Mapper.Context output)
           
 



Copyright © 2013 Apache Accumulo Project. All Rights Reserved.