Uses of Class
org.apache.accumulo.core.data.Value
-
-
Uses of Value in org.apache.accumulo.core.client
Methods in org.apache.accumulo.core.client that return types with arguments of type Value Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
ClientSideIteratorScanner.ScannerTranslator. deepCopy(IteratorEnvironment env)
Deprecated.Iterator<Map.Entry<Key,Value>>
ClientSideIteratorScanner. iterator()
Iterator<Map.Entry<Key,Value>>
IsolatedScanner. iterator()
Iterator<Map.Entry<Key,Value>>
IsolatedScanner.MemoryRowBuffer. iterator()
Iterator<Map.Entry<Key,Value>>
IsolatedScanner.RowBuffer. 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 Modifier and Type Method Description void
IsolatedScanner.MemoryRowBuffer. add(Map.Entry<Key,Value> entry)
void
IsolatedScanner.RowBuffer. add(Map.Entry<Key,Value> entry)
Constructor parameters in org.apache.accumulo.core.client with type arguments of type Value Constructor Description IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
Constructs an iterator setting using the given class's SimpleName for the iterator name.IteratorSetting(int priority, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass, Map<String,String> properties)
Constructs an iterator setting using the given class's SimpleName for the iterator name and configured for the specified scopes with the specified parameters.IteratorSetting(int priority, String name, Class<? extends SortedKeyValueIterator<Key,Value>> iteratorClass)
Constructs an iterator setting configured for the scan scope with no parameters.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.impl
Methods in org.apache.accumulo.core.client.impl that return types with arguments of type Value Modifier and Type Method Description Iterator<Map.Entry<Key,Value>>
OfflineScanner. iterator()
Iterator<Map.Entry<Key,Value>>
ScannerImpl. iterator()
Iterator<Map.Entry<Key,Value>>
ScannerOptions. iterator()
Iterator<Map.Entry<Key,Value>>
TabletServerBatchReader. iterator()
Map.Entry<Key,Value>
ScannerIterator. next()
Map.Entry<Key,Value>
TabletServerBatchReaderIterator. next()
SortedKeyValueIterator<Key,Value>
BaseIteratorEnvironment. reserveMapFileReader(String mapFileName)
Method parameters in org.apache.accumulo.core.client.impl with type arguments of type Value Modifier and Type Method Description static boolean
ThriftScanner. getBatchFromServer(ClientContext context, Range range, KeyExtent extent, String server, SortedMap<Key,Value> results, SortedSet<Column> fetchedColumns, List<IterInfo> serverSideIteratorList, Map<String,Map<String,String>> serverSideIteratorOptions, int size, Authorizations authorizations, boolean retry, long batchTimeOut, String classLoaderContext)
void
TabletServerBatchReaderIterator.ResultReceiver. receive(List<Map.Entry<Key,Value>> entries)
void
BaseIteratorEnvironment. registerSideChannel(SortedKeyValueIterator<Key,Value> iter)
-
Uses of Value in org.apache.accumulo.core.client.mapred
Fields in org.apache.accumulo.core.client.mapred with type parameters of type Value Modifier and Type Field Description protected Iterator<Map.Entry<Key,Value>>
AbstractInputFormat.AbstractRecordReader. scannerIterator
Methods in org.apache.accumulo.core.client.mapred that return types with arguments of type Value Modifier and Type Method Description org.apache.hadoop.mapred.RecordReader<Key,Value>
AccumuloInputFormat. getRecordReader(org.apache.hadoop.mapred.InputSplit split, org.apache.hadoop.mapred.JobConf job, org.apache.hadoop.mapred.Reporter reporter)
org.apache.hadoop.mapred.RecordReader<Key,Value>
AccumuloMultiTableInputFormat. 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 with type parameters of type Value Modifier and Type Field Description protected Iterator<Map.Entry<Key,Value>>
AbstractInputFormat.AbstractRecordReader. scannerIterator
Methods in org.apache.accumulo.core.client.mapreduce that return types with arguments of type Value Modifier and Type Method Description org.apache.hadoop.mapreduce.RecordReader<Key,Value>
AccumuloInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit split, org.apache.hadoop.mapreduce.TaskAttemptContext context)
org.apache.hadoop.mapreduce.RecordReader<Key,Value>
AccumuloMultiTableInputFormat. createRecordReader(org.apache.hadoop.mapreduce.InputSplit inputSplit, 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 Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
MockScannerBase. createFilter(SortedKeyValueIterator<Key,Value> inner)
Deprecated.Iterator<Map.Entry<Key,Value>>
MockBatchScanner. iterator()
Deprecated.Iterator<Map.Entry<Key,Value>>
MockScanner. iterator()
Deprecated.Iterator<Map.Entry<Key,Value>>
MockScannerBase. iterator()
Deprecated.Method parameters in org.apache.accumulo.core.client.mock with type arguments of type Value Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
MockScannerBase. createFilter(SortedKeyValueIterator<Key,Value> inner)
Deprecated.Constructor parameters in org.apache.accumulo.core.client.mock with type arguments of type Value Constructor Description IteratorAdapter(SortedKeyValueIterator<Key,Value> inner)
Deprecated. -
Uses of Value in org.apache.accumulo.core.client.rfile
Methods in org.apache.accumulo.core.client.rfile with parameters of type Value Modifier and Type Method Description void
RFileWriter. append(Key key, Value val)
Append the key and value to the last locality group that was started.Method parameters in org.apache.accumulo.core.client.rfile with type arguments of type Value Modifier and Type Method Description void
RFileWriter. append(Iterable<Map.Entry<Key,Value>> keyValues)
Append the keys and values to the last locality group that was started. -
Uses of Value in org.apache.accumulo.core.data
Methods in org.apache.accumulo.core.data that return Value Modifier and Type Method Description static Value
KeyExtent. encodePrevEndRow(org.apache.hadoop.io.Text per)
Deprecated.Methods in org.apache.accumulo.core.data with parameters of type Value Modifier and Type Method Description static org.apache.hadoop.io.Text
KeyExtent. decodePrevEndRow(Value ibw)
Deprecated.void
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.Constructors in org.apache.accumulo.core.data with parameters of type Value Constructor Description KeyExtent(org.apache.hadoop.io.Text flattenedExtent, Value prevEndRow)
Deprecated.KeyValue(Key key, Value value)
Creates a new key/value pair.Value(Value ibw)
Creates a new Value based on another. -
Uses of Value in org.apache.accumulo.core.data.impl
Methods in org.apache.accumulo.core.data.impl that return Value Modifier and Type Method Description static Value
KeyExtent. encodePrevEndRow(org.apache.hadoop.io.Text per)
Methods in org.apache.accumulo.core.data.impl with parameters of type Value Modifier and Type Method Description static org.apache.hadoop.io.Text
KeyExtent. decodePrevEndRow(Value ibw)
Constructors in org.apache.accumulo.core.data.impl with parameters of type Value Constructor Description KeyExtent(org.apache.hadoop.io.Text flattenedExtent, Value prevEndRow)
-
Uses of Value in org.apache.accumulo.core.file
Methods in org.apache.accumulo.core.file that return Value Modifier and Type Method Description Value
BloomFilterLayer.Reader. getTopValue()
Methods in org.apache.accumulo.core.file that return types with arguments of type Value Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
BloomFilterLayer.Reader. deepCopy(IteratorEnvironment env)
Methods in org.apache.accumulo.core.file with parameters of type Value Modifier and Type Method Description 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 Modifier and Type Method Description 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 Modifier and Type Method Description Value
MapFileOperations.RangeIterator. getTopValue()
Methods in org.apache.accumulo.core.file.map that return types with arguments of type Value Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
MapFileOperations.RangeIterator. deepCopy(IteratorEnvironment env)
Method parameters in org.apache.accumulo.core.file.map with type arguments of type Value Modifier and Type Method Description 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 Constructor Description 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 Modifier and Type Method Description SortedKeyValueIterator<Key,Value>
RFile.Reader. deepCopy(IteratorEnvironment env)
Methods in org.apache.accumulo.core.file.rfile with parameters of type Value Modifier and Type Method Description void
MetricsGatherer. addMetric(Key key, Value val)
Collect and store metrics for the given entry.void
VisMetricsGatherer. addMetric(Key key, Value val)
void
RFile.Writer. append(Key key, Value value)
Method parameters in org.apache.accumulo.core.file.rfile with type arguments of type Value Modifier and Type Method Description void
RFile.Reader. init(SortedKeyValueIterator<Key,Value> source, Map<String,String> options, IteratorEnvironment env)
-
Uses of Value in org.apache.accumulo.core.iterators
Methods in org.apache.accumulo.core.iterators that return Value Modifier and Type Method Description Value
AggregatingIterator. getTopValue()
Deprecated.Value
ColumnFamilyCounter. getTopValue()
Value
Combiner. getTopValue()
Value
DebugIterator. getTopValue()
Value
DevNull. getTopValue()
Value
OrIterator. getTopValue()
Value
SortedKeyIterator. getTopValue()
Value
SortedMapIterator. getTopValue()
Value
WrappingIterator. getTopValue()
Value
Combiner.ValueIterator. next()
abstract Value
Combiner. reduce(Key key, Iterator<Value> iter)
Reduces a list of Values into a single Value.Value
TypedValueCombiner. reduce(Key key, Iterator<Value> iter)
Methods in org.apache.accumulo.core.iterators with parameters of type Value Modifier and Type Method Description abstract boolean
Filter. accept(Key k, Value v)
Constructor parameters in org.apache.accumulo.core.iterators with type arguments of type Value Constructor Description AggregatingIterator(SortedKeyValueIterator<Key,Value> iterator, ColumnToClassMapping<Aggregator> aggregators)
Deprecated.DebugIterator(String prefix, SortedKeyValueIterator<Key,Value> source)
IteratorAdapter(SortedKeyValueIterator<Key,Value> inner)
SortedMapIterator(SortedMap<Key,Value> map)
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.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 Modifier and Type Method Description Value
Aggregator. aggregate()
Deprecated.Value
LongSummation. aggregate()
Deprecated.Value
NumArraySummation. aggregate()
Deprecated.Value
NumSummation. aggregate()
Deprecated.Value
StringMax. aggregate()
Deprecated.Value
StringMin. aggregate()
Deprecated.Value
StringSummation. aggregate()
Deprecated.Methods in org.apache.accumulo.core.iterators.aggregation with parameters of type Value Modifier and Type Method Description void
Aggregator. collect(Value value)
Deprecated.void
LongSummation. collect(Value value)
Deprecated.void
NumArraySummation. collect(Value value)
Deprecated.void
NumSummation. collect(Value value)
Deprecated.void
StringMax. collect(Value value)
Deprecated.void
StringMin. collect(Value value)
Deprecated.void
StringSummation. 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 Modifier and Type Method Description Value
EmptyIterator. getTopValue()
Value
HeapIterator. getTopValue()
Value
MapFileIterator. getTopValue()
Value
SequenceFileIterator. getTopValue()
Value
SourceSwitchingIterator. getTopValue()
Value
TimeSettingIterator. getTopValue()
Methods in org.apache.accumulo.core.iterators.system with parameters of type Value Modifier and Type Method Description boolean
ColumnQualifierFilter. accept(Key key, Value v)
boolean
SampleIterator. accept(Key k, Value v)
boolean
VisibilityFilter. accept(Key k, Value v)
-
Uses of Value in org.apache.accumulo.core.iterators.user
Fields in org.apache.accumulo.core.iterators.user declared as Value Modifier and Type Field Description 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 Modifier and Type Field Description SortedKeyValueIterator<Key,Value>
IndexedDocIterator. docSource
SortedKeyValueIterator<Key,Value>
IntersectingIterator.TermSource. iter
protected ArrayList<Pair<Key,Value>>
TransformingIterator. keys
protected SortedKeyValueIterator<Key,Value>
RowEncodingIterator. sourceIter
Methods in org.apache.accumulo.core.iterators.user that return Value Modifier and Type Method Description static Value
WholeColumnFamilyIterator. encodeColumnFamily(List<Key> keys, List<Value> values)
Encode row/cf.static Value
WholeRowIterator. encodeRow(List<Key> keys, List<Value> values)
Value
IntersectingIterator. getTopValue()
Value
LargeRowFilter. getTopValue()
Value
RowDeletingIterator. getTopValue()
Value
RowEncodingIterator. getTopValue()
Value
TransformingIterator. getTopValue()
Value
WholeColumnFamilyIterator. getTopValue()
abstract Value
RowEncodingIterator. rowEncoder(List<Key> keys, List<Value> values)
Take a stream of keys and values.Value
WholeRowIterator. rowEncoder(List<Key> keys, List<Value> values)
Methods in org.apache.accumulo.core.iterators.user with parameters of type Value Modifier and Type Method Description boolean
AgeOffFilter. accept(Key k, Value v)
Accepts entries whose timestamps are less than currentTime - threshold.boolean
CfCqSliceFilter. accept(Key k, Value v)
boolean
ColumnAgeOffFilter. accept(Key k, Value v)
boolean
ColumnSliceFilter. accept(Key key, Value value)
boolean
GrepIterator. accept(Key k, Value v)
boolean
RegExFilter. accept(Key key, Value value)
boolean
ReqVisFilter. accept(Key k, Value v)
boolean
TimestampFilter. accept(Key k, Value v)
boolean
VisibilityFilter. accept(Key k, Value v)
void
TransformingIterator.KVBuffer. append(Key key, Value val)
static SortedMap<Key,Value>
WholeColumnFamilyIterator. decodeColumnFamily(Key rowKey, Value rowValue)
Decode whole row/cf out of value.static SortedMap<Key,Value>
WholeRowIterator. decodeRow(Key rowKey, Value rowValue)
SeekingFilter.FilterResult
CfCqSliceSeekingFilter. filter(Key k, Value v)
abstract SeekingFilter.FilterResult
SeekingFilter. filter(Key k, Value v)
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.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.abstract SortedMap<Key,Value>
RowEncodingIterator. rowDecoder(Key rowKey, Value rowValue)
Given a value generated by the rowEncoder implementation, recreate the original Key, Value pairs.SortedMap<Key,Value>
WholeRowIterator. rowDecoder(Key rowKey, Value rowValue)
Constructor parameters in org.apache.accumulo.core.iterators.user with type arguments of type Value Constructor Description TermSource(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.core.metadata
Method parameters in org.apache.accumulo.core.metadata with type arguments of type Value Modifier and Type Method Description static TabletLocator.TabletLocations
MetadataLocationObtainer. getMetadataLocationEntries(SortedMap<Key,Value> entries)
-
Uses of Value in org.apache.accumulo.core.metadata.schema
Methods in org.apache.accumulo.core.metadata.schema that return Value Modifier and Type Method Description Value
DataFileValue. encodeAsValue()
-
Uses of Value in org.apache.accumulo.core.protobuf
Methods in org.apache.accumulo.core.protobuf that return Value Modifier and Type Method Description static Value
ProtobufUtil. toValue(com.google.protobuf.GeneratedMessage msg)
-
Uses of Value in org.apache.accumulo.core.replication
Methods in org.apache.accumulo.core.replication with parameters of type Value Modifier and Type Method Description static Mutation
ReplicationSchema.OrderSection. add(Mutation m, String tableId, Value v)
Add a column update to the given mutation with the provided tableId and valuestatic Mutation
ReplicationSchema.StatusSection. add(Mutation m, String tableId, Value v)
static Mutation
ReplicationSchema.WorkSection. add(Mutation m, org.apache.hadoop.io.Text serializedTarget, Value v)
-
Uses of Value in org.apache.accumulo.core.tabletserver.log
Methods in org.apache.accumulo.core.tabletserver.log that return Value Modifier and Type Method Description Value
LogEntry. getValue()
Methods in org.apache.accumulo.core.tabletserver.log with parameters of type Value Modifier and Type Method Description static LogEntry
LogEntry. fromKeyValue(Key key, Value value)
-
Uses of Value in org.apache.accumulo.core.util
Methods in org.apache.accumulo.core.util with parameters of type Value Modifier and Type Method Description void
ColumnFQ. put(Mutation m, Value v)
-
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 Modifier and Type Method Description Iterator<Map.Entry<Key,Value>>
DefaultFormatter. getScannerIterator()
Method parameters in org.apache.accumulo.core.util.format with type arguments of type Value Modifier and Type Method Description protected abstract void
AggregatingFormatter. aggregateStats(Map.Entry<Key,Value> next)
Generate statistics from eachMap.Entry
, called for each entry to be iterated over.protected void
ShardedTableDistributionFormatter. aggregateStats(Map.Entry<Key,Value> entry)
protected void
StatisticsDisplayFormatter. aggregateStats(Map.Entry<Key,Value> entry)
static String
BinaryFormatter. formatEntry(Map.Entry<Key,Value> entry, boolean printTimestamps, int shownLength)
Deprecated.String
DefaultFormatter. formatEntry(Map.Entry<Key,Value> entry)
static String
DefaultFormatter. formatEntry(Map.Entry<Key,Value> entry, boolean showTimestamps)
if showTimestamps, will useFormatterConfig.DefaultDateFormat
.
Preferably, useDefaultFormatter.formatEntry(java.util.Map.Entry, org.apache.accumulo.core.util.format.FormatterConfig)
static String
DefaultFormatter. formatEntry(Map.Entry<Key,Value> entry, DateFormat timestampFormat)
Does not show timestamps if timestampFormat is nullstatic String
DefaultFormatter. formatEntry(Map.Entry<Key,Value> entry, FormatterConfig config)
static Formatter
FormatterFactory. getDefaultFormatter(Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
static Formatter
FormatterFactory. getFormatter(Class<? extends Formatter> formatterClass, Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
void
DateStringFormatter. initialize(Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
Deprecated.void
DefaultFormatter. initialize(Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
void
Formatter. initialize(Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
void
HexFormatter. initialize(Iterable<Map.Entry<Key,Value>> scanner, FormatterConfig config)
-