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.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.filter   
org.apache.accumulo.core.trace   
org.apache.accumulo.core.util   
org.apache.accumulo.core.util.format   
org.apache.accumulo.core.util.shell   
 

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

Methods in org.apache.accumulo.core.client that return types with arguments of type Value
 java.util.Iterator<java.util.Map.Entry<Key,Value>> Scanner.iterator()
          Returns an iterator over a accumulo table.
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.RowBuffer.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> IsolatedScanner.MemoryRowBuffer.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> BatchScanner.iterator()
          Returns an iterator over a accumulo table.
 

Method parameters in org.apache.accumulo.core.client with type arguments of type Value
 void IsolatedScanner.RowBuffer.add(java.util.Map.Entry<Key,Value> entry)
           
 void IsolatedScanner.MemoryRowBuffer.add(java.util.Map.Entry<Key,Value> entry)
           
 

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
 java.util.Iterator<java.util.Map.Entry<Key,Value>> ScannerImpl.iterator()
          Returns an iterator over a accumulo table.
 java.util.Iterator<java.util.Map.Entry<Key,Value>> TabletServerBatchReader.iterator()
           
 java.util.Map.Entry<Key,Value> TabletServerBatchReaderIterator.next()
           
 java.util.Map.Entry<Key,Value> ScannerIterator.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, java.lang.String server, java.util.SortedMap<Key,Value> results, java.util.SortedSet<Column> fetchedColumns, boolean skipStartKey, int size, Authorizations authorizations, boolean retry, AccumuloConfiguration conf)
           
 

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

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 inSplit, org.apache.hadoop.mapreduce.TaskAttemptContext attempt)
           
 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)
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> MockScanner.iterator()
           
 java.util.Iterator<java.util.Map.Entry<Key,Value>> MockBatchScanner.iterator()
           
 

Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Value
 SortedKeyValueIterator<Key,Value> MockScannerBase.createFilter(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(java.lang.CharSequence columnFamily, java.lang.CharSequence columnQualifier, ColumnVisibility columnVisibility, long timestamp, Value value)
           
 void Mutation.put(java.lang.CharSequence columnFamily, java.lang.CharSequence columnQualifier, ColumnVisibility columnVisibility, Value value)
           
 void Mutation.put(java.lang.CharSequence columnFamily, java.lang.CharSequence columnQualifier, long timestamp, Value value)
           
 void Mutation.put(java.lang.CharSequence columnFamily, java.lang.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> FileCFSkippingIterator.deepCopy(IteratorEnvironment env)
           
 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, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 

Constructor parameters in org.apache.accumulo.core.file with type arguments of type Value
FileCFSkippingIterator(SortedKeyValueIterator<Key,Value> src, java.util.Set<ByteSequence> colFamSet, boolean inclusive)
           
 

Uses of Value in org.apache.accumulo.core.file.map
 

Methods in org.apache.accumulo.core.file.map that return Value
 Value MyMapFile.Reader.getTopValue()
           
 Value MapFileOperations.RangeIterator.getTopValue()
           
 

Methods in org.apache.accumulo.core.file.map that return types with arguments of type Value
 SortedKeyValueIterator<Key,Value> MyMapFile.Reader.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> MapFileOperations.RangeIterator.deepCopy(IteratorEnvironment env)
           
 

Method parameters in org.apache.accumulo.core.file.map with type arguments of type Value
 void MyMapFile.Reader.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void MapFileOperations.RangeIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.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, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 

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

Fields in org.apache.accumulo.core.iterators declared as Value
static Value RowDeletingIterator.DELETE_ROW_VALUE
           
static Value LargeRowFilter.SUPPRESS_ROW_VALUE
           
 

Fields in org.apache.accumulo.core.iterators with type parameters of type Value
 SortedKeyValueIterator<Key,Value> FamilyIntersectingIterator.docSource
           
 SortedKeyValueIterator<Key,Value> OrIterator.TermSource.iter
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.TermSource.iter
           
 

Methods in org.apache.accumulo.core.iterators that return Value
static Value WholeRowIterator.encodeRow(java.util.List<Key> keys, java.util.List<Value> values)
           
 Value ScanCache.getTopValue()
           
 Value SortedKeyIterator.getTopValue()
           
 Value LargeRowFilter.getTopValue()
           
 Value WrappingIterator.getTopValue()
           
 Value ColumnFamilyCounter.getTopValue()
           
 Value RowDeletingIterator.getTopValue()
           
 Value DevNull.getTopValue()
           
 Value SequenceFileIterator.getTopValue()
          Deprecated.  
 Value WholeRowIterator.getTopValue()
           
 Value HeapIterator.getTopValue()
           
 Value SourceSwitchingIterator.getTopValue()
           
 Value OrIterator.getTopValue()
           
 Value SortedMapIterator.getTopValue()
           
 Value IntersectingIterator.getTopValue()
           
 Value AggregatingIterator.getTopValue()
           
 Value DebugIterator.getTopValue()
           
 

Methods in org.apache.accumulo.core.iterators that return types with arguments of type Value
static java.util.SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilySkippingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> GrepIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SortedKeyIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> LargeRowFilter.deepCopy(IteratorEnvironment env)
           
abstract  SortedKeyValueIterator<Key,Value> WrappingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> ColumnFamilyCounter.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> RowDeletingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> DevNull.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> WholeRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FirstEntryInRowIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> OrIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> FamilyIntersectingIterator.deepCopy(IteratorEnvironment env)
           
 SortedKeyValueIterator<Key,Value> IntersectingIterator.deepCopy(IteratorEnvironment env)
           
protected  SortedKeyValueIterator<Key,Value> WrappingIterator.getSource()
           
 SortedKeyValueIterator<Key,Value> SourceSwitchingIterator.DataSource.iterator()
           
 SortedKeyValueIterator<Key,Value> IteratorEnvironment.reserveMapFileReader(java.lang.String mapFileName)
           
 

Methods in org.apache.accumulo.core.iterators with parameters of type Value
static java.util.SortedMap<Key,Value> WholeRowIterator.decodeRow(Key rowKey, Value rowValue)
           
 

Method parameters in org.apache.accumulo.core.iterators with type arguments of type Value
protected  void HeapIterator.addSource(SortedKeyValueIterator<Key,Value> source)
           
 void IntersectingIterator.addSource(SortedKeyValueIterator<Key,Value> source, IteratorEnvironment env, org.apache.hadoop.io.Text term, boolean notFlag)
           
 void OrIterator.addTerm(SortedKeyValueIterator<Key,Value> source, org.apache.hadoop.io.Text term, IteratorEnvironment env)
           
static Value WholeRowIterator.encodeRow(java.util.List<Key> keys, java.util.List<Value> values)
           
protected  boolean WholeRowIterator.filter(org.apache.hadoop.io.Text currentRow, java.util.List<Key> keys, java.util.List<Value> values)
           
 void FilteringIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void CountingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void GrepIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ScanCache.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void LargeRowFilter.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void WrappingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void MultiIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ColumnFamilyCounter.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void RowDeletingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DevNull.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SequenceFileIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
          Deprecated.  
 void WholeRowIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void FirstEntryInRowIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SourceSwitchingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void OrIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DeletingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void RegExIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void SortedMapIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void NoLabelIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void FamilyIntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void IntersectingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void AggregatingIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void VersioningIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void DebugIterator.init(SortedKeyValueIterator<Key,Value> source, java.util.Map<java.lang.String,java.lang.String> options, IteratorEnvironment env)
           
 void ScanCache.setAuthorityIterator(SortedKeyValueIterator<Key,Value> authorityIter)
           
protected  void WrappingIterator.setSource(SortedKeyValueIterator<Key,Value> source)
           
static java.lang.String IntersectingIterator.stringTopKey(SortedKeyValueIterator<Key,Value> iter)
           
 

Constructor parameters in org.apache.accumulo.core.iterators with type arguments of type Value
AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source)
           
ColumnFamilySkippingIterator(SortedKeyValueIterator<Key,Value> source, java.util.Set<ByteSequence> colFamSet, boolean inclusive)
           
CountingIterator(SortedKeyValueIterator<Key,Value> source)
           
DebugIterator(java.lang.String prefix, SortedKeyValueIterator<Key,Value> source)
           
DeletingIterator(SortedKeyValueIterator<Key,Value> iterator, boolean propogateDeletes)
           
FilteringIterator(SortedKeyValueIterator<Key,Value> iterator, java.util.List<? extends Filter> filters)
           
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)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> readers, boolean init)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> iters2, KeyExtent extent)
           
MultiIterator(java.util.List<SortedKeyValueIterator<Key,Value>> iters, Range seekFence)
           
OrIterator.TermSource(SortedKeyValueIterator<Key,Value> iter, org.apache.hadoop.io.Text term)
           
SortedMapIterator(java.util.SortedMap<Key,Value> map)
           
SystemScanIterator(SortedKeyValueIterator<Key,Value> iterator, Authorizations authorizations, byte[] defaultLabels, java.util.HashSet<Column> hsc)
           
VersioningIterator(SortedKeyValueIterator<Key,Value> iterator, int maxVersions)
           
 

Uses of Value in org.apache.accumulo.core.iterators.aggregation
 

Methods in org.apache.accumulo.core.iterators.aggregation that return Value
 Value Aggregator.aggregate()
           
 Value LongSummation.aggregate()
           
 Value NumSummation.aggregate()
           
 Value StringMax.aggregate()
           
 Value StringSummation.aggregate()
           
 Value NumArraySummation.aggregate()
           
 Value StringMin.aggregate()
           
 

Methods in org.apache.accumulo.core.iterators.aggregation with parameters of type Value
 void Aggregator.collect(Value value)
           
 void LongSummation.collect(Value value)
           
 void NumSummation.collect(Value value)
           
 void StringMax.collect(Value value)
           
 void StringSummation.collect(Value value)
           
 void NumArraySummation.collect(Value value)
           
 void StringMin.collect(Value value)
           
 

Uses of Value in org.apache.accumulo.core.iterators.filter
 

Methods in org.apache.accumulo.core.iterators.filter with parameters of type Value
 boolean NoLabelFilter.accept(Key k, Value v)
           
 boolean Filter.accept(Key k, Value v)
           
 boolean DeleteFilter.accept(Key key, Value value)
           
 boolean ColumnAgeOffFilter.accept(Key k, Value v)
           
 boolean AgeOffFilter.accept(Key k, Value v)
           
 boolean RegExFilter.accept(Key key, Value value)
           
 boolean VisibilityFilter.accept(Key k, Value v)
           
 boolean ColumnQualifierFilter.accept(Key key, Value v)
           
 

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(java.util.Map.Entry<Key,Value> entry)
           
 void TraceFormatter.initialize(java.lang.Iterable<java.util.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 java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(Instance instance, KeyExtent ke, java.util.List<ColumnFQ> columns, AuthInfo credentials)
           
static java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(java.util.SortedMap<Key,Value> tabletKeyValues, java.util.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 java.util.SortedMap<KeyExtent,org.apache.hadoop.io.Text> MetadataTable.getMetadataLocationEntries(java.util.SortedMap<Key,Value> entries)
           
static void MetadataTable.getTabletAndPrevTabletKeyValues(Instance instance, java.util.SortedMap<Key,Value> tkv, KeyExtent ke, java.util.List<ColumnFQ> columns, AuthInfo credentials)
           
static java.util.SortedMap<org.apache.hadoop.io.Text,java.util.SortedMap<ColumnFQ,Value>> MetadataTable.getTabletEntries(java.util.SortedMap<Key,Value> tabletKeyValues, java.util.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
 java.util.Iterator<java.util.Map.Entry<Key,Value>> DefaultFormatter.getScannerIterator()
           
 

Method parameters in org.apache.accumulo.core.util.format with type arguments of type Value
static java.lang.String DefaultFormatter.formatEntry(java.util.Map.Entry<Key,Value> entry, boolean showTimestamps)
           
static Formatter FormatterFactory.getDefaultFormatter(java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
static Formatter FormatterFactory.getFormatter(java.lang.Class<? extends Formatter> formatterClass, java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void Formatter.initialize(java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner, boolean printTimestamps)
           
 void DefaultFormatter.initialize(java.lang.Iterable<java.util.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, java.lang.Iterable<java.util.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
protected  void Shell.ScanCommand.printRecords(org.apache.commons.cli.CommandLine cl, Shell shellState, java.lang.Iterable<java.util.Map.Entry<Key,Value>> scanner)
           
 



Copyright © 2012 The Apache Software Foundation. All Rights Reserved.